Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

A

accepts(GenericType<?>) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Whether this codec is capable of processing the given Java type.
accepts(Class<?>) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Whether this codec is capable of processing the given Java class.
accepts(Object) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Whether this codec is capable of encoding the given Java object.
accepts(DataType) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Whether this codec is capable of processing the given CQL type.
AccessibleById - Interface in com.datastax.oss.driver.api.core.data
A data structure where the values are accessible via a CQL identifier.
AccessibleByIndex - Interface in com.datastax.oss.driver.api.core.data
A data structure where the values are accessible via an integer index.
AccessibleByName - Interface in com.datastax.oss.driver.api.core.data
A data structure where the values are accessible via a name string.
add(BatchableStatement<?>) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Adds a new statement to the batch.
addAll(Iterable<? extends BatchableStatement<?>>) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Adds new statements to the batch.
addAll(BatchableStatement<?>...) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
 
addChangeListener(Consumer<OptionsMap>) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Registers a listener that will get notified when this object changes.
addContactEndPoint(EndPoint) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Adds a contact point to use for the initial connection to the cluster.
addContactEndPoints(Collection<EndPoint>) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Adds contact points to use for the initial connection to the cluster.
addContactPoint(InetSocketAddress) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Adds a contact point to use for the initial connection to the cluster.
addContactPoints(Collection<InetSocketAddress>) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Adds contact points to use for the initial connection to the cluster.
addCustomPayload(String, ByteBuffer) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
addCustomPayload(String, ByteBuffer) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
addNamedValue(CqlIdentifier, Object) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
addNamedValue(String, Object) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
addPositionalValue(Object) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
addPositionalValues(Iterable<Object>) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
addPositionalValues(Object...) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
ADDRESS_TRANSLATOR_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the address translator to use to convert the addresses sent by Cassandra nodes into ones that the driver uses to connect.
AddressTranslator - Interface in com.datastax.oss.driver.api.core.addresstranslation
Translates IP addresses received from Cassandra nodes into locally queriable addresses.
addRing(Point, Point, Point, Point...) - Method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon.Builder
Adds a new ring for this polygon.
addSaslProperty(String, String) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
Add a SASL property to use when creating the SASL client.
addStatement(BatchableStatement<?>) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
Adds a new statement to the batch.
addStatements(Iterable<BatchableStatement<?>>) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
Adds new statements to the batch.
addStatements(BatchableStatement<?>...) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
Adds new statements to the batch.
addTo(Temporal) - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
addTraversal(GraphTraversal) - Method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Add a traversal to this statement.
addTraversal(GraphTraversal) - Method in class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
Add a traversal to this builder to include in the generated BatchGraphStatement.
addTraversals(Iterable<GraphTraversal>) - Method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Adds several traversals to this statement.
addTraversals(Iterable<GraphTraversal>) - Method in class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
Add several traversals to this builder to include in the generated BatchGraphStatement.
addTraversals(GraphTraversal...) - Method in class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
Add several traversals to this builder to include in the generated BatchGraphStatement.
addTypeCodecs(TypeCodec<?>...) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
addTypeCodecs(TypeCodec<?>...) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Registers additional codecs for custom type mappings.
AggregateMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A CQL aggregate in the schema metadata.
all() - Method in interface com.datastax.dse.driver.api.core.graph.GraphResultSet
Returns all the remaining nodes as a list; not recommended for paginated queries that return a large number of nodes.
ALL - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
all() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
Returns all the remaining elements as a list; not recommended for queries that return a large number of elements.
allIndicesOf(CqlIdentifier) - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
allIndicesOf(String) - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
allIndicesOf(String) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Returns the indices of all columns that use the given name.
allIndicesOf(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Returns the indices of all columns that use the given identifier.
allIndicesOf(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.AccessibleById
Returns all the indices where a given identifier appears.
allIndicesOf(String) - Method in interface com.datastax.oss.driver.api.core.data.AccessibleByName
Returns all the indices where a given identifier appears.
allIndicesOf(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
allIndicesOf(String) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
AllNodesFailedException - Exception in com.datastax.oss.driver.api.core
Thrown when a query failed on all the coordinators it was tried on.
AllNodesFailedException(String, ExecutionInfo, Map<Node, Throwable>) - Constructor for exception com.datastax.oss.driver.api.core.AllNodesFailedException
AllNodesFailedException(String, ExecutionInfo, Iterable<Map.Entry<Node, List<Throwable>>>) - Constructor for exception com.datastax.oss.driver.api.core.AllNodesFailedException
 
AlreadyExistsException - Exception in com.datastax.oss.driver.api.core.servererrors
Thrown when a query attempts to create a keyspace or table that already exists.
AlreadyExistsException(Node, String, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.AlreadyExistsException
 
ANY - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
APPLICATION_NAME - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The name of the application using the session.
APPLICATION_VERSION - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The version of the application using the session.
areBoundStatementsIdempotent() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
Whether bound statements that will be created from the prepared statement are idempotent.
areBoundStatementsTracing() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
Whether bound statements that will be created from the prepared statement are tracing.
arrayOf(Class<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
arrayOf(GenericType<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
as(Class<ResultT>) - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Deserializes and returns this node as an instance of clazz.
as(GenericType<ResultT>) - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Deserializes and returns this node as an instance of the given type.
asBoolean() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a boolean.
ASCII - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type ascii to Java's String.
ASCII - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
asCql(boolean) - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
Returns the identifier in a format appropriate for concatenation in a CQL query.
asCql(boolean, boolean) - Method in interface com.datastax.oss.driver.api.core.type.CustomType
 
asCql(boolean, boolean) - Method in interface com.datastax.oss.driver.api.core.type.DataType
Builds an appropriate representation for use in a CQL query.
asCql(boolean, boolean) - Method in interface com.datastax.oss.driver.api.core.type.ListType
 
asCql(boolean, boolean) - Method in interface com.datastax.oss.driver.api.core.type.MapType
 
asCql(boolean, boolean) - Method in interface com.datastax.oss.driver.api.core.type.SetType
 
asCql(boolean, boolean) - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
asCql(boolean, boolean) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
asDouble() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a long integer.
asEdge() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a Tinkerpop Edge.
asGeoJson() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Geometry
Returns a JSON representation of this geospatial type.
asInt() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as an integer.
asInternal() - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
Returns the identifier in the "internal" format.
asList() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Deserializes and returns this node as a List.
asLong() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a long integer.
asMap() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Deserializes and returns this node as a Map.
asMetricPrefix() - Method in interface com.datastax.oss.driver.api.core.metadata.EndPoint
Returns an alternate string representation for use in node-level metric names.
asPath() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a Tinkerpop Path.
asProperty() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a Tinkerpop Property.
asRawMap() - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Returns a live view of this object, using the driver's untyped DriverOption.
asSet() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Deserializes and returns this node as a Set.
asString() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
A valid string representation of this node.
asVertex() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a Tinkerpop Vertex.
asVertexProperty() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns this node as a Tinkerpop VertexProperty.
asWellKnownBinary() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Geometry
Returns a Well-known Binary (WKB) representation of this geospatial type.
asWellKnownText() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Geometry
Returns a Well-known Text (WKT) representation of this geospatial type.
ASYNC - Static variable in interface com.datastax.dse.driver.api.core.graph.GraphStatement
The type returned when a graph statement is executed asynchronously.
ASYNC - Static variable in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The type returned when a CQL statement is prepared asynchronously.
ASYNC - Static variable in interface com.datastax.oss.driver.api.core.cql.Statement
The type returned when a CQL statement is executed asynchronously.
AsyncAutoCloseable - Interface in com.datastax.oss.driver.api.core
An object that can be closed in an asynchronous, non-blocking manner.
AsyncCqlSession - Interface in com.datastax.oss.driver.api.core.cql
A session that offers user-friendly methods to execute CQL requests asynchronously.
AsyncGraphResultSet - Interface in com.datastax.dse.driver.api.core.graph
The result of an asynchronous graph query.
AsyncPagingIterable<ElementT,SelfT extends AsyncPagingIterable<ElementT,SelfT>> - Interface in com.datastax.oss.driver.api.core
An iterable of elements which are fetched asynchronously by the driver, possibly in multiple requests.
AsyncResultSet - Interface in com.datastax.oss.driver.api.core.cql
The result of an asynchronous CQL query.
attach(AttachmentPoint) - Method in interface com.datastax.oss.driver.api.core.detach.Detachable
 
AttachmentPoint - Interface in com.datastax.oss.driver.api.core.detach
 
AUTH_PROVIDER_AUTHORIZATION_ID - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Proxy authentication for GSSAPI authentication: allows to login as another user or role.
AUTH_PROVIDER_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the authentication provider.
AUTH_PROVIDER_LOGIN_CONFIGURATION - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Login configuration for GSSAPI authentication.
AUTH_PROVIDER_PASSWORD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Plain text auth provider password.
AUTH_PROVIDER_SASL_PROPERTIES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Internal SASL properties, if any, such as QOP, for GSSAPI authentication.
AUTH_PROVIDER_SERVICE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Service name for GSSAPI authentication.
AUTH_PROVIDER_USER_NAME - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Plain text auth provider username.
AuthenticationException - Exception in com.datastax.oss.driver.api.core.auth
Indicates an error during the authentication phase while connecting to a node.
AuthenticationException(EndPoint, String) - Constructor for exception com.datastax.oss.driver.api.core.auth.AuthenticationException
 
AuthenticationException(EndPoint, String, Throwable) - Constructor for exception com.datastax.oss.driver.api.core.auth.AuthenticationException
 
Authenticator - Interface in com.datastax.oss.driver.api.core.auth
Handles SASL authentication with Cassandra servers.
AuthProvider - Interface in com.datastax.oss.driver.api.core.auth
Provides Authenticator instances to use when connecting to Cassandra nodes.

B

BaseDseAuthenticator - Class in com.datastax.dse.driver.api.core.auth
Base class for SyncAuthenticator implementations that want to make use of the authentication scheme negotiation in DseAuthenticator.
BaseDseAuthenticator(String) - Constructor for class com.datastax.dse.driver.api.core.auth.BaseDseAuthenticator
 
BATCH - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
BATCH_LOG - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
BatchableStatement<SelfT extends BatchableStatement<SelfT>> - Interface in com.datastax.oss.driver.api.core.cql
A statement that can be added to a CQL batch.
BatchGraphStatement - Interface in com.datastax.dse.driver.api.core.graph
A graph statement that groups multiple mutating traversals together, to be executed in the same transaction.
BatchGraphStatementBuilder - Class in com.datastax.dse.driver.api.core.graph
A builder to create a batch graph statement.
BatchGraphStatementBuilder() - Constructor for class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
 
BatchGraphStatementBuilder(BatchGraphStatement) - Constructor for class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
 
BatchStatement - Interface in com.datastax.oss.driver.api.core.cql
A statement that groups a number of other statements, so that they can be executed as a batch (i.e.
BatchStatementBuilder - Class in com.datastax.oss.driver.api.core.cql
A builder to create a batch statement.
BatchStatementBuilder(BatchType) - Constructor for class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
BatchStatementBuilder(BatchStatement) - Constructor for class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
BatchType - Interface in com.datastax.oss.driver.api.core.cql
The type of a batch.
BIG_DECIMAL - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
BIG_INTEGER - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
BIGINT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type bigint to Java's long.
BIGINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
bind(Object...) - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
Builds an executable statement that associates a set of values with the bind variables.
Bindable<SelfT extends Bindable<SelfT>> - Interface in com.datastax.oss.driver.api.core.cql
A data container with the ability to unset values.
BLOB - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type blob to Java's ByteBuffer.
BLOB - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
BLOB_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type blob to Java's byte[].
BOOLEAN - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type boolean to Java's boolean.
BOOLEAN - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
BOOLEAN - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
BOOLEAN_LIST_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type list<boolean> to Java's boolean[].
BootstrappingException - Exception in com.datastax.oss.driver.api.core.servererrors
Thrown when the coordinator was bootstrapping when it received a query.
BootstrappingException(Node) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.BootstrappingException
 
BoundStatement - Interface in com.datastax.oss.driver.api.core.cql
A prepared statement in its executable form, with values bound to the variables.
BoundStatementBuilder - Class in com.datastax.oss.driver.api.core.cql
A builder to create a bound statement.
BoundStatementBuilder(PreparedStatement, ColumnDefinitions, ByteBuffer[], String, DriverExecutionProfile, CqlIdentifier, ByteBuffer, Token, Map<String, ByteBuffer>, Boolean, boolean, long, ByteBuffer, int, ConsistencyLevel, ConsistencyLevel, Duration, CodecRegistry, ProtocolVersion) - Constructor for class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
BoundStatementBuilder(BoundStatement) - Constructor for class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
boundStatementBuilder(Object...) - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
Returns a builder to construct an executable statement.
build() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
 
build() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon.Builder
 
build() - Method in class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
 
build() - Method in interface com.datastax.dse.driver.api.core.graph.DseGraphRemoteConnectionBuilder
Build the remote connection that was configured with this builder.
build() - Method in class com.datastax.dse.driver.api.core.graph.FluentGraphStatementBuilder
 
build() - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
Create the statement with the configuration defined by this builder object.
build() - Method in class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
 
build() - Method in interface com.datastax.oss.driver.api.core.config.ProgrammaticDriverConfigLoaderBuilder
 
build() - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
build() - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
build() - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
build() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
build() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
build() - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Convenience method to call SessionBuilder.buildAsync() and block on the result.
buildAsync() - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Creates the session with the options set by this builder.
buildContext(DriverConfigLoader, ProgrammaticArguments) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
This must return an instance of InternalDriverContext (it's not expressed directly in the signature to avoid leaking that type through the protected API).
buildContext(DriverConfigLoader, List<TypeCodec<?>>, NodeStateListener, SchemaChangeListener, RequestTracker, Map<String, String>, Map<String, Predicate<Node>>, ClassLoader) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Deprecated.
this method only exists for backward compatibility (if a subclass written for driver 4.1.0 returns a non-null result, that value will be used). Please override SessionBuilder.buildContext(DriverConfigLoader, ProgrammaticArguments) instead.
buildCustomPayload() - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
buildCustomPayload() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
buildDefaultSessionAsync() - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
builder() - Static method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions
 
Builder() - Constructor for class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
 
builder() - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon
Returns a polygon builder.
builder() - Static method in interface com.datastax.dse.driver.api.core.DseSession
Deprecated.
Returns a builder to create a new instance.
builder() - Static method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Create a builder helper object to start creating a new instance.
builder(BatchGraphStatement) - Static method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Create a builder helper object to start creating a new instance with an existing statement as a template.
builder(GraphTraversal<?, ?>) - Static method in interface com.datastax.dse.driver.api.core.graph.FluentGraphStatement
Create a builder object to start creating a new instance from the given traversal.
builder(FluentGraphStatement) - Static method in interface com.datastax.dse.driver.api.core.graph.FluentGraphStatement
Create a builder helper object to start creating a new instance with an existing statement as a template.
builder(String) - Static method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
Create a builder object to start creating a new instance from the given script.
builder(ScriptGraphStatement) - Static method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
Create a builder helper object to start creating a new instance with an existing statement as a template.
builder(BatchType) - Static method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Returns a builder to create an instance of the default implementation.
builder(BatchStatement) - Static method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Returns a builder to create an instance of the default implementation, copying the fields of the given statement.
builder(String) - Static method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Returns a builder to create an instance of the default implementation.
builder(SimpleStatement) - Static method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Returns a builder to create an instance of the default implementation, copying the fields of the given statement.
builder() - Static method in interface com.datastax.oss.driver.api.core.CqlSession
Returns a builder to create a new instance.
builder() - Static method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
Builder() - Constructor for class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
builtInValues() - Static method in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Returns the list of all built-in options known to the driver codebase; in other words, all the TypedDriverOption constants defined on this class.
BusyConnectionException - Exception in com.datastax.oss.driver.api.core.connection
Indicates that a write was attempted on a connection that already handles too many simultaneous requests.
BusyConnectionException(int) - Constructor for exception com.datastax.oss.driver.api.core.connection.BusyConnectionException
 
BusyConnectionException(String) - Constructor for exception com.datastax.oss.driver.api.core.connection.BusyConnectionException
 
BYTE - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
BYTE_BUFFER - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
BYTE_LIST_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type list<tinyint> to Java's byte[].
ByteUtils - Class in com.datastax.oss.driver.api.core.data
A set of static utility methods to work with byte buffers (associated with CQL type blob).

C

cancel() - Method in interface com.datastax.dse.driver.api.core.cql.continuous.ContinuousAsyncResultSet
Cancels the continuous query.
cancel() - Method in interface com.datastax.dse.driver.api.core.cql.continuous.ContinuousResultSet
Cancels the continuous query.
cancel() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
Cancels the query and asks the server to stop sending results.
cancel() - Method in interface com.datastax.dse.driver.api.core.graph.GraphResultSet
Cancels the query and asks the server to stop sending results.
CAS - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
CDC - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
checkSchemaAgreement() - Method in interface com.datastax.oss.driver.api.core.session.Session
Convenience method to call Session.checkSchemaAgreementAsync() and block for the result.
checkSchemaAgreementAsync() - Method in interface com.datastax.oss.driver.api.core.session.Session
Checks if all nodes in the cluster agree on a common schema version.
cipherSuites - Variable in class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
 
clear() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.Credentials
Clears the credentials from memory when they're no longer needed.
clear() - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Clears the batch, removing all the statements added so far.
clearCustomPayload() - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
clearCustomPayload() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
clearDatacenters() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
clearNamedValues() - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
clearPositionalValues() - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
clearQueryParams() - Method in class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
Clears all the parameters previously added to this builder.
clearStatements() - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
Clears all the statements in this batch.
clearTraversals() - Method in class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
Clears all the traversals previously added to this builder.
close() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase
 
close() - Method in interface com.datastax.oss.driver.api.core.addresstranslation.AddressTranslator
Called when the cluster that this translator is associated with closes.
close() - Method in interface com.datastax.oss.driver.api.core.AsyncAutoCloseable
close() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase
 
close() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Called when the cluster closes.
close() - Method in interface com.datastax.oss.driver.api.core.connection.ReconnectionPolicy
Called when the cluster that this policy is associated with closes.
close() - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Called when the cluster that this policy is associated with closes.
close() - Method in class com.datastax.oss.driver.api.core.metadata.NodeStateListenerBase
 
close() - Method in class com.datastax.oss.driver.api.core.metadata.SafeInitNodeStateListener
 
close() - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
close() - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
Called when the cluster that this policy is associated with closes.
close() - Method in interface com.datastax.oss.driver.api.core.specex.SpeculativeExecutionPolicy
Called when the cluster that this policy is associated with closes.
close() - Method in class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
 
closeAsync() - Method in interface com.datastax.oss.driver.api.core.AsyncAutoCloseable
Initiates an orderly shutdown: no new requests are accepted, but all pending requests are allowed to complete normally.
ClosedConnectionException - Exception in com.datastax.oss.driver.api.core.connection
Thrown when the connection on which a request was executing is closed due to an unrelated event.
ClosedConnectionException(String) - Constructor for exception com.datastax.oss.driver.api.core.connection.ClosedConnectionException
 
ClosedConnectionException(String, Throwable) - Constructor for exception com.datastax.oss.driver.api.core.connection.ClosedConnectionException
 
closeFuture() - Method in interface com.datastax.oss.driver.api.core.AsyncAutoCloseable
Returns a stage that will complete when AsyncAutoCloseable.close() or AsyncAutoCloseable.forceCloseAsync() is called, and the shutdown sequence completes.
CLOUD_SECURE_CONNECT_BUNDLE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The location of the cloud secure bundle used to connect to Datastax Apache Cassandra as a service.
cloudConfigInputStream - Variable in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
ClusteringOrder - Enum in com.datastax.oss.driver.api.core.metadata.schema
The order of a clustering column in a table or materialized view.
COALESCER_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The coalescer reschedule interval.
COALESCER_MAX_RUNS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Deprecated.
This option was removed in version 4.6.1.
codecFor(DataType, GenericType<JavaTypeT>) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
Returns a codec to handle the conversion between the given types.
codecFor(DataType, Class<JavaTypeT>) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
codecFor(DataType) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
Returns a codec to convert the given CQL type to the Java type deemed most appropriate to represent it.
codecFor(GenericType<JavaTypeT>) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
Returns a codec to convert the given Java type to the CQL type deemed most appropriate to represent it.
codecFor(Class<JavaTypeT>) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
codecFor(DataType, JavaTypeT) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
Returns a codec to convert the given Java object to the given CQL type.
codecFor(JavaTypeT) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
Returns a codec to convert the given Java object to the CQL type deemed most appropriate to represent it.
CodecNotFoundException - Exception in com.datastax.oss.driver.api.core.type.codec
Thrown when a suitable TypeCodec cannot be found by the CodecRegistry.
CodecNotFoundException(DataType, GenericType<?>) - Constructor for exception com.datastax.oss.driver.api.core.type.codec.CodecNotFoundException
 
CodecNotFoundException(Throwable, DataType, GenericType<?>) - Constructor for exception com.datastax.oss.driver.api.core.type.codec.CodecNotFoundException
 
codecRegistry() - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
codecRegistry() - Method in interface com.datastax.oss.driver.api.core.data.Data
Returns the registry of all the codecs currently available to convert values for this instance.
CodecRegistry - Interface in com.datastax.oss.driver.api.core.type.codec.registry
Provides codecs to convert CQL types to their Java equivalent, and vice-versa.
ColumnDefinition - Interface in com.datastax.oss.driver.api.core.cql
Metadata about a CQL column.
ColumnDefinitions - Interface in com.datastax.oss.driver.api.core.cql
Metadata about a set of CQL columns.
ColumnMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A column in the schema metadata.
com.datastax.dse.driver.api.core - package com.datastax.dse.driver.api.core
 
com.datastax.dse.driver.api.core.auth - package com.datastax.dse.driver.api.core.auth
 
com.datastax.dse.driver.api.core.config - package com.datastax.dse.driver.api.core.config
 
com.datastax.dse.driver.api.core.cql.continuous - package com.datastax.dse.driver.api.core.cql.continuous
 
com.datastax.dse.driver.api.core.cql.continuous.reactive - package com.datastax.dse.driver.api.core.cql.continuous.reactive
 
com.datastax.dse.driver.api.core.cql.reactive - package com.datastax.dse.driver.api.core.cql.reactive
Types related to CQL execution using reactive-style programming.
com.datastax.dse.driver.api.core.data.geometry - package com.datastax.dse.driver.api.core.data.geometry
 
com.datastax.dse.driver.api.core.data.time - package com.datastax.dse.driver.api.core.data.time
 
com.datastax.dse.driver.api.core.graph - package com.datastax.dse.driver.api.core.graph
 
com.datastax.dse.driver.api.core.graph.predicates - package com.datastax.dse.driver.api.core.graph.predicates
 
com.datastax.dse.driver.api.core.graph.reactive - package com.datastax.dse.driver.api.core.graph.reactive
 
com.datastax.dse.driver.api.core.metadata - package com.datastax.dse.driver.api.core.metadata
 
com.datastax.dse.driver.api.core.metadata.schema - package com.datastax.dse.driver.api.core.metadata.schema
 
com.datastax.dse.driver.api.core.metrics - package com.datastax.dse.driver.api.core.metrics
 
com.datastax.dse.driver.api.core.servererrors - package com.datastax.dse.driver.api.core.servererrors
 
com.datastax.dse.driver.api.core.type - package com.datastax.dse.driver.api.core.type
 
com.datastax.dse.driver.api.core.type.codec - package com.datastax.dse.driver.api.core.type.codec
 
com.datastax.oss.driver.api - package com.datastax.oss.driver.api
The driver's public API.
com.datastax.oss.driver.api.core - package com.datastax.oss.driver.api.core
The core API of the driver, that deals with query execution and cluster metadata.
com.datastax.oss.driver.api.core.addresstranslation - package com.datastax.oss.driver.api.core.addresstranslation
 
com.datastax.oss.driver.api.core.auth - package com.datastax.oss.driver.api.core.auth
Support for authentication between the driver and Cassandra nodes.
com.datastax.oss.driver.api.core.config - package com.datastax.oss.driver.api.core.config
The configuration of the driver.
com.datastax.oss.driver.api.core.connection - package com.datastax.oss.driver.api.core.connection
Types related to a connection to a Cassandra node.
com.datastax.oss.driver.api.core.context - package com.datastax.oss.driver.api.core.context
 
com.datastax.oss.driver.api.core.cql - package com.datastax.oss.driver.api.core.cql
 
com.datastax.oss.driver.api.core.data - package com.datastax.oss.driver.api.core.data
 
com.datastax.oss.driver.api.core.detach - package com.datastax.oss.driver.api.core.detach
 
com.datastax.oss.driver.api.core.loadbalancing - package com.datastax.oss.driver.api.core.loadbalancing
 
com.datastax.oss.driver.api.core.metadata - package com.datastax.oss.driver.api.core.metadata
 
com.datastax.oss.driver.api.core.metadata.schema - package com.datastax.oss.driver.api.core.metadata.schema
 
com.datastax.oss.driver.api.core.metadata.token - package com.datastax.oss.driver.api.core.metadata.token
 
com.datastax.oss.driver.api.core.metrics - package com.datastax.oss.driver.api.core.metrics
 
com.datastax.oss.driver.api.core.paging - package com.datastax.oss.driver.api.core.paging
 
com.datastax.oss.driver.api.core.retry - package com.datastax.oss.driver.api.core.retry
 
com.datastax.oss.driver.api.core.servererrors - package com.datastax.oss.driver.api.core.servererrors
 
com.datastax.oss.driver.api.core.session - package com.datastax.oss.driver.api.core.session
 
com.datastax.oss.driver.api.core.session.throttling - package com.datastax.oss.driver.api.core.session.throttling
 
com.datastax.oss.driver.api.core.specex - package com.datastax.oss.driver.api.core.specex
 
com.datastax.oss.driver.api.core.ssl - package com.datastax.oss.driver.api.core.ssl
Support for secured communication between the driver and Cassandra nodes.
com.datastax.oss.driver.api.core.time - package com.datastax.oss.driver.api.core.time
 
com.datastax.oss.driver.api.core.tracker - package com.datastax.oss.driver.api.core.tracker
 
com.datastax.oss.driver.api.core.type - package com.datastax.oss.driver.api.core.type
 
com.datastax.oss.driver.api.core.type.codec - package com.datastax.oss.driver.api.core.type.codec
 
com.datastax.oss.driver.api.core.type.codec.registry - package com.datastax.oss.driver.api.core.type.codec.registry
 
com.datastax.oss.driver.api.core.type.reflect - package com.datastax.oss.driver.api.core.type.reflect
 
com.datastax.oss.driver.api.core.uuid - package com.datastax.oss.driver.api.core.uuid
 
com.datastax.oss.driver.internal - package com.datastax.oss.driver.internal
Internal implementation details of the driver.
compareTo(Version) - Method in class com.datastax.oss.driver.api.core.Version
 
compose(DriverConfigLoader, DriverConfigLoader) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Composes two existing config loaders to form a new one.
computeSizeInBytes(DriverContext) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
 
computeSizeInBytes(DriverContext) - Method in interface com.datastax.oss.driver.api.core.cql.BoundStatement
 
computeSizeInBytes(DriverContext) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
 
computeSizeInBytes(DriverContext) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Calculates the approximate size in bytes that the statement will have when encoded.
CONFIG_RELOAD_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How often the driver tries to reload the configuration.
configLoader - Variable in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
CONNECTION_CONNECT_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The timeout to use when establishing driver connections.
CONNECTION_INIT_QUERY_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The timeout to use for internal queries that run as part of the initialization process.
CONNECTION_MAX_ORPHAN_REQUESTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of "orphaned" requests before a connection gets closed automatically.
CONNECTION_MAX_REQUESTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of requests that can be executed concurrently on a connection.
CONNECTION_POOL_LOCAL_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of connections in the LOCAL pool.
CONNECTION_POOL_REMOTE_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of connections in the REMOTE pool.
CONNECTION_SET_KEYSPACE_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The timeout to use when the driver changes the keyspace on a connection at runtime.
CONNECTION_WARN_INIT_ERROR - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to log non-fatal errors when the driver tries to open a new connection.
ConnectionInitException - Exception in com.datastax.oss.driver.api.core.connection
Indicates a generic error while initializing a connection.
ConnectionInitException(String, Throwable) - Constructor for exception com.datastax.oss.driver.api.core.connection.ConnectionInitException
 
consistencyLevel - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
ConsistencyLevel - Interface in com.datastax.oss.driver.api.core
The consistency level of a request.
consistencyLevel - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
CONTACT_POINTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The contact points to use for the initial connection to the cluster.
contains(Geometry) - Method in interface com.datastax.dse.driver.api.core.data.geometry.Geometry
Tests whether this geospatial type instance contains another instance.
contains(V) - Static method in class com.datastax.dse.driver.api.core.graph.predicates.CqlCollection
Checks if the target collection contains the given value.
contains(String) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Whether there is a definition using the given name.
contains(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Whether there is a definition using the given CQL identifier.
contains(Token) - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Checks whether this range contains a given token, i.e.
contains(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
contains(String) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
containsKey(K) - Static method in class com.datastax.dse.driver.api.core.graph.predicates.CqlCollection
Checks if the target map contains the given key.
containsValue(V) - Static method in class com.datastax.dse.driver.api.core.graph.predicates.CqlCollection
Checks if the target map contains the given value.
CONTINUOUS_PAGING_MAX_ENQUEUED_PAGES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of continuous pages that can be stored in the local queue.
CONTINUOUS_PAGING_MAX_PAGES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of continuous pages to return.
CONTINUOUS_PAGING_MAX_PAGES_PER_SECOND - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of continuous pages per second.
CONTINUOUS_PAGING_METRICS_SESSION_CQL_REQUESTS_DIGITS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of significant decimal digits to which internal structures will maintain for continuous requests.
CONTINUOUS_PAGING_METRICS_SESSION_CQL_REQUESTS_HIGHEST - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The largest latency that we expect to record for continuous requests.
CONTINUOUS_PAGING_METRICS_SESSION_CQL_REQUESTS_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval at which percentile data is refreshed for continuous requests.
CONTINUOUS_PAGING_PAGE_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The page size for continuous paging.
CONTINUOUS_PAGING_PAGE_SIZE_BYTES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether TypedDriverOption.CONTINUOUS_PAGING_PAGE_SIZE should be interpreted in number of rows or bytes.
CONTINUOUS_PAGING_TIMEOUT_FIRST_PAGE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long to wait for the coordinator to send the first continuous page.
CONTINUOUS_PAGING_TIMEOUT_OTHER_PAGES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long to wait for the coordinator to send subsequent continuous pages.
ContinuousAsyncResultSet - Interface in com.datastax.dse.driver.api.core.cql.continuous
ContinuousReactiveResultSet - Interface in com.datastax.dse.driver.api.core.cql.continuous.reactive
A marker interface for publishers returned by ContinuousReactiveSession.
ContinuousReactiveSession - Interface in com.datastax.dse.driver.api.core.cql.continuous.reactive
A Session that offers utility methods to issue queries using reactive-style programming and continuous paging, combined together.
ContinuousResultSet - Interface in com.datastax.dse.driver.api.core.cql.continuous
ContinuousSession - Interface in com.datastax.dse.driver.api.core.cql.continuous
A session that has the ability to execute continuous paging queries.
CONTROL_CONNECTION_AGREEMENT_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval between each schema agreement check attempt.
CONTROL_CONNECTION_AGREEMENT_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The timeout after which schema agreement fails.
CONTROL_CONNECTION_AGREEMENT_WARN - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to log a warning if schema agreement fails.
CONTROL_CONNECTION_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long the driver waits for responses to control queries.
CoordinatorException - Exception in com.datastax.oss.driver.api.core.servererrors
A server-side error thrown by the coordinator node in response to a driver request.
CoordinatorException(Node, String, ExecutionInfo, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.CoordinatorException
 
copy() - Method in exception com.datastax.dse.driver.api.core.servererrors.UnfitClientException
 
copy() - Method in exception com.datastax.oss.driver.api.core.AllNodesFailedException
 
copy() - Method in exception com.datastax.oss.driver.api.core.connection.BusyConnectionException
 
copy() - Method in exception com.datastax.oss.driver.api.core.connection.ClosedConnectionException
 
copy() - Method in exception com.datastax.oss.driver.api.core.connection.ConnectionInitException
 
copy() - Method in exception com.datastax.oss.driver.api.core.connection.CrcMismatchException
 
copy() - Method in exception com.datastax.oss.driver.api.core.connection.FrameTooLongException
 
copy() - Method in exception com.datastax.oss.driver.api.core.connection.HeartbeatException
 
copy(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Creates a new instance with a different paging state.
copy() - Method in exception com.datastax.oss.driver.api.core.DriverException
Copy the exception.
copy() - Method in exception com.datastax.oss.driver.api.core.DriverExecutionException
 
copy() - Method in exception com.datastax.oss.driver.api.core.DriverTimeoutException
 
copy() - Method in exception com.datastax.oss.driver.api.core.InvalidKeyspaceException
 
copy() - Method in exception com.datastax.oss.driver.api.core.NoNodeAvailableException
 
copy() - Method in exception com.datastax.oss.driver.api.core.RequestThrottlingException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.AlreadyExistsException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.BootstrappingException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.FunctionFailureException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.InvalidConfigurationInQueryException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.InvalidQueryException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.OverloadedException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.ProtocolError
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.ReadFailureException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.ReadTimeoutException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.ServerError
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.SyntaxError
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.TruncateException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.UnauthorizedException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.UnavailableException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.WriteFailureException
 
copy() - Method in exception com.datastax.oss.driver.api.core.servererrors.WriteTimeoutException
 
copy(boolean) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
copy() - Method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
 
COUNTER - Static variable in interface com.datastax.oss.driver.api.core.cql.BatchType
 
COUNTER - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
COUNTER - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type counter to Java's long.
COUNTER - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
CQL_DURATION - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
CqlCollection - Class in com.datastax.dse.driver.api.core.graph.predicates
Predicates that can be used on CQL collections (lists, sets and maps).
CqlCollection() - Constructor for class com.datastax.dse.driver.api.core.graph.predicates.CqlCollection
 
CqlDuration - Class in com.datastax.oss.driver.api.core.data
A duration, as defined in CQL.
CqlIdentifier - Class in com.datastax.oss.driver.api.core
The identifier of CQL element (keyspace, table, column, etc).
CqlSession - Interface in com.datastax.oss.driver.api.core
The default session type built by the driver.
CqlSessionBuilder - Class in com.datastax.oss.driver.api.core
Helper class to build a CqlSession instance.
CqlSessionBuilder() - Constructor for class com.datastax.oss.driver.api.core.CqlSessionBuilder
 
CrcMismatchException - Exception in com.datastax.oss.driver.api.core.connection
Thrown when the checksums in a server response don't match (protocol v5 or above).
CrcMismatchException(String) - Constructor for exception com.datastax.oss.driver.api.core.connection.CrcMismatchException
 
Credentials(char[], char[], char[]) - Constructor for class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.Credentials
Builds an instance for username/password authentication, and proxy authentication with the given authorizationId.
Credentials(char[], char[]) - Constructor for class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.Credentials
Builds an instance for simple username/password authentication.
currentPage() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
The nodes in the current page.
currentPage() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
The elements in the current page.
custom(DataType) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
Builds a new codec that maps a CQL custom type to Java's ByteBuffer.
custom(String) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
CustomType - Interface in com.datastax.oss.driver.api.core.type
 

D

Data - Interface in com.datastax.oss.driver.api.core.data
A data structure containing CQL values.
DataType - Interface in com.datastax.oss.driver.api.core.type
The type of a CQL column, field or function argument.
DataTypes - Class in com.datastax.oss.driver.api.core.type
Constants and factory methods to obtain data type instances.
DataTypes() - Constructor for class com.datastax.oss.driver.api.core.type.DataTypes
 
DATE - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type date to Java's LocalDate.
DATE - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
DATE_RANGE - Static variable in class com.datastax.dse.driver.api.core.type.codec.DseTypeCodecs
 
DATE_RANGE - Static variable in class com.datastax.dse.driver.api.core.type.DseDataTypes
 
DateRange - Class in com.datastax.dse.driver.api.core.data.time
A date range, as defined by the server type org.apache.cassandra.db.marshal.DateRangeType, corresponding to the Apache Solr type DateRangeField.
DateRange(DateRangeBound) - Constructor for class com.datastax.dse.driver.api.core.data.time.DateRange
Creates a "single bounded" instance, i.e., a date range whose upper and lower bounds are identical.
DateRange(DateRangeBound, DateRangeBound) - Constructor for class com.datastax.dse.driver.api.core.data.time.DateRange
Creates an instance composed of two distinct bounds.
DateRangeBound - Class in com.datastax.dse.driver.api.core.data.time
A date range bound.
DateRangePrecision - Enum in com.datastax.dse.driver.api.core.data.time
The precision of a DateRangeBound.
DECIMAL - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type decimal to Java's BigDecimal.
DECIMAL - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveBooleanCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveByteCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveDoubleCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveFloatCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveIntCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveLongCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveShortCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Decodes a value from the binary format of the CQL type handled by this codec.
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveBooleanCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveByteCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveDoubleCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveFloatCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveIntCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveLongCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveShortCodec
 
DEFAULT - Static variable in interface com.datastax.oss.driver.api.core.ProtocolVersion
The default version used for detached objects.
DEFAULT - Static variable in interface com.datastax.oss.driver.api.core.type.codec.registry.CodecRegistry
An immutable instance, that only handles built-in driver types (that is, primitive types, and collections, tuples, and user defined types thereof).
DEFAULT_NAME - Static variable in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
The name of the default profile (the string "default").
DEFAULT_SASL_SERVICE_NAME - Static variable in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase
The default SASL service name used by this auth provider.
DefaultBatchType - Enum in com.datastax.oss.driver.api.core.cql
A default batch type supported by the driver out of the box.
defaultConfigLoader() - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Deprecated.
defaultConfigLoader(ClassLoader) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
DefaultConsistencyLevel - Enum in com.datastax.oss.driver.api.core
A default consistency level supported by the driver out of the box.
DefaultDriverOption - Enum in com.datastax.oss.driver.api.core.config
Built-in driver options for the core driver.
DefaultNodeMetric - Enum in com.datastax.oss.driver.api.core.metrics
See reference.conf for a description of each metric.
DefaultProtocolVersion - Enum in com.datastax.oss.driver.api.core
A protocol version supported by default by the driver.
DefaultSessionMetric - Enum in com.datastax.oss.driver.api.core.metrics
See reference.conf for a description of each metric.
DefaultWriteType - Enum in com.datastax.oss.driver.api.core.servererrors
A default write type supported by the driver out of the box.
Describable - Interface in com.datastax.oss.driver.api.core.metadata.schema
A schema element that can be described in terms of CQL CREATE statements.
describe(boolean) - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseAggregateMetadata
 
describe(boolean) - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata
 
describe(boolean) - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseGraphKeyspaceMetadata
 
describe(boolean) - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseGraphTableMetadata
 
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
 
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.Describable
Returns a single CQL statement that creates the element.
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
 
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.TableMetadata
 
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ViewMetadata
 
describe(boolean) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
 
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.Describable
Returns a CQL script that creates the element and all of its children.
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
 
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.TableMetadata
Returns a CQL script that creates the element and all of its children.
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ViewMetadata
 
describeWithChildren(boolean) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
Detachable - Interface in com.datastax.oss.driver.api.core.detach
Defines the contract of an object that can be detached and reattached to a driver instance.
disableTracing() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for setTracing(false).
disableTracing() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for setTracing(false).
DOUBLE - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type double to Java's double.
DOUBLE - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
DOUBLE - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
DOUBLE_LIST_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type list<double> to Java's double[].
DriverConfig - Interface in com.datastax.oss.driver.api.core.config
The configuration of the driver.
DriverConfigLoader - Interface in com.datastax.oss.driver.api.core.config
Manages the initialization, and optionally the periodic reloading, of the driver configuration.
DriverContext - Interface in com.datastax.oss.driver.api.core.context
Holds common components that are shared throughout a driver instance.
driverDefaults() - Static method in class com.datastax.oss.driver.api.core.config.OptionsMap
Creates a new instance that contains the driver's default configuration.
DriverException - Exception in com.datastax.oss.driver.api.core
Base class for all exceptions thrown by the driver.
DriverException(String, ExecutionInfo, Throwable, boolean) - Constructor for exception com.datastax.oss.driver.api.core.DriverException
 
DriverExecutionException - Exception in com.datastax.oss.driver.api.core
Thrown by synchronous wrapper methods (such as SyncCqlSession.execute(Statement), when the underlying future was completed with a checked exception.
DriverExecutionException(Throwable) - Constructor for exception com.datastax.oss.driver.api.core.DriverExecutionException
 
DriverExecutionProfile - Interface in com.datastax.oss.driver.api.core.config
A profile in the driver's configuration.
DriverOption - Interface in com.datastax.oss.driver.api.core.config
Describes an option in the driver's configuration.
DriverTimeoutException - Exception in com.datastax.oss.driver.api.core
Thrown when a driver request timed out.
DriverTimeoutException(String) - Constructor for exception com.datastax.oss.driver.api.core.DriverTimeoutException
 
DSE_DRIVER_COORDINATES - Static variable in interface com.datastax.dse.driver.api.core.DseSession
Deprecated.
the DSE driver is no longer published as a separate artifact. This field is preserved for backward compatibility, but it returns the same value as Session.OSS_DRIVER_COORDINATES.
DSE_V1 - Static variable in interface com.datastax.oss.driver.api.core.ProtocolVersion
 
DSE_V2 - Static variable in interface com.datastax.oss.driver.api.core.ProtocolVersion
 
DSE_VERSION - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The DSE version that the node is running.
DSE_WORKLOADS - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The DSE workloads that the node is running.
DseAggregateMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized aggregate metadata for DSE.
DseColumnMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized column metadata for DSE.
DseDataTypes - Class in com.datastax.dse.driver.api.core.type
Extends DataTypes to handle DSE-specific types.
DseDataTypes() - Constructor for class com.datastax.dse.driver.api.core.type.DseDataTypes
 
DseDriverConfigLoader - Class in com.datastax.dse.driver.api.core.config
Deprecated.
This class only exists for backward compatibility. All of its methods delegate to their counterparts on DriverConfigLoader, which you should call directly instead.
DseDriverOption - Enum in com.datastax.dse.driver.api.core.config
 
DseEdgeMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Edge metadata, for a table that was created with CREATE TABLE ...
DseFunctionMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized function metadata for DSE.
DseFunctionMetadata.Monotonicity - Enum in com.datastax.dse.driver.api.core.metadata.schema
The monotonicity of a function.
DseGraph - Class in com.datastax.dse.driver.api.core.graph
General purpose utility class for interaction with DSE Graph via the DataStax Enterprise Java driver.
DseGraphKeyspaceMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized keyspace metadata, that handles the graph-specific properties introduced in DSE 6.8.
DseGraphRemoteConnectionBuilder - Interface in com.datastax.dse.driver.api.core.graph
A builder helper to create a RemoteConnection that will be used to build implicitly-executing fluent traversals.
DseGraphTableMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized table metadata, that handles the graph-specific properties introduced in DSE 6.8.
DseGssApiAuthProviderBase - Class in com.datastax.dse.driver.api.core.auth
 
DseGssApiAuthProviderBase(String) - Constructor for class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase
 
DseGssApiAuthProviderBase.GssApiAuthenticator - Class in com.datastax.dse.driver.api.core.auth
 
DseGssApiAuthProviderBase.GssApiOptions - Class in com.datastax.dse.driver.api.core.auth
The options to initialize a new authenticator.
DseGssApiAuthProviderBase.GssApiOptions.Builder - Class in com.datastax.dse.driver.api.core.auth
 
DseIndexMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized index metadata for DSE.
DseKeyspaceMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized keyspace metadata for DSE.
DseNodeMetric - Enum in com.datastax.dse.driver.api.core.metrics
See reference.conf for a description of each metric.
DseNodeProperties - Class in com.datastax.dse.driver.api.core.metadata
The keys for the additional DSE-specific properties stored in Node.getExtras().
DseNodeProperties() - Constructor for class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
 
DsePlainTextAuthProviderBase - Class in com.datastax.dse.driver.api.core.auth
Deprecated.
The driver's default plain text providers now support both Apache Cassandra and DSE. This type was preserved for backward compatibility, but implementors should now extend PlainTextAuthProviderBase instead.
DsePlainTextAuthProviderBase(String) - Constructor for class com.datastax.dse.driver.api.core.auth.DsePlainTextAuthProviderBase
Deprecated.
 
DseProtocolVersion - Enum in com.datastax.dse.driver.api.core
A DSE-specific protocol version.
DseRelationMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized table or materialized view metadata for DSE.
DseSession - Interface in com.datastax.dse.driver.api.core
Deprecated.
All DSE functionality is now available directly on CqlSession. This type is preserved for backward compatibility, but you should now use CqlSession instead.
DseSessionBuilder - Class in com.datastax.dse.driver.api.core
Deprecated.
DSE functionality is now exposed directly on CqlSession. This class is preserved for backward compatibility, but CqlSession.builder() should be used instead.
DseSessionBuilder() - Constructor for class com.datastax.dse.driver.api.core.DseSessionBuilder
Deprecated.
 
DseSessionMetric - Enum in com.datastax.dse.driver.api.core.metrics
See reference.conf for a description of each metric.
DseTableMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized table metadata for DSE.
DseTypeCodecs - Class in com.datastax.dse.driver.api.core.type.codec
Extends TypeCodecs to handle DSE-specific types.
DseTypeCodecs() - Constructor for class com.datastax.dse.driver.api.core.type.codec.DseTypeCodecs
 
DseVertexMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Vertex metadata, for a table that was created with CREATE TABLE ...
DseViewMetadata - Interface in com.datastax.dse.driver.api.core.metadata.schema
Specialized materialized view metadata for DSE.
DURATION - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type duration to the driver's CqlDuration.
DURATION - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
DURATION - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 

E

EACH_QUORUM - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
enableTracing() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for setTracing(true).
enableTracing() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for setTracing(true).
encode(OuterT, ProtocolVersion) - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
encode(Boolean, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveBooleanCodec
 
encode(Byte, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveByteCodec
 
encode(Double, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveDoubleCodec
 
encode(Float, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveFloatCodec
 
encode(Integer, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveIntCodec
 
encode(Long, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveLongCodec
 
encode(Short, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveShortCodec
 
encode(JavaTypeT, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Encodes the given value in the binary format of the CQL type handled by this codec.
encodePrimitive(boolean, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveBooleanCodec
 
encodePrimitive(byte, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveByteCodec
 
encodePrimitive(double, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveDoubleCodec
 
encodePrimitive(float, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveFloatCodec
 
encodePrimitive(int, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveIntCodec
 
encodePrimitive(long, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveLongCodec
 
encodePrimitive(short, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.PrimitiveShortCodec
 
endOf(long) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a "fake" time-based UUID that sorts as the biggest possible version 1 UUID generated at the provided timestamp.
EndPoint - Interface in com.datastax.oss.driver.api.core.metadata
Encapsulates the information needed to open connections to a node.
endProfile() - Method in interface com.datastax.oss.driver.api.core.config.ProgrammaticDriverConfigLoaderBuilder
Ends the definition of a profile.
entryEq(K, V) - Static method in class com.datastax.dse.driver.api.core.graph.predicates.CqlCollection
Checks if the target map contains the given entry.
entrySet() - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
Enumerates all the entries in this profile, including those that were inherited from another profile.
enumNamesOf(Class<EnumT>) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type text to a Java Enum, according to its constants' programmatic names.
enumOrdinalsOf(Class<EnumT>) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type int to a Java Enum, according to its constants' ordinals (STRONGLY discouraged, see explanations below).
equals(Object) - Method in class com.datastax.dse.driver.api.core.data.time.DateRange
 
equals(Object) - Method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.config.TypedDriverOption
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.Version
 
evaluateChallenge(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.auth.Authenticator
Evaluate a challenge received from the server.
evaluateChallenge(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
 
evaluateChallengeSync(ByteBuffer) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiAuthenticator
 
evaluateChallengeSync(ByteBuffer) - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.PlainTextAuthenticator
 
evaluateChallengeSync(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
Evaluate a challenge received from the server.
execute(GraphStatement<?>) - Method in interface com.datastax.dse.driver.api.core.graph.GraphSession
Executes a graph statement synchronously (the calling thread blocks until the result becomes available).
execute(Statement<?>) - Method in interface com.datastax.oss.driver.api.core.cql.SyncCqlSession
Executes a CQL statement synchronously (the calling thread blocks until the result becomes available).
execute(String) - Method in interface com.datastax.oss.driver.api.core.cql.SyncCqlSession
Executes a CQL statement synchronously (the calling thread blocks until the result becomes available).
execute(String, Object...) - Method in interface com.datastax.oss.driver.api.core.cql.SyncCqlSession
Executes a CQL statement synchronously (the calling thread blocks until the result becomes available).
execute(String, Map<String, Object>) - Method in interface com.datastax.oss.driver.api.core.cql.SyncCqlSession
Executes a CQL statement synchronously (the calling thread blocks until the result becomes available).
execute(RequestT, GenericType<ResultT>) - Method in interface com.datastax.oss.driver.api.core.session.Session
Executes an arbitrary request.
executeAs(String, StatementT) - Static method in class com.datastax.dse.driver.api.core.auth.ProxyAuthentication
Adds proxy authentication information to a CQL statement.
executeAs(String, StatementT) - Static method in class com.datastax.dse.driver.api.core.auth.ProxyAuthentication
Adds proxy authentication information to a graph statement.
executeAsync(GraphStatement<?>) - Method in interface com.datastax.dse.driver.api.core.graph.GraphSession
Executes a graph statement asynchronously (the call returns as soon as the statement was sent, generally before the result is available).
executeAsync(Statement<?>) - Method in interface com.datastax.oss.driver.api.core.cql.AsyncCqlSession
Executes a CQL statement asynchronously (the call returns as soon as the statement was sent, generally before the result is available).
executeAsync(String) - Method in interface com.datastax.oss.driver.api.core.cql.AsyncCqlSession
Executes a CQL statement asynchronously (the call returns as soon as the statement was sent, generally before the result is available).
executeAsync(String, Object...) - Method in interface com.datastax.oss.driver.api.core.cql.AsyncCqlSession
Executes a CQL statement asynchronously (the call returns as soon as the statement was sent, generally before the result is available).
executeAsync(String, Map<String, Object>) - Method in interface com.datastax.oss.driver.api.core.cql.AsyncCqlSession
Executes a CQL statement asynchronously (the call returns as soon as the statement was sent, generally before the result is available).
executeContinuously(Statement<?>) - Method in interface com.datastax.dse.driver.api.core.cql.continuous.ContinuousSession
Executes the provided query with continuous paging synchronously.
executeContinuouslyAsync(Statement<?>) - Method in interface com.datastax.dse.driver.api.core.cql.continuous.ContinuousSession
Executes the provided query with continuous paging asynchronously.
executeContinuouslyReactive(String) - Method in interface com.datastax.dse.driver.api.core.cql.continuous.reactive.ContinuousReactiveSession
Returns a Publisher that, once subscribed to, executes the given query continuously and emits all the results.
executeContinuouslyReactive(Statement<?>) - Method in interface com.datastax.dse.driver.api.core.cql.continuous.reactive.ContinuousReactiveSession
Returns a Publisher that, once subscribed to, executes the given query continuously and emits all the results.
executeReactive(String) - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveSession
Returns a Publisher that, once subscribed to, executes the given query and emits all the results.
executeReactive(String, Object...) - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveSession
Returns a Publisher that, once subscribed to, executes the given query and emits all the results.
executeReactive(String, Map<String, Object>) - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveSession
Returns a Publisher that, once subscribed to, executes the given query and emits all the results.
executeReactive(Statement<?>) - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveSession
Returns a Publisher that, once subscribed to, executes the given query and emits all the results.
executeReactive(GraphStatement<?>) - Method in interface com.datastax.dse.driver.api.core.graph.reactive.ReactiveGraphSession
Returns a ReactiveGraphResultSet that, once subscribed to, executes the given query and emits all the results.
ExecutionInfo - Interface in com.datastax.oss.driver.api.core.cql
Information about the execution of a query.
executionProfile - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
executionProfile - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
executionProfileName - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
executionProfileName - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
ExtraTypeCodecs - Class in com.datastax.oss.driver.api.core.type.codec
Additional codecs that can be registered to handle different type mappings.
ExtraTypeCodecs() - Constructor for class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
 

F

fetchLoginConfiguration(Map<String, String>) - Static method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
 
fetchNextPage() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
Fetch the next page of results asynchronously.
fetchNextPage() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
Fetch the next page of results asynchronously.
fillWithDriverDefaults(OptionsMap) - Static method in class com.datastax.oss.driver.api.core.config.OptionsMap
 
findNode(EndPoint) - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
Finds the node with the given connection information, if it exists.
findNode(InetSocketAddress) - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
Finds the node with the given untranslated broadcast RPC address, if it exists.
firstIndexOf(CqlIdentifier) - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
firstIndexOf(String) - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
firstIndexOf(String) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Returns the index of the first column that uses the given name.
firstIndexOf(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Returns the index of the first column that uses the given identifier.
firstIndexOf(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.AccessibleById
Returns the first index where a given identifier appears (depending on the implementation, identifiers may appear multiple times).
firstIndexOf(String) - Method in interface com.datastax.oss.driver.api.core.data.AccessibleByName
Returns the first index where a given identifier appears (depending on the implementation, identifiers may appear multiple times).
firstIndexOf(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
firstIndexOf(String) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
FLOAT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type float to Java's float.
FLOAT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
FLOAT - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
FLOAT_LIST_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type list<float> to Java's float[].
FluentGraphStatement - Interface in com.datastax.dse.driver.api.core.graph
A graph statement that uses a TinkerPop GraphTraversal as the query.
FluentGraphStatementBuilder - Class in com.datastax.dse.driver.api.core.graph
A builder to create a fluent graph statement.
FluentGraphStatementBuilder(GraphTraversal<?, ?>) - Constructor for class com.datastax.dse.driver.api.core.graph.FluentGraphStatementBuilder
 
FluentGraphStatementBuilder(FluentGraphStatement) - Constructor for class com.datastax.dse.driver.api.core.graph.FluentGraphStatementBuilder
 
forceCloseAsync() - Method in interface com.datastax.oss.driver.api.core.AsyncAutoCloseable
Initiates a forced shutdown of this instance: no new requests are accepted, and all pending requests will complete with an exception.
format(ZonedDateTime) - Method in enum com.datastax.dse.driver.api.core.data.time.DateRangePrecision
Formats the given timestamp according to this precision.
format(Token) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
Formats a token into a string representation appropriate for concatenation in a CQL query.
format(OuterT) - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
format(JavaTypeT) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Formats the given value as a valid CQL literal according to the CQL type handled by this codec.
formatInitCond() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
Formats the initial state value for inclusion in a CQL statement.
forNegotiation(EndPoint, List<ProtocolVersion>) - Static method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
 
forSingleAttempt(EndPoint, ProtocolVersion) - Static method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
 
FrameTooLongException - Exception in com.datastax.oss.driver.api.core.connection
Thrown when an incoming or outgoing protocol frame exceeds the limit defined by protocol.max-frame-length in the configuration.
FrameTooLongException(SocketAddress, String) - Constructor for exception com.datastax.oss.driver.api.core.connection.FrameTooLongException
 
from(String) - Static method in class com.datastax.oss.driver.api.core.data.CqlDuration
Converts a String into a duration.
fromBytes(byte[]) - Static method in interface com.datastax.oss.driver.api.core.cql.PagingState
Parses an instance from a byte array previously generated with PagingState.toBytes().
fromClasspath(String) - Static method in class com.datastax.dse.driver.api.core.config.DseDriverConfigLoader
Deprecated.
This method only exists for backward compatibility. It delegates to DriverConfigLoader.fromClasspath(String), which you should call directly instead.
fromClasspath(String) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Builds an instance using the driver's default implementation (based on Typesafe config), except that application-specific options are loaded from a classpath resource with a custom name.
fromClasspath(String, ClassLoader) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Just like DriverConfigLoader.fromClasspath(java.lang.String) except that application-specific classpath resources will be located using the provided ClassLoader instead of the current thread's context class loader.
fromCode(int) - Static method in enum com.datastax.oss.driver.api.core.DefaultConsistencyLevel
 
fromCoordinates(double, double) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Point
Creates a new point.
fromCql(String) - Static method in class com.datastax.oss.driver.api.core.CqlIdentifier
Creates an identifier from its CQL form.
fromDefaults(ClassLoader) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Builds an instance using the driver's default implementation (based on Typesafe config) except that application-specific classpath resources will be located using the provided ClassLoader instead of the current thread's context class loader.
fromEncoding(byte) - Static method in enum com.datastax.dse.driver.api.core.data.time.DateRangePrecision
 
fromErrors(Map<Node, Throwable>) - Static method in exception com.datastax.oss.driver.api.core.AllNodesFailedException
fromErrors(List<Map.Entry<Node, Throwable>>) - Static method in exception com.datastax.oss.driver.api.core.AllNodesFailedException
 
fromFile(File) - Static method in class com.datastax.dse.driver.api.core.config.DseDriverConfigLoader
Deprecated.
This method only exists for backward compatibility. It delegates to DriverConfigLoader.fromFile(File), which you should call directly instead.
fromFile(File) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Builds an instance using the driver's default implementation (based on Typesafe config), except that application-specific options are loaded from the given file.
fromGeoJson(String) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.LineString
Creates a line string from a GeoJSON LineString representation.
fromGeoJson(String) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Point
Creates a point from a GeoJSON Point representation.
fromGeoJson(String) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon
Creates a polygon from a GeoJSON Polygon representation.
fromHexString(String) - Static method in class com.datastax.oss.driver.api.core.data.ByteUtils
Parses a hex string representing a CQL blob.
fromInternal(String) - Static method in class com.datastax.oss.driver.api.core.CqlIdentifier
Creates an identifier from its internal form.
fromMap(OptionsMap) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Builds an instance backed by an OptionsMap, which holds all options in memory.
fromPath(String) - Static method in enum com.datastax.dse.driver.api.core.metrics.DseNodeMetric
 
fromPath(String) - Static method in enum com.datastax.dse.driver.api.core.metrics.DseSessionMetric
 
fromPath(Path) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Builds an instance using the driver's default implementation (based on Typesafe config), except that application-specific options are loaded from the given path.
fromPath(String) - Static method in enum com.datastax.oss.driver.api.core.metrics.DefaultNodeMetric
 
fromPath(String) - Static method in enum com.datastax.oss.driver.api.core.metrics.DefaultSessionMetric
 
fromPoints(Point, Point, Point...) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.LineString
Creates a line string from two or more points.
fromPoints(Point, Point, Point, Point...) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon
Creates a polygon from a series of 3 or more points.
fromString(String) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Builds an instance using the driver's default implementation (based on Typesafe config), except that application-specific options are parsed from the given string.
fromString(String) - Static method in interface com.datastax.oss.driver.api.core.cql.PagingState
Parses an instance from a string previously generated with toString().
fromUrl(URL) - Static method in class com.datastax.dse.driver.api.core.config.DseDriverConfigLoader
Deprecated.
This method only exists for backward compatibility. It delegates to DriverConfigLoader.fromUrl(URL), which you should call directly instead.
fromUrl(URL) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Builds an instance using the driver's default implementation (based on Typesafe config), except that application-specific options are loaded from the given URL.
fromWellKnownBinary(ByteBuffer) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.LineString
Creates a line string from its Well-known Binary (WKB) representation.
fromWellKnownBinary(ByteBuffer) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Point
Creates a point from its Well-known Binary (WKB) representation.
fromWellKnownBinary(ByteBuffer) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon
Creates a polygon from its Well-known Binary (WKB) representation.
fromWellKnownText(String) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.LineString
Creates a line string from its Well-known Text (WKT) representation.
fromWellKnownText(String) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Point
Creates a point from its Well-known Text (WKT) representation.
fromWellKnownText(String) - Static method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon
Creates a polygon from its Well-known Text (WKT) representation.
frozenListOf(DataType) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
frozenMapOf(DataType, DataType) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
frozenSetOf(DataType) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
FunctionFailureException - Exception in com.datastax.oss.driver.api.core.servererrors
An error during the execution of a CQL function.
FunctionFailureException(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.FunctionFailureException
 
FunctionMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A CQL function in the schema metadata.
FunctionSignature - Class in com.datastax.oss.driver.api.core.metadata.schema
The signature that uniquely identifies a CQL function or aggregate in a keyspace.
FunctionSignature(CqlIdentifier, Iterable<DataType>) - Constructor for class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
 
FunctionSignature(CqlIdentifier, DataType...) - Constructor for class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
 
FunctionSignature(String, Iterable<DataType>) - Constructor for class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
FunctionSignature(String, DataType...) - Constructor for class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
Shortcut for FunctionSignature(CqlIdentifier, DataType...) new FunctionSignature(CqlIdentifier.fromCql(name), parameterTypes)}.
fuzzy(String, int) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Supports fuzzy searches based on the Damerau-Levenshtein Distance, or Edit Distance algorithm (case sensitive).

G

g - Static variable in class com.datastax.dse.driver.api.core.graph.DseGraph
IMPORTANT: As of Tinkerpop 3.3.5, you should no longer use this shortcut if you intend to connect the traversal to DSE Graph using a remote connection, for example via the DseGraph.remoteConnectionBuilder(com.datastax.oss.driver.api.core.CqlSession) method declared below.
GenericType<T> - Class in com.datastax.oss.driver.api.core.type.reflect
Runtime representation of a generic Java type.
GenericType() - Constructor for class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
GenericTypeParameter<T> - Class in com.datastax.oss.driver.api.core.type.reflect
Captures a free type variable that can be used in GenericType.where(GenericTypeParameter, GenericType).
GenericTypeParameter() - Constructor for class com.datastax.oss.driver.api.core.type.reflect.GenericTypeParameter
 
Geo - Interface in com.datastax.dse.driver.api.core.graph.predicates
 
Geo.Unit - Enum in com.datastax.dse.driver.api.core.graph.predicates
 
Geometry - Interface in com.datastax.dse.driver.api.core.data.geometry
The driver-side representation for a DSE geospatial type.
get(String, TypedDriverOption<ValueT>) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Returns the value to which the specified option is mapped in the specified profile, or null if the option is not defined.
get(TypedDriverOption<ValueT>) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Returns the value to which the specified option is mapped in the default profile, or null if the option is not defined.
get(int) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
 
get(String) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Get a definition by name.
get(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
Get a definition by name.
get(TemporalUnit) - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
 
get(CqlIdentifier, TypeCodec<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id, using the given codec for the conversion.
get(CqlIdentifier, GenericType<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id, converting it to the given Java type.
get(CqlIdentifier, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id, converting it to the given Java type.
get(int, TypeCodec<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value, using the given codec for the conversion.
get(int, GenericType<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value, converting it to the given Java type.
get(int, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value, converting it to the given Java type.
get(String, TypeCodec<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name, using the given codec for the conversion.
get(String, GenericType<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name, converting it to the given Java type.
get(String, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name, converting it to the given Java type.
getActivity() - Method in interface com.datastax.oss.driver.api.core.cql.TraceEvent
Which activity this event corresponds to.
getAddress() - Method in exception com.datastax.oss.driver.api.core.connection.FrameTooLongException
The address of the node that encountered the error.
getAddress() - Method in exception com.datastax.oss.driver.api.core.connection.HeartbeatException
The address of the node that encountered the error.
getAddressTranslator() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getAggregate(FunctionSignature) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getAggregate(CqlIdentifier, Iterable<DataType>) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getAggregate(String, Iterable<DataType>) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
getAggregate(CqlIdentifier, DataType...) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getAggregate(String, DataType...) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
Shortcut for KeyspaceMetadata.getAggregate(CqlIdentifier, DataType...) getAggregate(CqlIdentifier.fromCql(aggregateName), parameterTypes)}.
getAggregates() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getAlive() - Method in exception com.datastax.oss.driver.api.core.servererrors.UnavailableException
The number of replicas that were known to be alive by the coordinator node when it tried to execute the operation.
getAllErrors() - Method in exception com.datastax.oss.driver.api.core.AllNodesFailedException
An immutable map containing all errors on each tried node.
getArray(ByteBuffer) - Static method in class com.datastax.oss.driver.api.core.data.ByteUtils
Extracts the content of the provided ByteBuffer as a byte array.
getArtifactId() - Method in interface com.datastax.oss.driver.api.core.MavenCoordinates
 
getAttachmentPoint() - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
getAttachmentPoint() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getAttemptedVersions() - Method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
The versions that were attempted.
getAuthenticationId() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.Credentials
Deprecated.
this method only exists for backward compatibility. It is a synonym for PlainTextAuthProviderBase.Credentials.getUsername(), which should be used instead.
getAuthorizationId() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions
 
getAuthorizationId() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.Credentials
 
getAuthProvider() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getAuthProvider() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getAvailableWithoutFetching() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
The number of elements that can be returned from this result set before a blocking background query needs to be performed to retrieve more results.
getBaseTable() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ViewMetadata
The table that this view is based on.
getBatchType() - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
 
getBigDecimal(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java big decimal.
getBigDecimal(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java big decimal.
getBigDecimal(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java big decimal.
getBigInteger(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java big integer.
getBigInteger(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java big integer.
getBigInteger(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java big integer.
getBlockFor() - Method in exception com.datastax.oss.driver.api.core.servererrors.QueryConsistencyException
The minimum number of replica acknowledgements/responses that were required to fulfill the operation.
getBody() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
getBool(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for GettableById.getBoolean(CqlIdentifier).
getBool(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for GettableByIndex.getBoolean(int).
getBool(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for GettableByName.getBoolean(String).
getBoolean(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBoolean(DriverOption, boolean) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBoolean(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java primitive boolean.
getBoolean(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java primitive boolean.
getBoolean(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java primitive boolean.
getBooleanList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBooleanList(DriverOption, List<Boolean>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBroadcastAddress() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The node's broadcast address.
getBroadcastRpcAddress() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The node's broadcast RPC address.
getBuildLabel() - Method in class com.datastax.oss.driver.api.core.Version
The build label if there is one.
getByIndex(int) - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns the element at the given index as a node.
getByKey(Object) - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns the value for the given key as a node.
getByte(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java primitive byte.
getByte(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java primitive byte.
getByte(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java primitive byte.
getByteBuffer(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java byte buffer.
getByteBuffer(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java byte buffer.
getByteBuffer(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java byte buffer.
getBytes(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBytes(DriverOption, long) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBytesList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBytesList(DriverOption, List<Long>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getBytesUnsafe(int) - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
getBytesUnsafe(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the raw binary representation of the value for the first occurrence of id.
getBytesUnsafe(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the raw binary representation of the ith value.
getBytesUnsafe(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the raw binary representation of the value for the first occurrence of name.
getCassandraVersion() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The Cassandra version of the server.
getClassLoader() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getClassName() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
If this index is custom, the name of the server-side implementation.
getClassName() - Method in interface com.datastax.oss.driver.api.core.type.CustomType
The fully qualified name of the subtype of org.apache.cassandra.db.marshal.AbstractType that represents this type server-side.
getCloudProxyAddress() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getClusteringColumns() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
 
getClusterName() - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
The cluster name to which this session is connected.
getCode() - Method in enum com.datastax.dse.driver.api.core.DseProtocolVersion
 
getCode() - Method in enum com.datastax.oss.driver.api.core.DefaultProtocolVersion
 
getCode() - Method in interface com.datastax.oss.driver.api.core.ProtocolVersion
A numeric code that uniquely identifies the version (this is the code used in network frames).
getCodecRegistry() - Method in interface com.datastax.oss.driver.api.core.detach.AttachmentPoint
Note that the default registry implementation returned by the driver also implements MutableCodecRegistry, which allows you to register new codecs at runtime.
getCodecRegistry() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getColumn(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
 
getColumn(String) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
getColumnDefinitions() - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveQueryMetadata
Returns metadata about the columns contained in this result set.
getColumnDefinitions() - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveRow
Returns the column definitions contained in this row.
getColumnDefinitions() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
Metadata about the columns returned by the CQL request that was used to build this result.
getColumnDefinitions() - Method in interface com.datastax.oss.driver.api.core.cql.Row
 
getColumnDefinitions() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
Metadata about the columns returned by the CQL request that was used to build this result.
getColumns() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
 
getComparisonKey(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
Returns a representation of all the child options under a given option.
getComponentType() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns the array component type if this type represents an array (int[], T[], <? extends Map<String, Integer>[]> etc.), or else null is returned.
getComponentTypes() - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
getCompressedResponseSizeInBytes() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The size of the compressed binary response in bytes.
getConfig() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getConfigLoader() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getConsistencyLevel() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Returns the consistency level to use for the statement.
getConsistencyLevel() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Returns the ConsistencyLevel to use for the statement.
getConsistencyLevel() - Method in exception com.datastax.oss.driver.api.core.servererrors.QueryConsistencyException
The consistency level of the operation that failed.
getConsistencyLevel() - Method in exception com.datastax.oss.driver.api.core.servererrors.UnavailableException
The consistency level of the operation triggering this exception.
getConsistencyLevelForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The consistency level to use for the bound statements that will be created from the prepared statement or null to use the default value from the configuration.
getContext() - Method in interface com.datastax.oss.driver.api.core.session.Session
Returns a context that provides access to all the policies used by this driver instance.
getCoordinator() - Method in interface com.datastax.dse.driver.api.core.graph.GraphExecutionInfo
Deprecated.
The node that was used as a coordinator to successfully complete the query.
getCoordinator() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The node that acted as a coordinator for the query.
getCoordinator() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
Deprecated.
returns the coordinator IP, but QueryTrace.getCoordinatorAddress() should be preferred, since C* 4.0 and above now returns the port was well.
getCoordinator() - Method in exception com.datastax.oss.driver.api.core.servererrors.CoordinatorException
 
getCoordinatorAddress() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
The IP and port of the node that coordinated the query.
getCqlDuration(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a duration.
getCqlDuration(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a duration.
getCqlDuration(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a duration.
getCqlType() - Method in exception com.datastax.oss.driver.api.core.type.codec.CodecNotFoundException
 
getCqlType() - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
getCqlType() - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
 
getCredentials(EndPoint, String) - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase
Retrieves the credentials from the underlying source.
getCustomPayload() - Method in interface com.datastax.oss.driver.api.core.session.Request
Returns the custom payload to send alongside the request.
getCustomPayloadForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
Returns the custom payload to send alongside the bound statements that will be created from the prepared statement.
getDatacenter() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The datacenter that this node belongs to (according to the server-side snitch).
getDays() - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
Returns the number of days in this duration.
getDefaultProfile() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfig
Alias to get the default profile, which is stored under the name DriverExecutionProfile.DEFAULT_NAME and always present.
getDefaultTimestamp() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for Statement.getQueryTimestamp().
getDeterministic() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseAggregateMetadata
Indicates if this aggregate is deterministic.
getDeterministic() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata
Indicates if this function is deterministic.
getDistance() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The distance assigned to this node by the LoadBalancingPolicy, that controls certain aspects of connection management.
getDouble(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDouble(DriverOption, double) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDouble(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java primitive double.
getDouble(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java primitive double.
getDouble(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java primitive double.
getDoubleList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDoubleList(DriverOption, List<Double>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDSEPatch() - Method in class com.datastax.oss.driver.api.core.Version
The DSE patch version number (will only be present for version of Cassandra in DSE).
getDuration(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDuration(DriverOption, Duration) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDurationList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDurationList(DriverOption, List<Duration>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getDurationMicros() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
The server-side duration of the query in microseconds.
getEdge() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseGraphTableMetadata
The edge metadata if this table represents an edge in graph, otherwise empty.
getElements() - Method in interface com.datastax.oss.driver.api.core.paging.OffsetPager.Page
The elements in the page.
getElementType() - Method in interface com.datastax.oss.driver.api.core.type.ListType
 
getElementType() - Method in interface com.datastax.oss.driver.api.core.type.SetType
 
getEncoding() - Method in enum com.datastax.dse.driver.api.core.data.time.DateRangePrecision
The code used to represent the precision when a date range is encoded to binary.
getEnd() - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
The end of the range (inclusive).
getEndPoint() - Method in exception com.datastax.oss.driver.api.core.auth.AuthenticationException
The address of the node that encountered the error.
getEndPoint() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The information that the driver uses to connect to the node.
getEndPoint() - Method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
The address of the node that threw the error.
getErrors() - Method in interface com.datastax.dse.driver.api.core.graph.GraphExecutionInfo
Deprecated.
The errors encountered on previous coordinators, if any.
getErrors() - Method in exception com.datastax.oss.driver.api.core.AllNodesFailedException
Deprecated.
getErrors() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The errors encountered on previous coordinators, if any.
getEvents() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
The events contained in this trace.
getExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.cql.continuous.ContinuousAsyncResultSet
Returns information about the execution of this page of results.
getExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.cql.continuous.ContinuousResultSet
The execution information for the last query performed for this iterable.
getExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveRow
The execution information for the paged request that produced this result.
getExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
getExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.graph.GraphResultSet
getExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.graph.reactive.ReactiveGraphNode
The execution information for the paged request that produced this result.
getExecutionInfo() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
Returns information about the execution of this page of results.
getExecutionInfo() - Method in exception com.datastax.oss.driver.api.core.DriverException
Returns execution information about the request that led to this error.
getExecutionInfo() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
The execution information for the last query performed for this iterable.
getExecutionInfos() - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveQueryMetadata
Returns information about the execution of all requests that have been performed so far to assemble this result set.
getExecutionInfos() - Method in interface com.datastax.dse.driver.api.core.graph.reactive.ReactiveGraphResultSet
Returns information about the execution of all requests that have been performed so far to assemble this result set.
getExecutionInfos() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
The execution information for all the queries that have been performed so far to assemble this iterable.
getExecutionProfile() - Method in interface com.datastax.oss.driver.api.core.session.Request
The execution profile to use for this request, or null if no profile has been set.
getExecutionProfileForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The execution profile to use for the bound statements that will be created from the prepared statement.
getExecutionProfileName() - Method in interface com.datastax.oss.driver.api.core.session.Request
The name of the execution profile that will be used for this request, or null if no profile has been set.
getExecutionProfileNameForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The name of the execution profile to use for the bound statements that will be created from the prepared statement.
getExpectedType() - Method in class com.datastax.oss.driver.api.core.config.TypedDriverOption
 
getExteriorRing() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon
Returns the external ring of the polygon.
getExtras() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
An additional map of free-form properties.
getFetchSize() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for Statement.getPageSize().
getFieldNames() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getFieldTypes() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getFinalFuncSignature() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
The signature of the final function of this aggregate, or empty if there is none.
getFloat(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java primitive float.
getFloat(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java primitive float.
getFloat(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java primitive float.
getFormattedContents() - Method in interface com.datastax.oss.driver.api.core.cql.Row
Returns a string representation of the contents of this row.
getFormattedContents() - Method in interface com.datastax.oss.driver.api.core.data.TupleValue
Returns a string representation of the contents of this tuple.
getFormattedContents() - Method in interface com.datastax.oss.driver.api.core.data.UdtValue
Returns a string representation of the contents of this UDT.
getFromClusteringColumns() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The columns in this table that match the clustering columns of the incoming vertex table.
getFromLabel() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The label of the incoming vertex in graph.
getFromPartitionKeyColumns() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The columns in this table that match the partition key of the incoming vertex table.
getFromTable() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The identifier of the table representing the incoming vertex.
getFunction(FunctionSignature) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getFunction(CqlIdentifier, Iterable<DataType>) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getFunction(String, Iterable<DataType>) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
getFunction(CqlIdentifier, DataType...) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getFunction(String, DataType...) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
getFunctions() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getGraphEngine() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseGraphKeyspaceMetadata
The graph engine that will be used to interpret this keyspace.
getGraphName() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
The name of the graph to use for this statement.
getGroupId() - Method in interface com.datastax.oss.driver.api.core.MavenCoordinates
 
getHostId() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The host ID that is assigned to this node by Cassandra.
getId() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
A unique identifier for this prepared statement.
getId() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
The unique id generated by the server for this element.
getIncomingPayload() - Method in interface com.datastax.dse.driver.api.core.graph.GraphExecutionInfo
Deprecated.
The custom payload sent back by the server with the response, if any (otherwise the map will be empty).
getIncomingPayload() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The custom payload sent back by the server with the response, if any (otherwise the map will be empty).
getIndex(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.TableMetadata
 
getIndex(String) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.TableMetadata
getIndexes() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.TableMetadata
 
getInetAddress(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java IP address.
getInetAddress(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java IP address.
getInetAddress(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java IP address.
getInitCond() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
The initial state value of this aggregate, or null if there is none.
getInitialConfig() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Loads the first configuration that will be used to initialize the driver.
getInitialServerChallenge() - Method in class com.datastax.dse.driver.api.core.auth.BaseDseAuthenticator
Return a byte buffer containing the expected successful server challenge.
getInitialServerChallenge() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiAuthenticator
 
getInitialServerChallenge() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.PlainTextAuthenticator
 
getInnerJavaType() - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
getInstant(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java instant.
getInstant(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java instant.
getInstant(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java instant.
getInt(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getInt(DriverOption, int) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getInt(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java primitive integer.
getInt(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java primitive integer.
getInt(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java primitive integer.
getInteriorRings() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Polygon
Returns the internal rings of the polygon, i.e.
getIntList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getIntList(DriverOption, List<Integer>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getJavaType() - Method in exception com.datastax.oss.driver.api.core.type.codec.CodecNotFoundException
 
getJavaType() - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
getJavaType() - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
 
getKeyspace() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Graph statements do not have a per-query keyspace, this method always returns null.
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.cql.BoundStatement
Always returns null (bound statements can't have a per-request keyspace, they always inherit the one of the statement that was initially prepared).
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinition
 
getKeyspace(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
 
getKeyspace(String) - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
 
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ColumnMetadata
 
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
 
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
 
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.session.Request
The CQL keyspace to execute this request in, or null if this request does not specify any keyspace.
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.session.Session
The keyspace that this session is currently connected to, or Optional.empty() if this session is not connected to any keyspace.
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getKeyspaces() - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
The keyspaces defined in this cluster.
getKeyType() - Method in interface com.datastax.oss.driver.api.core.type.MapType
 
getKind() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
 
getLabelName() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The label of the edge in graph.
getLabelName() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseVertexMetadata
The label of the vertex in graph.
getLanguage() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
getList(CqlIdentifier, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java list.
getList(int, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java list.
getList(String, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java list.
getListenAddress() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The node's listen address.
getLoadBalancingPolicies() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getLoadBalancingPolicy(String) - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getLocalDatacenters() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getLocalDate(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java local date.
getLocalDate(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java local date.
getLocalDate(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java local date.
getLocalTime(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java local time.
getLocalTime(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java local time.
getLocalTime(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java local time.
getLoginConfiguration() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions
 
getLong(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getLong(DriverOption, long) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getLong(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java primitive long.
getLong(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java primitive long.
getLong(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java primitive long.
getLongList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getLongList(DriverOption, List<Long>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getLowerBound() - Method in class com.datastax.dse.driver.api.core.data.time.DateRange
Returns the lower bound of this range (inclusive).
getMajor() - Method in class com.datastax.oss.driver.api.core.Version
The major version number.
getMap(CqlIdentifier, Class<KeyT>, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java map.
getMap(int, Class<KeyT>, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java map.
getMap(String, Class<KeyT>, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java map.
getMechanism() - Method in class com.datastax.dse.driver.api.core.auth.BaseDseAuthenticator
Return a byte buffer containing the required SASL mechanism.
getMechanism() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiAuthenticator
 
getMechanism() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.PlainTextAuthenticator
 
getMetadata() - Method in interface com.datastax.oss.driver.api.core.session.Session
Returns a snapshot of the Cassandra cluster's topology and schema metadata.
getMetricRegistry() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getMetrics() - Method in interface com.datastax.oss.driver.api.core.session.Session
Returns a gateway to the driver's DropWizard metrics, or Optional.empty() if all metrics are disabled, or if the driver has been configured to use MicroProfile or Micrometer instead of DropWizard (see advanced.metrics.factory.class in the configuration).
getMinor() - Method in class com.datastax.oss.driver.api.core.Version
The minor version number.
getMonotonicArgumentNames() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata
Returns a list of argument names that are monotonic.
getMonotonicity() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata
Returns this function's DseFunctionMetadata.Monotonicity.
getMonths() - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
Returns the number of months in this duration.
getName() - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
The name of the profile in the configuration.
getName() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinition
 
getName() - Method in interface com.datastax.oss.driver.api.core.MavenCoordinates
 
getName() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ColumnMetadata
 
getName() - Method in class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
 
getName() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
 
getName() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getName() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
 
getName() - Method in interface com.datastax.oss.driver.api.core.session.Session
The unique name identifying this session instance.
getName() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getNamedValues() - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
 
getNanoseconds() - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
Returns the number of nanoseconds in this duration.
getNode() - Method in interface com.datastax.oss.driver.api.core.session.Request
 
getNodeFilters() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getNodeMetric(Node, NodeMetric, String) - Method in interface com.datastax.oss.driver.api.core.metrics.Metrics
Retrieves a node-level metric for a given node from the registry.
getNodeMetric(Node, NodeMetric) - Method in interface com.datastax.oss.driver.api.core.metrics.Metrics
getNodes() - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
The nodes known to the driver, indexed by their unique identifier (host_id in system.local/system.peers).
getNodeStateListener() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getNodeStateListener() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getNowInSeconds() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
A custom "now in seconds" to use when applying the request (for testing purposes).
getNumFailures() - Method in exception com.datastax.oss.driver.api.core.servererrors.ReadFailureException
Returns the number of replicas that experienced a failure while executing the request.
getNumFailures() - Method in exception com.datastax.oss.driver.api.core.servererrors.WriteFailureException
Returns the number of replicas that experienced a failure while executing the request.
getObject(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id, converting it to the most appropriate Java type.
getObject(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value, converting it to the most appropriate Java type.
getObject(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name, converting it to the most appropriate Java type.
getOpenConnections() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The total number of active connections currently open by this driver instance to the node.
getOptions(EndPoint, String) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase
 
getOptions(EndPoint, String) - Method in class com.datastax.dse.driver.api.core.auth.ProgrammaticDseGssApiAuthProvider
 
getOptions() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
The options of the index.
getOptions() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
The options of this table or materialized view.
getPage(PagingIterable<ElementT>, int) - Method in class com.datastax.oss.driver.api.core.paging.OffsetPager
Extracts a page from a synchronous result set, by skipping rows until we get to the requested offset.
getPage(IterableT, int) - Method in class com.datastax.oss.driver.api.core.paging.OffsetPager
Extracts a page from an asynchronous result set, by skipping rows until we get to the requested offset.
getPageNumber() - Method in interface com.datastax.oss.driver.api.core.paging.OffsetPager.Page
The page number (1 for the first page, 2 for the second page, etc).
getPageSize() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Returns the page size to use for the statement.
getPageSizeForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The page size to use for the bound statements that will be created from the prepared statement.
getPagingState() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The paging state of the query, in its raw form.
getPagingState() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Returns the paging state to send with the statement, or null if this statement has no paging state.
getPagingStateForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The paging state to use for the bound statements that will be created from the prepared statement.
getParameterNames() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
The names of the parameters.
getParameters() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
The parameters attached to this trace.
getParameterTypes() - Method in class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
 
getParent() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ColumnMetadata
The identifier of the TableMetadata or a ViewMetadata that this column belongs to.
getPartitioner() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
The partitioner to use for token-aware routing.
getPartitioner() - Method in interface com.datastax.oss.driver.api.core.session.Request
The partitioner to use for token-aware routing.
getPartitionerName() - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The name of the partitioner class in use, as reported by the Cassandra nodes.
getPartitionKey() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
 
getPartitionKeyIndices() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
The indices of the variables in PreparedStatement.getVariableDefinitions() that correspond to the target table's partition key.
getPassword() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.Credentials
 
getPatch() - Method in class com.datastax.oss.driver.api.core.Version
The patch version number.
getPath() - Method in enum com.datastax.dse.driver.api.core.config.DseDriverOption
 
getPath() - Method in enum com.datastax.dse.driver.api.core.metrics.DseNodeMetric
 
getPath() - Method in enum com.datastax.dse.driver.api.core.metrics.DseSessionMetric
 
getPath() - Method in enum com.datastax.oss.driver.api.core.config.DefaultDriverOption
 
getPath() - Method in interface com.datastax.oss.driver.api.core.config.DriverOption
The option's path.
getPath() - Method in enum com.datastax.oss.driver.api.core.metrics.DefaultNodeMetric
 
getPath() - Method in enum com.datastax.oss.driver.api.core.metrics.DefaultSessionMetric
 
getPath() - Method in interface com.datastax.oss.driver.api.core.metrics.NodeMetric
 
getPath() - Method in interface com.datastax.oss.driver.api.core.metrics.SessionMetric
 
getPoints() - Method in interface com.datastax.dse.driver.api.core.data.geometry.LineString
 
getPositionalValues() - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
 
getPrecision() - Method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Returns the precision of this bound.
getPreparedStatement() - Method in interface com.datastax.oss.driver.api.core.cql.BoundStatement
The prepared statement that was used to create this statement.
getPreReleaseLabels() - Method in class com.datastax.oss.driver.api.core.Version
The pre-release labels if relevant, i.e.
getPrimaryKey() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.RelationMetadata
Convenience method to get all the primary key columns (partition key + clustering columns) in a single call.
getProfile(String) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfig
 
getProfiles() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfig
Returns an immutable view of all named profiles (including the default profile).
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.ConsistencyLevel
The numerical value that the level is encoded to in protocol frames.
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.cql.BatchType
The numerical value that the batch type is encoded to.
getProtocolCode() - Method in enum com.datastax.oss.driver.api.core.cql.DefaultBatchType
 
getProtocolCode() - Method in enum com.datastax.oss.driver.api.core.DefaultConsistencyLevel
 
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.type.CustomType
 
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.type.DataType
The code of the data type in the native protocol specification.
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.type.ListType
 
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.type.MapType
 
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.type.SetType
 
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
getProtocolCode() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getProtocolVersion() - Method in interface com.datastax.oss.driver.api.core.detach.AttachmentPoint
 
getQuery() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
 
getQuery() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The CQL query to prepare.
getQuery() - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
 
getQueryParams() - Method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
The query parameters to send along the request.
getQueryTimestamp() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Returns the query timestamp, in microseconds, to send with the statement.
getQueryTrace() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
Convenience method to call ExecutionInfo.getQueryTraceAsync() and block for the result.
getQueryTraceAsync() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
Fetches the query trace asynchronously, if tracing was enabled for this query.
getRack() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The rack that this node belongs to (according to the server-side snitch).
getRawOption() - Method in class com.datastax.oss.driver.api.core.config.TypedDriverOption
 
getRawPagingState() - Method in interface com.datastax.oss.driver.api.core.cql.PagingState
Returns the underlying "unsafe" paging state (the equivalent of ExecutionInfo.getPagingState()).
getRawType() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns the raw type of T.
getReadConsistencyLevel() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
The consistency level to use for the internal read queries that will be produced by this statement.
getReasonMap() - Method in exception com.datastax.oss.driver.api.core.servererrors.ReadFailureException
Returns the a failure reason code for each node that failed.
getReasonMap() - Method in exception com.datastax.oss.driver.api.core.servererrors.WriteFailureException
Returns the a failure reason code for each node that failed.
getReceived() - Method in exception com.datastax.oss.driver.api.core.servererrors.QueryConsistencyException
The number of replica that had acknowledged/responded to the operation before it failed.
getReconnectionPolicy() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getRegistry() - Method in interface com.datastax.oss.driver.api.core.metrics.Metrics
Returns the underlying Dropwizard registry.
getReplicas(CqlIdentifier, Partitioner, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The replicas for a given partition key in the given keyspace.
getReplicas(CqlIdentifier, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
getReplicas(String, Partitioner, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
getReplicas(String, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
getReplicas(CqlIdentifier, Token) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The replicas for a given token in the given keyspace.
getReplicas(String, Token) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
getReplicas(CqlIdentifier, TokenRange) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The replicas for a given range in the given keyspace.
getReplicas(String, TokenRange) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
getReplication() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
The replication options defined for this keyspace.
getRequest() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
 
getRequestExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
The execution information for this page of results.
getRequestExecutionInfo() - Method in interface com.datastax.dse.driver.api.core.graph.GraphResultSet
The execution information for the query that have been performed to assemble this result set.
getRequestThrottler() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getRequestTracker() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getRequestTracker() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getRequestType() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
 
getRequired() - Method in exception com.datastax.oss.driver.api.core.servererrors.UnavailableException
The number of replica acknowledgements/responses required to perform the operation (with its required consistency level).
getResponseSizeInBytes() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The size of the binary response in bytes.
getResultMetadataId() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
A unique identifier for result metadata (essentially a hash of PreparedStatement.getResultSetDefinitions()).
getResultSetDefinitions() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
A description of the result set that will be returned when this prepared statement is bound and executed.
getRetryDecision() - Method in interface com.datastax.oss.driver.api.core.retry.RetryVerdict
 
getRetryPolicies() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getRetryPolicy(String) - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getRetryRequest(RequestT) - Method in interface com.datastax.oss.driver.api.core.retry.RetryVerdict
Returns the request to retry, based on the request that was just executed (and failed).
getReturnType() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
The return type of this aggregate.
getReturnType() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
getRoutingKey() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Graph statements can't be routed, this method always returns null.
getRoutingKey() - Method in interface com.datastax.oss.driver.api.core.session.Request
The partition key to use for token-aware routing.
getRoutingKeyForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The routing key to use for the bound statements that will be created from the prepared statement.
getRoutingKeyspace() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Graph statements can't be routed, this method always returns null.
getRoutingKeyspace() - Method in interface com.datastax.oss.driver.api.core.session.Request
The keyspace to use for token-aware routing.
getRoutingKeyspaceForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The routing keyspace to use for the bound statements that will be created from the prepared statement.
getRoutingToken() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Graph statements can't be routed, this method always returns null.
getRoutingToken() - Method in interface com.datastax.oss.driver.api.core.session.Request
The token to use for token-aware routing.
getRoutingTokenForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The routing key to use for the bound statements that will be created from the prepared statement.
getSafePagingState() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The paging state of the query, in a safe wrapper that checks if it's reused on the right statement.
getSaslProperties() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions
 
getSaslProtocol() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions
 
getSchemaChangeListener() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getSchemaChangeListener() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getSchemaVersion() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The current version that is associated with the node's schema.
getScript() - Method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
The Gremlin-groovy script representing the graph query.
getSerialConsistencyLevel() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Returns the serial ConsistencyLevel to use for the statement.
getSerialConsistencyLevelForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The serial consistency level to use for the bound statements that will be created from the prepared statement or null to use the default value from the configuration.
getSessionMetric(SessionMetric, String) - Method in interface com.datastax.oss.driver.api.core.metrics.Metrics
Retrieves a session-level metric from the registry.
getSessionMetric(SessionMetric) - Method in interface com.datastax.oss.driver.api.core.metrics.Metrics
getSessionName() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
This is the same as Session.getName(), it's exposed here for components that only have a reference to the context.
getSet(CqlIdentifier, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java set.
getSet(int, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java set.
getSet(String, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java set.
getShort(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java primitive short.
getShort(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java primitive short.
getShort(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java primitive short.
getSignature() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
 
getSignature() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
getSource() - Method in interface com.datastax.oss.driver.api.core.cql.TraceEvent
Deprecated.
returns the source IP, but TraceEvent.getSourceAddress() should be preferred, since C* 4.0 and above now returns the port was well.
getSourceAddress() - Method in interface com.datastax.oss.driver.api.core.cql.TraceEvent
The IP and Port of the host having generated this event.
getSourceElapsedMicros() - Method in interface com.datastax.oss.driver.api.core.cql.TraceEvent
The number of microseconds elapsed on the source when this event occurred since the moment when the source started handling the query.
getSpeculativeExecutionCount() - Method in interface com.datastax.dse.driver.api.core.graph.GraphExecutionInfo
Deprecated.
The number of speculative executions that were started for this query.
getSpeculativeExecutionCount() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The number of speculative executions that were started for this query.
getSpeculativeExecutionPolicies() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getSpeculativeExecutionPolicy(String) - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getSslEngineFactory() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getSslEngineFactory() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getStart() - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
The start of the range (exclusive).
getStartedAt() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
The server-side timestamp of the start of this query.
getStartupApplicationName() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getStartupApplicationVersion() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getStartupClientId() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getState() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
 
getStateFuncSignature() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
The signature of the state function of this aggregate.
getStatement() - Method in interface com.datastax.dse.driver.api.core.graph.GraphExecutionInfo
Deprecated.
The statement that was executed.
getStatement() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
Deprecated.
getStatementsCount() - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
getStateType() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.AggregateMetadata
The state type of this aggregate.
getString(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getString(DriverOption, String) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getString(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java string.
getString(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java string.
getString(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java string.
getStringList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getStringList(DriverOption, List<String>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getStringMap(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getStringMap(DriverOption, Map<String, String>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
getSubject() - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions
 
getSubProtocol() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
The DSE graph sub-protocol to use for this statement.
getSubtype(Class<?>) - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns subtype of this with subclass as the raw class.
getSuccessfulExecutionIndex() - Method in interface com.datastax.dse.driver.api.core.graph.GraphExecutionInfo
Deprecated.
The index of the execution that completed this query.
getSuccessfulExecutionIndex() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The index of the execution that completed this query.
getSupertype(Class<? super T>) - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns the generic form of superclass.
getTable() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinition
 
getTable() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
 
getTable(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getTable(String) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
GettableById - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to retrieve its values via a CQL identifier.
GettableByIndex - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to retrieve its values via an integer index.
GettableByName - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to retrieve its values via a name.
getTables() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getTarget() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.IndexMetadata
 
getThreadName() - Method in interface com.datastax.oss.driver.api.core.cql.TraceEvent
The name of the thread on which this event occurred.
getTimeout() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
How long to wait for this request to complete.
getTimeout() - Method in interface com.datastax.oss.driver.api.core.session.Request
How long to wait for this request to complete.
getTimeoutForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The timeout to use for the bound statements that will be created from the prepared statement.
getTimestamp() - Method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Returns the timestamp of this bound.
getTimestamp() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Get the timestamp set on the statement.
getTimestamp() - Method in interface com.datastax.oss.driver.api.core.cql.TraceEvent
The server-side timestamp of the event.
getTimestampGenerator() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
getToClusteringColumns() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The columns in this table that match the clustering columns of the outgoing vertex table.
getToken(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a token.
getToken(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a token.
getToken(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a token.
getTokenMap() - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
The token map for this cluster.
getTokenRanges() - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The token ranges that define data distribution on the ring.
getTokenRanges(Node) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The token ranges for which a given node is the primary replica.
getTokenRanges(CqlIdentifier, Node) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The token ranges that are replicated on the given node, for the given keyspace.
getTokenRanges(String, Node) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
getTokens(Node) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
The tokens owned by the given node.
getToLabel() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The label of the outgoing vertex in graph.
getToPartitionKeyColumns() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The columns in this table that match the partition key of the outgoing vertex table.
getToTable() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseEdgeMetadata
The identifier of the table representing the outgoing vertex.
getTracingId() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The tracing identifier if tracing was enabled for this query, otherwise null.
getTracingId() - Method in interface com.datastax.oss.driver.api.core.cql.QueryTrace
 
getTraversal() - Method in interface com.datastax.dse.driver.api.core.graph.FluentGraphStatement
The underlying TinkerPop object representing the traversal executed by this statement.
getTraversalsCount() - Method in class com.datastax.dse.driver.api.core.graph.BatchGraphStatementBuilder
Returns the number of traversals added to this statement so far.
getTraversalSource() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
The name of the traversal source to use for this statement.
getTupleValue(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a tuple value.
getTupleValue(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a tuple value.
getTupleValue(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a tuple value.
getType(int) - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
getType() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinition
 
getType(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.AccessibleById
Returns the CQL type of the value for the first occurrence of id.
getType(int) - Method in interface com.datastax.oss.driver.api.core.data.AccessibleByIndex
Returns the CQL type of the ith value.
getType(String) - Method in interface com.datastax.oss.driver.api.core.data.AccessibleByName
Returns the CQL type of the value for the first occurrence of name.
getType(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
 
getType(String) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
 
getType() - Method in interface com.datastax.oss.driver.api.core.data.TupleValue
 
getType() - Method in interface com.datastax.oss.driver.api.core.data.UdtValue
 
getType() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ColumnMetadata
 
getType() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns the represented type.
getTypeCodecs() - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments
 
getTypeVariable() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericTypeParameter
 
getUdtValue(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a user defined type value.
getUdtValue(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a user defined type value.
getUdtValue(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a user defined type value.
getUnits() - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
 
getUpperBound() - Method in class com.datastax.dse.driver.api.core.data.time.DateRange
Returns the upper bound of this range (inclusive), or empty if the range is single-bounded.
getUpSinceMillis() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The last time that this node transitioned to the UP state, in milliseconds since the epoch, or -1 if it's not up at the moment.
getUserDefinedType(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getUserDefinedType(String) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
getUserDefinedTypes() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getUsername() - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.Credentials
 
getUuid(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Returns the value for the first occurrence of id as a Java UUID.
getUuid(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java UUID.
getUuid(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java UUID.
getValues() - Method in interface com.datastax.oss.driver.api.core.cql.BoundStatement
The values to bind, in their serialized form.
getValueType() - Method in interface com.datastax.oss.driver.api.core.type.MapType
 
getVariableDefinitions() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
A description of the bind variables of this prepared statement.
getVersion() - Method in interface com.datastax.oss.driver.api.core.MavenCoordinates
 
getVertex() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseGraphTableMetadata
The vertex metadata if this table represents a vertex in graph, otherwise empty.
getView(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getView(String) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
getViews() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
getViewsOnTable(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
Gets the views based on a given table.
getWarnings() - Method in interface com.datastax.dse.driver.api.core.graph.GraphExecutionInfo
Deprecated.
The server-side warnings for this query, if any (otherwise the list will be empty).
getWarnings() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The server-side warnings for this query, if any (otherwise the list will be empty).
getWhereClause() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ViewMetadata
 
getWriteConsistencyLevel() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
The consistency level to use for the internal write queries that will be produced by this statement.
getWriteType() - Method in exception com.datastax.oss.driver.api.core.servererrors.WriteFailureException
The type of the write for which this failure was raised.
getWriteType() - Method in exception com.datastax.oss.driver.api.core.servererrors.WriteTimeoutException
The type of the write for which a timeout was raised.
GRAPH_CONTINUOUS_PAGING_MAX_ENQUEUED_PAGES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of Graph continuous pages that can be stored in the local queue.
GRAPH_CONTINUOUS_PAGING_MAX_PAGES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of Graph continuous pages to return.
GRAPH_CONTINUOUS_PAGING_MAX_PAGES_PER_SECOND - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of Graph continuous pages per second.
GRAPH_CONTINUOUS_PAGING_PAGE_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The page size for Graph continuous paging.
GRAPH_IS_SYSTEM_QUERY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether a script statement represents a system query.
GRAPH_NAME - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The name of the graph targeted by graph statements.
GRAPH_PAGING_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to enable paging for Graph queries.
GRAPH_READ_CONSISTENCY_LEVEL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The read consistency level to use for graph statements.
GRAPH_SUB_PROTOCOL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The sub-protocol the driver will use to communicate with DSE Graph, on top of the Cassandra native protocol.
GRAPH_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long the driver waits for a graph request to complete.
GRAPH_TRAVERSAL_SOURCE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The traversal source to use for graph statements.
GRAPH_WRITE_CONSISTENCY_LEVEL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The write consistency level to use for graph statements.
GraphExecutionInfo - Interface in com.datastax.dse.driver.api.core.graph
Deprecated.
This interface is not used by any driver component anymore; the driver now exposes instances of ExecutionInfo for all Graph queries.
graphName - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
GraphNode - Interface in com.datastax.dse.driver.api.core.graph
A node in a tree-like structure representing a Graph or a Graph component.
GraphResultSet - Interface in com.datastax.dse.driver.api.core.graph
The result of a synchronous Graph query.
GraphSession - Interface in com.datastax.dse.driver.api.core.graph
A session that has the ability to execute DSE Graph requests.
GraphStatement<SelfT extends GraphStatement<SelfT>> - Interface in com.datastax.dse.driver.api.core.graph
A request to execute a DSE Graph query.
GraphStatementBuilderBase<SelfT extends GraphStatementBuilderBase<SelfT,StatementT>,StatementT extends GraphStatement<StatementT>> - Class in com.datastax.dse.driver.api.core.graph
 
GraphStatementBuilderBase() - Constructor for class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
GraphStatementBuilderBase(StatementT) - Constructor for class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
GssApiAuthenticator(DseGssApiAuthProviderBase.GssApiOptions, EndPoint, String) - Constructor for class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiAuthenticator
 

H

hash(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.metadata.token.Partitioner
 
hashCode() - Method in class com.datastax.dse.driver.api.core.data.time.DateRange
 
hashCode() - Method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
 
hashCode() - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
 
hashCode() - Method in class com.datastax.oss.driver.api.core.config.TypedDriverOption
 
hashCode() - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
 
hashCode() - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
 
hashCode() - Method in class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
 
hashCode() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
hashCode() - Method in class com.datastax.oss.driver.api.core.Version
 
hasMorePages() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
Whether there are more pages of results.
hasMorePages() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
Whether there are more pages of results.
HEARTBEAT_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The connection heartbeat interval.
HEARTBEAT_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long the driver waits for the response to a heartbeat.
HeartbeatException - Exception in com.datastax.oss.driver.api.core.connection
Thrown when a heartbeat query fails.
HeartbeatException(SocketAddress, String, Throwable) - Constructor for exception com.datastax.oss.driver.api.core.connection.HeartbeatException
 
HeartbeatException(SocketAddress, String, ExecutionInfo, Throwable) - Constructor for exception com.datastax.oss.driver.api.core.connection.HeartbeatException
 

I

idempotent - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
IGNORE - Static variable in interface com.datastax.oss.driver.api.core.retry.RetryVerdict
A retry verdict that ignores the error, returning and empty result set to the caller.
includesAllColumns() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ViewMetadata
Whether this view does a SELECT * on its base table (this only affects the output of ViewMetadata.describe(boolean)).
IndexKind - Enum in com.datastax.oss.driver.api.core.metadata.schema
A kind of index in the schema.
IndexMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A secondary index in the schema metadata.
INET - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type inet to Java's InetAddress.
INET - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
INET_ADDRESS - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
init(Map<UUID, Node>, LoadBalancingPolicy.DistanceReporter) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Initializes this policy with the nodes discovered during driver initialization.
initialResponse() - Method in interface com.datastax.oss.driver.api.core.auth.Authenticator
Obtain an initial response token for initializing the SASL handshake.
initialResponse() - Method in interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
 
initialResponseSync() - Method in class com.datastax.dse.driver.api.core.auth.BaseDseAuthenticator
 
initialResponseSync() - Method in interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
Obtain an initial response token for initializing the SASL handshake.
innerCodec - Variable in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
innerToOuter(InnerT) - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
Converts from an instance of the inner Java type to an instance of the outer Java type.
inside(Point, double, Geo.Unit) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Finds whether an entity is inside the given circular area using a geo coordinate system.
inside(Point, double) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Finds whether an entity is inside the given circular area using a cartesian coordinate system.
inside(Polygon) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Finds whether an entity is inside the given polygon.
INSTANT - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
INT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type int to Java's int.
INT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
INT_LIST_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type list<int> to Java's int[].
INTEGER - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
intersects(TokenRange) - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Whether this range intersects another one.
intersectWith(TokenRange) - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Computes the intersection of this range with another one, producing one or more ranges.
InvalidConfigurationInQueryException - Exception in com.datastax.oss.driver.api.core.servererrors
Indicates that a query is invalid because of some configuration problem.
InvalidConfigurationInQueryException(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.InvalidConfigurationInQueryException
 
InvalidKeyspaceException - Exception in com.datastax.oss.driver.api.core
Thrown when a session gets created with an invalid keyspace.
InvalidKeyspaceException(String) - Constructor for exception com.datastax.oss.driver.api.core.InvalidKeyspaceException
 
InvalidQueryException - Exception in com.datastax.oss.driver.api.core.servererrors
Indicates a syntactically correct, but invalid query.
InvalidQueryException(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.InvalidQueryException
 
isArray() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns true if this type is known to be an array type, such as int[], T[], <? extends Map<String, Integer>[]> etc.
isBeta() - Method in enum com.datastax.dse.driver.api.core.DseProtocolVersion
 
isBeta() - Method in enum com.datastax.oss.driver.api.core.DefaultProtocolVersion
 
isBeta() - Method in interface com.datastax.oss.driver.api.core.ProtocolVersion
Whether the protocol version is in a beta status.
isCalledOnNullInput() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.FunctionMetadata
 
isClosed() - Method in interface com.datastax.oss.driver.api.core.AsyncAutoCloseable
Whether shutdown has completed.
isCompactStorage() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.TableMetadata
 
isDcLocal() - Method in interface com.datastax.oss.driver.api.core.ConsistencyLevel
Whether this consistency level applies to the local datacenter only.
isDcLocal() - Method in enum com.datastax.oss.driver.api.core.DefaultConsistencyLevel
 
isDefined(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
isDetached() - Method in interface com.datastax.oss.driver.api.core.detach.Detachable
 
isDeterministic() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseAggregateMetadata
Deprecated.
isDeterministic() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata
Deprecated.
isDurableWrites() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
Whether durable writes are set on this keyspace.
isEdge() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a Edge, and false otherwise.
isEmpty() - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Whether this range is empty.
isFrozen() - Method in interface com.datastax.oss.driver.api.core.type.ListType
 
isFrozen() - Method in interface com.datastax.oss.driver.api.core.type.MapType
 
isFrozen() - Method in interface com.datastax.oss.driver.api.core.type.SetType
 
isFrozen() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
isFullRing() - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Whether this range represents the full ring.
isFullyFetched() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
Whether all pages have been fetched from the database.
isIdempotent - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
isIdempotent() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
Whether the request is idempotent; that is, whether applying the request twice leaves the database in the same state.
isIdempotent() - Method in interface com.datastax.oss.driver.api.core.session.Request
Whether the request is idempotent; that is, whether applying the request twice leaves the database in the same state.
isLast() - Method in interface com.datastax.oss.driver.api.core.paging.OffsetPager.Page
Whether this is the last page in the result set.
isList() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a List, and false otherwise.
isMap() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a Map, and false otherwise.
isMonotonic() - Method in interface com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata
Deprecated.
isNull() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Whether this node represents a null value.
isNull(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.GettableById
Indicates whether the value for the first occurrence of id is a CQL NULL.
isNull(int) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Indicates whether the ith value is a CQL NULL.
isNull(String) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Indicates whether the value for the first occurrence of name is a CQL NULL.
isPath() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a Path, and false otherwise.
isPrimitive() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns true if this type is one of the nine primitive types (including void).
isProperty() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a Property, and false otherwise.
isReconnecting() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
Whether the driver is currently trying to reconnect to this node.
isSchemaInAgreement() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
Whether the cluster reached schema agreement after the execution of this query.
isSchemaMetadataEnabled() - Method in interface com.datastax.oss.driver.api.core.session.Session
Whether schema metadata is currently enabled.
isSerial() - Method in interface com.datastax.oss.driver.api.core.ConsistencyLevel
Whether this consistency level is serial, that is, applies only to the "paxos" phase of a lightweight transaction.
isSerial() - Method in enum com.datastax.oss.driver.api.core.DefaultConsistencyLevel
 
isSet() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a Set, and false otherwise.
isSet(int) - Method in interface com.datastax.oss.driver.api.core.cql.Bindable
Whether the ith value has been set.
isSet(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.Bindable
Whether the value for the first occurrence of id has been set.
isSet(String) - Method in interface com.datastax.oss.driver.api.core.cql.Bindable
Whether the value for the first occurrence of name has been set.
isSingleBounded() - Method in class com.datastax.dse.driver.api.core.data.time.DateRange
Returns whether this range is single-bounded, i.e.
isStatic() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.ColumnMetadata
 
isSubtypeOf(GenericType<?>) - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns true if this type is a subtype of the given type.
isSupertypeOf(GenericType<?>) - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns true if this type is a supertype of the given type.
isSystemQuery() - Method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
Whether the statement is a system query, or null if it defaults to the value defined in the configuration.
isTracing() - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Whether tracing information should be recorded for this statement.
isTracing() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Whether tracing information should be recorded for this statement.
isUnbounded() - Method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Whether this bound is unbounded (i.e.
isValue() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a simple scalar value, (i.e., string, boolean or number), and false otherwise.
isVertex() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a Vertex, and false otherwise.
isVertexProperty() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
Returns true if this node is a VertexProperty, and false otherwise.
isVirtual() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
Whether this keyspace is virtual
isVirtual() - Method in interface com.datastax.oss.driver.api.core.metadata.schema.TableMetadata
Whether this table is virtual
isWrappedAround() - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Whether this range wraps around the end of the ring.

J

JMX_PORT - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The JMX port used by this node.
json(GenericType<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type text to the given Java type, using JSON serialization with a default Jackson mapper.
json(Class<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type text to the given Java type, using JSON serialization with a default Jackson mapper.
json(GenericType<T>, ObjectMapper) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type text to the given Java type, using JSON serialization with the provided Jackson mapper.
json(Class<T>, ObjectMapper) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type text to the given Java type, using JSON serialization with the provided Jackson mapper.

K

keys() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
The keys of this map node, or an empty iterator if it is not a map.
keyspace - Variable in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
KeyspaceMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A keyspace in the schema metadata.

L

LINE_STRING - Static variable in class com.datastax.dse.driver.api.core.type.codec.DseTypeCodecs
 
LINE_STRING - Static variable in class com.datastax.dse.driver.api.core.type.DseDataTypes
 
LineString - Interface in com.datastax.dse.driver.api.core.data.geometry
The driver-side representation for DSE's LineString.
lineString(Point, Point, Point...) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Creates a line string from the given (at least 2) points.
lineString(double...) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Creates a line string from the coordinates of its points.
listOf(TypeCodec<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
Builds a new codec that maps a CQL list to a Java list, using the given codec to map each element.
listOf(DataType) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
listOf(DataType, boolean) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
listOf(Class<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
listOf(GenericType<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
listToArrayOf(TypeCodec<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps a CQL list to a Java array.
ListType - Interface in com.datastax.oss.driver.api.core.type
 
LOAD_BALANCING_DC_FAILOVER_ALLOW_FOR_LOCAL_CONSISTENCY_LEVELS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to consider nodes from remote DCs if the request's consistency level is local.
LOAD_BALANCING_DC_FAILOVER_MAX_NODES_PER_REMOTE_DC - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of nodes from remote DCs to include in query plans.
LOAD_BALANCING_FILTER_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
A custom filter to include/exclude nodes.
LOAD_BALANCING_LOCAL_DATACENTER - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The datacenter that is considered "local".
LOAD_BALANCING_POLICY_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the load balancing policy.
LOAD_BALANCING_POLICY_SLOW_AVOIDANCE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether the slow replica avoidance should be enabled in the default LBP.
LoadBalancingPolicy - Interface in com.datastax.oss.driver.api.core.loadbalancing
Decides which Cassandra nodes to contact for each query.
LoadBalancingPolicy.DistanceReporter - Interface in com.datastax.oss.driver.api.core.loadbalancing
An object that the policy uses to signal decisions it makes about node distances.
LOCAL_DATE - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
LOCAL_DATE_TIME - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
LOCAL_ONE - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
LOCAL_QUORUM - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
LOCAL_SERIAL - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
LOCAL_TIME - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
LOCAL_TIMESTAMP_SYSTEM - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type timestamp to Java's LocalDateTime, using the system's default time zone.
LOCAL_TIMESTAMP_UTC - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type timestamp to Java's LocalDateTime, using the UTC time zone.
localTimestampAt(ZoneId) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type timestamp to Java's LocalDateTime.
LOGGED - Static variable in interface com.datastax.oss.driver.api.core.cql.BatchType
 
LONG - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
LONG_LIST_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type list<bigint> to Java's long[].
lowerBound(ZonedDateTime, DateRangePrecision) - Static method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Creates a date range lower bound from the given date and precision.

M

map(Function<? super ElementT, ? extends TargetT>) - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
Creates a new instance by transforming each element of this iterable with the provided function.
map(Function<? super ElementT, ? extends TargetElementT>) - Method in interface com.datastax.oss.driver.api.core.PagingIterable
Creates a new instance by transforming each element of this iterable with the provided function.
mapOf(TypeCodec<K>, TypeCodec<V>) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
Builds a new codec that maps a CQL map to a Java map, using the given codecs to map each key and value.
mapOf(DataType, DataType) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
mapOf(DataType, DataType, boolean) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
mapOf(Class<K>, Class<V>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
mapOf(GenericType<K>, GenericType<V>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
MappedAsyncPagingIterable<ElementT> - Interface in com.datastax.oss.driver.api.core
The result of calling AsyncPagingIterable.map(Function) on another async iterable.
MappingCodec<InnerT,OuterT> - Class in com.datastax.oss.driver.api.core.type.codec
A TypeCodec that maps instances of InnerT, a driver supported Java type, to instances of a target OuterT Java type.
MappingCodec(TypeCodec<InnerT>, GenericType<OuterT>) - Constructor for class com.datastax.oss.driver.api.core.type.codec.MappingCodec
Creates a new mapping codec providing support for OuterT based on an existing codec for InnerT.
MapType - Interface in com.datastax.oss.driver.api.core.type
 
matches(Statement<?>) - Method in interface com.datastax.oss.driver.api.core.cql.PagingState
Checks if this paging state can be safely reused for the given statement.
matches(Statement<?>, Session) - Method in interface com.datastax.oss.driver.api.core.cql.PagingState
Alternative to PagingState.matches(Statement) that specifies the session the statement will be executed with.
MavenCoordinates - Interface in com.datastax.oss.driver.api.core
 
mergeWith(TokenRange) - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Merges this range with another one.
Metadata - Interface in com.datastax.oss.driver.api.core.metadata
The metadata of the Cassandra cluster that this driver instance is connected to.
METADATA_NODE_STATE_LISTENER_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of a session-wide component that listens for node state changes.
METADATA_SCHEMA_CHANGE_LISTENER_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of a session-wide component that listens for schema changes.
METADATA_SCHEMA_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether schema metadata is enabled.
METADATA_SCHEMA_MAX_EVENTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of refreshes that can accumulate.
METADATA_SCHEMA_REFRESHED_KEYSPACES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The list of keyspaces for which schema and token metadata should be maintained.
METADATA_SCHEMA_REQUEST_PAGE_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The page size for the requests to the schema tables.
METADATA_SCHEMA_REQUEST_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The timeout for the requests to the schema tables.
METADATA_SCHEMA_WINDOW - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long the driver waits to apply a refresh.
METADATA_TOKEN_MAP_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether token metadata is enabled.
METADATA_TOPOLOGY_MAX_EVENTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of events that can accumulate.
METADATA_TOPOLOGY_WINDOW - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long the driver waits to propagate a Topology event.
Metrics - Interface in com.datastax.oss.driver.api.core.metrics
A wrapper around a MetricRegistry to expose the driver's metrics.
METRICS_FACTORY_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The classname of the desired MetricsFactory implementation.
METRICS_NODE_CQL_MESSAGES_DIGITS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of significant decimal digits to which internal structures will maintain for requests.
METRICS_NODE_CQL_MESSAGES_HIGHEST - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The largest latency that we expect to record for requests.
METRICS_NODE_CQL_MESSAGES_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval at which percentile data is refreshed for requests.
METRICS_NODE_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
List of enabled node-level metrics.
METRICS_NODE_EXPIRE_AFTER - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The time after which the node level metrics will be evicted.
METRICS_NODE_GRAPH_MESSAGES_DIGITS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of significant decimal digits to which internal structures will maintain for graph requests.
METRICS_NODE_GRAPH_MESSAGES_HIGHEST - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The largest latency that we expect to record for graph requests.
METRICS_NODE_GRAPH_MESSAGES_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval at which percentile data is refreshed for graph requests.
METRICS_SESSION_CQL_REQUESTS_DIGITS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of significant decimal digits to which internal structures will maintain for requests.
METRICS_SESSION_CQL_REQUESTS_HIGHEST - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The largest latency that we expect to record for requests.
METRICS_SESSION_CQL_REQUESTS_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval at which percentile data is refreshed for requests.
METRICS_SESSION_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
List of enabled session-level metrics.
METRICS_SESSION_GRAPH_REQUESTS_DIGITS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of significant decimal digits to which internal structures will maintain for graph requests.
METRICS_SESSION_GRAPH_REQUESTS_HIGHEST - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The largest latency that we expect to record for graph requests.
METRICS_SESSION_GRAPH_REQUESTS_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval at which percentile data is refreshed for graph requests.
METRICS_SESSION_THROTTLING_DIGITS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of significant decimal digits to which internal structures will maintain for throttling.
METRICS_SESSION_THROTTLING_HIGHEST - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The largest latency that we expect to record for throttling.
METRICS_SESSION_THROTTLING_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval at which percentile data is refreshed for throttling.
MONITOR_REPORTING_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to send events for Insights monitoring.
MutableCodecRegistry - Interface in com.datastax.oss.driver.api.core.type.codec.registry
A codec registry that can be extended with new user codecs at runtime.

N

name() - Method in interface com.datastax.oss.driver.api.core.ConsistencyLevel
The textual representation of the level in configuration files.
name() - Method in interface com.datastax.oss.driver.api.core.ProtocolVersion
A string representation of the version.
name() - Method in interface com.datastax.oss.driver.api.core.servererrors.WriteType
The textual representation that the write type is encoded to in protocol frames.
nameBased(UUID, String) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new name-based (version 3) UUID from the given namespace UUID and the given string representing the name part.
nameBased(UUID, byte[]) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new name-based (version 3) UUID from the given namespace UUID and the given byte array representing the name part.
nameBased(UUID, String, int) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new name-based (version 3 or version 5) UUID from the given namespace UUID and the given string representing the name part.
nameBased(UUID, byte[], int) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new name-based (version 3 or version 5) UUID from the given namespace UUID and the given byte array representing the name part.
nameBased(byte[]) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new name-based (version 3) UUID from the given byte array containing the namespace UUID and the name parts concatenated together.
nameBased(byte[], int) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new name-based (version 3 or version 5) UUID from the given byte array containing the namespace UUID and the name parts concatenated together.
NAMESPACE_DNS - Static variable in class com.datastax.oss.driver.api.core.uuid.Uuids
The namespace UUID for fully-qualified domain names, as defined in Appendix C of RFC-4122.
NAMESPACE_OID - Static variable in class com.datastax.oss.driver.api.core.uuid.Uuids
The namespace UUID for OIDs, as defined in Appendix C of RFC-4122.
NAMESPACE_URL - Static variable in class com.datastax.oss.driver.api.core.uuid.Uuids
The namespace UUID for URLs, as defined in Appendix C of RFC-4122.
NAMESPACE_X500 - Static variable in class com.datastax.oss.driver.api.core.uuid.Uuids
The namespace UUID for X.500 domain names, as defined in Appendix C of RFC-4122.
NATIVE_TRANSPORT_PORT - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The port for the native transport connections on the DSE node.
NATIVE_TRANSPORT_PORT_SSL - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The port for the encrypted native transport connections on the DSE node.
NETTY_ADMIN_SHUTDOWN_QUIET_PERIOD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Quiet period for admin group shutdown.
NETTY_ADMIN_SHUTDOWN_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Max time to wait for admin group shutdown.
NETTY_ADMIN_SHUTDOWN_UNIT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Units for admin group quiet period and timeout.
NETTY_ADMIN_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of threads in the Admin group.
NETTY_DAEMON - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether the threads created by the driver should be daemon threads.
NETTY_IO_SHUTDOWN_QUIET_PERIOD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Quiet period for I/O group shutdown.
NETTY_IO_SHUTDOWN_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Max time to wait for I/O group shutdown.
NETTY_IO_SHUTDOWN_UNIT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Units for I/O group quiet period and timeout.
NETTY_IO_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The number of threads in the I/O group.
NETTY_TIMER_TICK_DURATION - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
This is how frequent the timer should wake up to check for timed-out tasks or speculative executions.
NETTY_TIMER_TICKS_PER_WHEEL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Number of ticks in the Timer wheel.
newAuthenticator(EndPoint, String) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase
 
newAuthenticator(EndPoint, String) - Method in interface com.datastax.oss.driver.api.core.auth.AuthProvider
The authenticator to use when connecting to host.
newAuthenticator(EndPoint, String) - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase
 
newControlConnectionSchedule(boolean) - Method in interface com.datastax.oss.driver.api.core.connection.ReconnectionPolicy
Creates a new schedule for the control connection.
newInstance() - Static method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Create a new, empty instance.
newInstance(Iterable<GraphTraversal>) - Static method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Create a new instance from the given list of traversals.
newInstance(GraphTraversal...) - Static method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Create a new instance from the given list of traversals.
newInstance(GraphTraversal<?, ?>) - Static method in interface com.datastax.dse.driver.api.core.graph.FluentGraphStatement
Create a new instance from the given traversal.
newInstance(String) - Static method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
Create a new instance from the given script.
newInstance(BatchType) - Static method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Creates an instance of the default implementation for the given batch type.
newInstance(BatchType, Iterable<BatchableStatement<?>>) - Static method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Creates an instance of the default implementation for the given batch type, containing the given statements.
newInstance(BatchType, BatchableStatement<?>...) - Static method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Creates an instance of the default implementation for the given batch type, containing the given statements.
newInstance(String) - Static method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Shortcut to create an instance of the default implementation with only a CQL query (see SimpleStatementBuilder for the defaults for the other fields).
newInstance(String, Object...) - Static method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Shortcut to create an instance of the default implementation with only a CQL query and positional values (see SimpleStatementBuilder for the defaults for the other fields).
newInstance(String, Map<String, Object>) - Static method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Shortcut to create an instance of the default implementation with only a CQL query and named values (see SimpleStatementBuilder for the defaults for other fields).
newInstance(int, int, long) - Static method in class com.datastax.oss.driver.api.core.data.CqlDuration
Creates a duration with the given number of months, days and nanoseconds.
newNodeSchedule(Node) - Method in interface com.datastax.oss.driver.api.core.connection.ReconnectionPolicy
Creates a new schedule for the given node.
newQueryPlan(Request, Session) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Returns the coordinators to use for a new query.
newSslEngine(EndPoint) - Method in class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
 
newSslEngine(EndPoint) - Method in interface com.datastax.oss.driver.api.core.ssl.SslEngineFactory
Creates a new SSL engine each time a connection is established.
newToken(Partitioner, ByteBuffer...) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
Builds a token from a partition key.
newToken(ByteBuffer...) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
newTokenRange(Token, Token) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
 
newValue() - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
newValue(Object...) - Method in interface com.datastax.oss.driver.api.core.type.TupleType
Creates a new instance with the specified values for the fields.
newValue() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
newValue(Object...) - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
Creates a new instance with the specified values for the fields.
next() - Method in interface com.datastax.oss.driver.api.core.time.TimestampGenerator
Returns the next timestamp, in microseconds.
nextDelay() - Method in interface com.datastax.oss.driver.api.core.connection.ReconnectionPolicy.ReconnectionSchedule
How long to wait before the next reconnection attempt.
nextExecution(Node, CqlIdentifier, Request, int) - Method in interface com.datastax.oss.driver.api.core.specex.SpeculativeExecutionPolicy
 
nextStable() - Method in class com.datastax.oss.driver.api.core.Version
The next stable version, i.e.
NO_DEFAULT_TIMESTAMP - Static variable in interface com.datastax.oss.driver.api.core.cql.Statement
A special value for Statement.getQueryTimestamp() that means "no value".
NO_NOW_IN_SECONDS - Static variable in interface com.datastax.oss.driver.api.core.cql.Statement
A special value for Statement.getNowInSeconds() that means "no value".
node - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
node - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
Node - Interface in com.datastax.oss.driver.api.core.metadata
Metadata about a Cassandra node in the cluster.
NodeDistance - Enum in com.datastax.oss.driver.api.core.loadbalancing
Determines how the driver will manage connections to a Cassandra node.
NodeMetric - Interface in com.datastax.oss.driver.api.core.metrics
A node-level metric exposed through Session.getMetrics().
NodeState - Enum in com.datastax.oss.driver.api.core.metadata
The state of a node, as viewed from the driver.
NodeStateListener - Interface in com.datastax.oss.driver.api.core.metadata
A listener that gets notified when nodes states change.
NodeStateListenerBase - Class in com.datastax.oss.driver.api.core.metadata
Convenience class for listener implementations that that don't need to override all methods (all methods in this class are empty).
NodeStateListenerBase() - Constructor for class com.datastax.oss.driver.api.core.metadata.NodeStateListenerBase
 
NONE - Static variable in interface com.datastax.oss.driver.api.core.detach.AttachmentPoint
 
NoNodeAvailableException - Exception in com.datastax.oss.driver.api.core
Specialization of AllNodesFailedException when no coordinators were tried.
NoNodeAvailableException() - Constructor for exception com.datastax.oss.driver.api.core.NoNodeAvailableException
 
nowInSeconds - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 

O

of(Class<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
of(Type) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
OffsetPager - Class in com.datastax.oss.driver.api.core.paging
A utility to emulate offset queries on the client side (this comes with important performance trade-offs, make sure you read and understand the whole javadocs before using this class).
OffsetPager(int) - Constructor for class com.datastax.oss.driver.api.core.paging.OffsetPager
Creates a new instance.
OffsetPager.Page<ElementT> - Interface in com.datastax.oss.driver.api.core.paging
A page returned as the result of an offset query.
onAdd(Node) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Called when a node is added to the cluster.
onAdd(Node) - Method in interface com.datastax.oss.driver.api.core.metadata.NodeStateListener
Invoked when a node is first added to the cluster.
onAdd(Node) - Method in class com.datastax.oss.driver.api.core.metadata.NodeStateListenerBase
 
onAdd(Node) - Method in class com.datastax.oss.driver.api.core.metadata.SafeInitNodeStateListener
 
onAggregateCreated(AggregateMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onAggregateCreated(AggregateMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onAggregateDropped(AggregateMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onAggregateDropped(AggregateMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onAggregateUpdated(AggregateMetadata, AggregateMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onAggregateUpdated(AggregateMetadata, AggregateMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onAuthenticationSuccess(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.auth.Authenticator
Called when authentication is successful with the last information optionally sent by the server.
onAuthenticationSuccess(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
 
onAuthenticationSuccessSync(ByteBuffer) - Method in class com.datastax.dse.driver.api.core.auth.BaseDseAuthenticator
 
onAuthenticationSuccessSync(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
Called when authentication is successful with the last information optionally sent by the server.
onDown(Node) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Called when a node is determined to be down.
onDown(Node) - Method in interface com.datastax.oss.driver.api.core.metadata.NodeStateListener
Invoked when a node's state switches to NodeState.DOWN or NodeState.FORCED_DOWN.
onDown(Node) - Method in class com.datastax.oss.driver.api.core.metadata.NodeStateListenerBase
 
onDown(Node) - Method in class com.datastax.oss.driver.api.core.metadata.SafeInitNodeStateListener
 
onDriverInit(DriverContext) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Called when the driver initializes.
one() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
Returns the next node, or null if the result set is exhausted.
one() - Method in interface com.datastax.dse.driver.api.core.graph.GraphResultSet
Returns the next node, or null if the result set is exhausted.
one() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
Returns the next element, or null if the results are exhausted.
ONE - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
one() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
Returns the next element, or null if the iterable is exhausted.
onError(Request, Throwable, long, DriverExecutionProfile, Node) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Deprecated.
This method only exists for backward compatibility. Override RequestTracker.onError(Request, Throwable, long, DriverExecutionProfile, Node, String) instead.
onError(Request, Throwable, long, DriverExecutionProfile, Node, String) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Invoked each time a request fails.
onErrorResponse(Request, CoordinatorException, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
onErrorResponseVerdict(Request, CoordinatorException, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
Whether to retry when the server replied with a recoverable error (other than READ_TIMEOUT, WRITE_TIMEOUT or UNAVAILABLE).
onFunctionCreated(FunctionMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onFunctionCreated(FunctionMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onFunctionDropped(FunctionMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onFunctionDropped(FunctionMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onFunctionUpdated(FunctionMetadata, FunctionMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onFunctionUpdated(FunctionMetadata, FunctionMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
OngoingConfigOptions<SelfT extends OngoingConfigOptions<SelfT>> - Interface in com.datastax.oss.driver.api.core.config
An object where config options can be set programmatically.
onKeyspaceCreated(KeyspaceMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onKeyspaceCreated(KeyspaceMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onKeyspaceDropped(KeyspaceMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onKeyspaceDropped(KeyspaceMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onKeyspaceUpdated(KeyspaceMetadata, KeyspaceMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onKeyspaceUpdated(KeyspaceMetadata, KeyspaceMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onMissingChallenge(EndPoint) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase
 
onMissingChallenge(EndPoint) - Method in interface com.datastax.oss.driver.api.core.auth.AuthProvider
What to do if the server does not send back an authentication challenge (in other words, lets the client connect without any form of authentication).
onMissingChallenge(EndPoint) - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase
 
onNodeError(Request, Throwable, long, DriverExecutionProfile, Node) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Deprecated.
This method only exists for backward compatibility. Override RequestTracker.onNodeError(Request, Throwable, long, DriverExecutionProfile, Node, String) instead.
onNodeError(Request, Throwable, long, DriverExecutionProfile, Node, String) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Invoked each time a request fails at the node level.
onNodeSuccess(Request, long, DriverExecutionProfile, Node) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Deprecated.
This method only exists for backward compatibility. Override RequestTracker.onNodeSuccess(Request, long, DriverExecutionProfile, Node, String) instead.
onNodeSuccess(Request, long, DriverExecutionProfile, Node, String) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Invoked each time a request succeeds at the node level.
onReadTimeout(Request, ConsistencyLevel, int, int, boolean, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
onReadTimeoutVerdict(Request, ConsistencyLevel, int, int, boolean, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
Whether to retry when the server replied with a READ_TIMEOUT error; this indicates a server-side timeout during a read query, i.e.
onRemove(Node) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Called when a node is removed from the cluster.
onRemove(Node) - Method in interface com.datastax.oss.driver.api.core.metadata.NodeStateListener
Invoked when a node leaves the cluster.
onRemove(Node) - Method in class com.datastax.oss.driver.api.core.metadata.NodeStateListenerBase
 
onRemove(Node) - Method in class com.datastax.oss.driver.api.core.metadata.SafeInitNodeStateListener
 
onRequestAborted(Request, Throwable, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
Deprecated.
onRequestAbortedVerdict(Request, Throwable, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
Whether to retry when a request was aborted before we could get a response from the server.
onSessionReady(Session) - Method in interface com.datastax.oss.driver.api.core.metadata.NodeStateListener
Invoked when the session is ready to process user requests.
onSessionReady(Session) - Method in class com.datastax.oss.driver.api.core.metadata.SafeInitNodeStateListener
 
onSessionReady(Session) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
Invoked when the session is ready to process user requests.
onSessionReady(Session) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Invoked when the session is ready to process user requests.
onSuccess(Request, long, DriverExecutionProfile, Node) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Deprecated.
This method only exists for backward compatibility. Override RequestTracker.onSuccess(Request, long, DriverExecutionProfile, Node, String) instead.
onSuccess(Request, long, DriverExecutionProfile, Node, String) - Method in interface com.datastax.oss.driver.api.core.tracker.RequestTracker
Invoked each time a request succeeds.
onTableCreated(TableMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onTableCreated(TableMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onTableDropped(TableMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onTableDropped(TableMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onTableUpdated(TableMetadata, TableMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onTableUpdated(TableMetadata, TableMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onThrottleFailure(RequestThrottlingException) - Method in interface com.datastax.oss.driver.api.core.session.throttling.Throttled
Invoked by the throttler to indicate that the request cannot be fulfilled.
onThrottleReady(boolean) - Method in interface com.datastax.oss.driver.api.core.session.throttling.Throttled
Invoked by the throttler to indicate that the request can now start.
onUnavailable(Request, ConsistencyLevel, int, int, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
onUnavailableVerdict(Request, ConsistencyLevel, int, int, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
Whether to retry when the server replied with an UNAVAILABLE error; this indicates that the coordinator determined that there were not enough replicas alive to perform a query with the requested consistency level.
onUp(Node) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Called when a node is determined to be up.
onUp(Node) - Method in interface com.datastax.oss.driver.api.core.metadata.NodeStateListener
Invoked when a node's state switches to NodeState.UP.
onUp(Node) - Method in class com.datastax.oss.driver.api.core.metadata.NodeStateListenerBase
 
onUp(Node) - Method in class com.datastax.oss.driver.api.core.metadata.SafeInitNodeStateListener
 
onUserDefinedTypeCreated(UserDefinedType) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onUserDefinedTypeCreated(UserDefinedType) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onUserDefinedTypeDropped(UserDefinedType) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onUserDefinedTypeDropped(UserDefinedType) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onUserDefinedTypeUpdated(UserDefinedType, UserDefinedType) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onUserDefinedTypeUpdated(UserDefinedType, UserDefinedType) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onViewCreated(ViewMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onViewCreated(ViewMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onViewDropped(ViewMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onViewDropped(ViewMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onViewUpdated(ViewMetadata, ViewMetadata) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListener
 
onViewUpdated(ViewMetadata, ViewMetadata) - Method in class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
onWriteTimeout(Request, ConsistencyLevel, WriteType, int, int, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
onWriteTimeoutVerdict(Request, ConsistencyLevel, WriteType, int, int, int) - Method in interface com.datastax.oss.driver.api.core.retry.RetryPolicy
Whether to retry when the server replied with a WRITE_TIMEOUT error; this indicates a server-side timeout during a write query, i.e.
optionalOf(TypeCodec<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that wraps another codec's Java type into Optional instances (mapping CQL null to Optional.empty()).
optionalOf(Class<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
optionalOf(GenericType<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
OptionsMap - Class in com.datastax.oss.driver.api.core.config
An in-memory repository of config options, for use with DriverConfigLoader.fromMap(OptionsMap).
OptionsMap() - Constructor for class com.datastax.oss.driver.api.core.config.OptionsMap
 
OSS_DRIVER_COORDINATES - Static variable in interface com.datastax.oss.driver.api.core.session.Session
The Maven coordinates of the core driver artifact.
outerJavaType - Variable in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
outerToInner(OuterT) - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
Converts from an instance of the outer Java type to an instance of the inner Java type.
OverloadedException - Exception in com.datastax.oss.driver.api.core.servererrors
Thrown when the coordinator reported itself as being overloaded.
OverloadedException(Node) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.OverloadedException
 

P

pageNumber() - Method in interface com.datastax.dse.driver.api.core.cql.continuous.ContinuousAsyncResultSet
Returns the current page's number.
pageSize - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
PagingEnabledOptions - Enum in com.datastax.dse.driver.api.core.graph
 
PagingIterable<ElementT> - Interface in com.datastax.oss.driver.api.core
An iterable of elements which are fetched synchronously by the driver, possibly in multiple requests.
PagingState - Interface in com.datastax.oss.driver.api.core.cql
A safe wrapper around the paging state of a query.
pagingState - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
parse(String) - Static method in class com.datastax.dse.driver.api.core.data.time.DateRange
Parses the given string as a date range.
parse(String) - Method in interface com.datastax.oss.driver.api.core.metadata.TokenMap
Builds a token from its string representation.
parse(String) - Method in class com.datastax.oss.driver.api.core.type.codec.MappingCodec
 
parse(String) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
Parse the given CQL literal into an instance of the Java type handled by this codec.
parse(String) - Static method in class com.datastax.oss.driver.api.core.Version
Parses a version from a string.
parseLowerBound(String) - Static method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Parses the given input as a lower date range bound.
parseUpperBound(String) - Static method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Parses the given input as an upper date range bound.
Partitioner - Interface in com.datastax.oss.driver.api.core.metadata.token
Allows to hash partition key to a @code{Token}.
phrase(String, int) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Supports finding words which are a within a specific distance away (case insensitive).
PID_SYSTEM_PROPERTY - Static variable in class com.datastax.oss.driver.api.core.uuid.Uuids
The system property to use to force the value of the process ID ("com.datastax.oss.driver.PID").
PlainTextAuthenticator(PlainTextAuthProviderBase.Credentials, EndPoint, String) - Constructor for class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.PlainTextAuthenticator
 
PlainTextAuthenticator(PlainTextAuthProviderBase.Credentials) - Constructor for class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase.PlainTextAuthenticator
Deprecated.
Preserved for backward compatibility, implementors should use the 3-arg constructor PlainTextAuthenticator(Credentials, EndPoint, String) instead.
PlainTextAuthProviderBase - Class in com.datastax.oss.driver.api.core.auth
Common infrastructure for plain text auth providers.
PlainTextAuthProviderBase(String) - Constructor for class com.datastax.oss.driver.api.core.auth.PlainTextAuthProviderBase
 
PlainTextAuthProviderBase.Credentials - Class in com.datastax.oss.driver.api.core.auth
 
PlainTextAuthProviderBase.PlainTextAuthenticator - Class in com.datastax.oss.driver.api.core.auth
 
Point - Interface in com.datastax.dse.driver.api.core.data.geometry
The driver-side representation of DSE's Point.
point(double, double) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Creates a point from the given coordinates.
POINT - Static variable in class com.datastax.dse.driver.api.core.type.codec.DseTypeCodecs
 
POINT - Static variable in class com.datastax.dse.driver.api.core.type.DseDataTypes
 
Polygon - Interface in com.datastax.dse.driver.api.core.data.geometry
The driver-side representation of DSE's Polygon.
polygon(Point, Point, Point, Point...) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Creates a polygon from the given (at least 3) points.
polygon(double...) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Geo
Creates a polygon from the coordinates of its points.
POLYGON - Static variable in class com.datastax.dse.driver.api.core.type.codec.DseTypeCodecs
 
POLYGON - Static variable in class com.datastax.dse.driver.api.core.type.DseDataTypes
 
Polygon.Builder - Interface in com.datastax.dse.driver.api.core.data.geometry
Provides a simple DSL to build a polygon.
prefix(String) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Search for a specific prefix at the beginning of the text property targeted (case sensitive).
prepare(SimpleStatement) - Method in interface com.datastax.oss.driver.api.core.cql.SyncCqlSession
Prepares a CQL statement synchronously (the calling thread blocks until the statement is prepared).
prepare(String) - Method in interface com.datastax.oss.driver.api.core.cql.SyncCqlSession
Prepares a CQL statement synchronously (the calling thread blocks until the statement is prepared).
prepare(PrepareRequest) - Method in interface com.datastax.oss.driver.api.core.cql.SyncCqlSession
Prepares a CQL statement synchronously (the calling thread blocks until the statement is prepared).
PREPARE_ON_ALL_NODES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether `Session.prepare` calls should be sent to all nodes in the cluster.
prepareAsync(SimpleStatement) - Method in interface com.datastax.oss.driver.api.core.cql.AsyncCqlSession
Prepares a CQL statement asynchronously (the call returns as soon as the prepare query was sent, generally before the statement is prepared).
prepareAsync(String) - Method in interface com.datastax.oss.driver.api.core.cql.AsyncCqlSession
Prepares a CQL statement asynchronously (the call returns as soon as the prepare query was sent, generally before the statement is prepared).
prepareAsync(PrepareRequest) - Method in interface com.datastax.oss.driver.api.core.cql.AsyncCqlSession
Prepares a CQL statement asynchronously (the call returns as soon as the prepare query was sent, generally before the statement is prepared).
PreparedStatement - Interface in com.datastax.oss.driver.api.core.cql
A query with bind variables that has been pre-parsed by the database.
PrepareRequest - Interface in com.datastax.oss.driver.api.core.cql
A request to prepare a CQL query.
PrimitiveBooleanCodec - Interface in com.datastax.oss.driver.api.core.type.codec
A specialized boolean codec that knows how to deal with primitive types.
PrimitiveByteCodec - Interface in com.datastax.oss.driver.api.core.type.codec
A specialized byte codec that knows how to deal with primitive types.
PrimitiveDoubleCodec - Interface in com.datastax.oss.driver.api.core.type.codec
A specialized double codec that knows how to deal with primitive types.
PrimitiveFloatCodec - Interface in com.datastax.oss.driver.api.core.type.codec
A specialized float codec that knows how to deal with primitive types.
PrimitiveIntCodec - Interface in com.datastax.oss.driver.api.core.type.codec
A specialized integer codec that knows how to deal with primitive types.
PrimitiveLongCodec - Interface in com.datastax.oss.driver.api.core.type.codec
A specialized long codec that knows how to deal with primitive types.
PrimitiveShortCodec - Interface in com.datastax.oss.driver.api.core.type.codec
A specialized short codec that knows how to deal with primitive types.
ProgrammaticArguments - Class in com.datastax.oss.driver.api.core.session
The arguments that can be set programmatically when building a session.
ProgrammaticArguments.Builder - Class in com.datastax.oss.driver.api.core.session
 
programmaticArgumentsBuilder - Variable in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
programmaticBuilder() - Static method in class com.datastax.dse.driver.api.core.config.DseDriverConfigLoader
Deprecated.
This method only exists for backward compatibility. It delegates to DriverConfigLoader.programmaticBuilder(), which you should call directly instead.
programmaticBuilder() - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Starts a builder that allows configuration options to be overridden programmatically.
programmaticBuilder(ClassLoader) - Static method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Just like DriverConfigLoader.programmaticBuilder() except that application-specific classpath resources will be located using the provided ClassLoader instead of the current thread's context class loader.
programmaticContactPoints - Variable in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
ProgrammaticDriverConfigLoaderBuilder - Interface in com.datastax.oss.driver.api.core.config
A builder that allows the creation of a config loader where options are overridden programmatically.
ProgrammaticDseGssApiAuthProvider - Class in com.datastax.dse.driver.api.core.auth
AuthProvider that provides GSSAPI authenticator instances for clients to connect to DSE clusters secured with DseAuthenticator, in a programmatic way.
ProgrammaticDseGssApiAuthProvider(DseGssApiAuthProviderBase.GssApiOptions) - Constructor for class com.datastax.dse.driver.api.core.auth.ProgrammaticDseGssApiAuthProvider
 
ProgrammaticSslEngineFactory - Class in com.datastax.oss.driver.api.core.ssl
An SSL engine factory that allows you to configure the driver programmatically, by passing your own SSLContext.
ProgrammaticSslEngineFactory(SSLContext) - Constructor for class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
Creates an instance with the given SSLContext, default cipher suites and no host name validation.
ProgrammaticSslEngineFactory(SSLContext, String[]) - Constructor for class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
Creates an instance with the given SSLContext and cipher suites, and no host name validation.
ProgrammaticSslEngineFactory(SSLContext, String[], boolean) - Constructor for class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
Creates an instance with the given SSLContext, cipher suites and host name validation.
PROTOCOL_COMPRESSION - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The name of the algorithm used to compress protocol frames.
PROTOCOL_MAX_FRAME_LENGTH - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum length, in bytes, of the frames supported by the driver.
PROTOCOL_VERSION - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The native protocol version to use.
ProtocolError - Exception in com.datastax.oss.driver.api.core.servererrors
Indicates that the contacted node reported a protocol error.
ProtocolError(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.ProtocolError
 
protocolVersion() - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
protocolVersion() - Method in interface com.datastax.oss.driver.api.core.data.Data
Returns the protocol version that is currently used to convert values for this instance.
ProtocolVersion - Interface in com.datastax.oss.driver.api.core
A version of the native protocol used by the driver to communicate with the server.
ProxyAuthentication - Class in com.datastax.dse.driver.api.core.auth
 
ProxyAuthentication() - Constructor for class com.datastax.dse.driver.api.core.auth.ProxyAuthentication
 
put(String, TypedDriverOption<ValueT>, ValueT) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Associates the specified value for the specified option, in the specified execution profile.
put(TypedDriverOption<ValueT>, ValueT) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Associates the specified value for the specified option, in the default execution profile.

Q

QueryConsistencyException - Exception in com.datastax.oss.driver.api.core.servererrors
A failure to reach the required consistency level during the execution of a query.
QueryConsistencyException(Node, String, ConsistencyLevel, int, int, ExecutionInfo, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.QueryConsistencyException
 
QueryExecutionException - Exception in com.datastax.oss.driver.api.core.servererrors
A server-side error thrown when a valid query cannot be executed.
QueryExecutionException(Node, String, ExecutionInfo, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.QueryExecutionException
 
QueryTrace - Interface in com.datastax.oss.driver.api.core.cql
Tracing information for a query.
QueryValidationException - Exception in com.datastax.oss.driver.api.core.servererrors
A server-side error thrown when a query cannot be executed because it is syntactically incorrect, invalid or unauthorized.
QueryValidationException(Node, String, ExecutionInfo, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.QueryValidationException
 
QUORUM - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 

R

random() - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new random (version 4) UUID.
random(Random) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new random (version 4) UUID using the provided Random instance.
random(SplittableRandom) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new random (version 4) UUID using the provided SplittableRandom instance.
ReactiveGraphNode - Interface in com.datastax.dse.driver.api.core.graph.reactive
ReactiveGraphResultSet - Interface in com.datastax.dse.driver.api.core.graph.reactive
A Publisher of ReactiveGraphNodes returned by a ReactiveGraphSession.
ReactiveGraphSession - Interface in com.datastax.dse.driver.api.core.graph.reactive
A Session that offers utility methods to issue graph queries using reactive-style programming.
ReactiveQueryMetadata - Interface in com.datastax.dse.driver.api.core.cql.reactive
Interface implemented by all the reactive result set publishers provided by the driver, and notably by ReactiveResultSet.
ReactiveResultSet - Interface in com.datastax.dse.driver.api.core.cql.reactive
A Publisher of ReactiveRows returned by a ReactiveSession.
ReactiveRow - Interface in com.datastax.dse.driver.api.core.cql.reactive
A row produced by a reactive result set.
ReactiveSession - Interface in com.datastax.dse.driver.api.core.cql.reactive
A Session that offers utility methods to issue queries using reactive-style programming.
readConsistencyLevel - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
ReadFailureException - Exception in com.datastax.oss.driver.api.core.servererrors
A non-timeout error during a read query.
ReadFailureException(Node, ConsistencyLevel, int, int, int, boolean, Map<InetAddress, Integer>) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.ReadFailureException
 
ReadTimeoutException - Exception in com.datastax.oss.driver.api.core.servererrors
A server-side timeout during a read query.
ReadTimeoutException(Node, ConsistencyLevel, int, int, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.ReadTimeoutException
 
RECONNECT_ON_INIT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to schedule reconnection attempts if all contact points are unreachable on the first initialization attempt.
RECONNECTION_BASE_DELAY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Base delay for computing time between reconnection attempts.
RECONNECTION_MAX_DELAY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Maximum delay between reconnection attempts.
RECONNECTION_POLICY_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the reconnection policy.
ReconnectionPolicy - Interface in com.datastax.oss.driver.api.core.connection
Decides how often the driver tries to re-establish lost connections.
ReconnectionPolicy.ReconnectionSchedule - Interface in com.datastax.oss.driver.api.core.connection
The reconnection schedule from the time a connection is lost, to the time all connections to this node have been restored.
refreshSchema() - Method in interface com.datastax.oss.driver.api.core.session.Session
Convenience method to call Session.refreshSchemaAsync() and block for the result.
refreshSchemaAsync() - Method in interface com.datastax.oss.driver.api.core.session.Session
Force an immediate refresh of the schema metadata, even if it is currently disabled (either in the configuration or via Session.setSchemaMetadataEnabled(Boolean)).
regex(String) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Search for this regular expression inside the text property targeted (case sensitive).
register(Throttled) - Method in interface com.datastax.oss.driver.api.core.session.throttling.RequestThrottler
Registers a new request to be throttled.
register(TypeCodec<?>) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.MutableCodecRegistry
Adds the given codec to the registry.
register(TypeCodec<?>...) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.MutableCodecRegistry
Invokes MutableCodecRegistry.register(TypeCodec) for every codec in the given list.
register(Iterable<TypeCodec<?>>) - Method in interface com.datastax.oss.driver.api.core.type.codec.registry.MutableCodecRegistry
Invokes MutableCodecRegistry.register(TypeCodec) for every codec in the given list.
RelationMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A table or materialized view in the schema metadata.
reload() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Triggers an immediate reload attempt and returns a stage that completes once the attempt is finished, with a boolean indicating whether the configuration changed as a result of this reload.
remaining() - Method in interface com.datastax.dse.driver.api.core.graph.AsyncGraphResultSet
How many rows are left before the current page is exhausted.
remaining() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
How many rows are left before the current page is exhausted.
remoteConnectionBuilder(CqlSession) - Static method in class com.datastax.dse.driver.api.core.graph.DseGraph
Returns a builder helper class to help create RemoteConnection implementations that seamlessly connect to DSE Graph using the CqlSession in parameter.
remove(String, TypedDriverOption<ValueT>) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Removes the specified option from the specified profile.
remove(TypedDriverOption<ValueT>) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Removes the specified option from the default profile.
removeChangeListener(Consumer<OptionsMap>) - Method in class com.datastax.oss.driver.api.core.config.OptionsMap
Unregisters a listener that was previously registered with OptionsMap.addChangeListener(Consumer).
removeQueryParam(String) - Method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
Removes a binding for the given name from this statement.
removeQueryParam(String) - Method in class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
Removes a parameter.
REPREPARE_CHECK_SYSTEM_TABLE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to check `system.prepared_statements` on the target node before repreparing.
REPREPARE_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether the driver tries to prepare on new nodes at all.
REPREPARE_MAX_PARALLELISM - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of concurrent requests when repreparing.
REPREPARE_MAX_STATEMENTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of statements that should be reprepared.
REPREPARE_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The request timeout when repreparing.
Request - Interface in com.datastax.oss.driver.api.core.session
A request executed by a Session.
REQUEST_CONSISTENCY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The consistency level.
REQUEST_DEFAULT_IDEMPOTENCE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The default idempotence of a request.
REQUEST_LOG_WARNINGS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether logging of server warnings generated during query execution should be disabled by the driver.
REQUEST_LOGGER_ERROR_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to log failed requests.
REQUEST_LOGGER_MAX_QUERY_LENGTH - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum length of the query string in the log message.
REQUEST_LOGGER_MAX_VALUE_LENGTH - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum length for bound values in the log message.
REQUEST_LOGGER_MAX_VALUES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of bound values to log.
REQUEST_LOGGER_SLOW_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to log slow requests.
REQUEST_LOGGER_SLOW_THRESHOLD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The threshold to classify a successful request as "slow".
REQUEST_LOGGER_STACK_TRACES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to log stack traces for failed queries.
REQUEST_LOGGER_SUCCESS_ENABLED - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to log successful requests.
REQUEST_LOGGER_VALUES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to log bound values in addition to the query string.
REQUEST_PAGE_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The page size.
REQUEST_SERIAL_CONSISTENCY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The serial consistency level.
REQUEST_THROTTLER_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of a session-wide component that controls the rate at which requests are executed.
REQUEST_THROTTLER_DRAIN_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How often the throttler attempts to dequeue requests.
REQUEST_THROTTLER_MAX_CONCURRENT_REQUESTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of requests that are allowed to execute in parallel.
REQUEST_THROTTLER_MAX_QUEUE_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of requests that can be enqueued when the throttling threshold is exceeded.
REQUEST_THROTTLER_MAX_REQUESTS_PER_SECOND - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum allowed request rate.
REQUEST_TIMEOUT - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How long the driver waits for a request to complete.
REQUEST_TRACE_ATTEMPTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How many times the driver will attempt to fetch the query trace if it is not ready yet.
REQUEST_TRACE_CONSISTENCY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The consistency level to use for trace queries.
REQUEST_TRACE_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The interval between each attempt.
REQUEST_TRACKER_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of a session-wide component that tracks the outcome of requests.
REQUEST_WARN_IF_SET_KEYSPACE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether a warning is logged when a request (such as a CQL `USE ...`) changes the active keyspace.
RequestThrottler - Interface in com.datastax.oss.driver.api.core.session.throttling
Limits the number of concurrent requests executed by the driver.
RequestThrottlingException - Exception in com.datastax.oss.driver.api.core
Thrown if the session uses a request throttler, and it didn't allow the current request to execute.
RequestThrottlingException(String) - Constructor for exception com.datastax.oss.driver.api.core.RequestThrottlingException
 
RequestTracker - Interface in com.datastax.oss.driver.api.core.tracker
Tracks request execution for a session.
requireHostnameValidation - Variable in class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
 
resolve() - Method in interface com.datastax.oss.driver.api.core.metadata.EndPoint
Resolves this instance to a socket address.
RESOLVE_CONTACT_POINTS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to resolve the addresses passed to `basic.contact-points`.
ResultSet - Interface in com.datastax.oss.driver.api.core.cql
The result of a synchronous CQL query.
RETHROW - Static variable in interface com.datastax.oss.driver.api.core.retry.RetryVerdict
A retry verdict that rethrows the execution error to the calling code.
RETRY_NEXT - Static variable in interface com.datastax.oss.driver.api.core.retry.RetryVerdict
A retry verdict that retries the same request on the next node in the query plan.
RETRY_POLICY_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the retry policy.
RETRY_SAME - Static variable in interface com.datastax.oss.driver.api.core.retry.RetryVerdict
A retry verdict that retries the same request on the same node.
RetryDecision - Enum in com.datastax.oss.driver.api.core.retry
A decision from the RetryPolicy on how to handle a retry.
RetryPolicy - Interface in com.datastax.oss.driver.api.core.retry
Defines the behavior to adopt when a request fails.
RetryVerdict - Interface in com.datastax.oss.driver.api.core.retry
The verdict returned by a RetryPolicy determining what to do when a request failed.
reword(String) - Method in exception com.datastax.oss.driver.api.core.AllNodesFailedException
 
roundDown(ZonedDateTime) - Method in enum com.datastax.dse.driver.api.core.data.time.DateRangePrecision
Rounds down the given timestamp to this precision.
roundUp(ZonedDateTime) - Method in enum com.datastax.dse.driver.api.core.data.time.DateRangePrecision
Rounds up the given timestamp to this precision.
routingKey - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
routingKeyspace - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
routingToken - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
Row - Interface in com.datastax.oss.driver.api.core.cql
A row from a CQL table.

S

SafeInitNodeStateListener - Class in com.datastax.oss.driver.api.core.metadata
A node state listener wrapper that delays (or ignores) init events until after the session is ready.
SafeInitNodeStateListener(NodeStateListener, boolean) - Constructor for class com.datastax.oss.driver.api.core.metadata.SafeInitNodeStateListener
Creates a new instance.
SASL_SERVICE_NAME_PROPERTY - Static variable in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase
The name of the system property to use to specify the SASL service name.
SchemaChangeListener - Interface in com.datastax.oss.driver.api.core.metadata.schema
Tracks schema changes.
SchemaChangeListenerBase - Class in com.datastax.oss.driver.api.core.metadata.schema
Convenience class for listener implementations that that don't need to override all methods (all methods in this class are empty).
SchemaChangeListenerBase() - Constructor for class com.datastax.oss.driver.api.core.metadata.schema.SchemaChangeListenerBase
 
ScriptGraphStatement - Interface in com.datastax.dse.driver.api.core.graph
A graph statement that uses a Gremlin-groovy script the query.
ScriptGraphStatementBuilder - Class in com.datastax.dse.driver.api.core.graph
A builder to create a script graph statement.
ScriptGraphStatementBuilder() - Constructor for class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
 
ScriptGraphStatementBuilder(String) - Constructor for class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
 
ScriptGraphStatementBuilder(ScriptGraphStatement) - Constructor for class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
 
Search - Interface in com.datastax.dse.driver.api.core.graph.predicates
 
self - Variable in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
SERIAL - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
serialConsistencyLevel - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
SERVER_ID - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The value of the server_id field in the peers system table for this node.
ServerError - Exception in com.datastax.oss.driver.api.core.servererrors
Indicates that the contacted node reported an internal error.
ServerError(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.ServerError
 
Session - Interface in com.datastax.oss.driver.api.core.session
A nexus to send requests to a Cassandra cluster.
SESSION_KEYSPACE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The name of the keyspace that the session should initially be connected to.
SESSION_LEAK_THRESHOLD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of live sessions that are allowed to coexist in a given VM.
SESSION_NAME - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
A name that uniquely identifies the driver instance.
SessionBuilder<SelfT extends SessionBuilder,SessionT> - Class in com.datastax.oss.driver.api.core.session
Base implementation to build session instances.
SessionBuilder() - Constructor for class com.datastax.oss.driver.api.core.session.SessionBuilder
 
SessionMetric - Interface in com.datastax.oss.driver.api.core.metrics
A session-level metric exposed through Session.getMetrics().
set(CqlIdentifier, ValueT, TypeCodec<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id, using the given codec for the conversion.
set(CqlIdentifier, ValueT, GenericType<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id, converting it to the given Java type.
set(CqlIdentifier, ValueT, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Returns the value for all occurrences of id, converting it to the given Java type.
set(int, ValueT, TypeCodec<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value, using the given codec for the conversion.
set(int, ValueT, GenericType<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value, converting it to the given Java type.
set(int, ValueT, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Returns the ith value, converting it to the given Java type.
set(String, ValueT, TypeCodec<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name, using the given codec for the conversion.
set(String, ValueT, GenericType<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name, converting it to the given Java type.
set(String, ValueT, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Returns the value for all occurrences of name, converting it to the given Java type.
setBatchType(BatchType) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Sets the batch type.
setBigDecimal(CqlIdentifier, BigDecimal) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java big decimal.
setBigDecimal(int, BigDecimal) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java big decimal.
setBigDecimal(String, BigDecimal) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java big decimal.
setBigInteger(CqlIdentifier, BigInteger) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java big integer.
setBigInteger(int, BigInteger) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java big integer.
setBigInteger(String, BigInteger) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java big integer.
setBool(CqlIdentifier, boolean) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for SettableById.setBoolean(CqlIdentifier, boolean).
setBool(int, boolean) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for SettableByIndex.setBoolean(int, boolean).
setBool(String, boolean) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias forSettableByName.setBoolean(String, boolean).
setBoolean(CqlIdentifier, boolean) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java primitive boolean.
setBoolean(int, boolean) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java primitive boolean.
setBoolean(String, boolean) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java primitive boolean.
setByte(CqlIdentifier, byte) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java primitive byte.
setByte(int, byte) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java primitive byte.
setByte(String, byte) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java primitive byte.
setByteBuffer(CqlIdentifier, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java byte buffer.
setByteBuffer(int, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java byte buffer.
setByteBuffer(String, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java byte buffer.
setBytesUnsafe(int, ByteBuffer) - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
setBytesUnsafe(CqlIdentifier, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the raw binary representation of the value for all occurrences of id.
setBytesUnsafe(int, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the raw binary representation of the ith value.
setBytesUnsafe(String, ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the raw binary representation of the value for all occurrences of name.
setConsistencyLevel(ConsistencyLevel) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the consistency level to use for this statement.
setConsistencyLevel(ConsistencyLevel) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setConsistencyLevel(ConsistencyLevel) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the ConsistencyLevel to use for this statement.
setConsistencyLevel(ConsistencyLevel) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setCqlDuration(CqlIdentifier, CqlDuration) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided duration.
setCqlDuration(int, CqlDuration) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided duration.
setCqlDuration(String, CqlDuration) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided duration.
setCustomPayload(Map<String, ByteBuffer>) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the custom payload to use for execution.
setCustomPayload(Map<String, ByteBuffer>) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the custom payload to use for execution.
setDefaultTimestamp(long) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for Statement.setQueryTimestamp(long).
setDefaultTimestamp(long) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for StatementBuilder.setQueryTimestamp(long).
setDistance(Node, NodeDistance) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy.DistanceReporter
 
setDouble(CqlIdentifier, double) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java primitive double.
setDouble(int, double) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java primitive double.
setDouble(String, double) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java primitive double.
setExecutionInfo(ExecutionInfo) - Method in exception com.datastax.oss.driver.api.core.DriverException
This is for internal use by the driver, a client application has no reason to call it.
setExecutionProfile(DriverExecutionProfile) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the configuration profile to use for execution.
setExecutionProfile(DriverExecutionProfile) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setExecutionProfile(DriverExecutionProfile) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the execution profile to use for this statement.
setExecutionProfile(DriverExecutionProfile) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setExecutionProfileName(String) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the name of the driver configuration profile that will be used for execution.
setExecutionProfileName(String) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setExecutionProfileName(String) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the name of the execution profile that will be used for this statement.
setExecutionProfileName(String) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setFetchSize(int) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for Statement.setPageSize(int).
setFetchSize(int) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for StatementBuilder.setPageSize(int).
setFloat(CqlIdentifier, float) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java primitive float.
setFloat(int, float) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java primitive float.
setFloat(String, float) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java primitive float.
setGraphName(String) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the graph name.
setGraphName(String) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setIdempotence(Boolean) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setIdempotence(Boolean) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setIdempotent(Boolean) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Set the idempotence to use for execution.
setIdempotent(Boolean) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the idempotence to use for execution.
setInetAddress(CqlIdentifier, InetAddress) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java IP address.
setInetAddress(int, InetAddress) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java IP address.
setInetAddress(String, InetAddress) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java IP address.
setInstant(CqlIdentifier, Instant) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java instant.
setInstant(int, Instant) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java instant.
setInstant(String, Instant) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java instant.
setInt(CqlIdentifier, int) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java primitive integer.
setInt(int, int) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java primitive integer.
setInt(String, int) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java primitive integer.
setKeyspace(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Sets the CQL keyspace to associate with this batch.
setKeyspace(String) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
setKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
Sets the CQL keyspace to execute this batch in.
setKeyspace(String) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
Sets the CQL keyspace to execute this batch in.
setKeyspace(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Sets the CQL keyspace to associate with the query.
setKeyspace(String) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
setKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
setKeyspace(String) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
setList(CqlIdentifier, List<ElementT>, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java list.
setList(int, List<ElementT>, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java list.
setList(String, List<ElementT>, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java list.
setLocalDate(CqlIdentifier, LocalDate) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java local date.
setLocalDate(int, LocalDate) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java local date.
setLocalDate(String, LocalDate) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java local date.
setLocalTime(CqlIdentifier, LocalTime) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java local time.
setLocalTime(int, LocalTime) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java local time.
setLocalTime(String, LocalTime) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java local time.
setLong(CqlIdentifier, long) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java primitive long.
setLong(int, long) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java primitive long.
setLong(String, long) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java primitive long.
setMap(CqlIdentifier, Map<KeyT, ValueT>, Class<KeyT>, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java map.
setMap(int, Map<KeyT, ValueT>, Class<KeyT>, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java map.
setMap(String, Map<KeyT, ValueT>, Class<KeyT>, Class<ValueT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java map.
setNamedValues(Map<String, Object>) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Shortcut for SimpleStatement.setNamedValuesWithIds(Map) with raw strings as value names.
setNamedValuesWithIds(Map<CqlIdentifier, Object>) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Sets the named values to bind to named placeholders.
setNode(Node) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the Node that should handle this query.
setNode(Node) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setNode(Node) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the Node that should handle this query.
setNode(Node) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setNowInSeconds(int) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the "now in seconds" to use when applying the request (for testing purposes).
setNowInSeconds(int) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setOf(TypeCodec<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
Builds a new codec that maps a CQL set to a Java set, using the given codec to map each element.
setOf(DataType) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
setOf(DataType, boolean) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
setOf(Class<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
setOf(GenericType<T>) - Static method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
setPageSize(int) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Configures how many rows will be retrieved simultaneously in a single network roundtrip (the goal being to avoid loading too many results in memory at the same time).
setPageSize(int) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setPagingState(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the paging state to send with the statement, or null if this statement has no paging state.
setPagingState(PagingState) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the paging state to send with the statement, or null if this statement has no paging state.
setPagingState(PagingState, Session) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Alternative to Statement.setPagingState(PagingState) that specifies the session the statement will be executed with.
setPagingState(ByteBuffer) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setPositionalValues(List<Object>) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Sets the positional values to bind to anonymous placeholders.
setQuery(String) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Sets the CQL query to execute.
setQuery(String) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
setQueryParam(String, Object) - Method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
Set a value for a parameter defined in the Groovy script.
setQueryParam(String, Object) - Method in class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
Set a value for a parameter defined in the script query.
setQueryParams(Map<String, Object>) - Method in class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
Set multiple values for named parameters defined in the script query.
setQueryTimestamp(long) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the query timestamp, in microseconds, to send with the statement.
setQueryTimestamp(long) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setReadConsistencyLevel(ConsistencyLevel) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the read consistency level.
setReadConsistencyLevel(ConsistencyLevel) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setResultMetadata(ByteBuffer, ColumnDefinitions) - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
setRoutingKey(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the key to use for token-aware routing.
setRoutingKey(ByteBuffer...) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the key to use for token-aware routing, when the partition key has multiple components.
setRoutingKey(ByteBuffer) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setRoutingKey(ByteBuffer...) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setRoutingKeyspace(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the keyspace to use for token-aware routing.
setRoutingKeyspace(String) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
setRoutingKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setRoutingKeyspace(String) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
setRoutingToken(Token) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the token to use for token-aware routing.
setRoutingToken(Token) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setSchemaMetadataEnabled(Boolean) - Method in interface com.datastax.oss.driver.api.core.session.Session
Enable or disable schema metadata programmatically.
setScript(String) - Method in class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
 
setSerialConsistencyLevel(ConsistencyLevel) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the serial ConsistencyLevel to use for this statement.
setSerialConsistencyLevel(ConsistencyLevel) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setSet(CqlIdentifier, Set<ElementT>, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java set.
setSet(int, Set<ElementT>, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java set.
setSet(String, Set<ElementT>, Class<ElementT>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java set.
setShort(CqlIdentifier, short) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java primitive short.
setShort(int, short) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java primitive short.
setShort(String, short) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java primitive short.
setString(CqlIdentifier, String) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java string.
setString(int, String) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java string.
setString(String, String) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java string.
setSubProtocol(String) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the sub-protocol.
setSubProtocol(String) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setSystemQuery(Boolean) - Method in interface com.datastax.dse.driver.api.core.graph.ScriptGraphStatement
Defines if this statement is a system query.
setSystemQuery(Boolean) - Method in class com.datastax.dse.driver.api.core.graph.ScriptGraphStatementBuilder
 
SettableById<SelfT extends SettableById<SelfT>> - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to set its values via a CQL identifier.
SettableByIndex<SelfT extends SettableByIndex<SelfT>> - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to set its values via an integer index.
SettableByName<SelfT extends SettableByName<SelfT>> - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to set its values via a name.
setTimeout(Duration) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets how long to wait for this request to complete.
setTimeout(Duration) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setTimeout(Duration) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets how long to wait for this request to complete.
setTimeout(Duration) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setTimestamp(long) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Set the timestamp to use for execution.
setTimestamp(long) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setToken(CqlIdentifier, Token) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided token.
setToken(int, Token) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided token.
setToken(String, Token) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided token.
setToNull(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to CQL NULL.
setToNull(int) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to CQL NULL.
setToNull(String) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to CQL NULL.
setTracing(boolean) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets tracing for execution.
setTracing() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
This method is a shortcut to StatementBuilder.setTracing(boolean) with an argument of true.
setTracing(boolean) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
setTraversalSource(String) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the traversal source.
setTraversalSource(String) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
setTupleValue(CqlIdentifier, TupleValue) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided tuple value.
setTupleValue(int, TupleValue) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided tuple value.
setTupleValue(String, TupleValue) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided tuple value.
SetType - Interface in com.datastax.oss.driver.api.core.type
 
setUdtValue(CqlIdentifier, UdtValue) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided user defined type value.
setUdtValue(int, UdtValue) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided user defined type value.
setUdtValue(String, UdtValue) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided user defined type value.
setUuid(CqlIdentifier, UUID) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for all occurrences of id to the provided Java UUID.
setUuid(int, UUID) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java UUID.
setUuid(String, UUID) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for all occurrences of name to the provided Java UUID.
setWriteConsistencyLevel(ConsistencyLevel) - Method in interface com.datastax.dse.driver.api.core.graph.GraphStatement
Sets the write consistency level.
setWriteConsistencyLevel(ConsistencyLevel) - Method in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
shallowEquals(Object) - Method in interface com.datastax.oss.driver.api.core.metadata.schema.KeyspaceMetadata
 
SHORT - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
SHORT_LIST_TO_ARRAY - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type list<smallint> to Java's short[].
signalError(Throttled, Throwable) - Method in interface com.datastax.oss.driver.api.core.session.throttling.RequestThrottler
Signals that a request has failed.
signalSuccess(Throttled) - Method in interface com.datastax.oss.driver.api.core.session.throttling.RequestThrottler
Signals that a request has succeeded.
signalTimeout(Throttled) - Method in interface com.datastax.oss.driver.api.core.session.throttling.RequestThrottler
Signals that a request has timed out.
SIMPLE - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
SimpleStatement - Interface in com.datastax.oss.driver.api.core.cql
A one-off CQL statement consisting of a query string with optional placeholders, and a set of values for these placeholders.
SimpleStatementBuilder - Class in com.datastax.oss.driver.api.core.cql
A builder to create a simple statement.
SimpleStatementBuilder(String) - Constructor for class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
SimpleStatementBuilder(SimpleStatement) - Constructor for class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
size() - Method in interface com.datastax.dse.driver.api.core.graph.BatchGraphStatement
Get the number of traversals already added to this statement.
size() - Method in interface com.datastax.dse.driver.api.core.graph.GraphNode
The size of the current node, if it is a list or map, or 0 otherwise.
size() - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
 
size() - Method in class com.datastax.oss.driver.api.core.cql.BoundStatementBuilder
 
size() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinitions
 
size() - Method in interface com.datastax.oss.driver.api.core.data.AccessibleByIndex
Returns the number of values.
SMALLINT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type smallint to Java's short.
SMALLINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
SOCKET_KEEP_ALIVE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether or not to enable TCP keep-alive probes.
SOCKET_LINGER_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Sets the linger interval.
SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Sets a hint to the size of the underlying buffers for incoming network I/O.
SOCKET_REUSE_ADDRESS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether or not to allow address reuse.
SOCKET_SEND_BUFFER_SIZE - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Sets a hint to the size of the underlying buffers for outgoing network I/O.
SOCKET_TCP_NODELAY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether or not to disable the Nagle algorithm.
SPECULATIVE_EXECUTION_DELAY - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The delay between each execution.
SPECULATIVE_EXECUTION_MAX - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The maximum number of executions.
SPECULATIVE_EXECUTION_POLICY_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the speculative execution policy.
SpeculativeExecutionPolicy - Interface in com.datastax.oss.driver.api.core.specex
The policy that decides if the driver will send speculative queries to the next nodes when the current node takes too long to respond.
spliterator() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
splitEvenly(int) - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Splits this range into a number of smaller ranges of equal "size" (referring to the number of tokens, not the actual amount of data).
SSL_CIPHER_SUITES - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The cipher suites to enable when creating an SSLEngine for a connection.
SSL_ENGINE_FACTORY_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the SSL Engine Factory.
SSL_HOSTNAME_VALIDATION - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether or not to require validation that the hostname of the server certificate's common name matches the hostname of the server being connected to.
SSL_KEYSTORE_PASSWORD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The keystore password.
SSL_KEYSTORE_PATH - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The location of the keystore file.
SSL_TRUSTSTORE_PASSWORD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The truststore password.
SSL_TRUSTSTORE_PATH - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The location of the truststore file.
sslContext - Variable in class com.datastax.oss.driver.api.core.ssl.ProgrammaticSslEngineFactory
 
SslEngineFactory - Interface in com.datastax.oss.driver.api.core.ssl
Extension point to configure SSL based on the built-in JDK implementation.
startOf(long) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a "fake" time-based UUID that sorts as the smallest possible version 1 UUID generated at the provided timestamp.
startProfile(String) - Method in interface com.datastax.oss.driver.api.core.config.ProgrammaticDriverConfigLoaderBuilder
Starts the definition of a new profile.
Statement<SelfT extends Statement<SelfT>> - Interface in com.datastax.oss.driver.api.core.cql
A request to execute a CQL query.
StatementBuilder<SelfT extends StatementBuilder<SelfT,StatementT>,StatementT extends Statement<StatementT>> - Class in com.datastax.oss.driver.api.core.cql
Handle options common to all statement builders.
StatementBuilder() - Constructor for class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
StatementBuilder(StatementT) - Constructor for class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
STORAGE_PORT - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The storage port used by the DSE node.
STORAGE_PORT_SSL - Static variable in class com.datastax.dse.driver.api.core.metadata.DseNodeProperties
The encrypted storage port used by the DSE node.
STRING - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
subProtocol - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
subtractFrom(Temporal) - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
supportsReloading() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Whether this implementation supports programmatic reloading with the DriverConfigLoader.reload() method.
supportsShardingInfo() - Method in enum com.datastax.dse.driver.api.core.DseProtocolVersion
 
supportsShardingInfo() - Method in enum com.datastax.oss.driver.api.core.DefaultProtocolVersion
 
supportsShardingInfo() - Method in interface com.datastax.oss.driver.api.core.ProtocolVersion
Whether sharding info is supported in this protocol version
SYNC - Static variable in interface com.datastax.dse.driver.api.core.graph.GraphStatement
The type returned when a graph statement is executed synchronously.
SYNC - Static variable in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The type returned when a CQL statement is prepared synchronously.
SYNC - Static variable in interface com.datastax.oss.driver.api.core.cql.Statement
The type returned when a CQL statement is executed synchronously.
SyncAuthenticator - Interface in com.datastax.oss.driver.api.core.auth
An authenticator that performs all of its operations synchronously, on the calling thread.
SyncCqlSession - Interface in com.datastax.oss.driver.api.core.cql
A session that offers user-friendly methods to execute CQL requests synchronously.
SyntaxError - Exception in com.datastax.oss.driver.api.core.servererrors
A syntax error in a query.
SyntaxError(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.SyntaxError
 

T

TableMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A table in the schema metadata.
TEXT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type text to Java's String.
TEXT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
THREE - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
Throttled - Interface in com.datastax.oss.driver.api.core.session.throttling
A request that may be subjected to throttling by a RequestThrottler.
TIME - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type time to Java's LocalTime.
TIME - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
timeBased() - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Creates a new time-based (version 1) UUID.
timeout - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
timeout - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
timestamp - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
timestamp - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
TIMESTAMP - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type timestamp to Java's Instant, using the system's default time zone to parse and format CQL literals.
TIMESTAMP - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
TIMESTAMP_GENERATOR_CLASS - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
The class of the generator that assigns a microsecond timestamp to each request.
TIMESTAMP_GENERATOR_DRIFT_WARNING_INTERVAL - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How often the warning will be logged if timestamps keep drifting above the threshold.
TIMESTAMP_GENERATOR_DRIFT_WARNING_THRESHOLD - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
How far in the future timestamps are allowed to drift before the warning is logged.
TIMESTAMP_GENERATOR_FORCE_JAVA_CLOCK - Static variable in class com.datastax.oss.driver.api.core.config.TypedDriverOption
Whether to force the driver to use Java's millisecond-precision system clock.
TIMESTAMP_MILLIS_SYSTEM - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type timestamp to Java's long, representing the number of milliseconds since the Epoch, using the system's default time zone to parse and format CQL literals.
TIMESTAMP_MILLIS_UTC - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type timestamp to Java's long, representing the number of milliseconds since the Epoch, using the UTC time zone to parse and format CQL literals.
TIMESTAMP_UTC - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type timestamp to Java's Instant, using the UTC time zone to parse and format CQL literals.
timestampAt(ZoneId) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type timestamp to Java's Instant, using the given time zone to parse and format CQL literals.
TimestampGenerator - Interface in com.datastax.oss.driver.api.core.time
Generates client-side, microsecond-precision query timestamps.
timestampMillisAt(ZoneId) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type timestamp to Java's long, representing the number of milliseconds since the Epoch, using the given time zone to parse and format CQL literals.
TIMEUUID - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type timeuuid to Java's UUID.
TIMEUUID - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
TINYINT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type tinyint to Java's byte.
TINYINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
toBytes() - Method in interface com.datastax.oss.driver.api.core.cql.PagingState
Returns a representation of this object as a byte array.
toDegrees(double) - Method in enum com.datastax.dse.driver.api.core.graph.predicates.Geo.Unit
Convert distance to degrees (used internally only).
toHexString(ByteBuffer) - Static method in class com.datastax.oss.driver.api.core.data.ByteUtils
Converts a blob to its CQL hex string representation.
toHexString(byte[]) - Static method in class com.datastax.oss.driver.api.core.data.ByteUtils
Converts a blob to its CQL hex string representation.
token(String) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Search any instance of a certain token within the text property targeted (case insensitive).
Token - Interface in com.datastax.oss.driver.api.core.metadata.token
A token on the ring.
tokenFuzzy(String, int) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Supports fuzzy searches based on the Damerau-Levenshtein Distance, or Edit Distance algorithm after having tokenized the data stored (case insensitive).
TokenMap - Interface in com.datastax.oss.driver.api.core.metadata
Utility component to work with the tokens of a given driver instance.
tokenPrefix(String) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Search any instance of a certain token prefix within the text property targeted (case insensitive).
TokenRange - Interface in com.datastax.oss.driver.api.core.metadata.token
A range of tokens on the Cassandra ring.
tokenRegex(String) - Static method in interface com.datastax.dse.driver.api.core.graph.predicates.Search
Search any instance of the provided regular expression for the targeted property (case insensitive).
toString() - Method in class com.datastax.dse.driver.api.core.data.time.DateRange
Returns the string representation of this range, in a format compatible with Apache Solr DateRageField syntax
toString() - Method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Returns this bound as a Lucene-compliant string.
toString() - Method in class com.datastax.oss.driver.api.core.config.TypedDriverOption
 
toString() - Method in interface com.datastax.oss.driver.api.core.cql.Row
Returns an abstract representation of this object, that may not include the row's contents.
toString() - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
 
toString() - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
 
toString() - Method in interface com.datastax.oss.driver.api.core.data.TupleValue
Returns an abstract representation of this object, that may not include the tuple's contents.
toString() - Method in interface com.datastax.oss.driver.api.core.data.UdtValue
Returns an abstract representation of this object, that may not include the UDT's contents.
toString() - Method in class com.datastax.oss.driver.api.core.metadata.schema.FunctionSignature
 
toString() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
toString() - Method in class com.datastax.oss.driver.api.core.Version
 
TraceEvent - Interface in com.datastax.oss.driver.api.core.cql
An event in a QueryTrace.
tracing - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
translate(InetSocketAddress) - Method in interface com.datastax.oss.driver.api.core.addresstranslation.AddressTranslator
Translates an address reported by a Cassandra node into the address that the driver will use to connect.
traversalSource - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
TruncateException - Exception in com.datastax.oss.driver.api.core.servererrors
An error during a truncation operation.
TruncateException(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.TruncateException
 
TUPLE_VALUE - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
tupleOf(TupleType) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
Builds a new codec that maps a CQL tuple to the driver's TupleValue, for the given type definition.
tupleOf(DataType...) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
Builds a new, detached tuple type.
TupleType - Interface in com.datastax.oss.driver.api.core.type
 
TupleValue - Interface in com.datastax.oss.driver.api.core.data
Driver-side representation of a CQL tuple value.
TWO - Static variable in interface com.datastax.oss.driver.api.core.ConsistencyLevel
 
TypeCodec<JavaTypeT> - Interface in com.datastax.oss.driver.api.core.type.codec
Manages the two-way conversion between a CQL type and a Java type.
TypeCodecs - Class in com.datastax.oss.driver.api.core.type.codec
Constants and factory methods to obtain instances of the driver's default type codecs.
TypeCodecs() - Constructor for class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
TypedDriverOption<ValueT> - Class in com.datastax.oss.driver.api.core.config
A type-safe wrapper around DriverOption, that encodes the intended value type of each option.
TypedDriverOption(DriverOption, GenericType<ValueT>) - Constructor for class com.datastax.oss.driver.api.core.config.TypedDriverOption
 

U

UDT_VALUE - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
udtOf(UserDefinedType) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
Builds a new codec that maps a CQL user defined type to the driver's UdtValue, for the given type definition.
UdtValue - Interface in com.datastax.oss.driver.api.core.data
Driver-side representation of an instance of a CQL user defined type.
UnauthorizedException - Exception in com.datastax.oss.driver.api.core.servererrors
Indicates that a query cannot be performed due to the authorization restrictions of the logged user.
UnauthorizedException(Node, String) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.UnauthorizedException
 
UnavailableException - Exception in com.datastax.oss.driver.api.core.servererrors
Thrown when the coordinator knows there is not enough replicas alive to perform a query with the requested consistency level.
UnavailableException(Node, ConsistencyLevel, int, int) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.UnavailableException
 
UNBOUNDED - Static variable in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
The unbounded DateRangeBound instance.
UnfitClientException - Exception in com.datastax.dse.driver.api.core.servererrors
A server-side error triggered when DSE can't send asynchronous results back to the client.
UnfitClientException(Node, String) - Constructor for exception com.datastax.dse.driver.api.core.servererrors.UnfitClientException
 
unixTimestamp(UUID) - Static method in class com.datastax.oss.driver.api.core.uuid.Uuids
Returns the Unix timestamp contained by the provided time-based UUID.
UNLOGGED - Static variable in interface com.datastax.oss.driver.api.core.cql.BatchType
 
UNLOGGED_BATCH - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
unset(int) - Method in interface com.datastax.oss.driver.api.core.cql.Bindable
Unsets the ith value.
unset(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.cql.Bindable
Unsets the value for the first occurrence of id.
unset(String) - Method in interface com.datastax.oss.driver.api.core.cql.Bindable
Unsets the value for the first occurrence of name.
UnsupportedProtocolVersionException - Exception in com.datastax.oss.driver.api.core
Indicates that we've attempted to connect to a Cassandra node with a protocol version that it cannot handle (e.g., connecting to a C* 2.1 node with protocol version 4).
UnsupportedProtocolVersionException(EndPoint, String, List<ProtocolVersion>) - Constructor for exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
 
unwrap() - Method in interface com.datastax.oss.driver.api.core.metadata.token.TokenRange
Splits this range into a list of two non-wrapping ranges.
unwrap() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns the corresponding primitive type if this is a wrapper type; otherwise returns this itself.
upperBound(ZonedDateTime, DateRangePrecision) - Static method in class com.datastax.dse.driver.api.core.data.time.DateRangeBound
Creates a date range upper bound from the given date and precision.
UserDefinedType - Interface in com.datastax.oss.driver.api.core.type
 
UUID - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type uuid to Java's UUID.
UUID - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
UUID - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
Uuids - Class in com.datastax.oss.driver.api.core.uuid
Utility methods to help working with UUIDs, and more specifically, with time-based UUIDs (also known as Version 1 UUIDs).

V

V2_1_0 - Static variable in class com.datastax.oss.driver.api.core.Version
 
V2_2_0 - Static variable in class com.datastax.oss.driver.api.core.Version
 
V3 - Static variable in interface com.datastax.oss.driver.api.core.ProtocolVersion
 
V3_0_0 - Static variable in class com.datastax.oss.driver.api.core.Version
 
V4 - Static variable in interface com.datastax.oss.driver.api.core.ProtocolVersion
 
V4_0_0 - Static variable in class com.datastax.oss.driver.api.core.Version
 
V5 - Static variable in interface com.datastax.oss.driver.api.core.ProtocolVersion
 
V5_0_0 - Static variable in class com.datastax.oss.driver.api.core.Version
 
V6_7_0 - Static variable in class com.datastax.oss.driver.api.core.Version
 
V6_8_0 - Static variable in class com.datastax.oss.driver.api.core.Version
 
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.config.DseDriverOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.data.time.DateRangePrecision
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.DseProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.graph.PagingEnabledOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.graph.predicates.Geo.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata.Monotonicity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.metrics.DseNodeMetric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.dse.driver.api.core.metrics.DseSessionMetric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.config.DefaultDriverOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.cql.DefaultBatchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.DefaultConsistencyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.DefaultProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.loadbalancing.NodeDistance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.metadata.NodeState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.metadata.schema.ClusteringOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.metadata.schema.IndexKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.metrics.DefaultNodeMetric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.metrics.DefaultSessionMetric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.retry.RetryDecision
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.servererrors.DefaultWriteType
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.datastax.dse.driver.api.core.config.DseDriverOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.dse.driver.api.core.data.time.DateRangePrecision
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.dse.driver.api.core.DseProtocolVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.dse.driver.api.core.graph.PagingEnabledOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.dse.driver.api.core.graph.predicates.Geo.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.dse.driver.api.core.metadata.schema.DseFunctionMetadata.Monotonicity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.dse.driver.api.core.metrics.DseNodeMetric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.dse.driver.api.core.metrics.DseSessionMetric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.config.DefaultDriverOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.cql.DefaultBatchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.DefaultConsistencyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.DefaultProtocolVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.loadbalancing.NodeDistance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.metadata.NodeState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.metadata.schema.ClusteringOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.metadata.schema.IndexKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.metrics.DefaultNodeMetric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.metrics.DefaultSessionMetric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.retry.RetryDecision
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.datastax.oss.driver.api.core.servererrors.DefaultWriteType
Returns an array containing the constants of this enum type, in the order they are declared.
VARINT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
The default codec that maps CQL type varint to Java's BigInteger.
VARINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
Version - Class in com.datastax.oss.driver.api.core
A structured version number.
VIEW - Static variable in interface com.datastax.oss.driver.api.core.servererrors.WriteType
 
ViewMetadata - Interface in com.datastax.oss.driver.api.core.metadata.schema
A materialized view in the schema metadata.

W

wasApplied() - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveQueryMetadata
If the query that produced this result was a conditional update, indicates whether it was successfully applied.
wasApplied() - Method in interface com.datastax.dse.driver.api.core.cql.reactive.ReactiveRow
If the query that produced this result was a conditional update, indicates whether it was successfully applied.
wasApplied() - Method in interface com.datastax.oss.driver.api.core.AsyncPagingIterable
If the query that produced this result was a CQL conditional update, indicate whether it was successfully applied.
wasApplied() - Method in interface com.datastax.oss.driver.api.core.cql.AsyncResultSet
If the query that produced this result was a CQL conditional update, indicate whether it was successfully applied.
wasApplied() - Method in interface com.datastax.oss.driver.api.core.cql.ResultSet
If the query that produced this result was a CQL conditional update, indicate whether it was successfully applied.
wasApplied() - Method in interface com.datastax.oss.driver.api.core.PagingIterable
If the query that produced this result was a CQL conditional update, indicate whether it was successfully applied.
wasDataPresent() - Method in exception com.datastax.oss.driver.api.core.servererrors.ReadFailureException
Whether the actual data was amongst the received replica responses.
wasDataPresent() - Method in exception com.datastax.oss.driver.api.core.servererrors.ReadTimeoutException
Whether the actual data was amongst the received replica responses.
where(GenericTypeParameter<X>, GenericType<X>) - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Substitutes a free type variable with an actual type.
where(GenericTypeParameter<X>, Class<X>) - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Substitutes a free type variable with an actual type.
withApplicationName(String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
The name of the application using the created session.
withApplicationVersion(String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
The version of the application using the created session.
withAuthCredentials(String, String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Configures the session to use plaintext authentication with the given username and password.
withAuthCredentials(String, String, String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Configures the session to use DSE plaintext authentication with the given username and password, and perform proxy authentication with the given authorization id.
withAuthorizationId(String) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
Sets the authorization ID (allows proxy authentication).
withAuthProvider(AuthProvider) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withAuthProvider(AuthProvider) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Registers an authentication provider to use with the session.
withBoolean(DriverOption, boolean) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withBoolean(DriverOption, boolean) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withBooleanList(DriverOption, List<Boolean>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withBooleanList(DriverOption, List<Boolean>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withBytes(DriverOption, long) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withBytes(DriverOption, long) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withBytesList(DriverOption, List<Long>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withBytesList(DriverOption, List<Long>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withClass(DriverOption, Class<?>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
Note that this is just a shortcut to call OngoingConfigOptions.withString(DriverOption, String) with value.getName().
withClassLoader(ClassLoader) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withClassLoader(ClassLoader) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
The ClassLoader to use to reflectively load class names defined in configuration.
withClientId(UUID) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
A unique identifier for the created session.
withCloudProxyAddress(InetSocketAddress) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withCloudProxyAddress(InetSocketAddress) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Configures this SessionBuilder to use the provided Cloud proxy endpoint.
withCloudSecureConnectBundle(Path) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Configures this SessionBuilder for Cloud deployments by retrieving connection information from the provided Path.
withCloudSecureConnectBundle(URL) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Configures this SessionBuilder for Cloud deployments by retrieving connection information from the provided URL.
withCloudSecureConnectBundle(InputStream) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Configures this SessionBuilder for Cloud deployments by retrieving connection information from the provided InputStream.
withCodecRegistry(MutableCodecRegistry) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withCodecRegistry(MutableCodecRegistry) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Registers a CodecRegistry to use for the session.
withConfigLoader(DriverConfigLoader) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Sets the configuration loader to use.
withCredentials(String, String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for SessionBuilder.withAuthCredentials(String, String).
withCredentials(String, String, String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Deprecated.
this method only exists to ease the transition from driver 3, it is an alias for SessionBuilder.withAuthCredentials(String, String,String).
withDouble(DriverOption, double) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withDouble(DriverOption, double) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withDoubleList(DriverOption, List<Double>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withDoubleList(DriverOption, List<Double>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withDuration(DriverOption, Duration) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withDuration(DriverOption, Duration) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withDurationList(DriverOption, List<Duration>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withDurationList(DriverOption, List<Duration>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withExecutionProfile(DriverExecutionProfile) - Method in interface com.datastax.dse.driver.api.core.graph.DseGraphRemoteConnectionBuilder
Set a configuration profile that will be used for every traversal built using the remote connection.
withExecutionProfileName(String) - Method in interface com.datastax.dse.driver.api.core.graph.DseGraphRemoteConnectionBuilder
Set the name of an execution profile that will be used for every traversal using from the remote connection.
withInt(DriverOption, int) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withInt(DriverOption, int) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withIntList(DriverOption, List<Integer>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withIntList(DriverOption, List<Integer>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Sets the keyspace to connect the session to.
withKeyspace(String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
withLocalDatacenter(String, String) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withLocalDatacenter(String, String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Specifies the datacenter that is considered "local" by the load balancing policy.
withLocalDatacenter(String) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Alias to SessionBuilder.withLocalDatacenter(String, String) for the default profile.
withLocalDatacenters(Map<String, String>) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withLoginConfiguration(Configuration) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
Sets a login configuration that will be used to create a LoginContext.
withLoginConfiguration(Map<String, String>) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
Sets a login configuration that will be used to create a LoginContext.
withLong(DriverOption, long) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withLong(DriverOption, long) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withLongList(DriverOption, List<Long>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withLongList(DriverOption, List<Long>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withMetricRegistry(Object) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withMetricRegistry(Object) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
The metric registry object for storing driver metrics.
withNodeFilter(String, Predicate<Node>) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withNodeFilter(String, Predicate<Node>) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Adds a custom filter to include/exclude nodes for a particular execution profile.
withNodeFilter(Predicate<Node>) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Alias to SessionBuilder.withNodeFilter(String, Predicate) for the default profile.
withNodeFilters(Map<String, Predicate<Node>>) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withNodeStateListener(NodeStateListener) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withNodeStateListener(NodeStateListener) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Registers a node state listener to use with the session.
without(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
without(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withRequestTracker(RequestTracker) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withRequestTracker(RequestTracker) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Registers a request tracker to use with the session.
withSaslProtocol(String) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
Sets the SASL protocol name to use; should match the username of the Kerberos service principal used by the DSE server.
withSchemaChangeListener(SchemaChangeListener) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withSchemaChangeListener(SchemaChangeListener) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Registers a schema change listener to use with the session.
withSslContext(SSLContext) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Configures the session to use SSL with the given context.
withSslEngineFactory(SslEngineFactory) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withSslEngineFactory(SslEngineFactory) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
Registers an SSL engine factory for the session.
withStartupApplicationName(String) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withStartupApplicationVersion(String) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withStartupClientId(UUID) - Method in class com.datastax.oss.driver.api.core.session.ProgrammaticArguments.Builder
 
withString(DriverOption, String) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withString(DriverOption, String) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withStringList(DriverOption, List<String>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withStringList(DriverOption, List<String>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withStringMap(DriverOption, Map<String, String>) - Method in interface com.datastax.oss.driver.api.core.config.DriverExecutionProfile
 
withStringMap(DriverOption, Map<String, String>) - Method in interface com.datastax.oss.driver.api.core.config.OngoingConfigOptions
 
withSubject(Subject) - Method in class com.datastax.dse.driver.api.core.auth.DseGssApiAuthProviderBase.GssApiOptions.Builder
Sets a previously authenticated subject to reuse.
wrap(CqlSession) - Method in class com.datastax.dse.driver.api.core.DseSessionBuilder
Deprecated.
 
wrap(CqlSession) - Method in class com.datastax.oss.driver.api.core.CqlSessionBuilder
 
wrap(CqlSession) - Method in class com.datastax.oss.driver.api.core.session.SessionBuilder
 
wrap() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
Returns the corresponding wrapper type if this is a primitive type; otherwise returns this itself.
writeConsistencyLevel - Variable in class com.datastax.dse.driver.api.core.graph.GraphStatementBuilderBase
 
WriteFailureException - Exception in com.datastax.oss.driver.api.core.servererrors
A non-timeout error during a write query.
WriteFailureException(Node, ConsistencyLevel, int, int, WriteType, int, Map<InetAddress, Integer>) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.WriteFailureException
 
WriteTimeoutException - Exception in com.datastax.oss.driver.api.core.servererrors
A server-side timeout during a write query.
WriteTimeoutException(Node, ConsistencyLevel, int, int, WriteType) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.WriteTimeoutException
 
WriteType - Interface in com.datastax.oss.driver.api.core.servererrors
The type of a Cassandra write query.

X

X() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Point
Returns the X coordinate of this 2D point (or its longitude in Geographic Coordinate Systems).

Y

Y() - Method in interface com.datastax.dse.driver.api.core.data.geometry.Point
Returns the Y coordinate of this 2D point (or its latitude in Geographic Coordinate Systems).

Z

ZONED_DATE_TIME - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
ZONED_TIMESTAMP_PERSISTED - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type tuple<timestamp,text> to Java's ZonedDateTime, providing a pattern for maintaining timezone information in Cassandra.
ZONED_TIMESTAMP_SYSTEM - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type timestamp to Java's ZonedDateTime, using the system's default time zone.
ZONED_TIMESTAMP_SYSTEM - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
ZONED_TIMESTAMP_UTC - Static variable in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
A codec that maps CQL type timestamp to Java's ZonedDateTime, using the UTC time zone.
ZONED_TIMESTAMP_UTC - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
zonedTimestampAt(ZoneId) - Static method in class com.datastax.oss.driver.api.core.type.codec.ExtraTypeCodecs
Builds a new codec that maps CQL type timestamp to Java's ZonedDateTime.
zonedTimestampAt(ZoneId) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs

_

__getToken() - Method in class com.datastax.oss.driver.api.core.type.reflect.GenericType
This method is for internal use, DO NOT use it from client code.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links

Copyright © 2017–2024. All rights reserved.