Modifier and Type | Method and Description |
---|---|
void |
CFMetaData.addTriggerDefinition(TriggerDefinition def) |
void |
CFMetaData.renameColumn(ColumnIdentifier from,
ColumnIdentifier to) |
Modifier and Type | Method and Description |
---|---|
abstract boolean |
ColumnCondition.Bound.appliesTo(Composite rowPrefix,
ColumnFamily current,
long now)
Validates whether this condition applies to
current . |
boolean |
ColumnCondition.CollectionInBound.appliesTo(Composite rowPrefix,
ColumnFamily current,
long now) |
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 . |
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.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) |
void |
CQLStatement.checkAccess(ClientState state)
Perform any access verification necessary for the statement.
|
protected boolean |
ColumnCondition.Bound.compareWithOperator(Operator operator,
AbstractType<?> type,
java.nio.ByteBuffer value,
java.nio.ByteBuffer otherValue)
Returns true if the operator is satisfied (i.e.
|
void |
Constants.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Constants.Adder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Constants.Substracter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Constants.Deleter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Lists.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Lists.SetterByIndex.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Lists.Appender.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Lists.Prepender.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Lists.Discarder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Lists.DiscarderByIndex.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Maps.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Maps.SetterByKey.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Maps.Putter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Maps.DiscarderByKey.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
abstract void |
Operation.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params)
Execute the operation.
|
void |
Sets.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Sets.Adder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Sets.Discarder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
Sets.ElementDiscarder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
Composite prefix,
UpdateParameters params) |
void |
CQL3Type.Raw.freeze() |
static Lists.Value |
Lists.Value.fromSerialized(java.nio.ByteBuffer value,
ListType type,
int version) |
static Tuples.InValue |
Tuples.InValue.fromSerialized(java.nio.ByteBuffer value,
ListType type,
QueryOptions options) |
static Maps.Value |
Maps.Value.fromSerialized(java.nio.ByteBuffer value,
MapType type,
int version) |
static Sets.Value |
Sets.Value.fromSerialized(java.nio.ByteBuffer value,
SetType type,
int version) |
static CQL3Type.Raw |
CQL3Type.Raw.frozen(CQL3Type.Raw t) |
abstract java.nio.ByteBuffer |
Term.Terminal.get(int protocolVersion) |
Term |
QueryOptions.getJsonColumnValue(int bindIndex,
ColumnIdentifier columnName,
java.util.Collection<ColumnDefinition> expectedReceivers)
Returns the term corresponding to column
columnName in the JSON value of bind index bindIndex . |
long |
Attributes.getTimestamp(long now,
QueryOptions options) |
int |
Attributes.getTimeToLive(QueryOptions options,
CFMetaData metadata) |
protected boolean |
ColumnCondition.Bound.isSatisfiedByValue(java.nio.ByteBuffer value,
Cell c,
AbstractType<?> type,
Operator operator,
long now) |
Cell |
UpdateParameters.makeColumn(CellName name,
java.nio.ByteBuffer value) |
Cell |
UpdateParameters.makeCounter(CellName name,
long delta) |
RangeTombstone |
UpdateParameters.makeRangeTombstone(ColumnSlice slice) |
Cell |
UpdateParameters.makeTombstone(CellName name) |
RangeTombstone |
UpdateParameters.makeTombstoneForOverwrite(ColumnSlice slice) |
static void |
Attributes.maybeApplyExpirationDateOverflowPolicy(CFMetaData metadata,
int ttl,
boolean isDefaultTTL) |
protected Restriction |
MultiColumnRelation.newContainsRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
boolean isKey) |
protected abstract Restriction |
Relation.newContainsRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
boolean isKey)
Creates a new Contains restriction instance.
|
protected Restriction |
SingleColumnRelation.newContainsRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
boolean isKey) |
protected Restriction |
TokenRelation.newContainsRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
boolean isKey) |
protected Restriction |
MultiColumnRelation.newEQRestriction(CFMetaData cfm,
VariableSpecifications boundNames) |
protected abstract Restriction |
Relation.newEQRestriction(CFMetaData cfm,
VariableSpecifications boundNames)
Creates a new EQ restriction instance.
|
protected Restriction |
SingleColumnRelation.newEQRestriction(CFMetaData cfm,
VariableSpecifications boundNames) |
protected Restriction |
TokenRelation.newEQRestriction(CFMetaData cfm,
VariableSpecifications boundNames) |
protected Restriction |
MultiColumnRelation.newINRestriction(CFMetaData cfm,
VariableSpecifications boundNames) |
protected abstract Restriction |
Relation.newINRestriction(CFMetaData cfm,
VariableSpecifications boundNames)
Creates a new IN restriction instance.
|
protected Restriction |
SingleColumnRelation.newINRestriction(CFMetaData cfm,
VariableSpecifications boundNames) |
protected Restriction |
TokenRelation.newINRestriction(CFMetaData cfm,
VariableSpecifications boundNames) |
Selector.Factory |
ColumnIdentifier.newSelectorFactory(CFMetaData cfm,
java.util.List<ColumnDefinition> defs) |
protected Restriction |
MultiColumnRelation.newSliceRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
Bound bound,
boolean inclusive) |
protected abstract Restriction |
Relation.newSliceRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
Bound bound,
boolean inclusive)
Creates a new Slice restriction instance.
|
protected Restriction |
SingleColumnRelation.newSliceRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
Bound bound,
boolean inclusive) |
protected Restriction |
TokenRelation.newSliceRestriction(CFMetaData cfm,
VariableSpecifications boundNames,
Bound bound,
boolean inclusive) |
abstract CQL3Type |
CQL3Type.Raw.prepare(java.lang.String keyspace) |
ColumnCondition |
ColumnCondition.Raw.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Operation |
Operation.RawUpdate.prepare(java.lang.String keyspace,
ColumnDefinition receiver)
This method validates the operation (i.e.
|
Operation |
Operation.RawDeletion.prepare(java.lang.String keyspace,
ColumnDefinition receiver)
This method validates the operation (i.e.
|
Operation |
Operation.SetValue.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Operation |
Operation.SetElement.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Operation |
Operation.Addition.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Operation |
Operation.Substraction.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Operation |
Operation.Prepend.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Operation |
Operation.ColumnDeletion.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Operation |
Operation.ElementDeletion.prepare(java.lang.String keyspace,
ColumnDefinition receiver) |
Term.NonTerminal |
AbstractMarker.Raw.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
AbstractMarker |
AbstractMarker.INRaw.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Constants.Value |
Constants.Literal.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term |
Lists.Literal.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term |
Maps.Literal.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term |
Sets.Literal.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term |
Term.Raw.prepare(java.lang.String keyspace,
ColumnSpecification receiver)
This method validates this RawTerm is valid for provided column
specification and "prepare" this RawTerm, returning the resulting
prepared Term.
|
Term |
Tuples.Literal.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term |
TypeCast.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term |
UserTypes.Literal.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term |
Term.MultiColumnRaw.prepare(java.lang.String keyspace,
java.util.List<? extends ColumnSpecification> receiver) |
Term |
Tuples.Literal.prepare(java.lang.String keyspace,
java.util.List<? extends ColumnSpecification> receivers) |
AbstractMarker |
Tuples.Raw.prepare(java.lang.String keyspace,
java.util.List<? extends ColumnSpecification> receivers) |
AbstractMarker |
Tuples.INRaw.prepare(java.lang.String keyspace,
java.util.List<? extends ColumnSpecification> receivers) |
Attributes |
Attributes.Raw.prepare(java.lang.String ksName,
java.lang.String cfName) |
protected java.util.List<ColumnDefinition> |
MultiColumnRelation.receivers(CFMetaData cfm) |
protected ColumnDefinition |
Relation.toColumnDefinition(CFMetaData cfm,
ColumnIdentifier.Raw entity)
Converts the specified entity into a column definition.
|
Restriction |
Relation.toRestriction(CFMetaData cfm,
VariableSpecifications boundNames)
Converts this
Relation into a Restriction . |
protected Term |
MultiColumnRelation.toTerm(java.util.List<? extends ColumnSpecification> receivers,
Term.Raw raw,
java.lang.String keyspace,
VariableSpecifications boundNames) |
protected abstract Term |
Relation.toTerm(java.util.List<? extends ColumnSpecification> receivers,
Term.Raw raw,
java.lang.String keyspace,
VariableSpecifications boundNames)
Converts the specified
Raw into a Term . |
protected Term |
SingleColumnRelation.toTerm(java.util.List<? extends ColumnSpecification> receivers,
Term.Raw raw,
java.lang.String keyspace,
VariableSpecifications boundNames) |
protected Term |
TokenRelation.toTerm(java.util.List<? extends ColumnSpecification> receivers,
Term.Raw raw,
java.lang.String keyspace,
VariableSpecifications boundNames) |
protected java.util.List<Term> |
Relation.toTerms(java.util.List<? extends ColumnSpecification> receivers,
java.util.List<? extends Term.Raw> raws,
java.lang.String keyspace,
VariableSpecifications boundNames)
Converts the specified
Raw terms into a Term s. |
static void |
QueryProcessor.validateCellName(CellName name,
CellNameType type) |
static void |
QueryProcessor.validateCellNames(java.lang.Iterable<CellName> cellNames,
CellNameType type) |
static void |
QueryProcessor.validateComposite(Composite name,
CType type) |
static void |
QueryProcessor.validateKey(java.nio.ByteBuffer key) |
Constructor and Description |
---|
UpdateParameters(CFMetaData metadata,
QueryOptions options,
long timestamp,
int ttl,
java.util.Map<java.nio.ByteBuffer,CQL3Row> prefetchedLists) |
Modifier and Type | Method and Description |
---|---|
static UDAggregate |
UDAggregate.createBroken(FunctionName name,
java.util.List<AbstractType<?>> argTypes,
AbstractType<?> returnType,
java.nio.ByteBuffer initcond,
InvalidRequestException reason) |
static UDFunction |
UDFunction.createBrokenFunction(FunctionName name,
java.util.List<ColumnIdentifier> argNames,
java.util.List<AbstractType<?>> argTypes,
AbstractType<?> returnType,
boolean calledOnNullInput,
java.lang.String language,
java.lang.String body,
InvalidRequestException reason)
It can happen that a function has been declared (is listed in the scheam) but cannot
be loaded (maybe only on some nodes).
|
Modifier and Type | Method and Description |
---|---|
void |
AggregateFunction.Aggregate.addInput(int protocolVersion,
java.util.List<java.nio.ByteBuffer> values)
Adds the specified input to this aggregate.
|
Term.Terminal |
FunctionCall.bind(QueryOptions options) |
java.nio.ByteBuffer |
FunctionCall.bindAndGet(QueryOptions options) |
java.nio.ByteBuffer |
AggregateFunction.Aggregate.compute(int protocolVersion)
Computes and returns the aggregate current value.
|
static UDAggregate |
UDAggregate.create(FunctionName name,
java.util.List<AbstractType<?>> argTypes,
AbstractType<?> returnType,
FunctionName stateFunc,
FunctionName finalFunc,
AbstractType<?> stateType,
java.nio.ByteBuffer initcond) |
static UDFunction |
UDFunction.create(FunctionName name,
java.util.List<ColumnIdentifier> argNames,
java.util.List<AbstractType<?>> argTypes,
AbstractType<?> returnType,
boolean calledOnNullInput,
java.lang.String language,
java.lang.String body) |
java.nio.ByteBuffer |
ScalarFunction.execute(int protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters)
Applies this function to the specified parameter.
|
java.nio.ByteBuffer |
ToJsonFct.execute(int protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters) |
java.nio.ByteBuffer |
TokenFct.execute(int protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters) |
java.nio.ByteBuffer |
UDFunction.execute(int protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters) |
java.nio.ByteBuffer |
ScriptBasedUDF.executeUserDefined(int protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters) |
protected abstract java.nio.ByteBuffer |
UDFunction.executeUserDefined(int protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters) |
static Function |
Functions.get(java.lang.String keyspace,
FunctionName name,
java.util.List<? extends AssignmentTestable> providedArgs,
java.lang.String receiverKs,
java.lang.String receiverCf,
AbstractType<?> receiverType) |
static ToJsonFct |
ToJsonFct.getInstance(java.util.List<AbstractType<?>> argTypes) |
AggregateFunction.Aggregate |
AggregateFunction.newAggregate()
Creates a new
Aggregate instance. |
AggregateFunction.Aggregate |
UDAggregate.newAggregate() |
Term |
FunctionCall.Raw.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
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) |
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) |
protected abstract Restriction |
MultiColumnRestriction.doMergeWith(Restriction otherRestriction) |
Restriction |
MultiColumnRestriction.EQ.doMergeWith(Restriction otherRestriction) |
Restriction |
MultiColumnRestriction.IN.doMergeWith(Restriction otherRestriction) |
Restriction |
MultiColumnRestriction.Slice.doMergeWith(Restriction otherRestriction) |
protected abstract Restriction |
SingleColumnRestriction.doMergeWith(Restriction otherRestriction) |
Restriction |
SingleColumnRestriction.EQ.doMergeWith(Restriction otherRestriction) |
Restriction |
SingleColumnRestriction.IN.doMergeWith(Restriction otherRestriction) |
Restriction |
SingleColumnRestriction.Slice.doMergeWith(Restriction otherRestriction) |
Restriction |
SingleColumnRestriction.Contains.doMergeWith(Restriction otherRestriction) |
protected abstract org.apache.cassandra.cql3.restrictions.PrimaryKeyRestrictions |
TokenRestriction.doMergeWith(TokenRestriction otherRestriction)
Merges this restriction with the specified
TokenRestriction . |
protected org.apache.cassandra.cql3.restrictions.PrimaryKeyRestrictions |
TokenRestriction.EQ.doMergeWith(TokenRestriction otherRestriction) |
protected org.apache.cassandra.cql3.restrictions.PrimaryKeyRestrictions |
TokenRestriction.Slice.doMergeWith(TokenRestriction otherRestriction) |
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) |
Restriction |
MultiColumnRestriction.mergeWith(Restriction otherRestriction) |
Restriction |
Restriction.mergeWith(Restriction otherRestriction)
Merges this restriction with the specified one.
|
Restriction |
SingleColumnRestriction.mergeWith(Restriction otherRestriction) |
org.apache.cassandra.cql3.restrictions.PrimaryKeyRestrictions |
TokenRestriction.mergeWith(Restriction otherRestriction) |
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 |
---|---|
abstract void |
Selector.addInput(int protocolVersion,
Selection.ResultSetBuilder rs)
Add the current value from the specified
ResultSetBuilder . |
void |
SimpleSelector.addInput(int protocolVersion,
Selection.ResultSetBuilder rs) |
ResultSet |
Selection.ResultSetBuilder.build(int protocolVersion) |
static Selection |
Selection.fromSelectors(CFMetaData cfm,
java.util.List<RawSelector> rawSelectors) |
abstract java.nio.ByteBuffer |
Selector.getOutput(int protocolVersion)
Returns the selector output.
|
java.nio.ByteBuffer |
SimpleSelector.getOutput(int protocolVersion) |
abstract Selector |
Selector.Factory.newInstance()
Creates a new
Selector instance. |
void |
Selection.ResultSetBuilder.newRow(int protocolVersion) |
abstract Selector.Factory |
Selectable.newSelectorFactory(CFMetaData cfm,
java.util.List<ColumnDefinition> defs) |
Selector.Factory |
Selectable.WritetimeOrTTL.newSelectorFactory(CFMetaData cfm,
java.util.List<ColumnDefinition> defs) |
Selector.Factory |
Selectable.WithFunction.newSelectorFactory(CFMetaData cfm,
java.util.List<ColumnDefinition> defs) |
Selector.Factory |
Selectable.WithFieldSelection.newSelectorFactory(CFMetaData cfm,
java.util.List<ColumnDefinition> defs) |
protected abstract org.apache.cassandra.cql3.selection.Selection.Selectors |
Selection.newSelectors() |
Selection.ResultSetBuilder |
Selection.resultSetBuilder(long now,
boolean isJson) |
Modifier and Type | Method and Description |
---|---|
static InvalidRequestException |
RequestValidations.invalidRequest(java.lang.String messageTemplate,
java.lang.Object... messageArgs)
Returns an
InvalidRequestException with the specified message. |
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.addExist(Composite prefix) |
void |
ModificationStatement.addKeyValue(ColumnDefinition def,
Term value) |
void |
CQL3CasRequest.addNotExist(Composite prefix) |
void |
DeleteStatement.addUpdateForKey(ColumnFamily cf,
java.nio.ByteBuffer key,
Composite prefix,
UpdateParameters params) |
abstract void |
ModificationStatement.addUpdateForKey(ColumnFamily updates,
java.nio.ByteBuffer key,
Composite prefix,
UpdateParameters params) |
void |
UpdateStatement.addUpdateForKey(ColumnFamily cf,
java.nio.ByteBuffer key,
Composite prefix,
UpdateParameters params) |
void |
UpdateStatement.addUpdateForKey(ColumnFamily cf,
java.nio.ByteBuffer key,
Composite prefix,
UpdateParameters params,
boolean validateIndexedColumns) |
boolean |
AlterTypeStatement.announceMigration(boolean isLocalOnly) |
boolean |
CreateTriggerStatement.announceMigration(boolean isLocalOnly) |
boolean |
CreateTypeStatement.announceMigration(boolean isLocalOnly) |
boolean |
DropIndexStatement.announceMigration(boolean isLocalOnly) |
boolean |
DropTriggerStatement.announceMigration(boolean isLocalOnly) |
boolean |
DropTypeStatement.announceMigration(boolean isLocalOnly) |
boolean |
CQL3CasRequest.appliesTo(ColumnFamily current) |
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) |
void |
AlterKeyspaceStatement.checkAccess(ClientState state) |
void |
AlterTableStatement.checkAccess(ClientState state) |
void |
AlterTypeStatement.checkAccess(ClientState state) |
void |
BatchStatement.checkAccess(ClientState state) |
void |
CreateAggregateStatement.checkAccess(ClientState state) |
void |
CreateFunctionStatement.checkAccess(ClientState state) |
void |
CreateIndexStatement.checkAccess(ClientState state) |
void |
CreateTableStatement.checkAccess(ClientState state) |
void |
CreateTypeStatement.checkAccess(ClientState state) |
void |
DropAggregateStatement.checkAccess(ClientState state) |
void |
DropFunctionStatement.checkAccess(ClientState state) |
void |
DropIndexStatement.checkAccess(ClientState state) |
void |
DropKeyspaceStatement.checkAccess(ClientState state) |
void |
DropTableStatement.checkAccess(ClientState state) |
void |
DropTypeStatement.checkAccess(ClientState state) |
void |
ListRolesStatement.checkAccess(ClientState state) |
void |
ModificationStatement.checkAccess(ClientState state) |
void |
SelectStatement.checkAccess(ClientState state) |
void |
TruncateStatement.checkAccess(ClientState state) |
static void |
RequestValidations.checkBindValueSet(java.nio.ByteBuffer b,
java.lang.String messageTemplate,
java.lang.Object... messageArgs)
Checks that the specified bind marker value is set to a meaningful value.
|
static void |
RequestValidations.checkContainsNoDuplicates(java.util.List<?> list,
java.lang.String message)
Checks that the specified list does not contains duplicates.
|
static <E> void |
RequestValidations.checkContainsOnly(java.util.List<E> list,
java.util.List<E> expectedElements,
java.lang.String message)
Checks that the specified list contains only the specified elements.
|
static void |
RequestValidations.checkFalse(boolean expression,
java.lang.String message)
Checks that the specified expression is
false . |
static void |
RequestValidations.checkFalse(boolean expression,
java.lang.String messageTemplate,
java.lang.Object... messageArgs)
Checks that the specified expression is
false . |
static void |
CreateTypeStatement.checkForDuplicateNames(UserType type) |
static <T> T |
RequestValidations.checkNotNull(T object,
java.lang.String messageTemplate,
java.lang.Object... messageArgs)
Checks that the specified object is NOT
null . |
static <T> T |
RequestValidations.checkNull(T object,
java.lang.String message)
Checks that the specified object is
null . |
static <T> T |
RequestValidations.checkNull(T object,
java.lang.String messageTemplate,
java.lang.Object... messageArgs)
Checks that the specified object is
null . |
static void |
RequestValidations.checkTrue(boolean expression,
java.lang.String message)
Checks that the specified expression is
true . |
static void |
RequestValidations.checkTrue(boolean expression,
java.lang.String messageTemplate,
java.lang.Object... messageArgs)
Checks that the specified expression is
true . |
Composite |
ModificationStatement.createClusteringPrefix(QueryOptions options) |
ResultMessage |
TruncateStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
UseStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
UseStatement.executeInternal(QueryState state,
QueryOptions options) |
int |
SelectStatement.getLimit(QueryOptions options)
May be used by custom QueryHandler implementations
|
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
|
protected abstract UserType |
AlterTypeStatement.makeUpdatedType(UserType toUpdate) |
ColumnFamily |
CQL3CasRequest.makeUpdates(ColumnFamily current) |
static IResource |
AuthorizationStatement.maybeCorrectResource(IResource resource,
ClientState state) |
ParsedStatement.Prepared |
BatchStatement.Parsed.prepare() |
ParsedStatement.Prepared |
CreateFunctionStatement.prepare() |
ParsedStatement.Prepared |
DropFunctionStatement.prepare() |
ParsedStatement.Prepared |
ModificationStatement.Parsed.prepare() |
ParsedStatement.Prepared |
SelectStatement.RawStatement.prepare() |
ParsedStatement.Prepared |
TruncateStatement.prepare() |
ParsedStatement.Prepared |
UseStatement.prepare() |
ModificationStatement |
ModificationStatement.Parsed.prepare(VariableSpecifications boundNames) |
protected ModificationStatement |
DeleteStatement.Parsed.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
protected abstract ModificationStatement |
ModificationStatement.Parsed.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
protected ModificationStatement |
UpdateStatement.ParsedInsert.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
protected ModificationStatement |
UpdateStatement.ParsedInsertJson.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
protected ModificationStatement |
UpdateStatement.ParsedUpdate.prepareInternal(CFMetaData cfm,
VariableSpecifications boundNames,
Attributes attrs) |
void |
AlterTypeStatement.prepareKeyspace(ClientState state) |
void |
BatchStatement.Parsed.prepareKeyspace(ClientState state) |
void |
CFStatement.prepareKeyspace(ClientState state) |
void |
CreateAggregateStatement.prepareKeyspace(ClientState state) |
void |
CreateFunctionStatement.prepareKeyspace(ClientState state) |
void |
CreateTypeStatement.prepareKeyspace(ClientState state) |
void |
DropAggregateStatement.prepareKeyspace(ClientState state) |
void |
DropFunctionStatement.prepareKeyspace(ClientState state) |
void |
DropTypeStatement.prepareKeyspace(ClientState state) |
void |
SchemaAlteringStatement.prepareKeyspace(ClientState state) |
ResultSet |
SelectStatement.process(java.util.List<Row> rows) |
void |
ModificationStatement.processWhereClause(java.util.List<Relation> whereClause,
VariableSpecifications names) |
void |
BatchStatement.validate() |
void |
BatchStatement.validate(ClientState state) |
void |
CreateAggregateStatement.validate(ClientState state) |
void |
CreateFunctionStatement.validate(ClientState state) |
void |
ListRolesStatement.validate(ClientState state) |
void |
ModificationStatement.validate(ClientState state) |
void |
SelectStatement.validate(ClientState state) |
void |
TruncateStatement.validate(ClientState state) |
void |
UseStatement.validate(ClientState state) |
protected void |
DeleteStatement.validateWhereClauseForConditions() |
protected void |
ModificationStatement.validateWhereClauseForConditions()
If there are conditions on the statement, this is called after the where clause and conditions have been
processed to check that they are compatible.
|
static void |
BatchStatement.verifyBatchSize(java.lang.Iterable<ColumnFamily> cfs)
Checks batch size to ensure threshold is met.
|
Modifier and Type | Class and Description |
---|---|
class |
KeyspaceNotDefinedException |
Modifier and Type | Method and Description |
---|---|
void |
ConsistencyLevel.validateCounterForWrite(CFMetaData metadata) |
void |
ConsistencyLevel.validateForCas() |
void |
ConsistencyLevel.validateForCasCommit(java.lang.String keyspaceName) |
void |
ConsistencyLevel.validateForRead(java.lang.String keyspaceName) |
void |
ConsistencyLevel.validateForWrite(java.lang.String keyspaceName) |
Modifier and Type | Method and Description |
---|---|
void |
PerRowSecondaryIndex.validate(java.nio.ByteBuffer key,
ColumnFamily cf) |
void |
SecondaryIndexSearcher.validate(IndexExpression indexExpression)
Validates the specified
IndexExpression . |
void |
SecondaryIndexManager.validateIndexSearchersForQuery(java.util.List<IndexExpression> clause)
Validates an union of expression index types.
|
void |
SecondaryIndexManager.validateRowLevelIndexes(java.nio.ByteBuffer key,
ColumnFamily cf) |
Modifier and Type | Class and Description |
---|---|
class |
UnrecognizedEntityException
Exception thrown when an entity is not recognized within a relation.
|
Modifier and Type | Method and Description |
---|---|
protected org.apache.cassandra.thrift.CfDef |
CassandraStorage.getCfDef(org.apache.cassandra.thrift.Cassandra.Client client)
Deprecated.
return the CfInfo for the column family
|
protected CFMetaData |
CassandraStorage.getCFMetaData(java.lang.String ks,
java.lang.String cf,
org.apache.cassandra.thrift.Cassandra.Client client)
Deprecated.
get CFMetaData of a column family
|
protected java.util.List<org.apache.cassandra.thrift.ColumnDef> |
CassandraStorage.getColumnMeta(org.apache.cassandra.thrift.Cassandra.Client client,
boolean cassandraStorage,
boolean includeCompactValueColumn)
Deprecated.
get column meta data
|
protected java.util.List<org.apache.cassandra.thrift.ColumnDef> |
CassandraStorage.getColumnMetadata(org.apache.cassandra.thrift.Cassandra.Client client)
Deprecated.
get a list of column for the column family
|
Modifier and Type | Method and Description |
---|---|
CQLSSTableWriter |
CQLSSTableWriter.addRow(java.util.List<java.lang.Object> values)
Adds a new row to the writer.
|
CQLSSTableWriter |
CQLSSTableWriter.addRow(java.util.Map<java.lang.String,java.lang.Object> values)
Adds a new row to the writer.
|
CQLSSTableWriter |
CQLSSTableWriter.addRow(java.lang.Object... values)
Adds a new row to the writer.
|
CQLSSTableWriter |
CQLSSTableWriter.rawAddRow(java.nio.ByteBuffer... values)
Adds a new row to the writer given already serialized values.
|
CQLSSTableWriter |
CQLSSTableWriter.rawAddRow(java.util.List<java.nio.ByteBuffer> values)
Adds a new row to the writer given already serialized values.
|
CQLSSTableWriter |
CQLSSTableWriter.rawAddRow(java.util.Map<java.lang.String,java.nio.ByteBuffer> values)
Adds a new row to the writer given already serialized values.
|
Modifier and Type | Method and Description |
---|---|
boolean |
CASRequest.appliesTo(ColumnFamily current)
Returns whether the provided CF, that represents the values fetched using the
readFilter(), match the CAS conditions this object stands for.
|
static ColumnFamily |
StorageProxy.cas(java.lang.String keyspaceName,
java.lang.String cfName,
java.nio.ByteBuffer key,
CASRequest request,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit,
ClientState state)
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
|
java.util.List<org.apache.cassandra.thrift.TokenRange> |
StorageService.describeLocalRing(java.lang.String keyspace)
The same as
describeRing(String) but considers only the part of the ring formed by nodes in the local DC. |
java.util.List<org.apache.cassandra.thrift.TokenRange> |
StorageService.describeRing(java.lang.String keyspace)
The TokenRange for a given keyspace.
|
java.lang.String |
ClientState.getKeyspace() |
void |
ClientState.hasColumnFamilyAccess(java.lang.String keyspace,
java.lang.String columnFamily,
Permission perm) |
void |
ClientState.hasKeyspaceAccess(java.lang.String keyspace,
Permission perm) |
ColumnFamily |
CASRequest.makeUpdates(ColumnFamily current)
The updates to perform of a CAS success.
|
static void |
StorageProxy.mutateWithTriggers(java.util.Collection<? extends IMutation> mutations,
ConsistencyLevel consistencyLevel,
boolean mutateAtomically) |
static java.util.List<Row> |
StorageProxy.read(java.util.List<ReadCommand> commands,
ConsistencyLevel consistencyLevel) |
static java.util.List<Row> |
StorageProxy.read(java.util.List<ReadCommand> commands,
ConsistencyLevel consistencyLevel,
ClientState state)
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
|
void |
ClientState.setKeyspace(java.lang.String ks) |
Modifier and Type | Method and Description |
---|---|
static CFMetaData |
ThriftConversion.fromThrift(org.apache.cassandra.thrift.CfDef cf_def) |
static CFMetaData |
ThriftConversion.fromThriftForUpdate(org.apache.cassandra.thrift.CfDef cf_def,
CFMetaData toUpdate) |
protected java.util.Map<DecoratedKey,ColumnFamily> |
CassandraServer.readColumnFamily(java.util.List<ReadCommand> commands,
ConsistencyLevel consistency_level,
ClientState cState) |
static void |
ThriftValidation.validateColumnData(CFMetaData metadata,
java.nio.ByteBuffer key,
java.nio.ByteBuffer scName,
org.apache.cassandra.thrift.Column column)
Validates the data part of the column (everything in the column object but the name, which is assumed to be valid)
|
static CFMetaData |
ThriftValidation.validateColumnFamily(java.lang.String keyspaceName,
java.lang.String cfName) |
static CFMetaData |
ThriftValidation.validateColumnFamily(java.lang.String keyspaceName,
java.lang.String cfName,
boolean isCommutativeOp) |
static void |
ThriftValidation.validateColumnNames(CFMetaData metadata,
org.apache.cassandra.thrift.ColumnParent column_parent,
java.lang.Iterable<java.nio.ByteBuffer> column_names) |
static void |
ThriftValidation.validateColumnOrSuperColumn(CFMetaData metadata,
java.nio.ByteBuffer key,
org.apache.cassandra.thrift.ColumnOrSuperColumn cosc) |
static void |
ThriftValidation.validateColumnParent(CFMetaData metadata,
org.apache.cassandra.thrift.ColumnParent column_parent) |
static void |
ThriftValidation.validateColumnPath(CFMetaData metadata,
org.apache.cassandra.thrift.ColumnPath column_path)
validates all parts of the path to the column, including the column name
|
static void |
ThriftValidation.validateDeletion(CFMetaData metadata,
org.apache.cassandra.thrift.Deletion del) |
static boolean |
ThriftValidation.validateFilterClauses(CFMetaData metadata,
java.util.List<org.apache.cassandra.thrift.IndexExpression> index_clause) |
static void |
ThriftValidation.validateIndexClauses(CFMetaData metadata,
org.apache.cassandra.thrift.IndexClause index_clause) |
static void |
ThriftValidation.validateKey(CFMetaData metadata,
java.nio.ByteBuffer key) |
static void |
ThriftValidation.validateKeyRange(CFMetaData metadata,
java.nio.ByteBuffer superColumn,
org.apache.cassandra.thrift.KeyRange range) |
static void |
ThriftValidation.validateKeyspaceNotSystem(java.lang.String modifiedKeyspace) |
static void |
ThriftValidation.validateKeyspaceNotYetExisting(java.lang.String newKsName) |
static void |
ThriftValidation.validateMutation(CFMetaData metadata,
java.nio.ByteBuffer key,
org.apache.cassandra.thrift.Mutation mut) |
static void |
ThriftValidation.validatePredicate(CFMetaData metadata,
org.apache.cassandra.thrift.ColumnParent column_parent,
org.apache.cassandra.thrift.SlicePredicate predicate) |
static void |
ThriftValidation.validateRange(CFMetaData metadata,
org.apache.cassandra.thrift.ColumnParent column_parent,
org.apache.cassandra.thrift.SliceRange range) |
static void |
ThriftValidation.validateSlicePredicate(CFMetaData metadata,
java.nio.ByteBuffer scName,
org.apache.cassandra.thrift.SlicePredicate predicate) |
Modifier and Type | Method and Description |
---|---|
ColumnFamily |
TriggerExecutor.execute(java.nio.ByteBuffer key,
ColumnFamily updates)
Augment a partition update by executing triggers to generate an intermediate
set of mutations, then merging the ColumnFamily from each mutation with those
supplied.
|
java.util.Collection<Mutation> |
TriggerExecutor.execute(java.util.Collection<? extends IMutation> mutations)
Takes a collection of mutations and possibly augments it by adding extra mutations
generated by configured triggers.
|
Copyright © 2018 The Apache Software Foundation