Package | Description |
---|---|
com.datastax.dse.driver.api.core.graph | |
com.datastax.dse.driver.api.core.metadata.schema | |
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.cql | |
com.datastax.oss.driver.api.core.data | |
com.datastax.oss.driver.api.core.metadata | |
com.datastax.oss.driver.api.core.metadata.schema | |
com.datastax.oss.driver.api.core.session | |
com.datastax.oss.driver.api.core.specex | |
com.datastax.oss.driver.api.core.type |
Modifier and Type | Method and Description |
---|---|
default CqlIdentifier |
GraphStatement.getKeyspace()
Graph statements do not have a per-query keyspace, this method always returns
null . |
default CqlIdentifier |
GraphStatement.getRoutingKeyspace()
Graph statements can't be routed, this method always returns
null . |
Modifier and Type | Method and Description |
---|---|
CqlIdentifier |
DseEdgeMetadata.getFromLabel()
The label of the incoming vertex in graph.
|
CqlIdentifier |
DseEdgeMetadata.getFromTable()
The identifier of the table representing the incoming vertex.
|
CqlIdentifier |
DseEdgeMetadata.getLabelName()
The label of the edge in graph.
|
CqlIdentifier |
DseVertexMetadata.getLabelName()
The label of the vertex in graph.
|
CqlIdentifier |
DseEdgeMetadata.getToLabel()
The label of the outgoing vertex in graph.
|
CqlIdentifier |
DseEdgeMetadata.getToTable()
The identifier of the table representing the outgoing vertex.
|
Modifier and Type | Method and Description |
---|---|
List<CqlIdentifier> |
DseEdgeMetadata.getFromClusteringColumns()
The columns in this table that match the clustering columns of the incoming vertex table.
|
List<CqlIdentifier> |
DseEdgeMetadata.getFromPartitionKeyColumns()
The columns in this table that match the partition key of the incoming vertex table.
|
List<CqlIdentifier> |
DseFunctionMetadata.getMonotonicArgumentNames()
Returns a list of argument names that are monotonic.
|
List<CqlIdentifier> |
DseEdgeMetadata.getToClusteringColumns()
The columns in this table that match the clustering columns of the outgoing vertex table.
|
List<CqlIdentifier> |
DseEdgeMetadata.getToPartitionKeyColumns()
The columns in this table that match the partition key of the outgoing vertex table.
|
Modifier and Type | Method and Description |
---|---|
static CqlIdentifier |
CqlIdentifier.fromCql(String cql)
Creates an identifier from its
CQL form . |
static CqlIdentifier |
CqlIdentifier.fromInternal(String internal)
Creates an identifier from its
internal form . |
Modifier and Type | Field and Description |
---|---|
protected CqlIdentifier |
StatementBuilder.routingKeyspace |
Modifier and Type | Method and Description |
---|---|
default CqlIdentifier |
BoundStatement.getKeyspace()
Always returns
null (bound statements can't have a per-request keyspace, they always
inherit the one of the statement that was initially prepared). |
CqlIdentifier |
ColumnDefinition.getKeyspace() |
CqlIdentifier |
ColumnDefinition.getName() |
CqlIdentifier |
PrepareRequest.getRoutingKeyspaceForBoundStatements()
The routing keyspace to use for the bound statements that will be created from the prepared
statement.
|
CqlIdentifier |
ColumnDefinition.getTable() |
Modifier and Type | Method and Description |
---|---|
Map<CqlIdentifier,Object> |
SimpleStatement.getNamedValues() |
Modifier and Type | Method and Description |
---|---|
SimpleStatementBuilder |
SimpleStatementBuilder.addNamedValue(CqlIdentifier name,
Object value) |
boolean |
ColumnDefinitions.contains(CqlIdentifier id)
Whether there is a definition using the given CQL identifier.
|
int |
BoundStatementBuilder.firstIndexOf(CqlIdentifier id) |
int |
ColumnDefinitions.firstIndexOf(CqlIdentifier id)
Returns the index of the first column that uses the given identifier.
|
default ColumnDefinition |
ColumnDefinitions.get(CqlIdentifier name)
Get a definition by name.
|
default boolean |
Bindable.isSet(CqlIdentifier id)
Whether the value for the first occurrence of
id has been set. |
SimpleStatement |
SimpleStatement.setKeyspace(CqlIdentifier newKeyspace)
Sets the CQL keyspace to associate with the query.
|
SimpleStatementBuilder |
SimpleStatementBuilder.setKeyspace(CqlIdentifier keyspace) |
BatchStatement |
BatchStatement.setKeyspace(CqlIdentifier newKeyspace)
Sets the CQL keyspace to associate with this batch.
|
BatchStatementBuilder |
BatchStatementBuilder.setKeyspace(CqlIdentifier keyspace)
Sets the CQL keyspace to execute this batch in.
|
SelfT |
StatementBuilder.setRoutingKeyspace(CqlIdentifier routingKeyspace) |
SelfT |
Statement.setRoutingKeyspace(CqlIdentifier newRoutingKeyspace)
Sets the keyspace to use for token-aware routing.
|
default SelfT |
Bindable.unset(CqlIdentifier id)
Unsets the value for the first occurrence of
id . |
Modifier and Type | Method and Description |
---|---|
SimpleStatement |
SimpleStatement.setNamedValuesWithIds(Map<CqlIdentifier,Object> newNamedValues)
Sets the named values to bind to named placeholders.
|
Constructor and Description |
---|
BoundStatementBuilder(PreparedStatement preparedStatement,
ColumnDefinitions variableDefinitions,
ByteBuffer[] values,
String executionProfileName,
DriverExecutionProfile executionProfile,
CqlIdentifier routingKeyspace,
ByteBuffer routingKey,
Token routingToken,
Map<String,ByteBuffer> customPayload,
Boolean idempotent,
boolean tracing,
long timestamp,
ByteBuffer pagingState,
int pageSize,
ConsistencyLevel consistencyLevel,
ConsistencyLevel serialConsistencyLevel,
Duration timeout,
CodecRegistry codecRegistry,
ProtocolVersion protocolVersion) |
Modifier and Type | Method and Description |
---|---|
int |
AccessibleById.firstIndexOf(CqlIdentifier id)
Returns the first index where a given identifier appears (depending on the implementation,
identifiers may appear multiple times).
|
default <ValueT> ValueT |
GettableById.get(CqlIdentifier id,
Class<ValueT> targetClass)
Returns the value for the first occurrence of
id , converting it to the given Java type. |
default <ValueT> ValueT |
GettableById.get(CqlIdentifier id,
GenericType<ValueT> targetType)
Returns the value for the first occurrence of
id , converting it to the given Java type. |
default <ValueT> ValueT |
GettableById.get(CqlIdentifier id,
TypeCodec<ValueT> codec)
Returns the value for the first occurrence of
id , using the given codec for the
conversion. |
default BigDecimal |
GettableById.getBigDecimal(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java big decimal. |
default BigInteger |
GettableById.getBigInteger(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java big integer. |
default boolean |
GettableById.getBoolean(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java primitive boolean. |
default byte |
GettableById.getByte(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java primitive byte. |
default ByteBuffer |
GettableById.getByteBuffer(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java byte buffer. |
default ByteBuffer |
GettableById.getBytesUnsafe(CqlIdentifier id)
Returns the raw binary representation of the value for the first occurrence of
id . |
default CqlDuration |
GettableById.getCqlDuration(CqlIdentifier id)
Returns the value for the first occurrence of
id as a duration. |
default double |
GettableById.getDouble(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java primitive double. |
default float |
GettableById.getFloat(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java primitive float. |
default InetAddress |
GettableById.getInetAddress(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java IP address. |
default Instant |
GettableById.getInstant(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java instant. |
default int |
GettableById.getInt(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java primitive integer. |
default <ElementT> List<ElementT> |
GettableById.getList(CqlIdentifier id,
Class<ElementT> elementsClass)
Returns the value for the first occurrence of
id as a Java list. |
default LocalDate |
GettableById.getLocalDate(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java local date. |
default LocalTime |
GettableById.getLocalTime(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java local time. |
default long |
GettableById.getLong(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java primitive long. |
default <KeyT,ValueT> |
GettableById.getMap(CqlIdentifier id,
Class<KeyT> keyClass,
Class<ValueT> valueClass)
Returns the value for the first occurrence of
id as a Java map. |
default Object |
GettableById.getObject(CqlIdentifier id)
Returns the value for the first occurrence of
id , converting it to the most appropriate
Java type. |
default <ElementT> Set<ElementT> |
GettableById.getSet(CqlIdentifier id,
Class<ElementT> elementsClass)
Returns the value for the first occurrence of
id as a Java set. |
default short |
GettableById.getShort(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java primitive short. |
default String |
GettableById.getString(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java string. |
default Token |
GettableById.getToken(CqlIdentifier id)
Returns the value for the first occurrence of
id as a token. |
default TupleValue |
GettableById.getTupleValue(CqlIdentifier id)
Returns the value for the first occurrence of
id as a tuple value. |
default DataType |
SettableById.getType(CqlIdentifier id) |
DataType |
AccessibleById.getType(CqlIdentifier id)
Returns the CQL type of the value for the first occurrence of
id . |
default UdtValue |
GettableById.getUdtValue(CqlIdentifier id)
Returns the value for the first occurrence of
id as a user defined type value. |
default UUID |
GettableById.getUuid(CqlIdentifier id)
Returns the value for the first occurrence of
id as a Java UUID. |
default boolean |
GettableById.isNull(CqlIdentifier id)
Indicates whether the value for the first occurrence of
id is a CQL NULL . |
default <ValueT> SelfT |
SettableById.set(CqlIdentifier id,
ValueT v,
Class<ValueT> targetClass)
Returns the value for the first occurrence of
id , converting it to the given Java type. |
default <ValueT> SelfT |
SettableById.set(CqlIdentifier id,
ValueT v,
GenericType<ValueT> targetType)
Sets the value for the first occurrence of
id , converting it to the given Java type. |
default <ValueT> SelfT |
SettableById.set(CqlIdentifier id,
ValueT v,
TypeCodec<ValueT> codec)
Sets the value for the first occurrence of
id , using the given codec for the
conversion. |
default SelfT |
SettableById.setBigDecimal(CqlIdentifier id,
BigDecimal v)
Sets the value for the first occurrence of
id to the provided Java big decimal. |
default SelfT |
SettableById.setBigInteger(CqlIdentifier id,
BigInteger v)
Sets the value for the first occurrence of
id to the provided Java big integer. |
default SelfT |
SettableById.setBoolean(CqlIdentifier id,
boolean v)
Sets the value for the first occurrence of
id to the provided Java primitive boolean. |
default SelfT |
SettableById.setByte(CqlIdentifier id,
byte v)
Sets the value for the first occurrence of
id to the provided Java primitive byte. |
default SelfT |
SettableById.setByteBuffer(CqlIdentifier id,
ByteBuffer v)
Sets the value for the first occurrence of
id to the provided Java byte buffer. |
default SelfT |
SettableById.setBytesUnsafe(CqlIdentifier id,
ByteBuffer v)
Sets the raw binary representation of the value for the first occurrence of
id . |
default SelfT |
SettableById.setCqlDuration(CqlIdentifier id,
CqlDuration v)
Sets the value for the first occurrence of
id to the provided duration. |
default SelfT |
SettableById.setDouble(CqlIdentifier id,
double v)
Sets the value for the first occurrence of
id to the provided Java primitive double. |
default SelfT |
SettableById.setFloat(CqlIdentifier id,
float v)
Sets the value for the first occurrence of
id to the provided Java primitive float. |
default SelfT |
SettableById.setInetAddress(CqlIdentifier id,
InetAddress v)
Sets the value for the first occurrence of
id to the provided Java IP address. |
default SelfT |
SettableById.setInstant(CqlIdentifier id,
Instant v)
Sets the value for the first occurrence of
id to the provided Java instant. |
default SelfT |
SettableById.setInt(CqlIdentifier id,
int v)
Sets the value for the first occurrence of
id to the provided Java primitive integer. |
default <ElementT> SelfT |
SettableById.setList(CqlIdentifier id,
List<ElementT> v,
Class<ElementT> elementsClass)
Sets the value for the first occurrence of
id to the provided Java list. |
default SelfT |
SettableById.setLocalDate(CqlIdentifier id,
LocalDate v)
Sets the value for the first occurrence of
id to the provided Java local date. |
default SelfT |
SettableById.setLocalTime(CqlIdentifier id,
LocalTime v)
Sets the value for the first occurrence of
id to the provided Java local time. |
default SelfT |
SettableById.setLong(CqlIdentifier id,
long v)
Sets the value for the first occurrence of
id to the provided Java primitive long. |
default <KeyT,ValueT> |
SettableById.setMap(CqlIdentifier id,
Map<KeyT,ValueT> v,
Class<KeyT> keyClass,
Class<ValueT> valueClass)
Sets the value for the first occurrence of
id to the provided Java map. |
default <ElementT> SelfT |
SettableById.setSet(CqlIdentifier id,
Set<ElementT> v,
Class<ElementT> elementsClass)
Sets the value for the first occurrence of
id to the provided Java set. |
default SelfT |
SettableById.setShort(CqlIdentifier id,
short v)
Sets the value for the first occurrence of
id to the provided Java primitive short. |
default SelfT |
SettableById.setString(CqlIdentifier id,
String v)
Sets the value for the first occurrence of
id to the provided Java string. |
default SelfT |
SettableById.setToken(CqlIdentifier id,
Token v)
Sets the value for the first occurrence of
id to the provided token. |
default SelfT |
SettableById.setToNull(CqlIdentifier id)
Sets the value for the first occurrence of
id to CQL NULL . |
default SelfT |
SettableById.setTupleValue(CqlIdentifier id,
TupleValue v)
Sets the value for the first occurrence of
id to the provided tuple value. |
default SelfT |
SettableById.setUdtValue(CqlIdentifier id,
UdtValue v)
Sets the value for the first occurrence of
id to the provided user defined type value. |
default SelfT |
SettableById.setUuid(CqlIdentifier id,
UUID v)
Sets the value for the first occurrence of
id to the provided Java UUID. |
Modifier and Type | Method and Description |
---|---|
Map<CqlIdentifier,KeyspaceMetadata> |
Metadata.getKeyspaces()
The keyspaces defined in this cluster.
|
Modifier and Type | Method and Description |
---|---|
default Optional<KeyspaceMetadata> |
Metadata.getKeyspace(CqlIdentifier keyspaceId) |
default Set<Node> |
TokenMap.getReplicas(CqlIdentifier keyspace,
ByteBuffer partitionKey)
Shortcut for
getReplicas(keyspace,
null, partitionKey) . |
Set<Node> |
TokenMap.getReplicas(CqlIdentifier keyspace,
Partitioner partitioner,
ByteBuffer partitionKey)
The replicas for a given partition key in the given keyspace.
|
Set<Node> |
TokenMap.getReplicas(CqlIdentifier keyspace,
Token token)
The replicas for a given token in the given keyspace.
|
default Set<Node> |
TokenMap.getReplicas(CqlIdentifier keyspace,
TokenRange range)
The replicas for a given range in the given keyspace.
|
Set<TokenRange> |
TokenMap.getTokenRanges(CqlIdentifier keyspace,
Node replica)
The token ranges that are replicated on the given node, for the given keyspace.
|
Modifier and Type | Method and Description |
---|---|
CqlIdentifier |
ViewMetadata.getBaseTable()
The table that this view is based on.
|
CqlIdentifier |
IndexMetadata.getKeyspace() |
CqlIdentifier |
RelationMetadata.getKeyspace() |
CqlIdentifier |
ColumnMetadata.getKeyspace() |
CqlIdentifier |
AggregateMetadata.getKeyspace() |
CqlIdentifier |
FunctionMetadata.getKeyspace() |
CqlIdentifier |
IndexMetadata.getName() |
CqlIdentifier |
KeyspaceMetadata.getName() |
CqlIdentifier |
FunctionSignature.getName() |
CqlIdentifier |
RelationMetadata.getName() |
CqlIdentifier |
ColumnMetadata.getName() |
CqlIdentifier |
ColumnMetadata.getParent()
The identifier of the
TableMetadata or a ViewMetadata that this column belongs
to. |
CqlIdentifier |
IndexMetadata.getTable() |
Modifier and Type | Method and Description |
---|---|
Map<CqlIdentifier,ColumnMetadata> |
RelationMetadata.getColumns() |
Map<CqlIdentifier,IndexMetadata> |
TableMetadata.getIndexes() |
Map<CqlIdentifier,Object> |
RelationMetadata.getOptions()
The options of this table or materialized view.
|
List<CqlIdentifier> |
FunctionMetadata.getParameterNames()
The names of the parameters.
|
Map<CqlIdentifier,TableMetadata> |
KeyspaceMetadata.getTables() |
Map<CqlIdentifier,UserDefinedType> |
KeyspaceMetadata.getUserDefinedTypes() |
Map<CqlIdentifier,ViewMetadata> |
KeyspaceMetadata.getViews() |
default Map<CqlIdentifier,ViewMetadata> |
KeyspaceMetadata.getViewsOnTable(CqlIdentifier tableId)
Gets the views based on a given table.
|
Modifier and Type | Method and Description |
---|---|
default Optional<AggregateMetadata> |
KeyspaceMetadata.getAggregate(CqlIdentifier aggregateId,
DataType... parameterTypes) |
default Optional<AggregateMetadata> |
KeyspaceMetadata.getAggregate(CqlIdentifier aggregateId,
Iterable<DataType> parameterTypes) |
default Optional<ColumnMetadata> |
RelationMetadata.getColumn(CqlIdentifier columnId) |
default Optional<FunctionMetadata> |
KeyspaceMetadata.getFunction(CqlIdentifier functionId,
DataType... parameterTypes) |
default Optional<FunctionMetadata> |
KeyspaceMetadata.getFunction(CqlIdentifier functionId,
Iterable<DataType> parameterTypes) |
default Optional<IndexMetadata> |
TableMetadata.getIndex(CqlIdentifier indexId) |
default Optional<TableMetadata> |
KeyspaceMetadata.getTable(CqlIdentifier tableId) |
default Optional<UserDefinedType> |
KeyspaceMetadata.getUserDefinedType(CqlIdentifier typeId) |
default Optional<ViewMetadata> |
KeyspaceMetadata.getView(CqlIdentifier viewId) |
default Map<CqlIdentifier,ViewMetadata> |
KeyspaceMetadata.getViewsOnTable(CqlIdentifier tableId)
Gets the views based on a given table.
|
Constructor and Description |
---|
FunctionSignature(CqlIdentifier name,
DataType... parameterTypes) |
FunctionSignature(CqlIdentifier name,
Iterable<DataType> parameterTypes) |
Modifier and Type | Field and Description |
---|---|
protected CqlIdentifier |
SessionBuilder.keyspace |
Modifier and Type | Method and Description |
---|---|
CqlIdentifier |
Request.getKeyspace()
The CQL keyspace to execute this request in, or
null if this request does not specify
any keyspace. |
CqlIdentifier |
Request.getRoutingKeyspace()
The keyspace to use for token-aware routing.
|
Modifier and Type | Method and Description |
---|---|
Optional<CqlIdentifier> |
Session.getKeyspace()
The keyspace that this session is currently connected to, or
Optional.empty() if this
session is not connected to any keyspace. |
Modifier and Type | Method and Description |
---|---|
SelfT |
SessionBuilder.withKeyspace(CqlIdentifier keyspace)
Sets the keyspace to connect the session to.
|
Modifier and Type | Method and Description |
---|---|
long |
SpeculativeExecutionPolicy.nextExecution(Node node,
CqlIdentifier keyspace,
Request request,
int runningExecutions) |
Modifier and Type | Method and Description |
---|---|
CqlIdentifier |
UserDefinedType.getKeyspace() |
CqlIdentifier |
UserDefinedType.getName() |
Modifier and Type | Method and Description |
---|---|
List<CqlIdentifier> |
UserDefinedType.getFieldNames() |
Modifier and Type | Method and Description |
---|---|
default boolean |
UserDefinedType.contains(CqlIdentifier id) |
int |
UserDefinedType.firstIndexOf(CqlIdentifier id) |
Copyright © 2017–2024. All rights reserved.