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 |
---|---|
static CFMetaData |
CFMetaData.fromThrift(org.apache.cassandra.thrift.CfDef cf_def) |
void |
CFMetaData.renameColumn(java.nio.ByteBuffer from,
java.lang.String strFrom,
java.nio.ByteBuffer to,
java.lang.String strTo) |
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) |
RowMutation |
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,
java.nio.ByteBuffer name,
java.nio.ByteBuffer value) |
static void |
QueryProcessor.validateColumnName(java.nio.ByteBuffer 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 |
---|---|
boolean |
ColumnCondition.WithVariables.appliesTo(ColumnNameBuilder rowPrefix,
ColumnFamily current,
long now)
Validates whether this condition applies to
current . |
Constants.Value |
Constants.Marker.bind(java.util.List<java.nio.ByteBuffer> values) |
Lists.Value |
Lists.DelayedValue.bind(java.util.List<java.nio.ByteBuffer> values) |
Lists.Value |
Lists.Marker.bind(java.util.List<java.nio.ByteBuffer> values) |
Maps.Value |
Maps.DelayedValue.bind(java.util.List<java.nio.ByteBuffer> values) |
Maps.Value |
Maps.Marker.bind(java.util.List<java.nio.ByteBuffer> values) |
Sets.Value |
Sets.DelayedValue.bind(java.util.List<java.nio.ByteBuffer> values) |
Sets.Value |
Sets.Marker.bind(java.util.List<java.nio.ByteBuffer> values) |
Term.Terminal |
Term.bind(java.util.List<java.nio.ByteBuffer> values)
Bind the values in this term to the values contained in
values . |
java.nio.ByteBuffer |
Constants.Marker.bindAndGet(java.util.List<java.nio.ByteBuffer> values) |
java.nio.ByteBuffer |
Term.bindAndGet(java.util.List<java.nio.ByteBuffer> values)
A shorter for bind(values).get().
|
java.nio.ByteBuffer |
Term.Terminal.bindAndGet(java.util.List<java.nio.ByteBuffer> values) |
java.nio.ByteBuffer |
Term.NonTerminal.bindAndGet(java.util.List<java.nio.ByteBuffer> values) |
void |
CQLStatement.checkAccess(ClientState state)
Perform any access verification necessary for the statement.
|
boolean |
ColumnCondition.WithVariables.equalsTo(ColumnCondition.WithVariables other) |
void |
Constants.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Constants.Adder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Constants.Substracter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Constants.Deleter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.SetterByIndex.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Appender.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Prepender.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Discarder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.DiscarderByIndex.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.SetterByKey.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.Putter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.DiscarderByKey.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
abstract void |
Operation.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder namePrefix,
UpdateParameters params)
Execute the operation.
|
void |
Sets.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Sets.Adder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Sets.Discarder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
static Lists.Value |
Lists.Value.fromSerialized(java.nio.ByteBuffer value,
ListType type) |
static Maps.Value |
Maps.Value.fromSerialized(java.nio.ByteBuffer value,
MapType type) |
static Sets.Value |
Sets.Value.fromSerialized(java.nio.ByteBuffer value,
SetType type) |
java.nio.ByteBuffer |
ColumnCondition.WithVariables.getCollectionElementValue() |
long |
Attributes.getTimestamp(long now,
java.util.List<java.nio.ByteBuffer> variables) |
int |
Attributes.getTimeToLive(java.util.List<java.nio.ByteBuffer> variables) |
static CQL3Type.Collection |
CQL3Type.Collection.list(CQL3Type t) |
Column |
UpdateParameters.makeColumn(java.nio.ByteBuffer name,
java.nio.ByteBuffer value) |
RangeTombstone |
UpdateParameters.makeRangeTombstone(java.nio.ByteBuffer start,
java.nio.ByteBuffer end) |
Column |
UpdateParameters.makeTombstone(java.nio.ByteBuffer name) |
RangeTombstone |
UpdateParameters.makeTombstoneForOverwrite(java.nio.ByteBuffer start,
java.nio.ByteBuffer end) |
static CQL3Type.Collection |
CQL3Type.Collection.map(CQL3Type t1,
CQL3Type t2) |
ColumnCondition |
ColumnCondition.Raw.prepare(CFDefinition.Name receiver) |
Operation |
Operation.RawUpdate.prepare(CFDefinition.Name receiver)
This method validates the operation (i.e.
|
Operation |
Operation.SetValue.prepare(CFDefinition.Name receiver) |
Operation |
Operation.SetElement.prepare(CFDefinition.Name receiver) |
Operation |
Operation.Addition.prepare(CFDefinition.Name receiver) |
Operation |
Operation.Substraction.prepare(CFDefinition.Name receiver) |
Operation |
Operation.Prepend.prepare(CFDefinition.Name receiver) |
AbstractMarker |
AbstractMarker.Raw.prepare(ColumnSpecification receiver) |
AbstractMarker |
AbstractMarker.INRaw.prepare(ColumnSpecification receiver) |
Constants.Value |
Constants.Literal.prepare(ColumnSpecification receiver) |
Term |
Lists.Literal.prepare(ColumnSpecification receiver) |
Term |
Maps.Literal.prepare(ColumnSpecification receiver) |
Operation |
Operation.RawDeletion.prepare(ColumnSpecification receiver)
This method validates the operation (i.e.
|
Operation |
Operation.ColumnDeletion.prepare(ColumnSpecification receiver) |
Operation |
Operation.ElementDeletion.prepare(ColumnSpecification receiver) |
Term |
Sets.Literal.prepare(ColumnSpecification receiver) |
Term |
Term.Raw.prepare(ColumnSpecification receiver)
This method validates this RawTerm is valid for provided column
specification and "prepare" this RawTerm, returning the resulting
prepared Term.
|
Term |
TypeCast.prepare(ColumnSpecification receiver) |
Attributes |
Attributes.Raw.prepare(java.lang.String ksName,
java.lang.String cfName) |
static CQL3Type.Collection |
CQL3Type.Collection.set(CQL3Type t) |
void |
UserOptions.validate() |
static void |
QueryProcessor.validateCellName(java.nio.ByteBuffer name) |
static void |
QueryProcessor.validateCellNames(java.lang.Iterable<java.nio.ByteBuffer> cellNames) |
static void |
QueryProcessor.validateKey(java.nio.ByteBuffer key) |
Modifier and Type | Method and Description |
---|---|
Term.Terminal |
FunctionCall.bind(java.util.List<java.nio.ByteBuffer> values) |
java.nio.ByteBuffer |
FunctionCall.bindAndGet(java.util.List<java.nio.ByteBuffer> values) |
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 name,
java.util.List<? extends AssignementTestable> providedArgs,
ColumnSpecification receiver) |
Term |
FunctionCall.Raw.prepare(ColumnSpecification receiver) |
Modifier and Type | Method and Description |
---|---|
void |
ModificationStatement.addCondition(ColumnCondition cond) |
void |
CQL3CasConditions.addConditions(ColumnNameBuilder prefix,
java.util.Collection<ColumnCondition> conds,
java.util.List<java.nio.ByteBuffer> variables) |
void |
CQL3CasConditions.addExist(ColumnNameBuilder prefix) |
void |
ModificationStatement.addKeyValue(CFDefinition.Name name,
Term value) |
void |
CQL3CasConditions.addNotExist(ColumnNameBuilder prefix) |
void |
DeleteStatement.addUpdateForKey(ColumnFamily cf,
java.nio.ByteBuffer key,
ColumnNameBuilder builder,
UpdateParameters params) |
abstract void |
ModificationStatement.addUpdateForKey(ColumnFamily updates,
java.nio.ByteBuffer key,
ColumnNameBuilder builder,
UpdateParameters params) |
void |
UpdateStatement.addUpdateForKey(ColumnFamily cf,
java.nio.ByteBuffer key,
ColumnNameBuilder builder,
UpdateParameters params) |
void |
ModificationStatement.addUpdatesAndConditions(java.nio.ByteBuffer key,
ColumnNameBuilder clusteringPrefix,
ColumnFamily updates,
CQL3CasConditions conditions,
java.util.List<java.nio.ByteBuffer> variables,
long now) |
void |
DropIndexStatement.announceMigration() |
boolean |
CQL3CasConditions.appliesTo(ColumnFamily current) |
java.nio.ByteBuffer |
Restriction.Slice.bound(Bound b,
java.util.List<java.nio.ByteBuffer> variables) |
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<ColumnIdentifier> columnsWithConditions,
boolean isBatch) |
java.util.List<java.nio.ByteBuffer> |
ModificationStatement.buildPartitionKeyNames(java.util.List<java.nio.ByteBuffer> variables) |
void |
AlterKeyspaceStatement.checkAccess(ClientState state) |
void |
AlterTableStatement.checkAccess(ClientState state) |
void |
BatchStatement.checkAccess(ClientState state) |
void |
CreateIndexStatement.checkAccess(ClientState state) |
void |
CreateTableStatement.checkAccess(ClientState state) |
void |
DropIndexStatement.checkAccess(ClientState state) |
void |
DropKeyspaceStatement.checkAccess(ClientState state) |
void |
DropTableStatement.checkAccess(ClientState state) |
void |
ModificationStatement.checkAccess(ClientState state) |
void |
SelectStatement.checkAccess(ClientState state) |
void |
TruncateStatement.checkAccess(ClientState state) |
static Restriction.IN |
Restriction.IN.create(Term value) |
ColumnNameBuilder |
ModificationStatement.createClusteringPrefixBuilder(java.util.List<java.nio.ByteBuffer> variables) |
ResultMessage |
TruncateStatement.execute(QueryState state,
QueryOptions options) |
ResultMessage |
UseStatement.execute(QueryState state,
QueryOptions options) |
static Selection |
Selection.fromSelectors(CFDefinition cfDef,
java.util.List<RawSelector> rawSelectors) |
java.util.List<org.apache.cassandra.thrift.IndexExpression> |
SelectStatement.getIndexExpressions(java.util.List<java.nio.ByteBuffer> variables) |
long |
ModificationStatement.getTimestamp(long now,
java.util.List<java.nio.ByteBuffer> variables) |
int |
ModificationStatement.getTimeToLive(java.util.List<java.nio.ByteBuffer> variables) |
protected abstract java.util.List<java.nio.ByteBuffer> |
Selection.handleRow(Selection.ResultSetBuilder rs) |
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(CFDefinition cfDef,
VariableSpecifications boundNames,
Attributes attrs) |
protected abstract ModificationStatement |
ModificationStatement.Parsed.prepareInternal(CFDefinition cfDef,
VariableSpecifications boundNames,
Attributes attrs) |
protected ModificationStatement |
UpdateStatement.ParsedInsert.prepareInternal(CFDefinition cfDef,
VariableSpecifications boundNames,
Attributes attrs) |
protected ModificationStatement |
UpdateStatement.ParsedUpdate.prepareInternal(CFDefinition cfDef,
VariableSpecifications boundNames,
Attributes attrs) |
void |
BatchStatement.Parsed.prepareKeyspace(ClientState state) |
void |
CFStatement.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(ColumnIdentifier name,
Relation.Type type,
Term t,
ColumnIdentifier previousName) |
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) |
java.util.List<java.nio.ByteBuffer> |
Restriction.values(java.util.List<java.nio.ByteBuffer> variables) |
java.util.List<java.nio.ByteBuffer> |
Restriction.EQ.values(java.util.List<java.nio.ByteBuffer> variables) |
java.util.List<java.nio.ByteBuffer> |
Restriction.Slice.values(java.util.List<java.nio.ByteBuffer> variables) |
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 |
---|---|
protected CFDefinition |
AbstractCassandraStorage.getCfDefinition(java.lang.String ks,
java.lang.String cf,
org.apache.cassandra.thrift.Cassandra.Client client)
get CFDefinition of a column family
|
protected AbstractCassandraStorage.CfInfo |
AbstractCassandraStorage.getCfInfo(org.apache.cassandra.thrift.Cassandra.Client client)
return the CfInfo for the 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> |
CqlStorage.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 |
CASConditions.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,
CASConditions conditions,
ColumnFamily updates,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit)
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) |
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 consistency_level)
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 |
---|---|
static org.apache.cassandra.thrift.InvalidRequestException |
ThriftConversion.toThrift(InvalidRequestException e) |
Modifier and Type | Method and Description |
---|---|
protected java.util.Map<DecoratedKey,ColumnFamily> |
CassandraServer.readColumnFamily(java.util.List<ReadCommand> commands,
ConsistencyLevel consistency_level) |
static void |
ThriftValidation.validateColumnData(CFMetaData metadata,
org.apache.cassandra.thrift.Column column,
boolean isSubColumn)
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,
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,
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) |
java.util.Collection<RowMutation> |
TriggerExecutor.execute(java.util.Collection<? extends IMutation> updates) |
Copyright © 2014 The Apache Software Foundation