Modifier and Type | Method and Description |
---|---|
void |
AllowAllAuthenticator.alter(java.lang.String username,
java.util.Map<IAuthenticator.Option,java.lang.Object> options) |
void |
AllowAllAuthenticator.create(java.lang.String username,
java.util.Map<IAuthenticator.Option,java.lang.Object> options) |
void |
PasswordAuthenticator.create(java.lang.String username,
java.util.Map<IAuthenticator.Option,java.lang.Object> options) |
void |
AllowAllAuthenticator.drop(java.lang.String username) |
void |
AllowAllAuthorizer.grant(AuthenticatedUser performer,
java.util.Set<Permission> permissions,
IResource resource,
java.lang.String to) |
void |
LegacyAuthorizer.grant(AuthenticatedUser performer,
java.util.Set<Permission> permissions,
IResource resource,
java.lang.String to) |
java.util.Set<PermissionDetails> |
AllowAllAuthorizer.list(AuthenticatedUser performer,
java.util.Set<Permission> permissions,
IResource resource,
java.lang.String of) |
java.util.Set<PermissionDetails> |
LegacyAuthorizer.list(AuthenticatedUser performer,
java.util.Set<Permission> permissions,
IResource resource,
java.lang.String of) |
void |
AllowAllAuthorizer.revoke(AuthenticatedUser performer,
java.util.Set<Permission> permissions,
IResource resource,
java.lang.String from) |
void |
LegacyAuthorizer.revoke(AuthenticatedUser performer,
java.util.Set<Permission> permissions,
IResource resource,
java.lang.String from) |
Modifier and Type | Method and Description |
---|---|
void |
CFMetaData.addTriggerDefinition(TriggerDefinition def) |
static CFMetaData |
CFMetaData.fromThrift(org.apache.cassandra.thrift.CfDef cf_def) |
static CFMetaData |
CFMetaData.fromThriftForUpdate(org.apache.cassandra.thrift.CfDef cf_def,
CFMetaData toUpdate) |
void |
CFMetaData.renameColumn(ColumnIdentifier from,
ColumnIdentifier to) |
Modifier and Type | Method and Description |
---|---|
static void |
AlterTableStatement.applyPropertiesToCFMetadata(CFMetaData cfm,
CFPropDefs cfProps) |
CFMetaData |
DropIndexStatement.generateCFMetadataUpdate() |
java.nio.ByteBuffer |
Term.getByteBuffer()
Returns the typed value, serialized to a ByteBuffer.
|
java.nio.ByteBuffer |
Term.getByteBuffer(AbstractType<?> validator,
java.util.List<java.nio.ByteBuffer> variables)
Returns the typed value, serialized to a ByteBuffer according to a
comparator/validator.
|
CFMetaData |
AlterTableStatement.getCFMetaData(java.lang.String keyspace) |
CFMetaData |
CreateColumnFamilyStatement.getCFMetaData(java.lang.String keyspace,
java.util.List<java.nio.ByteBuffer> variables)
Returns a CFMetaData instance based on the parameters parsed from this
CREATE statement, or defaults where applicable. |
java.lang.String |
DropIndexStatement.getColumnFamily() |
java.util.Map<Term,Operation> |
UpdateStatement.getColumns() |
java.util.List<IMutation> |
BatchStatement.getMutations(java.lang.String keyspace,
ThriftClientState clientState,
java.util.List<java.nio.ByteBuffer> variables) |
java.lang.Double |
CFPropDefs.getPropertyDouble(java.lang.String key,
java.lang.Double defaultValue) |
java.lang.Integer |
CFPropDefs.getPropertyInt(java.lang.String key,
java.lang.Integer defaultValue) |
Mutation |
DeleteStatement.mutationForKey(java.nio.ByteBuffer key,
java.lang.String keyspace,
java.lang.Long timestamp,
ThriftClientState clientState,
java.util.List<java.nio.ByteBuffer> variables,
CFMetaData metadata) |
abstract java.util.List<IMutation> |
AbstractModification.prepareRowMutations(java.lang.String keyspace,
ThriftClientState clientState,
java.util.List<java.nio.ByteBuffer> variables)
Convert statement into a list of mutations to apply on the server
|
java.util.List<IMutation> |
DeleteStatement.prepareRowMutations(java.lang.String keyspace,
ThriftClientState clientState,
java.util.List<java.nio.ByteBuffer> variables) |
java.util.List<IMutation> |
UpdateStatement.prepareRowMutations(java.lang.String keyspace,
ThriftClientState clientState,
java.util.List<java.nio.ByteBuffer> variables)
Convert statement into a list of mutations to apply on the server
|
abstract java.util.List<IMutation> |
AbstractModification.prepareRowMutations(java.lang.String keyspace,
ThriftClientState clientState,
java.lang.Long timestamp,
java.util.List<java.nio.ByteBuffer> variables)
Convert statement into a list of mutations to apply on the server
|
java.util.List<IMutation> |
DeleteStatement.prepareRowMutations(java.lang.String keyspace,
ThriftClientState clientState,
java.lang.Long timestamp,
java.util.List<java.nio.ByteBuffer> variables) |
java.util.List<IMutation> |
UpdateStatement.prepareRowMutations(java.lang.String keyspace,
ThriftClientState clientState,
java.lang.Long timestamp,
java.util.List<java.nio.ByteBuffer> variables)
Convert statement into a list of mutations to apply on the server
|
void |
CFPropDefs.validate() |
void |
CreateKeyspaceStatement.validate()
The
CqlParser only goes as far as extracting the keyword arguments
from these statements, so this method is responsible for processing and
validating, and must be called prior to access. |
static void |
QueryProcessor.validateColumn(CFMetaData metadata,
CellName name,
java.nio.ByteBuffer value) |
static void |
QueryProcessor.validateColumnName(CellName column) |
static void |
QueryProcessor.validateKey(java.nio.ByteBuffer key) |
static void |
QueryProcessor.validateKeyAlias(CFMetaData cfm,
java.lang.String key) |
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) |
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 . |
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) |
long |
Attributes.getTimestamp(long now,
QueryOptions options) |
int |
Attributes.getTimeToLive(QueryOptions options) |
boolean |
AssignementTestable.isAssignableTo(java.lang.String keyspace,
ColumnSpecification receiver) |
boolean |
TypeCast.isAssignableTo(java.lang.String keyspace,
ColumnSpecification receiver) |
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) |
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) |
AbstractMarker |
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) |
void |
UserOptions.validate() |
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 |
---|---|
Term.Terminal |
FunctionCall.bind(QueryOptions options) |
java.nio.ByteBuffer |
FunctionCall.bindAndGet(QueryOptions options) |
java.nio.ByteBuffer |
Function.execute(java.util.List<java.nio.ByteBuffer> parameters) |
java.nio.ByteBuffer |
TokenFct.execute(java.util.List<java.nio.ByteBuffer> parameters) |
static Function |
Functions.get(java.lang.String keyspace,
java.lang.String name,
java.util.List<? extends AssignementTestable> providedArgs,
ColumnSpecification receiver) |
Term |
FunctionCall.Raw.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
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) |
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) |
ResultSet |
Selection.ResultSetBuilder.build() |
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 |
CreateIndexStatement.checkAccess(ClientState state) |
void |
CreateTableStatement.checkAccess(ClientState state) |
void |
CreateTypeStatement.checkAccess(ClientState state) |
void |
DropIndexStatement.checkAccess(ClientState state) |
void |
DropKeyspaceStatement.checkAccess(ClientState state) |
void |
DropTableStatement.checkAccess(ClientState state) |
void |
DropTypeStatement.checkAccess(ClientState state) |
void |
ModificationStatement.checkAccess(ClientState state) |
void |
SelectStatement.checkAccess(ClientState state) |
void |
TruncateStatement.checkAccess(ClientState state) |
static void |
CreateTypeStatement.checkForDuplicateNames(UserType type) |
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 |
TruncateStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
UseStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
UseStatement.executeInternal(QueryState state,
QueryOptions options) |
static Selection |
Selection.fromSelectors(CFMetaData cfm,
java.util.List<RawSelector> rawSelectors) |
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
|
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 java.util.List<java.nio.ByteBuffer> |
Selection.handleRow(Selection.ResultSetBuilder rs) |
java.util.List<java.nio.ByteBuffer> |
SingleColumnRestriction.Contains.keys(QueryOptions options) |
protected abstract UserType |
AlterTypeStatement.makeUpdatedType(UserType toUpdate) |
ColumnFamily |
CQL3CasRequest.makeUpdates(ColumnFamily current) |
static DataResource |
AuthorizationStatement.maybeCorrectResource(DataResource resource,
ClientState state) |
void |
Selection.ResultSetBuilder.newRow() |
ParsedStatement.Prepared |
BatchStatement.Parsed.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.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 |
CreateTypeStatement.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 |
Restriction.Slice.setBound(Operator type,
Term t) |
void |
SingleColumnRestriction.Slice.setBound(Operator operator,
Term t) |
void |
Restriction.Slice.setBound(Restriction.Slice restriction) |
void |
SingleColumnRestriction.Slice.setBound(Restriction.Slice slice) |
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) |
void |
BatchStatement.validate() |
void |
BatchStatement.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.
|
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 | 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 | Method and Description |
---|---|
protected AbstractCassandraStorage.CfInfo |
AbstractCassandraStorage.getCfInfo(org.apache.cassandra.thrift.Cassandra.Client client)
return the CfInfo for the column family
|
protected CFMetaData |
AbstractCassandraStorage.getCFMetaData(java.lang.String ks,
java.lang.String cf,
org.apache.cassandra.thrift.Cassandra.Client client)
get CFMetaData of a column family
|
protected java.util.List<org.apache.cassandra.thrift.ColumnDef> |
AbstractCassandraStorage.getColumnMeta(org.apache.cassandra.thrift.Cassandra.Client client,
boolean cassandraStorage,
boolean includeCompactValueColumn)
get column meta data
|
protected abstract java.util.List<org.apache.cassandra.thrift.ColumnDef> |
AbstractCassandraStorage.getColumnMetadata(org.apache.cassandra.thrift.Cassandra.Client client)
get a list of columns
|
protected java.util.List<org.apache.cassandra.thrift.ColumnDef> |
CassandraStorage.getColumnMetadata(org.apache.cassandra.thrift.Cassandra.Client client)
get a list of column for the column family
|
protected java.util.List<org.apache.cassandra.thrift.ColumnDef> |
CqlNativeStorage.getColumnMetadata(org.apache.cassandra.thrift.Cassandra.Client client)
include key columns
|
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.setCQLVersion(java.lang.String str) |
void |
ClientState.setKeyspace(java.lang.String ks) |
Modifier and Type | Method and Description |
---|---|
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 © 2016 The Apache Software Foundation