Package | Description |
---|---|
org.apache.cassandra.cql3 | |
org.apache.cassandra.cql3.functions | |
org.apache.cassandra.cql3.statements | |
org.apache.cassandra.transport.messages |
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.create(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values,
boolean skipMetadata,
int pageSize,
PagingState pagingState,
ConsistencyLevel serialConsistency) |
static QueryOptions |
QueryOptions.forInternalCalls(ConsistencyLevel consistency,
java.util.List<java.nio.ByteBuffer> values) |
static QueryOptions |
QueryOptions.forInternalCalls(java.util.List<java.nio.ByteBuffer> values) |
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) |
QueryOptions |
QueryOptions.prepare(java.util.List<ColumnSpecification> specs) |
Modifier and Type | Method and Description |
---|---|
ColumnCondition.Bound |
ColumnCondition.bind(QueryOptions options) |
Constants.Value |
Constants.Marker.bind(QueryOptions options) |
Lists.Value |
Lists.DelayedValue.bind(QueryOptions options) |
Lists.Value |
Lists.Marker.bind(QueryOptions options) |
Maps.Value |
Maps.DelayedValue.bind(QueryOptions options) |
Maps.Value |
Maps.Marker.bind(QueryOptions options) |
Sets.Value |
Sets.DelayedValue.bind(QueryOptions options) |
Sets.Value |
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)
Variante 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) |
java.nio.ByteBuffer |
Constants.Value.get(QueryOptions options) |
java.nio.ByteBuffer |
Lists.Value.get(QueryOptions options) |
java.nio.ByteBuffer |
Maps.Value.get(QueryOptions options) |
java.nio.ByteBuffer |
Sets.Value.get(QueryOptions options) |
abstract java.nio.ByteBuffer |
Term.Terminal.get(QueryOptions options) |
java.nio.ByteBuffer |
Tuples.Value.get(QueryOptions options) |
java.nio.ByteBuffer |
Tuples.InValue.get(QueryOptions options) |
long |
Attributes.getTimestamp(long now,
QueryOptions options) |
int |
Attributes.getTimeToLive(QueryOptions options,
CFMetaData metadata) |
ResultMessage |
QueryHandler.process(java.lang.String query,
QueryState state,
QueryOptions options) |
ResultMessage |
QueryProcessor.process(java.lang.String queryString,
QueryState queryState,
QueryOptions options) |
ResultMessage |
QueryHandler.processPrepared(CQLStatement statement,
QueryState state,
QueryOptions options) |
ResultMessage |
QueryProcessor.processPrepared(CQLStatement statement,
QueryState queryState,
QueryOptions options) |
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 |
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) |
java.nio.ByteBuffer |
MultiColumnRestriction.Slice.bound(Bound b,
QueryOptions options) |
java.nio.ByteBuffer |
Restriction.Slice.bound(Bound b,
QueryOptions options) |
java.nio.ByteBuffer |
SingleColumnRestriction.Slice.bound(Bound b,
QueryOptions options) |
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) |
java.util.List<java.nio.ByteBuffer> |
MultiColumnRestriction.Slice.componentBounds(Bound b,
QueryOptions options)
Similar to bounds(), but returns one ByteBuffer per-component in the bound instead of a single
ByteBuffer to represent the entire bound.
|
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) |
AbstractBounds<RowPosition> |
SelectStatement.getKeyBounds(QueryOptions options)
May be used by custom QueryHandler implementations
|
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
|
java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.Contains.keys(QueryOptions options) |
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) |
java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.IN.splitValues(QueryOptions options) |
java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.InWithValues.splitValues(QueryOptions options) |
java.util.List<java.util.List<java.nio.ByteBuffer>> |
MultiColumnRestriction.InWithMarker.splitValues(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
MultiColumnRestriction.EQ.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
Restriction.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
Restriction.Slice.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.EQ.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.InWithValues.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.InWithMarker.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.Slice.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.Contains.values(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 © 2020 The Apache Software Foundation