- 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
-
- 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
-
- 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
-
- 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
-
- connect() - Method in interface com.datastax.oss.driver.api.core.Cluster
-
- 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
-
- 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
-
- currentTimeMicros() - Static method in class com.datastax.oss.driver.internal.core.os.Native
-
- 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
-
- CycleDetector(String) - Constructor for class com.datastax.oss.driver.internal.core.util.concurrent.CycleDetector
-
- 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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.
- 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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 i
th 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
-