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 _ 

A

accept(T) - Method in class com.datastax.oss.driver.internal.core.util.concurrent.ReplayingEventFilter
 
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 type.
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.
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeUuidCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeUuidCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
accepts(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
accepts(Class<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
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.
actualClusterName - Variable in exception com.datastax.oss.driver.internal.core.channel.ClusterNameMismatchException
 
add(BatchableStatement<?>) - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Adds a new statement to the batch.
add(BatchableStatement<?>) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
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
 
addAll(Iterable<? extends BatchableStatement<?>>) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
addContactPoint(InetSocketAddress) - Method in class com.datastax.oss.driver.api.core.ClusterBuilder
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.ClusterBuilder
Adds contact points to use for the initial connection to the cluster.
addContactPoints(Set<InetSocketAddress>) - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
addCustomPayload(String, ByteBuffer) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
added(DefaultNode) - Static method in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
addNamedValue(String, Object) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
addNode(Node) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultMetadata
 
addNode(InetSocketAddress) - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
AddNodeRefresh - Class in com.datastax.oss.driver.internal.core.metadata
 
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 - Variable in exception com.datastax.oss.driver.internal.core.channel.ClusterNameMismatchException
 
address() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
 
address - Variable in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
 
AddressTranslator - Interface in com.datastax.oss.driver.api.core.addresstranslation
Translates IP addresses received from Cassandra nodes into locally queriable addresses.
addressTranslator() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
addressTranslator() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
addStatement(BatchableStatement<?>) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
addStatements(Iterable<BatchableStatement<?>>) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
addStatements(BatchableStatement<?>...) - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
addTypeCodecs(TypeCodec<?>...) - Method in class com.datastax.oss.driver.api.core.ClusterBuilder
Registers additional codecs for custom type mappings.
adminEventExecutorGroup() - Method in class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
adminEventExecutorGroup() - Method in interface com.datastax.oss.driver.internal.core.context.NettyOptions
An event executor group that will be used to schedule all tasks not related to request I/O: cluster events, refreshing metadata, reconnection, etc.
AdminRequestHandler - Class in com.datastax.oss.driver.internal.core.adminrequest
Handles the lifecyle of an admin request (such as a node refresh or schema refresh query).
AdminRequestHandler(DriverChannel, Message, Duration, String, String) - Constructor for class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
AdminResult - Class in com.datastax.oss.driver.internal.core.adminrequest
 
AdminResult(Rows, AdminRequestHandler, ProtocolVersion) - Constructor for class com.datastax.oss.driver.internal.core.adminrequest.AdminResult
 
AdminResult.Row - Class in com.datastax.oss.driver.internal.core.adminrequest
 
afterBootstrapInitialized(Bootstrap) - Method in class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
afterBootstrapInitialized(Bootstrap) - Method in interface com.datastax.oss.driver.internal.core.context.NettyOptions
A hook invoked each time the driver creates a client bootstrap in order to open a channel.
afterChannelInitialized(Channel) - Method in class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
afterChannelInitialized(Channel) - Method in interface com.datastax.oss.driver.internal.core.context.NettyOptions
A hook invoked on each channel, right after the channel has initialized it.
allDone(List<CompletionStage<T>>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
 
AllNodesFailedException - Exception in com.datastax.oss.driver.api.core
Thrown when a query failed on all the coordinators it was tried on.
AllNodesFailedException(String, Map<Node, Throwable>) - Constructor for exception com.datastax.oss.driver.api.core.AllNodesFailedException
 
allocate(int) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
allocator() - Method in class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
allocator() - Method in interface com.datastax.oss.driver.internal.core.context.NettyOptions
The byte buffer allocator to use.
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
 
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.
areBoundStatementsIdempotent() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
ASCII - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
ASCII - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
asCql() - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
Returns the identifier in a format appropriate for concatenation in a CQL query.
asInternal() - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
Returns the identifier in the "internal" format.
asPrettyCql() - Method in class com.datastax.oss.driver.api.core.CqlIdentifier
Returns the identifier in a format appropriate for concatenation in a CQL query, using the simplest possible representation.
AsyncAutoCloseable - Interface in com.datastax.oss.driver.api.core
An object that can be closed in an asynchronous, non-blocking manner.
asyncResult() - Method in class com.datastax.oss.driver.internal.core.cql.CqlPrepareHandler
 
asyncResult() - Method in class com.datastax.oss.driver.internal.core.cql.CqlRequestHandler
 
asyncResult() - Method in interface com.datastax.oss.driver.internal.core.session.RequestHandler
Immediately returns an object that represents the pending request; that object will complete when the request is done.
AsyncResultSet - Interface in com.datastax.oss.driver.api.core.cql
The result of an asynchronous CQL query.
AtomicTimestampGenerator - Class in com.datastax.oss.driver.api.core.time
A timestamp generator that guarantees monotonically increasing timestamps across all client threads, and logs warnings when timestamps drift in the future.
AtomicTimestampGenerator(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.time.AtomicTimestampGenerator
 
attach(AttachmentPoint) - Method in interface com.datastax.oss.driver.api.core.detach.Detachable
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
attach(AttachmentPoint) - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.type.DefaultCustomType
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.type.DefaultListType
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
attach(AttachmentPoint) - Method in class com.datastax.oss.driver.internal.core.type.PrimitiveType
 
AttachmentPoint - Interface in com.datastax.oss.driver.api.core.detach
 
AuthenticationException - Exception in com.datastax.oss.driver.api.core.auth
Indicates an error during the authentication phase while connecting to a node.
AuthenticationException(SocketAddress, String) - Constructor for exception com.datastax.oss.driver.api.core.auth.AuthenticationException
 
AuthenticationException(SocketAddress, 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.
authProvider() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
The authentication provider, if authentication was configured.
authProvider() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
availableIds() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
 

B

BatchableStatement<T extends BatchableStatement<T>> - Interface in com.datastax.oss.driver.api.core.cql
A statement that can be added to a CQL batch.
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
 
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 - Enum 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
 
BIGINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
BigIntCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
BigIntCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
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.
bind(Object...) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
Bindable<T extends Bindable<T>> - 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
 
BLOB - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
BlobCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
BlobCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
BlockingOperation - Class in com.datastax.oss.driver.internal.core.util.concurrent
Safeguards against bad usage patterns in client code that could introduce deadlocks in the driver.
BlockingOperation() - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.BlockingOperation
 
BlockingOperation.SafeThreadFactory - Class in com.datastax.oss.driver.internal.core.util.concurrent
Marks threads as driver threads, so that they will be detected by BlockingOperation.checkNotDriverThread()
BOOLEAN - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
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
 
BooleanCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
BooleanCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
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
 
BoundStatementBuilder(PreparedStatement, ColumnDefinitions, 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() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
Returns a builder to construct an executable statement.
boundStatementBuilder() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
build() - Method in class com.datastax.oss.driver.api.core.ClusterBuilder
Convenience method to call ClusterBuilder.buildAsync() and block on the result.
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.internal.core.channel.DriverChannelOptions.Builder
 
build() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
build() - Method in class com.datastax.oss.driver.internal.core.type.UserDefinedTypeBuilder
 
buildAddressTranslator() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildAsync() - Method in class com.datastax.oss.driver.api.core.ClusterBuilder
Creates the cluster with the options set by this builder.
buildAuthProvider() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildChannelFactory() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildCodecRegistry(String, List<TypeCodec<?>>) - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildCompressor() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildControlConnection() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
builder() - Static method in interface com.datastax.oss.driver.api.core.Cluster
Returns a builder to create a new instance of the default implementation.
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 class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions
 
Builder() - Constructor for class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions.Builder
 
builder() - Static method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
Builder() - Constructor for class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
buildEventBus() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildFrameCodec() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildFromConfig(DriverContext, DriverOption, Class<T>) - Static method in class com.datastax.oss.driver.internal.core.util.Reflection
Tries to create an instance of a class, given a set of options defined in the driver configuration.
buildLoadBalancingPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildLoadBalancingPolicyWrapper() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildMetadataManager() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildNettyOptions() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildProtocolVersionRegistry() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildReconnectionPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildRetryPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildSpeculativeExecutionPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildSslEngineFactory() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildSslHandlerFactory() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildTimestampGenerator() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildTopologyMonitor() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
buildWriteCoalescer() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
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
 
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
 
ByteBufPrimitiveCodec - Class in com.datastax.oss.driver.internal.core.protocol
 
ByteBufPrimitiveCodec(ByteBufAllocator) - Constructor for class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 

C

cache - Variable in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
CacheKey(DataType, GenericType<?>) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry.CacheKey
 
CachingCodecRegistry - Class in com.datastax.oss.driver.internal.core.type.codec.registry
A codec registry that handles built-in type mappings, can be extended with a list of user-provided codecs, generates more complex codecs from those basic codecs, and caches generated codecs for reuse.
CachingCodecRegistry(String, TypeCodec<?>...) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
 
cancel(ResponseCallback) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
Cancels a callback, indicating that the client that wrote it is no longer interested in the answer.
canProcess(T) - Method in class com.datastax.oss.driver.internal.core.cql.CqlPrepareProcessor
 
canProcess(T) - Method in class com.datastax.oss.driver.internal.core.cql.CqlRequestProcessor
 
canProcess(T) - Method in interface com.datastax.oss.driver.internal.core.session.RequestProcessor
Whether the processor can handle a given request.
CassandraVersion - Class in com.datastax.oss.driver.api.core
The version of a Cassandra release.
changed(NodeState, NodeState, DefaultNode) - Static method in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
channel() - Method in class com.datastax.oss.driver.internal.core.control.ControlConnection
The channel currently used by this control connection.
channelActive(ChannelHandlerContext) - Method in class com.datastax.oss.driver.internal.core.channel.InFlightHandler
 
channelClass() - Method in class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
channelClass() - Method in interface com.datastax.oss.driver.internal.core.context.NettyOptions
The class to create Channel instances from.
channelClosed(Node) - Static method in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
ChannelEvent - Class in com.datastax.oss.driver.internal.core.channel
Events relating to driver channels.
ChannelEvent(ChannelEvent.Type, Node) - Constructor for class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
ChannelEvent.Type - Enum in com.datastax.oss.driver.internal.core.channel
 
ChannelFactory - Class in com.datastax.oss.driver.internal.core.channel
Builds DriverChannel objects for an instance of the driver.
ChannelFactory(InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.channel.ChannelFactory
 
channelFactory() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
channelFactory() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
channelInactive(ChannelHandlerContext) - Method in class com.datastax.oss.driver.internal.core.channel.InFlightHandler
 
channelOpened(Node) - Static method in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
ChannelPool - Class in com.datastax.oss.driver.internal.core.pool
The channel pool maintains a set of DriverChannel instances connected to a given node.
channelPoolFactory() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
channelPoolFactory() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
ChannelPoolFactory - Class in com.datastax.oss.driver.internal.core.pool
Just a level of indirection to make testing easier.
ChannelPoolFactory() - Constructor for class com.datastax.oss.driver.internal.core.pool.ChannelPoolFactory
 
channelRead(ChannelHandlerContext, Object) - Method in class com.datastax.oss.driver.internal.core.channel.InFlightHandler
 
checkNotDriverThread() - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.BlockingOperation
This method is invoked from each synchronous driver method, and checks that we are not on a driver thread.
clear() - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
Clears the batch, removing all the statements added so far.
clear() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
clearCustomPayload() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
clearNamedValues() - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
clearPositionalValues() - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
clearStatements() - Method in class com.datastax.oss.driver.api.core.cql.BatchStatementBuilder
 
Clock - Interface in com.datastax.oss.driver.internal.core.time
A small abstraction around system clock that aims to provide microsecond precision with the best accuracy possible.
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 class com.datastax.oss.driver.api.core.addresstranslation.PassThroughAddressTranslator
 
close() - Method in interface com.datastax.oss.driver.api.core.AsyncAutoCloseable
close() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Called when the cluster closes.
close() - Method in class com.datastax.oss.driver.api.core.connection.ExponentialReconnectionPolicy
 
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.loadbalancing.RoundRobinLoadBalancingPolicy
 
close() - Method in class com.datastax.oss.driver.api.core.retry.DefaultRetryPolicy
 
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 class com.datastax.oss.driver.api.core.specex.ConstantSpeculativeExecutionPolicy
 
close() - Method in class com.datastax.oss.driver.api.core.specex.NoSpeculativeExecutionPolicy
 
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.internal.core.channel.DriverChannel
Initiates a graceful shutdown: no new requests will be accepted, but all pending requests will be allowed to complete before the underlying channel is closed.
close() - Method in class com.datastax.oss.driver.internal.core.config.typesafe.DefaultDriverConfigLoader
 
close() - Method in class com.datastax.oss.driver.internal.core.metadata.LoadBalancingPolicyWrapper
 
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.
closeAsync() - Method in class com.datastax.oss.driver.internal.core.control.ControlConnection
 
closeAsync() - Method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
closeAsync() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
closeAsync() - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
closeAsync() - Method in class com.datastax.oss.driver.internal.core.metadata.NodeStateManager
 
closeAsync() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
 
closeAsync() - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
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.
closeFuture() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
Does not close the channel, but returns a future that will complete when it is completely closed.
closeFuture() - Method in class com.datastax.oss.driver.internal.core.control.ControlConnection
 
closeFuture() - Method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
closeFuture() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
closeFuture() - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
closeFuture() - Method in class com.datastax.oss.driver.internal.core.metadata.NodeStateManager
 
closeFuture() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
 
closeFuture() - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
closeStartedFuture() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
Returns a future that will complete when a graceful close has started, but not yet completed.
Cluster - Interface in com.datastax.oss.driver.api.core
An instance of the driver, that connects to a Cassandra cluster.
ClusterBuilder - Class in com.datastax.oss.driver.api.core
Helper class to build an instance of the default Cluster implementation.
ClusterBuilder() - Constructor for class com.datastax.oss.driver.api.core.ClusterBuilder
 
clusterName() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
This is the same as Cluster.getName(), it's exposed here for components that only have a reference to the context.
clusterName() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
ClusterNameMismatchException - Exception in com.datastax.oss.driver.internal.core.channel
Indicates that we've attempted to connect to a node with a cluster name that doesn't match that of the other nodes known to the driver.
ClusterNameMismatchException(SocketAddress, String, String) - Constructor for exception com.datastax.oss.driver.internal.core.channel.ClusterNameMismatchException
 
codecFor(DataType, GenericType<T>) - 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<T>) - 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) - 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(T) - 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.
codecFor(DataType, GenericType<T>) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
 
codecFor(DataType, Class<T>) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
 
codecFor(DataType) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
 
codecFor(T) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
 
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() - Method in interface com.datastax.oss.driver.api.core.detach.AttachmentPoint
 
CodecRegistry - Interface in com.datastax.oss.driver.api.core.type.codec.registry
 
codecRegistry() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
codecRegistry() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
codecRegistry() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
codecRegistry() - Method in class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
codecRegistry() - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
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.
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.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.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.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.internal - package com.datastax.oss.driver.internal
Internal implementation details of the driver.
com.datastax.oss.driver.internal.core - package com.datastax.oss.driver.internal.core
 
com.datastax.oss.driver.internal.core.adminrequest - package com.datastax.oss.driver.internal.core.adminrequest
Infrastructure to execute internal requests in the driver, for example control connection queries, or automatic statement preparation.
com.datastax.oss.driver.internal.core.channel - package com.datastax.oss.driver.internal.core.channel
Handling of a single connection to a Cassandra node.
com.datastax.oss.driver.internal.core.config - package com.datastax.oss.driver.internal.core.config
 
com.datastax.oss.driver.internal.core.config.typesafe - package com.datastax.oss.driver.internal.core.config.typesafe
Implementation of the driver configuration based on the Typesafe config library.
com.datastax.oss.driver.internal.core.context - package com.datastax.oss.driver.internal.core.context
 
com.datastax.oss.driver.internal.core.control - package com.datastax.oss.driver.internal.core.control
 
com.datastax.oss.driver.internal.core.cql - package com.datastax.oss.driver.internal.core.cql
 
com.datastax.oss.driver.internal.core.data - package com.datastax.oss.driver.internal.core.data
 
com.datastax.oss.driver.internal.core.metadata - package com.datastax.oss.driver.internal.core.metadata
 
com.datastax.oss.driver.internal.core.os - package com.datastax.oss.driver.internal.core.os
 
com.datastax.oss.driver.internal.core.pool - package com.datastax.oss.driver.internal.core.pool
 
com.datastax.oss.driver.internal.core.protocol - package com.datastax.oss.driver.internal.core.protocol
Specialization of the native protocol layer for the driver, based on Netty.
com.datastax.oss.driver.internal.core.session - package com.datastax.oss.driver.internal.core.session
 
com.datastax.oss.driver.internal.core.ssl - package com.datastax.oss.driver.internal.core.ssl
 
com.datastax.oss.driver.internal.core.time - package com.datastax.oss.driver.internal.core.time
 
com.datastax.oss.driver.internal.core.type - package com.datastax.oss.driver.internal.core.type
 
com.datastax.oss.driver.internal.core.type.codec - package com.datastax.oss.driver.internal.core.type.codec
 
com.datastax.oss.driver.internal.core.type.codec.registry - package com.datastax.oss.driver.internal.core.type.codec.registry
 
com.datastax.oss.driver.internal.core.type.util - package com.datastax.oss.driver.internal.core.type.util
 
com.datastax.oss.driver.internal.core.util - package com.datastax.oss.driver.internal.core.util
Internal utilities specific to Netty.
com.datastax.oss.driver.internal.core.util.concurrent - package com.datastax.oss.driver.internal.core.util.concurrent
 
compareTo(CassandraVersion) - Method in class com.datastax.oss.driver.api.core.CassandraVersion
 
CompletableFutures - Class in com.datastax.oss.driver.internal.core.util.concurrent
 
CompletableFutures() - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
 
completeFrom(CompletionStage<T>, CompletableFuture<T>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
Completes target with the outcome of source.
compressor() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
compressor() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
computeNewNodes() - Method in class com.datastax.oss.driver.internal.core.metadata.AddNodeRefresh
 
computeNewNodes() - Method in class com.datastax.oss.driver.internal.core.metadata.RemoveNodeRefresh
 
computeNext() - Method in class com.datastax.oss.driver.internal.core.util.CountingIterator
 
computeVIntSize(long) - Static method in class com.datastax.oss.driver.internal.core.type.util.VIntCoding
Compute the number of bytes that would be needed to encode a varint.
concat(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverOption
Concatenates two options to build a longer path.
concat(ByteBuf, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
config() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
config() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
ConfigChangeEvent - Enum in com.datastax.oss.driver.internal.core.config
An event triggered when the configuration was changed.
configLoader() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
configLoader() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
configProfile - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
configProfile - Variable in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
configProfileName - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
connect(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.Cluster
Convenience method to call Cluster.connectAsync(CqlIdentifier) and block for the result.
connect() - Method in interface com.datastax.oss.driver.api.core.Cluster
Convenience method to call Cluster.connectAsync() and block for the result.
connect(SocketAddress, DriverChannelOptions) - Method in class com.datastax.oss.driver.internal.core.channel.ChannelFactory
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.datastax.oss.driver.internal.core.channel.ConnectInitHandler
 
connectAsync(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.Cluster
Creates a new session to execute requests against a given keyspace.
connectAsync() - Method in interface com.datastax.oss.driver.api.core.Cluster
Creates a new session not tied to any keyspace.
connectAsync(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
ConnectInitHandler - Class in com.datastax.oss.driver.internal.core.channel
A handler that delays the promise returned by bootstrap.connect(), in order to run a custom initialization process before making the channel available to clients.
ConnectInitHandler() - Constructor for class com.datastax.oss.driver.internal.core.channel.ConnectInitHandler
 
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 - Enum in com.datastax.oss.driver.api.core
The consistency level of a request.
ConstantSpeculativeExecutionPolicy - Class in com.datastax.oss.driver.api.core.specex
A policy that schedules a configurable number of speculative executions, separated by a fixed delay.
ConstantSpeculativeExecutionPolicy(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.specex.ConstantSpeculativeExecutionPolicy
 
ContactPoints - Class in com.datastax.oss.driver.internal.core
Utility class to handle the initial contact points passed to the driver.
ContactPoints() - Constructor for class com.datastax.oss.driver.internal.core.ContactPoints
 
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(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
 
contains(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
contains(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
contains(String) - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
contains(CqlIdentifier) - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
context - Variable in class com.datastax.oss.driver.internal.core.channel.ChannelFactory
 
context - Variable in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
controlConnection() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
controlConnection() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
ControlConnection - Class in com.datastax.oss.driver.internal.core.control
Maintains a dedicated connection to a Cassandra node for administrative queries: schema refreshes, and cluster topology queries and events.
ControlConnection(InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.control.ControlConnection
 
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, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.CoordinatorException
 
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.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.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() - Method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
 
CoreDriverOption - Enum in com.datastax.oss.driver.api.core.config
Built-in driver options for the core driver.
CoreProtocolVersion - Enum in com.datastax.oss.driver.api.core
A protocol version supported by default by the driver.
COUNTER - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
COUNTER - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
CounterCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
CounterCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.CounterCodec
 
CountingIterator<T> - Class in com.datastax.oss.driver.internal.core.util
An iterator that knows in advance how many elements it will return, and maintains a counter as elements get returned.
CountingIterator(int) - Constructor for class com.datastax.oss.driver.internal.core.util.CountingIterator
 
CQL_DURATION - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
CqlDuration - Class in com.datastax.oss.driver.api.core.data
A duration, as defined in CQL.
CqlDurationCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
CqlDurationCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
CqlIdentifier - Class in com.datastax.oss.driver.api.core
The identifier of CQL element (keyspace, table, column, etc).
CqlPrepareHandler - Class in com.datastax.oss.driver.internal.core.cql
Handles the lifecycle of the preparation of a CQL statement.
CqlPrepareProcessor - Class in com.datastax.oss.driver.internal.core.cql
Handles the preparation of CQL queries.
CqlPrepareProcessor() - Constructor for class com.datastax.oss.driver.internal.core.cql.CqlPrepareProcessor
 
CqlRequestHandler - Class in com.datastax.oss.driver.internal.core.cql
Handles execution of a Statement.
CqlRequestProcessor - Class in com.datastax.oss.driver.internal.core.cql
 
CqlRequestProcessor() - Constructor for class com.datastax.oss.driver.internal.core.cql.CqlRequestProcessor
 
cqlType - Variable in class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry.CacheKey
 
createCodec(DataType, GenericType<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
 
CURRENT_TIME_MICROS_AVAILABLE - Static variable in class com.datastax.oss.driver.internal.core.os.Native
Whether Native.currentTimeMicros() is available on this system.
currentTimeMicros() - Static method in class com.datastax.oss.driver.internal.core.os.Native
The current time in microseconds, as returned by libc.gettimeofday(); can only be used if Native.CURRENT_TIME_MICROS_AVAILABLE is true.
currentTimeMicros() - Method in interface com.datastax.oss.driver.internal.core.time.Clock
Returns the difference, measured in microseconds, between the current time and and the Epoch (that is, midnight, January 1, 1970 UTC).
currentTimeMicros() - Method in class com.datastax.oss.driver.internal.core.time.JavaClock
 
currentTimeMicros() - Method in class com.datastax.oss.driver.internal.core.time.NativeClock
 
custom(DataType) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
custom(String) - Static method in class com.datastax.oss.driver.api.core.type.DataTypes
 
CustomCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
CustomCodec(CustomType) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
customPayload - Variable in class com.datastax.oss.driver.internal.core.session.RepreparePayload
 
customPayloadBuilder - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
CustomType - Interface in com.datastax.oss.driver.api.core.type
 
CycleDetector - Class in com.datastax.oss.driver.internal.core.util.concurrent
Detects cycles between a set of LazyReference instances.
CycleDetector(String) - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.CycleDetector
 

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.
DataTypeHelper - Class in com.datastax.oss.driver.internal.core.type
 
DataTypeHelper() - Constructor for class com.datastax.oss.driver.internal.core.type.DataTypeHelper
 
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
 
DATE - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
DateCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
DateCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
Debouncer<T,R> - Class in com.datastax.oss.driver.internal.core.util.concurrent
Debounces a sequence of events to smoothen temporary oscillations.
Debouncer(EventExecutor, Function<List<T>, R>, Consumer<R>, Duration, long) - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.Debouncer
Creates a new instance.
DECIMAL - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
DECIMAL - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
DecimalCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
DecimalCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
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
 
decode(ChannelHandlerContext, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.FrameDecoder
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
decode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
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
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
decodePrimitive(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
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 - Static variable in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions
No keyspace, no events, don't report available stream ids.
DEFAULT_CONFIG_SUPPLIER - Static variable in class com.datastax.oss.driver.internal.core.config.typesafe.DefaultDriverConfigLoader
 
DefaultAsyncResultSet - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultAsyncResultSet(ColumnDefinitions, ExecutionInfo, Queue<List<ByteBuffer>>, Session, InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
DefaultBatchStatement - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultBatchStatement(BatchType, List<BatchableStatement<?>>, String, DriverConfigProfile, String, Map<String, ByteBuffer>, Boolean, boolean, long, ByteBuffer) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
DefaultBoundStatement - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultBoundStatement(PreparedStatement, ColumnDefinitions, ByteBuffer[], String, DriverConfigProfile, String, Map<String, ByteBuffer>, Boolean, boolean, long, ByteBuffer, CodecRegistry, ProtocolVersion) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
DefaultCluster - Class in com.datastax.oss.driver.internal.core
 
DefaultCodecRegistry - Class in com.datastax.oss.driver.internal.core.type.codec.registry
The default codec registry implementation.
DefaultCodecRegistry(String, int, BiFunction<DefaultCodecRegistry.CacheKey, TypeCodec<?>, Integer>, int, BiConsumer<DefaultCodecRegistry.CacheKey, TypeCodec<?>>, TypeCodec<?>...) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry
Creates a new instance, with some amount of control over the cache behavior.
DefaultCodecRegistry(String, TypeCodec<?>...) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry
 
DefaultCodecRegistry.CacheKey - Class in com.datastax.oss.driver.internal.core.type.codec.registry
 
DefaultColumnDefinition - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultColumnDefinition(ColumnSpec, AttachmentPoint) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
DefaultColumnDefinitions - Class in com.datastax.oss.driver.internal.core.cql
 
defaultCqlProcessors(String) - Static method in class com.datastax.oss.driver.internal.core.session.RequestProcessorRegistry
 
DefaultCustomType - Class in com.datastax.oss.driver.internal.core.type
 
DefaultCustomType(String) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultCustomType
 
DefaultDriverConfigLoader - Class in com.datastax.oss.driver.internal.core.config.typesafe
The default loader; it is based on TypeSafe Config and reloads at a configurable interval.
DefaultDriverConfigLoader() - Constructor for class com.datastax.oss.driver.internal.core.config.typesafe.DefaultDriverConfigLoader
Builds a new instance with the default TypeSafe config loading rules (documented in ClusterBuilder.withConfigLoader(DriverConfigLoader)) and the core driver options.
DefaultDriverConfigLoader(Supplier<Config>, DriverOption[]...) - Constructor for class com.datastax.oss.driver.internal.core.config.typesafe.DefaultDriverConfigLoader
Builds an instance with custom arguments, if you want to load the configuration from somewhere else or have custom options.
DefaultDriverContext - Class in com.datastax.oss.driver.internal.core.context
Default implementation of the driver context.
DefaultDriverContext(DriverConfigLoader, List<TypeCodec<?>>) - Constructor for class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
DefaultExecutionInfo - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultExecutionInfo(Statement, Node, int, int, List<Map.Entry<Node, Throwable>>, ByteBuffer, Frame) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
DefaultListType - Class in com.datastax.oss.driver.internal.core.type
 
DefaultListType(DataType, boolean) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultListType
 
DefaultMapType - Class in com.datastax.oss.driver.internal.core.type
 
DefaultMapType(DataType, DataType, boolean) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
DefaultMetadata - Class in com.datastax.oss.driver.internal.core.metadata
This class is immutable, so that metadata changes are atomic for the client.
DefaultMetadata(Map<InetSocketAddress, Node>) - Constructor for class com.datastax.oss.driver.internal.core.metadata.DefaultMetadata
 
DefaultNettyOptions - Class in com.datastax.oss.driver.internal.core.context
 
DefaultNettyOptions(InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
DefaultNode - Class in com.datastax.oss.driver.internal.core.metadata
Implementation note: all the mutable state in this class is read concurrently, but only mutated from MetadataManager's admin thread.
DefaultNode(InetSocketAddress) - Constructor for class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
DefaultNodeInfo - Class in com.datastax.oss.driver.internal.core.metadata
 
DefaultNodeInfo.Builder - Class in com.datastax.oss.driver.internal.core.metadata
 
DefaultPreparedStatement - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultPreparedStatement(ByteBuffer, String, ColumnDefinitions, ColumnDefinitions, String, DriverConfigProfile, String, Map<String, ByteBuffer>, Boolean, CodecRegistry, ProtocolVersion, Map<String, ByteBuffer>) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
DefaultPrepareRequest - Class in com.datastax.oss.driver.internal.core.cql
For simplicity, this default implementation makes opinionated choices about *ForBoundStatements methods: these should be appropriate for most cases, but not all use cases are supported (for example, preparing with one profile and having the bound statements use another profile is not possible).
DefaultPrepareRequest(SimpleStatement) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
DefaultPrepareRequest(String) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
DefaultRetryPolicy - Class in com.datastax.oss.driver.api.core.retry
The default retry policy.
DefaultRetryPolicy(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.retry.DefaultRetryPolicy
 
DefaultRow - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultRow(ColumnDefinitions, List<ByteBuffer>, AttachmentPoint) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
DefaultRow(ColumnDefinitions, List<ByteBuffer>) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
DefaultSession - Class in com.datastax.oss.driver.internal.core.session
The session implementation.
DefaultSetType - Class in com.datastax.oss.driver.internal.core.type
 
DefaultSetType(DataType, boolean) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
DefaultSimpleStatement - Class in com.datastax.oss.driver.internal.core.cql
 
DefaultSimpleStatement(String, List<Object>, Map<String, Object>, String, DriverConfigProfile, Map<String, ByteBuffer>, Boolean, boolean, long, ByteBuffer) - Constructor for class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
DefaultSslEngineFactory - Class in com.datastax.oss.driver.api.core.ssl
Default SSL implementation.
DefaultSslEngineFactory(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.ssl.DefaultSslEngineFactory
Builds a new instance from the driver configuration.
DefaultTopologyMonitor - Class in com.datastax.oss.driver.internal.core.metadata
The default topology monitor, based on ControlConnection.
DefaultTopologyMonitor(InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
DefaultTupleType - Class in com.datastax.oss.driver.internal.core.type
 
DefaultTupleType(List<DataType>, AttachmentPoint) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
DefaultTupleType(List<DataType>) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
DefaultTupleValue - Class in com.datastax.oss.driver.internal.core.data
 
DefaultTupleValue(TupleType) - Constructor for class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
DefaultUdtValue - Class in com.datastax.oss.driver.internal.core.data
 
DefaultUdtValue(UserDefinedType) - Constructor for class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
DefaultUserDefinedType - Class in com.datastax.oss.driver.internal.core.type
 
DefaultUserDefinedType(CqlIdentifier, CqlIdentifier, List<CqlIdentifier>, List<DataType>, AttachmentPoint) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
DefaultUserDefinedType(CqlIdentifier, CqlIdentifier, List<CqlIdentifier>, List<DataType>) - Constructor for class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
DefaultWriteCoalescer - Class in com.datastax.oss.driver.internal.core.channel
Default write coalescing strategy.
DefaultWriteCoalescer(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.internal.core.channel.DefaultWriteCoalescer
 
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.
distance - Variable in class com.datastax.oss.driver.internal.core.metadata.DistanceEvent
 
DistanceEvent - Class in com.datastax.oss.driver.internal.core.metadata
Fired when the load balancing policy assigns a new distance to a host.
DistanceEvent(NodeDistance, DefaultNode) - Constructor for class com.datastax.oss.driver.internal.core.metadata.DistanceEvent
 
DOUBLE - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
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
 
DoubleCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
DoubleCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
doubleQuote(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Double quote the given string; double quotes are escaped.
downgrade(ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.ProtocolVersionRegistry
Downgrade to a lower version if the current version is not supported by the server.
DriverChannel - Class in com.datastax.oss.driver.internal.core.channel
A thin wrapper around a Netty Channel, to send requests to a Cassandra node and receive responses.
DriverChannelOptions - Class in com.datastax.oss.driver.internal.core.channel
Options for the creation of a driver channel.
DriverChannelOptions.Builder - Class in com.datastax.oss.driver.internal.core.channel
 
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.
DriverConfigProfile - Interface in com.datastax.oss.driver.api.core.config
A profile in the driver's configuration.
DriverContext - Interface in com.datastax.oss.driver.api.core.context
Holds common components that are shared throughout a driver instance.
DriverException - Exception in com.datastax.oss.driver.api.core
Base class for all exceptions thrown by the driver.
DriverException(String, 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 Cluster.connect(), when the underlying future was completed with a checked exception.
DriverExecutionException(Throwable) - Constructor for exception com.datastax.oss.driver.api.core.DriverExecutionException
 
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
 
DURATION - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
DURATION - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 

E

EMPTY - Static variable in class com.datastax.oss.driver.internal.core.metadata.DefaultMetadata
 
EmptyColumnDefinitions - Enum in com.datastax.oss.driver.internal.core.cql
The singleton that represents no column definitions (implemented as an enum which provides the serialization machinery for free).
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(T, ProtocolVersion) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
 
encode(ChannelHandlerContext, Frame, List<Object>) - Method in class com.datastax.oss.driver.internal.core.protocol.FrameEncoder
 
encode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
encode(CqlDuration, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
encode(ByteBuffer, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
encode(LocalDate, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
encode(BigDecimal, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
encode(InetAddress, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
encode(List<T>, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
encode(Map<K, V>, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
encode(Set<T>, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
encode(String, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
encode(LocalTime, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
encode(Instant, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
encode(UUID, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeUuidCodec
 
encode(TupleValue, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
encode(UdtValue, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
encode(UUID, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
encode(BigInteger, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
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
 
encodePrimitive(long, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
encodePrimitive(boolean, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
encodePrimitive(double, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
encodePrimitive(float, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
encodePrimitive(int, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
encodePrimitive(short, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
encodePrimitive(byte, ProtocolVersion) - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
endOfData() - Method in class com.datastax.oss.driver.internal.core.util.CountingIterator
 
equals(Object) - Method in class com.datastax.oss.driver.api.core.CassandraVersion
 
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.type.reflect.GenericType
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.metadata.DistanceEvent
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry.CacheKey
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.DefaultCustomType
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.DefaultListType
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
equals(Object) - Method in class com.datastax.oss.driver.internal.core.type.PrimitiveType
 
errorCodeString(int) - Static method in class com.datastax.oss.driver.internal.core.util.ProtocolUtils
Formats an error code for logs and error messages.
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 interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
Evaluate a challenge received from the server.
eventBus() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
EventBus - Class in com.datastax.oss.driver.internal.core.context
Barebones event bus implementation, that allows components to communicate without knowing about each other.
EventBus(String) - Constructor for class com.datastax.oss.driver.internal.core.context.EventBus
 
eventBus() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
eventCallback - Variable in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions
 
EventCallback - Interface in com.datastax.oss.driver.internal.core.channel
 
eventLoop() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
 
eventTypes - Variable in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions
What kind of protocol events to listen for.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.datastax.oss.driver.internal.core.channel.InFlightHandler
Called if an exception was thrown while processing an inbound event (i.e.
execute(Request<SyncResultT, AsyncResultT>) - Method in interface com.datastax.oss.driver.api.core.session.Session
Executes a request, and blocks until the result is available.
execute(Statement<?>) - Method in interface com.datastax.oss.driver.api.core.session.Session
Executes a CQL statement synchronously.
execute(String) - Method in interface com.datastax.oss.driver.api.core.session.Session
Executes a CQL statement synchronously.
execute(Request<SyncResultT, AsyncResultT>) - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
executeAsync(Request<SyncResultT, AsyncResultT>) - Method in interface com.datastax.oss.driver.api.core.session.Session
Executes a request, returning as soon as it has been scheduled, but generally before the result is available.
executeAsync(Statement<?>) - Method in interface com.datastax.oss.driver.api.core.session.Session
Executes a CQL statement asynchronously.
executeAsync(String) - Method in interface com.datastax.oss.driver.api.core.session.Session
Executes a CQL statement asynchronously.
executeAsync(Request<SyncResultT, AsyncResultT>) - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
ExecutionInfo - Interface in com.datastax.oss.driver.api.core.cql
Information about the execution of a query.
expectedClusterName - Variable in exception com.datastax.oss.driver.internal.core.channel.ClusterNameMismatchException
 
ExponentialReconnectionPolicy - Class in com.datastax.oss.driver.api.core.connection
A reconnection policy that waits exponentially longer between each reconnection attempt (but keeps a constant delay once a maximum delay is reached).
ExponentialReconnectionPolicy(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.connection.ExponentialReconnectionPolicy
Builds a new instance.
extractFrame(ChannelHandlerContext, ByteBuf, int, int) - Method in class com.datastax.oss.driver.internal.core.protocol.FrameDecoder
 

F

failedFuture(Throwable) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
 
fetchNextPage() - Method in interface com.datastax.oss.driver.api.core.cql.AsyncResultSet
Fetch the next page of results asynchronously.
fetchNextPage() - Method in interface com.datastax.oss.driver.api.core.cql.ResultSet
Forces the driver to fetch the next page of results, regardless of whether the current page is exhausted.
fetchNextPage() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
fetchNextPage() - Method in class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 
fetchNextPage() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
fire(Object) - Method in class com.datastax.oss.driver.internal.core.context.EventBus
Sends an event that will notify any registered listener for that class.
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
 
firstIndexOf(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
firstIndexOf(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
firstIndexOf(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
firstIndexOf(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
firstIndexOf(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
firstIndexOf(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
firstIndexOf(String) - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
firstIndexOf(CqlIdentifier) - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
firstIndexOf(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
firstIndexOf(String) - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
firstIndexOf(String) - Method in class com.datastax.oss.driver.internal.core.data.IdentifierIndex
Returns the first occurrence of a given name, given the matching rules described in AccessibleByName, or -1 if it's not in the list.
firstIndexOf(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.data.IdentifierIndex
Returns the first occurrence of a given identifier, or -1 if it's not in the list.
firstIndexOf(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
firstIndexOf(String) - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
FLOAT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
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
 
FloatCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
FloatCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
forceClose() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
Initiates a forced shutdown: any pending request will be aborted and the underlying channel will be closed.
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.
forceCloseAsync() - Method in class com.datastax.oss.driver.internal.core.control.ControlConnection
 
forceCloseAsync() - Method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
forceCloseAsync() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
forceCloseAsync() - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
forceCloseAsync() - Method in class com.datastax.oss.driver.internal.core.metadata.NodeStateManager
 
forceCloseAsync() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
 
forceCloseAsync() - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
forceDown(InetSocketAddress) - Static method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
Forces the driver to set a node down.
ForceReloadConfigEvent - Enum in com.datastax.oss.driver.internal.core.config
An event that forces an immediate reload of the configuration.
forceUp(InetSocketAddress) - Static method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
Cancels a previous TopologyEvent.forceDown(InetSocketAddress) event for the node.
format(T) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
 
format(Long) - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
format(ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
format(Boolean) - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
format(CqlDuration) - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
format(ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
format(LocalDate) - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
format(BigDecimal) - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
format(Double) - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
format(Float) - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
format(InetAddress) - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
format(Integer) - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
format(List<T>) - Method in class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
format(Map<K, V>) - Method in class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
format(Set<T>) - Method in class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
format(Short) - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
format(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
format(LocalTime) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
format(Instant) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
format(UUID) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeUuidCodec
 
format(Byte) - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
format(TupleValue) - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
format(UdtValue) - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
format(UUID) - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
format(BigInteger) - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
forNegotiation(SocketAddress, List<ProtocolVersion>) - Static method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
 
forSingleAttempt(SocketAddress, ProtocolVersion) - Static method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
 
frameCodec() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
frameCodec() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
FrameDecoder - Class in com.datastax.oss.driver.internal.core.protocol
 
FrameDecoder(FrameCodec<ByteBuf>, int) - Constructor for class com.datastax.oss.driver.internal.core.protocol.FrameDecoder
 
FrameDecodingException - Exception in com.datastax.oss.driver.internal.core.protocol
Wraps an error while decoding an incoming protocol frame.
FrameDecodingException(int, Throwable) - Constructor for exception com.datastax.oss.driver.internal.core.protocol.FrameDecodingException
 
FrameEncoder - Class in com.datastax.oss.driver.internal.core.protocol
 
FrameEncoder(FrameCodec<ByteBuf>, int) - Constructor for class com.datastax.oss.driver.internal.core.protocol.FrameEncoder
 
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.
fromCode(int) - Static method in enum com.datastax.oss.driver.api.core.ConsistencyLevel
 
fromCode(int) - Method in class com.datastax.oss.driver.internal.core.ProtocolVersionRegistry
 
fromCql(String) - Static method in class com.datastax.oss.driver.api.core.CqlIdentifier
Creates an identifier from its CQL form.
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
 
fromInternal(String) - Static method in class com.datastax.oss.driver.api.core.CqlIdentifier
Creates an identifier from its internal form.
fromName(String) - Method in class com.datastax.oss.driver.internal.core.ProtocolVersionRegistry
 
fromProtocolSpec(RawType, AttachmentPoint) - Static method in class com.datastax.oss.driver.internal.core.type.DataTypeHelper
 
fromProtocolString(String) - Static method in enum com.datastax.oss.driver.internal.core.metadata.SchemaElementKind
 
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
 

G

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
 
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(CqlIdentifier, TypeCodec<T>) - 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<T>) - 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<T>) - 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<T>) - 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<T>) - 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<T>) - 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<T>) - 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<T>) - 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<T>) - 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(int) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
get(int) - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
get() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.LazyReference
 
getAddedOptions() - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
The extra options that were added with withXxx methods.
getAddress() - Method in exception com.datastax.oss.driver.api.core.auth.AuthenticationException
The address of the node that encountered the error.
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.
getAddress() - Method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
The address of the node that threw the error.
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.
getAttachmentPoint() - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
getAttachmentPoint() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getAttachmentPoint() - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
getAttachmentPoint() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
getAttemptedVersions() - Method in exception com.datastax.oss.driver.api.core.UnsupportedProtocolVersionException
The versions that were attempted.
getAvailableWithoutFetching() - Method in interface com.datastax.oss.driver.api.core.cql.ResultSet
The number of rows that can be returned from this result set before a blocking background query needs to be performed to retrieve more results.
getAvailableWithoutFetching() - Method in class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 
getAvailableWithoutFetching() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
getBaseDelayMs() - Method in class com.datastax.oss.driver.api.core.connection.ExponentialReconnectionPolicy
The base delay in milliseconds for this policy (e.g.
getBaseProfile() - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
The original profile in the driver's configuration that this profile was derived from.
getBatchType() - Method in interface com.datastax.oss.driver.api.core.cql.BatchStatement
 
getBatchType() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
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.
getBoolean(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
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.
getBoolean(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getBoolean(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
getBroadcastAddress() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The node's broadcast address.
getBroadcastAddress() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getBroadcastAddress() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getBroadcastAddress() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
The node's broadcast address.
getBuildLabel() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
The build label if there is one.
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.
getByteBuffer(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getBytes(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
Returns a size in bytes.
getBytes(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
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.
getBytesUnsafe(int) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getBytesUnsafe(int) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
getBytesUnsafe(int) - Method in class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
getBytesUnsafe(int) - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
getCachedCodec(DataType, GenericType<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
Gets a complex codec from the cache.
getCachedCodec(DataType, GenericType<?>) - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry
 
getCassandraVersion() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
 
getCassandraVersion() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getCassandraVersion() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getCassandraVersion() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
The Cassandra version that this node runs.
getChannel(Node, String) - Method in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
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.
getClassName() - Method in class com.datastax.oss.driver.internal.core.type.DefaultCustomType
 
getClusterName() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
 
getCode() - Method in enum com.datastax.oss.driver.api.core.CoreProtocolVersion
 
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).
getColumnDefinitions() - Method in interface com.datastax.oss.driver.api.core.cql.AsyncResultSet
 
getColumnDefinitions() - Method in interface com.datastax.oss.driver.api.core.cql.ResultSet
 
getColumnDefinitions() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
getColumnDefinitions() - Method in class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 
getColumnDefinitions() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
getCompleted(CompletableFuture<T>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
Get the result now, when we know for sure that the future is complete.
getComponentTypes() - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
getComponentTypes() - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
getConfigProfile() - Method in interface com.datastax.oss.driver.api.core.session.Request
The configuration profile to use for execution.
getConfigProfile() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
getConfigProfile() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getConfigProfile() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getConfigProfile() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getConfigProfileForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The configuration profile to use for the bound statements that will be created from the prepared statement.
getConfigProfileForBoundStatements() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getConfigProfileName() - Method in interface com.datastax.oss.driver.api.core.session.Request
The name of the driver configuration profile that will be used for execution.
getConfigProfileName() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
getConfigProfileName() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getConfigProfileName() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getConfigProfileName() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getConfigProfileNameForBoundStatements() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
The name of the driver configuration profile to use for the bound statements that will be created from the prepared statement.
getConfigProfileNameForBoundStatements() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getConnectAddress() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
The address that the driver uses to connect to the node.
getConnectAddress() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getConnectAddress() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getConnectAddress() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
The address that the driver uses to connect to the node.
getConsistencyLevel(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
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.
getConsistencyLevel(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
getContext() - Method in interface com.datastax.oss.driver.api.core.Cluster
Returns a context that provides access to all the policies used by this driver instance.
getContext() - Method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
getCoordinator() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The node that was used as a coordinator to successfully complete the query.
getCoordinator() - Method in exception com.datastax.oss.driver.api.core.servererrors.CoordinatorException
 
getCoordinator() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
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 interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.CounterCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeUuidCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
getCqlType() - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
getCustomPayload() - Method in interface com.datastax.oss.driver.api.core.session.Request
Returns the custom payload to send alongside the request.
getCustomPayload() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
getCustomPayload() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getCustomPayload() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getCustomPayload() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
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.
getCustomPayloadForBoundStatements() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getDatacenter() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
 
getDatacenter() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getDatacenter() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getDatacenter() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
The data center that this node belongs to, according to the Cassandra 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
 
getDefaultProfile() - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypeSafeDriverConfig
 
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.
getDistance() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
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.
getDouble(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getDSEPatch() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
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.DriverConfigProfile
 
getDuration(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
getEffectiveOptions() - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
The actual options that will be used to answer getXxx calls.
getElementType() - Method in interface com.datastax.oss.driver.api.core.type.ListType
 
getElementType() - Method in interface com.datastax.oss.driver.api.core.type.SetType
 
getElementType() - Method in class com.datastax.oss.driver.internal.core.type.DefaultListType
 
getElementType() - Method in class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
getErrors() - Method in exception com.datastax.oss.driver.api.core.AllNodesFailedException
The details of the individual error on each node.
getErrors() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The errors encountered on previous coordinators, if any.
getErrors() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
getExecutionInfo() - Method in interface com.datastax.oss.driver.api.core.cql.AsyncResultSet
 
getExecutionInfo() - Method in interface com.datastax.oss.driver.api.core.cql.ResultSet
The execution information for the last query performed for this result set.
getExecutionInfo() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
getExecutionInfo() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
getExecutionInfos() - Method in interface com.datastax.oss.driver.api.core.cql.ResultSet
The execution information for all the queries that have been performed so far to assemble this result set.
getExecutionInfos() - Method in class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 
getExecutionInfos() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
getExtras() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
An additional map of free-form properties.
getExtras() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getExtras() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getExtras() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
An additional map of free-form properties, that can be used by custom implementations.
getFailed(CompletableFuture<?>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
Get the error now, when we know for sure that the future is failed.
getFieldNames() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getFieldNames() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
getFieldTypes() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getFieldTypes() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
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.
getId() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
A unique identifier for this prepared statement.
getId() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
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).
getIncomingPayload() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
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.
getInetAddress(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getInitialConfig() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Loads the first configuration that will be used to initialize the driver.
getInitialConfig() - Method in class com.datastax.oss.driver.internal.core.config.typesafe.DefaultDriverConfigLoader
 
getInitialKeyspaceName() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
The keyspace with which the pool was initialized (therefore a constant, it's not updated if the keyspace is switched later).
getInstance(boolean) - Static method in interface com.datastax.oss.driver.internal.core.time.Clock
Returns the best implementation for the current platform.
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.DriverConfigProfile
 
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.
getInt(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
getInteger(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getJavaType() - Method in exception com.datastax.oss.driver.api.core.type.codec.CodecNotFoundException
 
getJavaType() - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
getJavaType() - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinition
 
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.session.Request
NOT YET SUPPORTED -- the CQL keyspace to associate with the query.
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.session.Session
The keyspace that this session is currently connected to.
getKeyspace() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getKeyspace() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
getKeyspace() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getKeyspace() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
getKeyspace() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getKeyspace() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getKeyspace() - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
getKeyspace() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
getKeyType() - Method in interface com.datastax.oss.driver.api.core.type.MapType
 
getKeyType() - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
getList(CqlIdentifier, Class<T>) - 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<T>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java list.
getList(String, Class<T>) - 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.
getListenAddress() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getListenAddress() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getListenAddress() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
The node's listen address.
getListOfString(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
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.
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.
getMajor() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
The major version number.
getMap(CqlIdentifier, Class<K>, Class<V>) - 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<K>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java map.
getMap(String, Class<K>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java map.
getMapOfStringToByteBuffer(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getMapOfStringToString(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getMapOfUuidToByteBuffer(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getMaxDelayMs() - Method in class com.datastax.oss.driver.api.core.connection.ExponentialReconnectionPolicy
The maximum delay in milliseconds between reconnection attempts for this policy.
getMetadata() - Method in interface com.datastax.oss.driver.api.core.Cluster
Returns a snapshot of the Cassandra cluster's topology and schema metadata.
getMetadata() - Method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
getMetadata() - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
getMinor() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
The minor version number.
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.Cluster
The unique name identifying this cluster.
getName() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinition
 
getName() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
getName() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
getName() - Method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
getName() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
getName() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.LazyReference
 
getNamedProfile(String) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfig
 
getNamedProfile(String) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypeSafeDriverConfig
 
getNamedProfiles() - Method in interface com.datastax.oss.driver.api.core.config.DriverConfig
Returns an immutable view of all the named profiles.
getNamedProfiles() - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypeSafeDriverConfig
 
getNamedValues() - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
 
getNamedValues() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getNanoseconds() - Method in class com.datastax.oss.driver.api.core.data.CqlDuration
Returns the number of nanoseconds in this duration.
getNewNodeInfo(InetSocketAddress) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
getNewNodeInfo(InetSocketAddress) - Method in interface com.datastax.oss.driver.internal.core.metadata.TopologyMonitor
Invoked when the driver needs to get information about a newly discovered node.
getNode() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
 
getNodes() - Method in interface com.datastax.oss.driver.api.core.metadata.Metadata
The nodes known to the driver, indexed by the address that it uses to connect to them.
getNodes() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultMetadata
 
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.
getOpenConnections() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getPagingState() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The paging state of the query.
getPagingState() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
 
getPagingState() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
getPagingState() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getPagingState() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
getPagingState() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getPatch() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
The patch version number.
getPath() - Method in enum com.datastax.oss.driver.api.core.config.CoreDriverOption
 
getPath() - Method in interface com.datastax.oss.driver.api.core.config.DriverOption
 
getPools() - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
getPositionalValues() - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
 
getPositionalValues() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getPreparedStatement() - Method in interface com.datastax.oss.driver.api.core.cql.BoundStatement
The prepared statement that was used to create this statement.
getPreparedStatement() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getPreReleaseLabels() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
The pre-release labels if relevant, i.e.
getProtocolCode() - Method in enum com.datastax.oss.driver.api.core.ConsistencyLevel
 
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
 
getProtocolCode() - Method in class com.datastax.oss.driver.internal.core.type.PrimitiveType
 
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
 
getQuery() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
getQuery() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPrepareRequest
 
getQuery() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getRack() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
 
getRack() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getRack() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getRack() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
The rack that this node belongs to, according to the Cassandra snitch.
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.
getRepreparePayload() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
getRepreparePayloads() - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
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).
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.
getResultSetDefinitions() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
getSet(CqlIdentifier, Class<T>) - 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<T>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByIndex
Returns the ith value as a Java set.
getSet(String, Class<T>) - Method in interface com.datastax.oss.driver.api.core.data.GettableByName
Returns the value for the first occurrence of name as a Java set.
getSetOfString(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
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.
getSpeculativeExecutionCount() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The number of speculative executions that were started for this query.
getSpeculativeExecutionCount() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
getState() - Method in interface com.datastax.oss.driver.api.core.metadata.Node
 
getState() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
getStatement() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The statement that was executed.
getStatement() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
getString(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
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.
getString(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getString(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
getStringList(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
getStringList(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
getSuccessfulExecutionIndex() - Method in interface com.datastax.oss.driver.api.core.cql.ExecutionInfo
The index of the execution that completed this query.
getSuccessfulExecutionIndex() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
getTable() - Method in interface com.datastax.oss.driver.api.core.cql.ColumnDefinition
 
getTable() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
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.
gettimeofday(Native.Timeval, Pointer) - Method in interface com.datastax.oss.driver.internal.core.os.Native.LibC
 
getTimestamp() - Method in interface com.datastax.oss.driver.api.core.cql.Statement
 
getTimestamp() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
getTimestamp() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getTimestamp() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
getTokens() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo
 
getTokens() - Method in interface com.datastax.oss.driver.internal.core.metadata.NodeInfo
The tokens that this node owns on the ring.
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(int) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getType() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
getType(int) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
getType(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
getType(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
getType() - Method in class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
getType(int) - Method in class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
getType() - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
getType(int) - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
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.
getUninterruptibly(CompletionStage<T>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
 
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.
getUuid(String) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult.Row
 
getValues() - Method in interface com.datastax.oss.driver.api.core.cql.BoundStatement
The values to bind, in their serialized form.
getValues() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
getValueType() - Method in interface com.datastax.oss.driver.api.core.type.MapType
 
getValueType() - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
getVariableDefinitions() - Method in interface com.datastax.oss.driver.api.core.cql.PreparedStatement
A description of the bind variables of this prepared statement.
getVariableDefinitions() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultPreparedStatement
 
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).
getWarnings() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultExecutionInfo
 
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.

H

hashCode() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
 
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.type.reflect.GenericType
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.metadata.DistanceEvent
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry.CacheKey
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.DefaultCustomType
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.DefaultListType
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
hashCode() - Method in class com.datastax.oss.driver.internal.core.type.PrimitiveType
 
hasMorePages() - Method in interface com.datastax.oss.driver.api.core.cql.AsyncResultSet
Whether there are more pages of results.
hasMorePages() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
hasNext() - Method in class com.datastax.oss.driver.internal.core.util.CountingIterator
 
hasNextPage() - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult
 
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
 
highestNonBeta() - Method in class com.datastax.oss.driver.internal.core.ProtocolVersionRegistry
 
holdStreamId() - Method in interface com.datastax.oss.driver.internal.core.channel.ResponseCallback
Whether to hold the stream id beyond the first response.

I

id - Variable in class com.datastax.oss.driver.internal.core.session.RepreparePayload
 
idempotent - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
IdentifierIndex - Class in com.datastax.oss.driver.internal.core.data
Indexes an ordered list of identifiers.
IdentifierIndex(List<CqlIdentifier>) - Constructor for class com.datastax.oss.driver.internal.core.data.IdentifierIndex
 
INET - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
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
 
InetCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
InetCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
InFlightHandler - Class in com.datastax.oss.driver.internal.core.channel
Manages requests that are currently executing on a channel.
init(Set<Node>, LoadBalancingPolicy.DistanceReporter) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Initializes this policy with the nodes discovered during driver initialization.
init(Set<Node>, LoadBalancingPolicy.DistanceReporter) - Method in class com.datastax.oss.driver.api.core.loadbalancing.RoundRobinLoadBalancingPolicy
 
init(boolean) - Method in class com.datastax.oss.driver.internal.core.control.ControlConnection
 
init(InternalDriverContext, Set<InetSocketAddress>) - Static method in class com.datastax.oss.driver.internal.core.DefaultCluster
 
init() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
init() - Method in class com.datastax.oss.driver.internal.core.metadata.LoadBalancingPolicyWrapper
 
init() - Method in interface com.datastax.oss.driver.internal.core.metadata.TopologyMonitor
Triggers the initialization of the monitor.
init(Node, CqlIdentifier, NodeDistance, InternalDriverContext, String) - Static method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
Initializes a new pool.
init(Node, CqlIdentifier, NodeDistance, InternalDriverContext, String) - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPoolFactory
 
init(InternalDriverContext, CqlIdentifier, String) - Static method in class com.datastax.oss.driver.internal.core.session.DefaultSession
 
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 interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
Obtain an initial response token for initializing the SASL handshake.
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
 
INT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
IntCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
IntCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
INTEGER - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
InternalDriverContext - Interface in com.datastax.oss.driver.internal.core.context
Extends the driver context with additional components that are not exposed by our public API.
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
 
ioEventLoopGroup() - Method in class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
ioEventLoopGroup() - Method in interface com.datastax.oss.driver.internal.core.context.NettyOptions
The event loop group that will be used for I/O.
isBeta() - Method in enum com.datastax.oss.driver.api.core.CoreProtocolVersion
 
isBeta() - Method in interface com.datastax.oss.driver.api.core.ProtocolVersion
Whether the protocol version is in a beta status.
isDefined(DriverOption) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
isDefined(DriverOption) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
isDetached() - Method in interface com.datastax.oss.driver.api.core.detach.Detachable
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
isDetached() - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.type.DefaultCustomType
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.type.DefaultListType
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
isDetached() - Method in class com.datastax.oss.driver.internal.core.type.PrimitiveType
 
isDoubleQuoted(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Return true if the given string is surrounded by double quotes, and false otherwise.
isForceEvent() - Method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
 
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 class com.datastax.oss.driver.internal.core.type.DefaultListType
 
isFrozen() - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
isFrozen() - Method in class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
isFullyFetched() - Method in interface com.datastax.oss.driver.api.core.cql.ResultSet
Whether all pages have been fetched from the database.
isFullyFetched() - Method in class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 
isFullyFetched() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
isIdempotent() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
Whether the request is idempotent; that is, whether applying the request twice yields the same result.
isIdempotent() - Method in interface com.datastax.oss.driver.api.core.session.Request
Whether the request is idempotent; that is, whether applying the request twice yields the same result.
isIdempotent() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
isIdempotent() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
isIdempotent() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
isIdempotent - Variable in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
isInvalidKeyspace() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
Whether all channels failed due to an invalid keyspace.
isLongLiteral(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Check whether the given string corresponds to a valid CQL long literal.
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.
isQuoted(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Return true if the given string is surrounded by single quotes, 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.
isReconnecting() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
isRunning() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.Reconnection
 
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.
isTracing() - Method in interface com.datastax.oss.driver.api.core.cql.PrepareRequest
 
isTracing() - Method in interface com.datastax.oss.driver.api.core.session.Request
Whether tracing information should be recorded for this request.
isTracing() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
isTracing() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
isTracing() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
iterator() - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult
This consumes the result's data and can be called only once.
iterator() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
iterator() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
iterator() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
iterator() - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
iterator() - Method in class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 
iterator() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 

J

JavaClock - Class in com.datastax.oss.driver.internal.core.time
 
JavaClock() - Constructor for class com.datastax.oss.driver.internal.core.time.JavaClock
 
javaType - Variable in class com.datastax.oss.driver.internal.core.type.codec.registry.DefaultCodecRegistry.CacheKey
 
JdkSslHandlerFactory - Class in com.datastax.oss.driver.internal.core.ssl
SSL handler factory used when JDK-based SSL was configured through the driver's public API.
JdkSslHandlerFactory(SslEngineFactory) - Constructor for class com.datastax.oss.driver.internal.core.ssl.JdkSslHandlerFactory
 

K

keyspace - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
keyspace - Variable in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions
 
keyspace - Variable in class com.datastax.oss.driver.internal.core.session.RepreparePayload
The keyspace that is set independently from the query string (see CASSANDRA-10145)
keyspace - Variable in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 

L

LazyReference<T> - Class in com.datastax.oss.driver.internal.core.util.concurrent
Holds a reference to an object that is initialized on first access.
LazyReference(String, Supplier<T>, CycleDetector) - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.LazyReference
 
ListCodec<T> - Class in com.datastax.oss.driver.internal.core.type.codec
 
ListCodec(DataType, TypeCodec<T>) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
listOf(TypeCodec<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
listOf(DataType) - 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
 
ListType - Interface in com.datastax.oss.driver.api.core.type
 
loadBalancingPolicy() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
LoadBalancingPolicy - Interface in com.datastax.oss.driver.api.core.loadbalancing
Decides which Cassandra nodes to contact for each query.
loadBalancingPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
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.
loadBalancingPolicyWrapper() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
loadBalancingPolicyWrapper() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
LoadBalancingPolicyWrapper - Class in com.datastax.oss.driver.internal.core.metadata
Wraps the user-provided LBP for internal use.
LoadBalancingPolicyWrapper(InternalDriverContext, LoadBalancingPolicy) - Constructor for class com.datastax.oss.driver.internal.core.metadata.LoadBalancingPolicyWrapper
 
loadClass(String, String) - Static method in class com.datastax.oss.driver.internal.core.util.Reflection
Loads a class by name.
LOCAL_DATE - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
LOCAL_TIME - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
LOG - Static variable in interface com.datastax.oss.driver.internal.core.time.Clock
 
log(Future<T>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.UncaughtExceptions
 
log(Throwable) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.UncaughtExceptions
 
logPrefix - Variable in class com.datastax.oss.driver.internal.core.type.codec.registry.CachingCodecRegistry
 
LONG - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 

M

MapCodec<K,V> - Class in com.datastax.oss.driver.internal.core.type.codec
 
MapCodec(DataType, TypeCodec<K>, TypeCodec<V>) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
mapOf(TypeCodec<K>, TypeCodec<V>) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
mapOf(DataType, DataType) - 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
 
MapType - Interface in com.datastax.oss.driver.api.core.type
 
markReady() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.ReplayingEventFilter
 
merge(Set<InetSocketAddress>, List<String>) - Static method in class com.datastax.oss.driver.internal.core.ContactPoints
 
Metadata - Interface in com.datastax.oss.driver.api.core.metadata
The metadata of the Cassandra cluster that this driver instance is connected to.
metadataManager() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
metadataManager() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
MetadataManager - Class in com.datastax.oss.driver.internal.core.metadata
Holds the immutable instance of the Metadata, and handles requests to update it.
MetadataManager(InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
MultiPageResultSet - Class in com.datastax.oss.driver.internal.core.cql
 
MultiPageResultSet(AsyncResultSet) - Constructor for class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 

N

name() - Method in interface com.datastax.oss.driver.api.core.ProtocolVersion
A string representation of the version.
Native - Class in com.datastax.oss.driver.internal.core.os
A gateway to perform system calls.
Native() - Constructor for class com.datastax.oss.driver.internal.core.os.Native
 
Native.LibC - Interface in com.datastax.oss.driver.internal.core.os
Handles libc calls through JNR (must be public).
NativeClock - Class in com.datastax.oss.driver.internal.core.time
Provides the current time with microseconds precision with some reasonable accuracy through the use of Native.currentTimeMicros().
NativeClock() - Constructor for class com.datastax.oss.driver.internal.core.time.NativeClock
 
needsDoubleQuotes(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Whether a string needs double quotes to be a valid CQL identifier.
nettyOptions() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
nettyOptions() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
NettyOptions - Interface in com.datastax.oss.driver.internal.core.context
Low-level hooks to control certain aspects of Netty usage in the driver.
newAuthenticator(SocketAddress, String) - Method in interface com.datastax.oss.driver.api.core.auth.AuthProvider
The authenticator to use when connecting to host.
newAuthenticator(SocketAddress, String) - Method in class com.datastax.oss.driver.api.core.auth.PlainTextAuthProvider
 
newHandler(Request<PreparedStatement, CompletionStage<PreparedStatement>>, DefaultSession, InternalDriverContext, String) - Method in class com.datastax.oss.driver.internal.core.cql.CqlPrepareProcessor
 
newHandler(Request<ResultSet, CompletionStage<AsyncResultSet>>, DefaultSession, InternalDriverContext, String) - Method in class com.datastax.oss.driver.internal.core.cql.CqlRequestProcessor
 
newHandler(Request<SyncResultT, AsyncResultT>, DefaultSession, InternalDriverContext, String) - Method in interface com.datastax.oss.driver.internal.core.session.RequestProcessor
Builds a new handler to process a given request.
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, 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.
newInstance(AsyncResultSet) - Static method in class com.datastax.oss.driver.internal.core.cql.ResultSets
 
newQueryPlan() - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy
Returns the coordinators to use for a new query.
newQueryPlan() - Method in class com.datastax.oss.driver.api.core.loadbalancing.RoundRobinLoadBalancingPolicy
 
newQueryPlan() - Method in class com.datastax.oss.driver.internal.core.metadata.LoadBalancingPolicyWrapper
 
newSchedule() - Method in class com.datastax.oss.driver.api.core.connection.ExponentialReconnectionPolicy
A new schedule that used an exponentially growing delay between reconnection attempts.
newSchedule() - Method in interface com.datastax.oss.driver.api.core.connection.ReconnectionPolicy
Creates a new schedule.
newSslEngine(SocketAddress) - Method in class com.datastax.oss.driver.api.core.ssl.DefaultSslEngineFactory
 
newSslEngine(SocketAddress) - Method in interface com.datastax.oss.driver.api.core.ssl.SslEngineFactory
Creates a new SSL engine each time a connection is established.
newSslHandler(Channel, SocketAddress) - Method in class com.datastax.oss.driver.internal.core.ssl.JdkSslHandlerFactory
 
newSslHandler(Channel, SocketAddress) - Method in interface com.datastax.oss.driver.internal.core.ssl.SslHandlerFactory
 
newState - Variable in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
newThread(Runnable) - Method in class com.datastax.oss.driver.internal.core.util.concurrent.BlockingOperation.SafeThreadFactory
 
newValue() - Method in interface com.datastax.oss.driver.api.core.type.TupleType
 
newValue() - Method in interface com.datastax.oss.driver.api.core.type.UserDefinedType
 
newValue() - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
newValue() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
next() - Method in class com.datastax.oss.driver.api.core.time.AtomicTimestampGenerator
 
next() - Method in class com.datastax.oss.driver.api.core.time.ServerSideTimestampGenerator
 
next() - Method in class com.datastax.oss.driver.api.core.time.ThreadLocalTimestampGenerator
 
next() - Method in interface com.datastax.oss.driver.api.core.time.TimestampGenerator
Returns the next timestamp, in microseconds.
next() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
 
next() - Method in class com.datastax.oss.driver.internal.core.util.CountingIterator
 
nextDelay() - Method in interface com.datastax.oss.driver.api.core.connection.ReconnectionPolicy.ReconnectionSchedule
How long to wait before the next reconnection attempt.
nextExecution(CqlIdentifier, Request, int) - Method in class com.datastax.oss.driver.api.core.specex.ConstantSpeculativeExecutionPolicy
 
nextExecution(CqlIdentifier, Request, int) - Method in class com.datastax.oss.driver.api.core.specex.NoSpeculativeExecutionPolicy
 
nextExecution(CqlIdentifier, Request, int) - Method in interface com.datastax.oss.driver.api.core.specex.SpeculativeExecutionPolicy
 
nextPage() - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminResult
 
nextStable() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
The next stable version, i.e.
Node - Interface in com.datastax.oss.driver.api.core.metadata
Metadata about a Cassandra node in the cluster.
node - Variable in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
node - Variable in class com.datastax.oss.driver.internal.core.metadata.DistanceEvent
 
node - Variable in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
NodeDistance - Enum in com.datastax.oss.driver.api.core.loadbalancing
Determines how the driver will manage connections to a Cassandra node.
NodeInfo - Interface in com.datastax.oss.driver.internal.core.metadata
Information about a node, returned by the TopologyMonitor.
NodeState - Enum in com.datastax.oss.driver.api.core.metadata
The state of a node, as viewed from the driver.
NodeStateEvent - Class in com.datastax.oss.driver.internal.core.metadata
 
NodeStateManager - Class in com.datastax.oss.driver.internal.core.metadata
Maintains the state of the Cassandra nodes, based on the events received from other components of the driver.
NodeStateManager(InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.metadata.NodeStateManager
 
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
 
NoSpeculativeExecutionPolicy - Class in com.datastax.oss.driver.api.core.specex
A policy that never triggers speculative executions.
NoSpeculativeExecutionPolicy(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.specex.NoSpeculativeExecutionPolicy
 

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
 
oldState - Variable in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
on(EventExecutor, Runnable) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.RunOrSchedule
 
on(EventExecutor, Consumer<T>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.RunOrSchedule
 
on(EventExecutor, Callable<CompletionStage<T>>) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.RunOrSchedule
 
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 class com.datastax.oss.driver.api.core.loadbalancing.RoundRobinLoadBalancingPolicy
 
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 interface com.datastax.oss.driver.api.core.auth.SyncAuthenticator
Called when authentication is successful with the last information optionally sent by the server.
onClose() - Method in class com.datastax.oss.driver.internal.core.context.DefaultNettyOptions
 
onClose() - Method in interface com.datastax.oss.driver.internal.core.context.NettyOptions
A hook involved when the driver instance shuts down.
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 class com.datastax.oss.driver.api.core.loadbalancing.RoundRobinLoadBalancingPolicy
 
onDriverInit(DriverContext) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigLoader
Called when the driver initializes.
onDriverInit(DriverContext) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.DefaultDriverConfigLoader
 
onErrorResponse(Request, CoordinatorException, int) - Method in class com.datastax.oss.driver.api.core.retry.DefaultRetryPolicy
Whether to retry when the server replied with a recoverable error (other than READ_TIMEOUT, WRITE_TIMEOUT or UNAVAILABLE).
onErrorResponse(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).
onEvent(Message) - Method in interface com.datastax.oss.driver.internal.core.channel.EventCallback
Invoked when a protocol event is received.
onEvent(Message) - Method in class com.datastax.oss.driver.internal.core.control.ControlConnection
 
onFailure(Throwable) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
onFailure(Throwable) - Method in interface com.datastax.oss.driver.internal.core.channel.ResponseCallback
Invoked if we couldn't get the response.
onReadTimeout(Request, ConsistencyLevel, int, int, boolean, int) - Method in class com.datastax.oss.driver.api.core.retry.DefaultRetryPolicy
Whether to retry when the server replied with a READ_TIMEOUT error; this indicates a server-side timeout during a read query, i.e.
onReadTimeout(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.
onRealConnect(ChannelHandlerContext) - Method in class com.datastax.oss.driver.internal.core.channel.ConnectInitHandler
 
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 class com.datastax.oss.driver.api.core.loadbalancing.RoundRobinLoadBalancingPolicy
 
onRequestAborted(Request, Throwable, int) - Method in class com.datastax.oss.driver.api.core.retry.DefaultRetryPolicy
Whether to retry when a request was aborted before we could get a response from the server.
onRequestAborted(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.
onResponse(Frame) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
onResponse(Frame) - Method in interface com.datastax.oss.driver.internal.core.channel.ResponseCallback
Invoked when the server replies (note that the response frame might contain an error message).
onStreamIdAssigned(int) - Method in interface com.datastax.oss.driver.internal.core.channel.ResponseCallback
Reports the stream id to the caller if ResponseCallback.holdStreamId() is true.
onUnavailable(Request, ConsistencyLevel, int, int, int) - Method in class com.datastax.oss.driver.api.core.retry.DefaultRetryPolicy
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.
onUnavailable(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 class com.datastax.oss.driver.api.core.loadbalancing.RoundRobinLoadBalancingPolicy
 
onWriteTimeout(Request, ConsistencyLevel, WriteType, int, int, int) - Method in class com.datastax.oss.driver.api.core.retry.DefaultRetryPolicy
Whether to retry when the server replied with a WRITE_TIMEOUT error; this indicates a server-side timeout during a write query, i.e.
onWriteTimeout(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.
opcodeString(int) - Static method in class com.datastax.oss.driver.internal.core.util.ProtocolUtils
Formats a message opcode for logs and error messages.
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
 
ownerLogPrefix - Variable in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions
 

P

pagingState - Variable in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
parse(String) - Static method in class com.datastax.oss.driver.api.core.CassandraVersion
Parses a version from a string.
parse(String) - Method in interface com.datastax.oss.driver.api.core.type.codec.TypeCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.BigIntCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.BlobCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.BooleanCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.CqlDurationCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.CustomCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.DateCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.DecimalCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.DoubleCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.FloatCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.InetCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.IntCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.ListCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.MapCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 
parse(String) - Method in class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
ParseUtils - Class in com.datastax.oss.driver.internal.core.type.codec
 
ParseUtils() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.ParseUtils
 
PassThroughAddressTranslator - Class in com.datastax.oss.driver.api.core.addresstranslation
An address translator that always returns the same address unchanged.
PassThroughAddressTranslator(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.addresstranslation.PassThroughAddressTranslator
 
PassThroughWriteCoalescer - Class in com.datastax.oss.driver.internal.core.channel
No-op implementation of the write coalescer: each write is flushed immediately.
PassThroughWriteCoalescer(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.internal.core.channel.PassThroughWriteCoalescer
 
peek() - Method in class com.datastax.oss.driver.internal.core.util.CountingIterator
 
PlainTextAuthProvider - Class in com.datastax.oss.driver.api.core.auth
A simple authentication provider that supports SASL authentication using the PLAIN mechanism for version 3 (or above) of the CQL native protocol.
PlainTextAuthProvider(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.auth.PlainTextAuthProvider
Builds a new instance.
prepare(SimpleStatement) - Method in interface com.datastax.oss.driver.api.core.session.Session
Prepares a CQL statement synchronously.
prepare(String) - Method in interface com.datastax.oss.driver.api.core.session.Session
Prepares a CQL statement synchronously.
prepareAsync(String) - Method in interface com.datastax.oss.driver.api.core.session.Session
Prepares a CQL statement asynchronously.
prepareAsync(SimpleStatement) - Method in interface com.datastax.oss.driver.api.core.session.Session
Prepares a CQL statement asynchronously.
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.
PrimitiveType - Class in com.datastax.oss.driver.internal.core.type
 
PrimitiveType(int) - Constructor for class com.datastax.oss.driver.internal.core.type.PrimitiveType
 
processorFor(Request<SyncResultT, AsyncResultT>) - Method in class com.datastax.oss.driver.internal.core.session.RequestProcessorRegistry
 
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
 
ProtocolUtils - Class in com.datastax.oss.driver.internal.core.util
 
ProtocolUtils() - Constructor for class com.datastax.oss.driver.internal.core.util.ProtocolUtils
 
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() - Method in interface com.datastax.oss.driver.api.core.detach.AttachmentPoint
 
ProtocolVersion - Interface in com.datastax.oss.driver.api.core
A version of the native protocol used by the driver to communicate with the server.
protocolVersion() - Method in class com.datastax.oss.driver.internal.core.channel.ChannelFactory
 
protocolVersion() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
 
protocolVersion() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
protocolVersion() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
protocolVersion() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
protocolVersion() - Method in class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
protocolVersion() - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
protocolVersionRegistry() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
protocolVersionRegistry() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
ProtocolVersionRegistry - Class in com.datastax.oss.driver.internal.core
Manages all the native protocol versions supported by the driver.
ProtocolVersionRegistry(ProtocolVersion[]...) - Constructor for class com.datastax.oss.driver.internal.core.ProtocolVersionRegistry
 
ProtocolVersionRegistry() - Constructor for class com.datastax.oss.driver.internal.core.ProtocolVersionRegistry
Default implementation, initialized with the core OSS versions.

Q

query(DriverChannel, String, Map<String, Object>, Duration, int, String) - Static method in class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
query(DriverChannel, String, Duration, int, String) - Static method in class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
query(DriverChannel, String, Map<String, Object>) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
query - Variable in class com.datastax.oss.driver.internal.core.session.RepreparePayload
 
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, 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, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.QueryExecutionException
 
queryPlan - Variable in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
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, boolean) - Constructor for exception com.datastax.oss.driver.api.core.servererrors.QueryValidationException
 
quote(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Quote the given string; single quotes are escaped.

R

readByte(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
readBytes(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
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
 
readInetAddr(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
readInt(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
readLong(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
readLongString(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
readShortBytes(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
readString(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
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
 
readUnsignedShort(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
readVInt(DataInput) - Static method in class com.datastax.oss.driver.internal.core.type.util.VIntCoding
 
receive(T) - Method in class com.datastax.oss.driver.internal.core.util.concurrent.Debouncer
This must be called on eventExecutor too.
Reconnection - Class in com.datastax.oss.driver.internal.core.util.concurrent
A reconnection process that, if failed, is retried periodically according to the intervals defined by a policy.
Reconnection(String, EventExecutor, ReconnectionPolicy, Callable<CompletionStage<Boolean>>, Runnable, Runnable) - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.Reconnection
 
Reconnection(String, EventExecutor, ReconnectionPolicy, Callable<CompletionStage<Boolean>>) - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.Reconnection
 
ReconnectionPolicy - Interface in com.datastax.oss.driver.api.core.connection
Decides how often the driver tries to re-establish lost connections to a node.
reconnectionPolicy() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
reconnectionPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
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.
reconnectionStarted(Node) - Static method in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
reconnectionStopped(Node) - Static method in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
reconnectNow() - Method in class com.datastax.oss.driver.internal.core.control.ControlConnection
Forces an immediate reconnect: if we were connected to a node, that connection will be closed; if we were already reconnecting, the next attempt is started immediately, without waiting for the next scheduled interval; in all cases, a new query plan is fetched from the load balancing policy, and each node in it will be tried in sequence.
reconnectNow() - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
 
reconnectNow(boolean) - Method in class com.datastax.oss.driver.internal.core.util.concurrent.Reconnection
Forces a reconnection now, without waiting for the next scheduled attempt.
recordedEvents() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.ReplayingEventFilter
 
Reflection - Class in com.datastax.oss.driver.internal.core.util
 
Reflection() - Constructor for class com.datastax.oss.driver.internal.core.util.Reflection
 
refreshNode(Node) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
refreshNode(Node) - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
refreshNode(Node) - Method in interface com.datastax.oss.driver.internal.core.metadata.TopologyMonitor
Invoked when the driver needs to refresh the information about an existing node.
refreshNodeList() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultTopologyMonitor
 
refreshNodeList() - Method in interface com.datastax.oss.driver.internal.core.metadata.TopologyMonitor
Invoked when the driver needs to refresh information about all the nodes.
refreshNodes() - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
refreshSchema(SchemaElementKind, String, String, List<String>) - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
register(Class<T>, Consumer<T>) - Method in class com.datastax.oss.driver.internal.core.context.EventBus
Registers a listener for an event type.
release(int) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
Releases a stream id if the client was holding onto it, and has now determined that it can be safely reused.
release(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
reload(Config) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypeSafeDriverConfig
 
remaining() - Method in interface com.datastax.oss.driver.api.core.cql.AsyncResultSet
How many rows are left before the current page is exhausted.
remaining() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
remaining - Variable in class com.datastax.oss.driver.internal.core.util.CountingIterator
 
remaining() - Method in class com.datastax.oss.driver.internal.core.util.CountingIterator
 
removed(DefaultNode) - Static method in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
removeNode(InetSocketAddress) - Method in class com.datastax.oss.driver.internal.core.metadata.MetadataManager
 
RemoveNodeRefresh - Class in com.datastax.oss.driver.internal.core.metadata
 
ReplayingEventFilter<T> - Class in com.datastax.oss.driver.internal.core.util.concurrent
Filters a list of events, accumulating them during an initialization period.
ReplayingEventFilter(Consumer<T>) - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.ReplayingEventFilter
 
reportAvailableIds(boolean) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions.Builder
 
reportAvailableIds - Variable in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions
Whether DriverChannel.availableIds() should be maintained
RepreparePayload - Class in com.datastax.oss.driver.internal.core.session
The information that's necessary to reprepare an already prepared statement, in case we hit a node that doesn't have it in its cache.
RepreparePayload(ByteBuffer, String, String, Map<String, ByteBuffer>) - Constructor for class com.datastax.oss.driver.internal.core.session.RepreparePayload
 
Request<SyncResultT,AsyncResultT> - Interface in com.datastax.oss.driver.api.core.session
A request executed by a Session.
request - Variable in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
RequestHandler<SyncResultT,AsyncResultT> - Interface in com.datastax.oss.driver.internal.core.session
Manages the execution of a given request.
RequestHandlerBase<SyncResultT,AsyncResultT> - Class in com.datastax.oss.driver.internal.core.session
Factors code that should be common to most request handler implementations.
RequestHandlerBase(Request<SyncResultT, AsyncResultT>, DefaultSession, InternalDriverContext) - Constructor for class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
RequestProcessor<SyncResultT,AsyncResultT> - Interface in com.datastax.oss.driver.internal.core.session
Handles a type of request in the driver.
requestProcessorRegistry() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
requestProcessorRegistry() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
RequestProcessorRegistry - Class in com.datastax.oss.driver.internal.core.session
 
RequestProcessorRegistry(String, RequestProcessor<?, ?>...) - Constructor for class com.datastax.oss.driver.internal.core.session.RequestProcessorRegistry
 
required() - Method in enum com.datastax.oss.driver.api.core.config.CoreDriverOption
 
required() - Method in interface com.datastax.oss.driver.api.core.config.DriverOption
 
resize(NodeDistance) - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
 
ResponseCallback - Interface in com.datastax.oss.driver.internal.core.channel
The outcome of a request sent to a Cassandra node.
ResultSet - Interface in com.datastax.oss.driver.api.core.cql
The result of a synchronous CQL query.
ResultSets - Class in com.datastax.oss.driver.internal.core.cql
 
ResultSets() - Constructor for class com.datastax.oss.driver.internal.core.cql.ResultSets
 
RetryDecision - Enum in com.datastax.oss.driver.api.core.retry
A decision from the RetryPolicy on how to handle a retry.
retryPolicy() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
RetryPolicy - Interface in com.datastax.oss.driver.api.core.retry
Defines the behavior to adopt when a request fails.
retryPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
RoundRobinLoadBalancingPolicy - Class in com.datastax.oss.driver.api.core.loadbalancing
A round-robin load balancing policy.
RoundRobinLoadBalancingPolicy(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.loadbalancing.RoundRobinLoadBalancingPolicy
 
Row - Interface in com.datastax.oss.driver.api.core.cql
A row from a CQL table.
RunOrSchedule - Class in com.datastax.oss.driver.internal.core.util.concurrent
Utility to run a task on a Netty event executor (i.e.
RunOrSchedule() - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.RunOrSchedule
 

S

SafeThreadFactory() - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.BlockingOperation.SafeThreadFactory
 
SchemaElementKind - Enum in com.datastax.oss.driver.internal.core.metadata
The different kinds of objects in a schema.
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
 
ServerSideTimestampGenerator - Class in com.datastax.oss.driver.api.core.time
A timestamp generator that never sends a timestamp with any query, therefore letting Cassandra assign a server-side timestamp.
ServerSideTimestampGenerator(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.time.ServerSideTimestampGenerator
 
Session - Interface in com.datastax.oss.driver.api.core.session
A nexus to send requests to a Cassandra cluster.
session - Variable in class com.datastax.oss.driver.internal.core.session.RequestHandlerBase
 
set(CqlIdentifier, V, TypeCodec<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence of id, using the given codec for the conversion.
set(CqlIdentifier, V, GenericType<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence of id, converting it to the given Java type.
set(CqlIdentifier, V, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Returns the value for the first occurrence of id, converting it to the given Java type.
set(int, V, TypeCodec<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value, using the given codec for the conversion.
set(int, V, GenericType<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value, converting it to the given Java type.
set(int, V, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Returns the ith value, converting it to the given Java type.
set(String, V, TypeCodec<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for the first occurrence of name, using the given codec for the conversion.
set(String, V, GenericType<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for the first occurrence of name, converting it to the given Java type.
set(String, V, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Returns the value for the first occurrence 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.
setBatchType(BatchType) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setBigDecimal(CqlIdentifier, BigDecimal) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence of name to the provided Java big integer.
setBoolean(CqlIdentifier, boolean) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence of name.
setBytesUnsafe(int, ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setBytesUnsafe(int, ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
setBytesUnsafe(int, ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
SetCodec<T> - Class in com.datastax.oss.driver.internal.core.type.codec
 
SetCodec(DataType, TypeCodec<T>) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.SetCodec
 
setConfigProfile(DriverConfigProfile) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the configuration profile to use for execution.
setConfigProfile(DriverConfigProfile) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setConfigProfile(DriverConfigProfile) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setConfigProfile(DriverConfigProfile) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setConfigProfileName(String) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the name of the driver configuration profile that will be used for execution.
setConfigProfileName(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setConfigProfileName(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setConfigProfileName(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setConnectFailure(Throwable) - Method in class com.datastax.oss.driver.internal.core.channel.ConnectInitHandler
 
setConnectSuccess() - Method in class com.datastax.oss.driver.internal.core.channel.ConnectInitHandler
 
setCqlDuration(CqlIdentifier, CqlDuration) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence of name to the provided duration.
setCustomPayload(Map<String, ByteBuffer>) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the custom payload to use for execution.
setCustomPayload(Map<String, ByteBuffer>) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setCustomPayload(Map<String, ByteBuffer>) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setCustomPayload(Map<String, ByteBuffer>) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setDistance(Node, NodeDistance) - Method in interface com.datastax.oss.driver.api.core.loadbalancing.LoadBalancingPolicy.DistanceReporter
 
setDistance(Node, NodeDistance) - Method in class com.datastax.oss.driver.internal.core.metadata.LoadBalancingPolicyWrapper
 
setDouble(CqlIdentifier, double) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence of name to the provided Java primitive double.
setFloat(CqlIdentifier, float) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence of name to the provided Java primitive float.
setIdempotent(Boolean) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the idempotence to use for execution.
setIdempotent(Boolean) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setIdempotent(Boolean) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setIdempotent(Boolean) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setInetAddress(CqlIdentifier, InetAddress) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence of name to the provided Java primitive integer.
setKeyspace(String) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
NOT YET SUPPORTED -- sets the CQL keyspace to associate with the query.
setKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
Switches the underlying Cassandra connection to a new keyspace (as if a USE ... statement was issued).
setKeyspace(String) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.pool.ChannelPool
Changes the keyspace name on all the channels in this pool.
setKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.session.DefaultSession
INTERNAL USE ONLY -- switches the session to a new keyspace.
setList(CqlIdentifier, List<V>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence of id to the provided Java list.
setList(int, List<V>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java list.
setList(String, List<V>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence of name to the provided Java primitive long.
setMap(CqlIdentifier, Map<K, V>, Class<K>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence of id to the provided Java map.
setMap(int, Map<K, V>, Class<K>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java map.
setMap(String, Map<K, V>, Class<K>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for the first occurrence of name to the provided Java map.
setNamedValues(Map<String, Object>) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Sets the named values to bind to named placeholders.
setNamedValues(Map<String, Object>) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setOf(TypeCodec<T>) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
setOf(DataType) - 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
 
setPagingState(ByteBuffer) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the paging state to send with the statement.
setPagingState(ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setPagingState(ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setPagingState(ByteBuffer) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setPositionalValues(List<Object>) - Method in interface com.datastax.oss.driver.api.core.cql.SimpleStatement
Sets the positional values to bind to anonymous placeholders.
setPositionalValues(List<Object>) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
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.internal.core.cql.DefaultSimpleStatement
 
setSet(CqlIdentifier, Set<V>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence of id to the provided Java set.
setSet(int, Set<V>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByIndex
Sets the ith value to the provided Java set.
setSet(String, Set<V>, Class<V>) - Method in interface com.datastax.oss.driver.api.core.data.SettableByName
Sets the value for the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence of name to the provided Java string.
SettableById<T extends SettableById<T>> - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to set its values via a CQL identifier.
SettableByIndex<T extends SettableByIndex<T>> - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to set its values via an integer index.
SettableByName<T extends SettableByName<T>> - Interface in com.datastax.oss.driver.api.core.data
A data structure that provides methods to set its values via a name.
setTimestamp(long) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets the query timestamp to send with the statement.
setTimestamp(long) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setTimestamp(long) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setTimestamp(long) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setToNull(CqlIdentifier) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence of name to CQL NULL.
setTracing(boolean) - Method in interface com.datastax.oss.driver.api.core.cql.Statement
Sets tracing for execution.
setTracing(boolean) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
setTracing(boolean) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
setTracing(boolean) - Method in class com.datastax.oss.driver.internal.core.cql.DefaultSimpleStatement
 
setTupleValue(CqlIdentifier, TupleValue) - Method in interface com.datastax.oss.driver.api.core.data.SettableById
Sets the value for the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence 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 the first occurrence of name to the provided Java UUID.
SHORT - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
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
 
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
 
SinglePageResultSet - Class in com.datastax.oss.driver.internal.core.cql
 
SinglePageResultSet(AsyncResultSet) - Constructor for class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
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.
size() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBatchStatement
 
size() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultBoundStatement
 
size() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinitions
 
size() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultRow
 
size() - Method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
 
size() - Method in class com.datastax.oss.driver.internal.core.data.DefaultTupleValue
 
size() - Method in class com.datastax.oss.driver.internal.core.data.DefaultUdtValue
 
sizeOf(ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
skipCQLId(String, int) - Static method in class com.datastax.oss.driver.internal.core.type.codec.ParseUtils
Assuming that idx points to the beginning of a CQL identifier in toParse, returns the index of the first character after this identifier.
skipCQLValue(String, int) - Static method in class com.datastax.oss.driver.internal.core.type.codec.ParseUtils
Assuming that idx points to the beginning of a CQL value in toParse, returns the index of the first character after this value.
skipSpaces(String, int) - Static method in class com.datastax.oss.driver.internal.core.type.codec.ParseUtils
Returns the index of the first character in toParse from idx that is not a "space".
SMALLINT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
SMALLINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
SmallIntCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
SmallIntCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.SmallIntCodec
 
speculativeExecutionPolicy() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
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.
speculativeExecutionPolicy() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
sslEngineFactory() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
The SSL engine factory, if SSL was configured.
SslEngineFactory - Interface in com.datastax.oss.driver.api.core.ssl
Extension point to configure SSL based on the built-in JDK implementation.
sslEngineFactory() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
sslHandlerFactory() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
sslHandlerFactory() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
SslHandlerFactory - Interface in com.datastax.oss.driver.internal.core.ssl
Low-level SSL extension point.
start() - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
start(Map<String, ByteBuffer>) - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
start() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.Reconnection
 
start() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.ReplayingEventFilter
 
Statement<T extends Statement<T>> - Interface in com.datastax.oss.driver.api.core.cql
A request to execute a CQL query.
StatementBuilder<T extends StatementBuilder<T,S>,S extends Statement<S>> - 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(S) - Constructor for class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
stop() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.Debouncer
Stop debouncing: the next flush is cancelled, and all pending and future events will be ignored.
stop() - Method in class com.datastax.oss.driver.internal.core.util.concurrent.Reconnection
 
streamId - Variable in exception com.datastax.oss.driver.internal.core.protocol.FrameDecodingException
 
STRING - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
StringCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
StringCodec(DataType, Charset) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.StringCodec
 
Strings - Class in com.datastax.oss.driver.internal.core.util
 
suggestAdded(InetSocketAddress) - Static method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
Suggests that a new node was added in the cluster.
suggestDown(InetSocketAddress) - Static method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
Suggests that a node is down.
suggestRemoved(InetSocketAddress) - Static method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
Suggests that a node was removed from the cluster.
suggestUp(InetSocketAddress) - Static method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
Suggests that a node is up.
SyncAuthenticator - Interface in com.datastax.oss.driver.api.core.auth
An authenticator that performs all of its operations synchronously, on the calling thread.
syncResult() - Method in class com.datastax.oss.driver.internal.core.cql.CqlPrepareHandler
 
syncResult() - Method in class com.datastax.oss.driver.internal.core.cql.CqlRequestHandler
 
syncResult() - Method in interface com.datastax.oss.driver.internal.core.session.RequestHandler
Blocks until the request is done, and returns an object representing the completed result.
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

TEXT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
TEXT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
ThreadLocalTimestampGenerator - Class in com.datastax.oss.driver.api.core.time
A timestamp generator that guarantees monotonically increasing timestamps within each thread, and logs warnings when timestamps drift in the future.
ThreadLocalTimestampGenerator(DriverContext, DriverOption) - Constructor for class com.datastax.oss.driver.api.core.time.ThreadLocalTimestampGenerator
 
TIME - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
TIME - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
TimeCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
TimeCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.TimeCodec
 
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
 
TIMESTAMP - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
TimestampCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
TimestampCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.TimestampCodec
 
timestampGenerator() - Method in interface com.datastax.oss.driver.api.core.context.DriverContext
 
TimestampGenerator - Interface in com.datastax.oss.driver.api.core.time
Generates client-side, microsecond-precision query timestamps.
timestampGenerator() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
TIMEUUID - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
TIMEUUID - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
TimeUuidCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
TimeUuidCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.TimeUuidCodec
 
TINYINT - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
TINYINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
TinyIntCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
TinyIntCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.TinyIntCodec
 
TopologyEvent - Class in com.datastax.oss.driver.internal.core.metadata
An event emitted from the TopologyMonitor, indicating a change in the topology of the Cassandra cluster.
TopologyEvent(TopologyEvent.Type, InetSocketAddress) - Constructor for class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
Builds a new instance (the static methods in this class are a preferred alternative).
TopologyEvent.Type - Enum in com.datastax.oss.driver.internal.core.metadata
 
topologyMonitor() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
topologyMonitor() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
TopologyMonitor - Interface in com.datastax.oss.driver.internal.core.metadata
Monitors the state of the Cassandra cluster.
toString() - Method in class com.datastax.oss.driver.api.core.CassandraVersion
 
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 class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
toString() - Method in class com.datastax.oss.driver.internal.core.adminrequest.AdminRequestHandler
 
toString() - Method in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
toString() - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
 
toString() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultColumnDefinition
 
toString() - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNode
 
toString() - Method in class com.datastax.oss.driver.internal.core.metadata.DistanceEvent
 
toString() - Method in class com.datastax.oss.driver.internal.core.metadata.NodeStateEvent
 
toString() - Method in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
 
toString() - Method in class com.datastax.oss.driver.internal.core.type.DefaultCustomType
 
toString() - Method in class com.datastax.oss.driver.internal.core.type.DefaultListType
 
toString() - Method in class com.datastax.oss.driver.internal.core.type.DefaultMapType
 
toString() - Method in class com.datastax.oss.driver.internal.core.type.DefaultSetType
 
toString() - Method in class com.datastax.oss.driver.internal.core.type.DefaultTupleType
 
toString() - Method in class com.datastax.oss.driver.internal.core.type.DefaultUserDefinedType
 
toString() - Method in class com.datastax.oss.driver.internal.core.type.PrimitiveType
 
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.
translate(InetSocketAddress) - Method in class com.datastax.oss.driver.api.core.addresstranslation.PassThroughAddressTranslator
 
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
 
TupleCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
TupleCodec(TupleType) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.TupleCodec
 
tupleOf(TupleType) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
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.
type - Variable in class com.datastax.oss.driver.internal.core.channel.ChannelEvent
 
type - Variable in class com.datastax.oss.driver.internal.core.metadata.TopologyEvent
 
TypeCodec<T> - 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 type codec instances.
TypeCodecs() - Constructor for class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
TypeSafeDriverConfig - Class in com.datastax.oss.driver.internal.core.config.typesafe
 
TypeSafeDriverConfig(Config, DriverOption[]...) - Constructor for class com.datastax.oss.driver.internal.core.config.typesafe.TypeSafeDriverConfig
 
TypesafeDriverConfigProfile - Class in com.datastax.oss.driver.internal.core.config.typesafe
 
TypesafeDriverConfigProfile() - Constructor for class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 

U

UDT_VALUE - Static variable in class com.datastax.oss.driver.api.core.type.reflect.GenericType
 
UdtCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
UdtCodec(UserDefinedType) - Constructor for class com.datastax.oss.driver.internal.core.type.codec.UdtCodec
 
udtOf(UserDefinedType) - Static method in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
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
 
UncaughtExceptions - Class in com.datastax.oss.driver.internal.core.util.concurrent
Utility methods to log unexpected exceptions in asynchronous tasks.
UncaughtExceptions() - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.UncaughtExceptions
 
unDoubleQuote(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Unquote the given string if it is double quoted; double quotes are unescaped.
unquote(String) - Static method in class com.datastax.oss.driver.internal.core.util.Strings
Unquote the given string if it is quoted; single quotes are unescaped.
unregister(Object, Class<T>) - Method in class com.datastax.oss.driver.internal.core.context.EventBus
Unregisters a listener.
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).
UserDefinedType - Interface in com.datastax.oss.driver.api.core.type
 
UserDefinedTypeBuilder - Class in com.datastax.oss.driver.internal.core.type
Helper class to build UserDefinedType instances.
UserDefinedTypeBuilder(CqlIdentifier, CqlIdentifier) - Constructor for class com.datastax.oss.driver.internal.core.type.UserDefinedTypeBuilder
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.datastax.oss.driver.internal.core.channel.InFlightHandler
 
UUID - Static variable in class com.datastax.oss.driver.api.core.type.codec.TypeCodecs
 
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
 
UuidCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
UuidCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.UuidCodec
 

V

valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.config.CoreDriverOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.ConsistencyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.CoreProtocolVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.api.core.cql.BatchType
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.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.retry.WriteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.internal.core.channel.ChannelEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.internal.core.config.ConfigChangeEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.internal.core.config.ForceReloadConfigEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.internal.core.cql.EmptyColumnDefinitions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.internal.core.metadata.SchemaElementKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.datastax.oss.driver.internal.core.metadata.TopologyEvent.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.datastax.oss.driver.api.core.config.CoreDriverOption
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.ConsistencyLevel
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.CoreProtocolVersion
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.BatchType
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.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.retry.WriteType
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.internal.core.channel.ChannelEvent.Type
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.internal.core.config.ConfigChangeEvent
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.internal.core.config.ForceReloadConfigEvent
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.internal.core.cql.EmptyColumnDefinitions
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.internal.core.metadata.SchemaElementKind
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.internal.core.metadata.TopologyEvent.Type
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
 
VARINT - Static variable in class com.datastax.oss.driver.api.core.type.DataTypes
 
VarIntCodec - Class in com.datastax.oss.driver.internal.core.type.codec
 
VarIntCodec() - Constructor for class com.datastax.oss.driver.internal.core.type.codec.VarIntCodec
 
VIntCoding - Class in com.datastax.oss.driver.internal.core.type.util
Variable length encoding inspired from Google varints.
VIntCoding() - Constructor for class com.datastax.oss.driver.internal.core.type.util.VIntCoding
 

W

wasApplied() - Method in interface com.datastax.oss.driver.api.core.cql.AsyncResultSet
If the query that produced this result was a 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 conditional update, indicate whether it was successfully applied.
wasApplied() - Method in class com.datastax.oss.driver.internal.core.cql.DefaultAsyncResultSet
 
wasApplied() - Method in class com.datastax.oss.driver.internal.core.cql.MultiPageResultSet
 
wasApplied() - Method in class com.datastax.oss.driver.internal.core.cql.SinglePageResultSet
 
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.
whenAllDone(List<CompletionStage<T>>, Runnable, Executor) - Static method in class com.datastax.oss.driver.internal.core.util.concurrent.CompletableFutures
Do something when all inputs are done (success or failure).
withBoolean(DriverOption, boolean) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
withBoolean(DriverOption, boolean) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
withBroadcastAddress(InetAddress) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withBytes(DriverOption, long) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
withBytes(DriverOption, long) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
withCassandraVersion(String) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withConfigLoader(DriverConfigLoader) - Method in class com.datastax.oss.driver.api.core.ClusterBuilder
Sets the configuration loader to use.
withConfigProfile(DriverConfigProfile) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
withConfigProfileName(String) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
withConnectAddress(InetSocketAddress) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withConsistencyLevel(DriverOption, ConsistencyLevel) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
withConsistencyLevel(DriverOption, ConsistencyLevel) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
withDatacenter(String) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withDuration(DriverOption, Duration) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
withDuration(DriverOption, Duration) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
withEvents(List<String>, EventCallback) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions.Builder
 
withExtra(String, Object) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withField(CqlIdentifier, DataType) - Method in class com.datastax.oss.driver.internal.core.type.UserDefinedTypeBuilder
Adds a new field.
withIdempotence(boolean) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
withInt(DriverOption, int) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
withInt(DriverOption, int) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
withKeyspace(CqlIdentifier) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions.Builder
 
withListenAddress(InetAddress) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withOwnerLogPrefix(String) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannelOptions.Builder
 
withPagingState(ByteBuffer) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
withQuery(String) - Method in class com.datastax.oss.driver.api.core.cql.SimpleStatementBuilder
 
withRack(String) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withString(DriverOption, String) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
withString(DriverOption, String) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
withStringList(DriverOption, List<String>) - Method in interface com.datastax.oss.driver.api.core.config.DriverConfigProfile
 
withStringList(DriverOption, List<String>) - Method in class com.datastax.oss.driver.internal.core.config.typesafe.TypesafeDriverConfigProfile
 
withTimestamp(long) - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
withTokens(Set<String>) - Method in class com.datastax.oss.driver.internal.core.metadata.DefaultNodeInfo.Builder
 
withTracing() - Method in class com.datastax.oss.driver.api.core.cql.StatementBuilder
 
write(Message, boolean, Map<String, ByteBuffer>, ResponseCallback) - Method in class com.datastax.oss.driver.internal.core.channel.DriverChannel
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.datastax.oss.driver.internal.core.channel.InFlightHandler
 
writeAndFlush(Channel, Object) - Method in class com.datastax.oss.driver.internal.core.channel.DefaultWriteCoalescer
 
writeAndFlush(Channel, Object) - Method in class com.datastax.oss.driver.internal.core.channel.PassThroughWriteCoalescer
 
writeAndFlush(Channel, Object) - Method in interface com.datastax.oss.driver.internal.core.channel.WriteCoalescer
Writes and flushes the message to the channel, possibly at a later time, but the order of messages must be preserved.
writeByte(byte, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
writeBytes(ByteBuffer, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
WriteCoalescer - Interface in com.datastax.oss.driver.internal.core.channel
Optimizes the write operations on Netty channels.
writeCoalescer() - Method in class com.datastax.oss.driver.internal.core.context.DefaultDriverContext
 
writeCoalescer() - Method in interface com.datastax.oss.driver.internal.core.context.InternalDriverContext
 
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
 
writeInetAddr(InetAddress, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
writeInt(int, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
writeLong(long, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
writeLongString(String, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
writeShortBytes(byte[], ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
writeString(String, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
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 - Enum in com.datastax.oss.driver.api.core.retry
The type of a Cassandra write query.
writeUnsignedShort(int, ByteBuf) - Method in class com.datastax.oss.driver.internal.core.protocol.ByteBufPrimitiveCodec
 
writeVInt(long, DataOutput) - Static method in class com.datastax.oss.driver.internal.core.type.util.VIntCoding
 

_

__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 _ 
Skip navigation links

Copyright © 2017. All rights reserved.