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,
ProtocolVersion version) |
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(ProtocolVersion protocolVersion) |
abstract QueryOptions |
BatchQueryOptions.forStatement(int i) |
static QueryOptions |
QueryOptions.fromThrift(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> 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) |
void |
ColumnConditions.addConditionsTo(CQL3CasRequest request,
Clustering clustering,
QueryOptions options)
Adds the conditions to the specified CAS request.
|
void |
Conditions.addConditionsTo(CQL3CasRequest request,
Clustering clustering,
QueryOptions options)
Adds the conditions to the specified CAS request.
|
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) |
UserTypes.Value |
UserTypes.DelayedValue.bind(QueryOptions options) |
Term.Terminal |
UserTypes.Marker.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,
long queryStartNanoTime)
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,
int defaultTimeToLive) |
ResultMessage |
QueryProcessor.process(java.lang.String queryString,
QueryState queryState,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
CustomPayloadMirroringQueryHandler.process(java.lang.String query,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload,
long queryStartNanoTime) |
ResultMessage |
QueryHandler.process(java.lang.String query,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload,
long queryStartNanoTime) |
ResultMessage |
QueryProcessor.process(java.lang.String query,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload,
long queryStartNanoTime) |
ResultMessage |
QueryProcessor.processPrepared(CQLStatement statement,
QueryState queryState,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
CustomPayloadMirroringQueryHandler.processPrepared(CQLStatement statement,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload,
long queryStartNanoTime) |
ResultMessage |
QueryHandler.processPrepared(CQLStatement statement,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload,
long queryStartNanoTime) |
ResultMessage |
QueryProcessor.processPrepared(CQLStatement statement,
QueryState state,
QueryOptions options,
java.util.Map<java.lang.String,java.nio.ByteBuffer> customPayload,
long queryStartNanoTime) |
ResultMessage |
QueryProcessor.processStatement(CQLStatement statement,
QueryState queryState,
QueryOptions options,
long queryStartNanoTime) |
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,
PartitionColumns updatedColumns,
QueryOptions options,
long timestamp,
int ttl,
java.util.Map<DecoratedKey,Partition> prefetchedRows) |
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.EQRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexMananger,
QueryOptions options) |
void |
MultiColumnRestriction.INRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
MultiColumnRestriction.SliceRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
MultiColumnRestriction.NotNullRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexMananger,
QueryOptions options) |
void |
Restriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options)
Adds to the specified row filter the expressions corresponding to this
Restriction . |
void |
SingleColumnRestriction.EQRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.INRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.SliceRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.ContainsRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.IsNotNullRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
SingleColumnRestriction.LikeRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
TokenRestriction.addRowFilterTo(RowFilter filter,
SecondaryIndexManager indexManager,
QueryOptions options) |
void |
CustomIndexExpression.addToRowFilter(RowFilter filter,
CFMetaData cfm,
QueryOptions options) |
MultiCBuilder |
MultiColumnRestriction.SliceRestriction.appendBoundTo(MultiCBuilder builder,
Bound bound,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.SliceRestriction.appendBoundTo(MultiCBuilder builder,
Bound bound,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.ContainsRestriction.appendBoundTo(MultiCBuilder builder,
Bound bound,
QueryOptions options) |
default MultiCBuilder |
SingleRestriction.appendBoundTo(MultiCBuilder builder,
Bound bound,
QueryOptions options)
Appends the values of the
SingleRestriction for the specified bound to the specified builder. |
MultiCBuilder |
MultiColumnRestriction.EQRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
MultiColumnRestriction.INRestriction.appendTo(MultiCBuilder builder,
QueryOptions options)
Appends the values of this
SingleRestriction to the specified builder. |
MultiCBuilder |
MultiColumnRestriction.SliceRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
MultiColumnRestriction.NotNullRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.EQRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.INRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.SliceRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.ContainsRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.IsNotNullRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
SingleColumnRestriction.LikeRestriction.appendTo(MultiCBuilder builder,
QueryOptions options) |
MultiCBuilder |
SingleRestriction.appendTo(MultiCBuilder builder,
QueryOptions options)
Appends the values of this
SingleRestriction to the specified builder. |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.EQRestriction.bounds(Bound b,
QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.SliceRestriction.bounds(Bound b,
QueryOptions options) |
java.util.NavigableSet<Clustering> |
StatementRestrictions.getClusteringColumns(QueryOptions options)
Returns the requested clustering columns.
|
java.util.NavigableSet<ClusteringBound> |
StatementRestrictions.getClusteringColumnsBounds(Bound b,
QueryOptions options)
Returns the bounds (start or end) of the clustering columns.
|
AbstractBounds<PartitionPosition> |
StatementRestrictions.getPartitionKeyBounds(QueryOptions options)
Returns the partition key bounds.
|
java.util.List<java.nio.ByteBuffer> |
StatementRestrictions.getPartitionKeys(QueryOptions options)
Returns the partition keys for which the data is requested.
|
RowFilter |
StatementRestrictions.getRowFilter(SecondaryIndexManager indexManager,
QueryOptions options) |
protected abstract java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.INRestriction.getValues(QueryOptions options) |
protected java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.InRestrictionWithValues.getValues(QueryOptions options) |
protected java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.InRestrictionWithMarker.getValues(QueryOptions options) |
protected abstract java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.INRestriction.splitValues(QueryOptions options) |
protected java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.InRestrictionWithValues.splitValues(QueryOptions options) |
protected java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.InRestrictionWithMarker.splitValues(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.EQRestriction.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.SliceRestriction.values(QueryOptions options) |
Modifier and Type | Method and Description |
---|---|
abstract Selector |
Selector.Factory.newInstance(QueryOptions options)
Creates a new
Selector instance. |
protected abstract org.apache.cassandra.cql3.selection.Selection.Selectors |
Selection.newSelectors(QueryOptions options) |
Selection.ResultSetBuilder |
Selection.resultSetBuilder(QueryOptions options,
boolean isJson) |
Selection.ResultSetBuilder |
Selection.resultSetBuilder(QueryOptions options,
boolean isJson,
AggregationSpecification aggregationSpec) |
Modifier and Type | Method and Description |
---|---|
void |
CQL3CasRequest.addConditions(Clustering clustering,
java.util.Collection<ColumnCondition> conds,
QueryOptions options) |
void |
ModificationStatement.addConditions(Clustering clustering,
CQL3CasRequest request,
QueryOptions options) |
void |
CQL3CasRequest.addRowUpdate(Clustering clustering,
ModificationStatement stmt,
QueryOptions options,
long timestamp) |
static ResultSet |
ModificationStatement.buildCasResultSet(java.lang.String ksName,
java.lang.String tableName,
RowIterator partition,
java.lang.Iterable<ColumnDefinition> columnsWithConditions,
boolean isBatch,
QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
ModificationStatement.buildPartitionKeyNames(QueryOptions options) |
java.util.NavigableSet<Clustering> |
ModificationStatement.createClustering(QueryOptions options) |
ResultMessage |
AuthenticationStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
AuthorizationStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
BatchStatement.execute(QueryState queryState,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
DropIndexStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
ModificationStatement.execute(QueryState queryState,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
SchemaAlteringStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage.Rows |
SelectStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
TruncateStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
UseStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
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,
int nowInSec,
long queryStartNanoTime) |
ResultMessage |
ModificationStatement.executeInternalWithCondition(QueryState state,
QueryOptions options) |
ResultMessage |
ModificationStatement.executeInternalWithoutCondition(QueryState queryState,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
ModificationStatement.executeWithCondition(QueryState queryState,
QueryOptions options,
long queryStartNanoTime) |
int |
SelectStatement.getLimit(QueryOptions options)
Returns the limit specified by the user.
|
int |
SelectStatement.getPerPartitionLimit(QueryOptions options)
Returns the per partition limit specified by the user.
|
ReadQuery |
SelectStatement.getQuery(QueryOptions options,
int nowInSec) |
ReadQuery |
SelectStatement.getQuery(QueryOptions options,
int nowInSec,
int userLimit,
int perPartitionLimit,
int pageSize) |
RowFilter |
SelectStatement.getRowFilter(QueryOptions options)
May be used by custom QueryHandler implementations
|
long |
ModificationStatement.getTimestamp(long now,
QueryOptions options) |
int |
ModificationStatement.getTimeToLive(QueryOptions options) |
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 © 2017 The Apache Software Foundation