Modifier and Type | Field and Description |
---|---|
static QueryOptions |
QueryOptions.DEFAULT |
QueryOptions |
UpdateParameters.options |
protected QueryOptions |
BatchQueryOptions.wrapped |
Modifier and Type | Field and Description |
---|---|
static CBCodec<QueryOptions> |
QueryOptions.codec |
Modifier and Type | Method and Description |
---|---|
static QueryOptions |
QueryOptions.addColumnSpecifications(QueryOptions options,
java.util.List<ColumnSpecification> columnSpecs) |
static QueryOptions |
QueryOptions.create(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values,
boolean skipMetadata,
int pageSize,
PagingState pagingState,
ConsistencyLevel serialConsistency) |
static QueryOptions |
QueryOptions.create(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values,
boolean skipMetadata,
int pageSize,
PagingState pagingState,
ConsistencyLevel serialConsistency,
int protocolVersion) |
static QueryOptions |
QueryOptions.forInternalCalls(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values) |
static QueryOptions |
QueryOptions.forInternalCalls(java.util.List<java.nio.ByteBuffer> values) |
static QueryOptions |
QueryOptions.forProtocolVersion(int protocolVersion) |
abstract QueryOptions |
BatchQueryOptions.forStatement(int i) |
static QueryOptions |
QueryOptions.fromPreV3Batch(ConsistencyLevel consistency) |
static QueryOptions |
QueryOptions.fromProtocolV1(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values) |
static QueryOptions |
QueryOptions.fromProtocolV2(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values) |
static QueryOptions |
QueryProcessor.makeInternalOptions(ParsedStatement.Prepared prepared,
java.lang.Object[] values) |
QueryOptions |
QueryOptions.prepare(java.util.List<ColumnSpecification> specs) |
Modifier and Type | Method and Description |
---|---|
static QueryOptions |
QueryOptions.addColumnSpecifications(QueryOptions options,
java.util.List<ColumnSpecification> columnSpecs) |
ColumnCondition.Bound |
ColumnCondition.bind(QueryOptions options) |
Constants.Value |
Constants.Marker.bind(QueryOptions options) |
Term.Terminal |
Lists.DelayedValue.bind(QueryOptions options) |
Term.Terminal |
Lists.Marker.bind(QueryOptions options) |
Term.Terminal |
Maps.DelayedValue.bind(QueryOptions options) |
Term.Terminal |
Maps.Marker.bind(QueryOptions options) |
Term.Terminal |
Sets.DelayedValue.bind(QueryOptions options) |
Term.Terminal |
Sets.Marker.bind(QueryOptions options) |
Term.Terminal |
Term.bind(QueryOptions options)
Bind the values in this term to the values contained in
values . |
Term.Terminal |
Term.Terminal.bind(QueryOptions options) |
Tuples.Value |
Tuples.DelayedValue.bind(QueryOptions options) |
Tuples.Value |
Tuples.Marker.bind(QueryOptions options) |
Tuples.InValue |
Tuples.InMarker.bind(QueryOptions options) |
Constants.Value |
UserTypes.DelayedValue.bind(QueryOptions options) |
java.nio.ByteBuffer |
Constants.Value.bindAndGet(QueryOptions options) |
java.nio.ByteBuffer |
Constants.Marker.bindAndGet(QueryOptions options) |
java.nio.ByteBuffer |
Term.bindAndGet(QueryOptions options)
A shorter for bind(values).get().
|
java.nio.ByteBuffer |
Term.Terminal.bindAndGet(QueryOptions options) |
java.nio.ByteBuffer |
Term.NonTerminal.bindAndGet(QueryOptions options) |
java.nio.ByteBuffer |
Tuples.DelayedValue.bindAndGet(QueryOptions options) |
java.nio.ByteBuffer |
UserTypes.DelayedValue.bindAndGet(QueryOptions options) |
ResultMessage |
CQLStatement.execute(QueryState state,
QueryOptions options)
Execute the statement and return the resulting result or null if there is no result.
|
ResultMessage |
CQLStatement.executeInternal(QueryState state,
QueryOptions options)
Variant of execute used for internal query against the system tables, and thus only query the local node.
|
static Tuples.InValue |
Tuples.InValue.fromSerialized(java.nio.ByteBuffer value,
ListType type,
QueryOptions options) |
long |
Attributes.getTimestamp(long now,
QueryOptions options) |
int |
Attributes.getTimeToLive(QueryOptions options,
CFMetaData metadata) |
ResultMessage |
QueryProcessor.process(java.lang.String queryString,
QueryState queryState,
QueryOptions options) |
ResultMessage |
CustomPayloadMirroringQueryHandler.process(java.lang.String query,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload) |
ResultMessage |
QueryHandler.process(java.lang.String query,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload) |
ResultMessage |
QueryProcessor.process(java.lang.String query,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload) |
ResultMessage |
QueryProcessor.processPrepared(CQLStatement statement,
QueryState queryState,
QueryOptions options) |
ResultMessage |
CustomPayloadMirroringQueryHandler.processPrepared(CQLStatement statement,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload) |
ResultMessage |
QueryHandler.processPrepared(CQLStatement statement,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload) |
ResultMessage |
QueryProcessor.processPrepared(CQLStatement statement,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload) |
ResultMessage |
QueryProcessor.processStatement(CQLStatement statement,
QueryState queryState,
QueryOptions options) |
static BatchQueryOptions |
BatchQueryOptions.withoutPerStatementVariables(QueryOptions options) |
static BatchQueryOptions |
BatchQueryOptions.withPerStatementVariables(QueryOptions options,
java.util.List<java.util.List<java.nio.ByteBuffer>> variables,
java.util.List<java.lang.Object> queryOrIdList) |
Constructor and Description |
---|
BatchQueryOptions(QueryOptions wrapped,
java.util.List<java.lang.Object> queryOrIdList) |
UpdateParameters(CFMetaData metadata,
QueryOptions options,
long timestamp,
int ttl,
java.util.Map<java.nio.ByteBuffer,CQL3Row> prefetchedLists) |
Modifier and Type | Method and Description |
---|---|
Term.Terminal |
FunctionCall.bind(QueryOptions options) |
java.nio.ByteBuffer |
FunctionCall.bindAndGet(QueryOptions options) |
Modifier and Type | Method and Description |
---|---|
void |
MultiColumnRestriction.EQ.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
MultiColumnRestriction.IN.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
MultiColumnRestriction.Slice.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
Restriction.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options)
Adds to the specified list the
IndexExpression s corresponding to this Restriction . |
void |
SingleColumnRestriction.EQ.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.IN.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.Slice.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.Contains.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
TokenRestriction.addIndexExpressionTo(java.util.List<IndexExpression> expressions,
SecondaryIndexManager indexManager,
QueryOptions options) |
CompositesBuilder |
MultiColumnRestriction.Slice.appendBoundTo(CFMetaData cfm,
CompositesBuilder builder,
Bound bound,
QueryOptions options) |
CompositesBuilder |
Restriction.appendBoundTo(CFMetaData cfm,
CompositesBuilder builder,
Bound bound,
QueryOptions options)
Appends the values of the
Restriction for the specified bound to the specified builder. |
CompositesBuilder |
SingleColumnRestriction.Slice.appendBoundTo(CFMetaData cfm,
CompositesBuilder builder,
Bound bound,
QueryOptions options) |
CompositesBuilder |
SingleColumnRestriction.Contains.appendBoundTo(CFMetaData cfm,
CompositesBuilder builder,
Bound bound,
QueryOptions options) |
CompositesBuilder |
MultiColumnRestriction.EQ.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options) |
CompositesBuilder |
MultiColumnRestriction.IN.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options)
Appends the values of this
Restriction to the specified builder. |
CompositesBuilder |
MultiColumnRestriction.Slice.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options) |
CompositesBuilder |
Restriction.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options)
Appends the values of this
Restriction to the specified builder. |
CompositesBuilder |
SingleColumnRestriction.EQ.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options) |
CompositesBuilder |
SingleColumnRestriction.IN.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options) |
CompositesBuilder |
SingleColumnRestriction.Slice.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options) |
CompositesBuilder |
SingleColumnRestriction.Contains.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options) |
CompositesBuilder |
TokenRestriction.appendTo(CFMetaData cfm,
CompositesBuilder builder,
QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.Slice.bounds(CFMetaData cfm,
Bound b,
QueryOptions options) |
java.util.List<Composite> |
TokenRestriction.boundsAsComposites(CFMetaData cfm,
Bound bound,
QueryOptions options) |
java.util.List<Composite> |
StatementRestrictions.getClusteringColumnsAsComposites(QueryOptions options)
Returns the requested clustering columns as
Composite s. |
java.util.List<java.nio.ByteBuffer> |
StatementRestrictions.getClusteringColumnsBounds(Bound b,
QueryOptions options)
Returns the bounds (start or end) of the clustering columns.
|
java.util.List<Composite> |
StatementRestrictions.getClusteringColumnsBoundsAsComposites(Bound b,
QueryOptions options)
Returns the bounds (start or end) of the clustering columns as
Composites . |
java.util.List<IndexExpression> |
StatementRestrictions.getIndexExpressions(SecondaryIndexManager indexManager,
QueryOptions options) |
AbstractBounds<RowPosition> |
StatementRestrictions.getPartitionKeyBounds(QueryOptions options)
Returns the partition key bounds.
|
java.util.Collection<java.nio.ByteBuffer> |
StatementRestrictions.getPartitionKeys(QueryOptions options)
Returns the partition keys for which the data is requested.
|
protected abstract java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.IN.getValues(QueryOptions options) |
protected java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.InWithValues.getValues(QueryOptions options) |
protected java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.InWithMarker.getValues(QueryOptions options) |
boolean |
MultiColumnRestriction.EQ.isNotReturningAnyRows(CFMetaData cfm,
QueryOptions options) |
boolean |
MultiColumnRestriction.Slice.isNotReturningAnyRows(CFMetaData cfm,
QueryOptions options) |
boolean |
Restriction.isNotReturningAnyRows(CFMetaData cfm,
QueryOptions options)
Checks if this restriction will prevent the query to return any rows.
|
boolean |
SingleColumnRestriction.EQ.isNotReturningAnyRows(CFMetaData cfm,
QueryOptions options) |
boolean |
SingleColumnRestriction.Slice.isNotReturningAnyRows(CFMetaData cfm,
QueryOptions options) |
boolean |
StatementRestrictions.isNotReturningAnyRows(QueryOptions options)
Checks if the query will never return any rows.
|
protected abstract java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.IN.splitValues(QueryOptions options) |
protected java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.InWithValues.splitValues(QueryOptions options) |
protected java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.InWithMarker.splitValues(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.EQ.values(CFMetaData cfm,
QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.Slice.values(CFMetaData cfm,
QueryOptions options) |
java.util.List<Composite> |
TokenRestriction.valuesAsComposites(CFMetaData cfm,
QueryOptions options) |
Modifier and Type | Method and Description |
---|---|
void |
CQL3CasRequest.addConditions(Composite prefix,
java.util.Collection<ColumnCondition> conds,
QueryOptions options) |
void |
ModificationStatement.addConditions(Composite clusteringPrefix,
CQL3CasRequest request,
QueryOptions options) |
void |
CQL3CasRequest.addRowUpdate(Composite prefix,
ModificationStatement stmt,
QueryOptions options,
long timestamp) |
static ResultSet |
ModificationStatement.buildCasResultSet(java.lang.String ksName,
java.nio.ByteBuffer key,
java.lang.String cfName,
ColumnFamily cf,
java.lang.Iterable<ColumnDefinition> columnsWithConditions,
boolean isBatch,
QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
ModificationStatement.buildPartitionKeyNames(QueryOptions options) |
Composite |
ModificationStatement.createClusteringPrefix(QueryOptions options) |
ResultMessage |
AuthenticationStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
AuthorizationStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
BatchStatement.execute(QueryState queryState,
QueryOptions options) |
ResultMessage |
DropIndexStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
ModificationStatement.execute(QueryState queryState,
QueryOptions options) |
ResultMessage |
SchemaAlteringStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage.Rows |
SelectStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
TruncateStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
UseStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
AuthenticationStatement.executeInternal(QueryState state,
QueryOptions options) |
ResultMessage |
AuthorizationStatement.executeInternal(QueryState state,
QueryOptions options) |
ResultMessage |
BatchStatement.executeInternal(QueryState queryState,
QueryOptions options) |
ResultMessage |
ModificationStatement.executeInternal(QueryState queryState,
QueryOptions options) |
ResultMessage |
SchemaAlteringStatement.executeInternal(QueryState state,
QueryOptions options) |
ResultMessage.Rows |
SelectStatement.executeInternal(QueryState state,
QueryOptions options) |
ResultMessage |
TruncateStatement.executeInternal(QueryState state,
QueryOptions options) |
ResultMessage |
UseStatement.executeInternal(QueryState state,
QueryOptions options) |
ResultMessage.Rows |
SelectStatement.executeInternal(QueryState state,
QueryOptions options,
long now) |
ResultMessage |
ModificationStatement.executeInternalWithCondition(QueryState state,
QueryOptions options) |
ResultMessage |
ModificationStatement.executeInternalWithoutCondition(QueryState queryState,
QueryOptions options) |
ResultMessage |
ModificationStatement.executeWithCondition(QueryState queryState,
QueryOptions options) |
int |
SelectStatement.getLimit(QueryOptions options)
May be used by custom QueryHandler implementations
|
Pageable |
SelectStatement.getPageableCommand(QueryOptions options) |
long |
ModificationStatement.getTimestamp(long now,
QueryOptions options) |
int |
ModificationStatement.getTimeToLive(QueryOptions options) |
java.util.List<IndexExpression> |
SelectStatement.getValidatedIndexExpressions(QueryOptions options)
May be used by custom QueryHandler implementations
|
UpdateParameters |
ModificationStatement.makeUpdateParameters(java.util.Collection<java.nio.ByteBuffer> keys,
Composite prefix,
QueryOptions options,
boolean local,
long now) |
ResultMessage.Rows |
SelectStatement.processResults(java.util.List<Row> rows,
QueryOptions options,
int limit,
long now) |
Modifier and Type | Field and Description |
---|---|
QueryOptions |
BatchMessage.options |
QueryOptions |
ExecuteMessage.options |
QueryOptions |
QueryMessage.options |
Constructor and Description |
---|
BatchMessage(BatchStatement.Type type,
java.util.List<java.lang.Object> queryOrIdList,
java.util.List<java.util.List<java.nio.ByteBuffer>> values,
QueryOptions options) |
ExecuteMessage(MD5Digest statementId,
QueryOptions options) |
QueryMessage(java.lang.String query,
QueryOptions options) |
Copyright © 2020 The Apache Software Foundation