Modifier and Type | Method and Description |
---|---|
void |
UpdateParameters.addCell(ColumnMetadata column,
java.nio.ByteBuffer value) |
void |
UpdateParameters.addCell(ColumnMetadata column,
CellPath path,
java.nio.ByteBuffer value) |
void |
UpdateParameters.addCounter(ColumnMetadata column,
long increment) |
void |
UpdateParameters.addTombstone(ColumnMetadata column) |
void |
UpdateParameters.addTombstone(ColumnMetadata column,
CellPath path) |
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) |
UserTypes.Value |
UserTypes.DelayedValue.bind(QueryOptions options) |
Term.Terminal |
UserTypes.Marker.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 |
Constants.Setter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Constants.Adder.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Constants.Substracter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Constants.Deleter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Lists.Setter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Lists.SetterByIndex.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Lists.Appender.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Lists.Prepender.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Lists.Discarder.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Lists.DiscarderByIndex.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Maps.Setter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Maps.SetterByKey.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Maps.Putter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Maps.DiscarderByKey.execute(DecoratedKey partitionKey,
UpdateParameters params) |
abstract void |
Operation.execute(DecoratedKey partitionKey,
UpdateParameters params)
Execute the operation.
|
void |
Sets.Setter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Sets.Adder.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Sets.Discarder.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
Sets.ElementDiscarder.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
UserTypes.Setter.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
UserTypes.SetterByField.execute(DecoratedKey partitionKey,
UpdateParameters params) |
void |
UserTypes.DeleterByField.execute(DecoratedKey partitionKey,
UpdateParameters params) |
static Lists.Value |
Lists.Value.fromSerialized(java.nio.ByteBuffer value,
ListType type,
ProtocolVersion 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,
ProtocolVersion version) |
static Sets.Value |
Sets.Value.fromSerialized(java.nio.ByteBuffer value,
SetType type,
ProtocolVersion version) |
abstract java.nio.ByteBuffer |
Term.Terminal.get(ProtocolVersion protocolVersion) |
Term |
QueryOptions.getJsonColumnValue(int bindIndex,
ColumnIdentifier columnName,
java.util.Collection<ColumnMetadata> expectedReceivers)
Returns the term corresponding to column
columnName in the JSON value of bind index bindIndex . |
static ResultMessage.Prepared |
QueryProcessor.getStoredPreparedStatement(java.lang.String queryString,
java.lang.String clientKeyspace) |
long |
Attributes.getTimestamp(long now,
QueryOptions options) |
int |
Attributes.getTimeToLive(QueryOptions options,
TableMetadata metadata) |
protected Restriction |
SingleColumnRelation.newContainsRestriction(TableMetadata table,
VariableSpecifications boundNames,
boolean isKey) |
protected Restriction |
SingleColumnRelation.newIsNotRestriction(TableMetadata table,
VariableSpecifications boundNames) |
<V> void |
UpdateParameters.newRow(Clustering<V> clustering) |
Operation |
Operation.RawDeletion.prepare(java.lang.String keyspace,
ColumnMetadata receiver,
TableMetadata metadata)
This method validates the operation (i.e.
|
Operation |
Operation.ColumnDeletion.prepare(java.lang.String keyspace,
ColumnMetadata receiver,
TableMetadata metadata) |
Operation |
Operation.ElementDeletion.prepare(java.lang.String keyspace,
ColumnMetadata receiver,
TableMetadata metadata) |
Operation |
Operation.FieldDeletion.prepare(java.lang.String keyspace,
ColumnMetadata receiver,
TableMetadata metadata) |
Term.NonTerminal |
AbstractMarker.Raw.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Term.NonTerminal |
AbstractMarker.MultiColumnRaw.prepare(java.lang.String keyspace,
ColumnSpecification receiver) |
Lists.Marker |
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) |
abstract 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) |
abstract 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) |
abstract CQL3Type |
CQL3Type.Raw.prepare(java.lang.String keyspace,
Types udts) |
Operation |
Operation.RawUpdate.prepare(TableMetadata metadata,
ColumnMetadata receiver)
This method validates the operation (i.e.
|
Operation |
Operation.SetValue.prepare(TableMetadata metadata,
ColumnMetadata receiver) |
Operation |
Operation.SetElement.prepare(TableMetadata metadata,
ColumnMetadata receiver) |
Operation |
Operation.SetField.prepare(TableMetadata metadata,
ColumnMetadata receiver) |
Operation |
Operation.Addition.prepare(TableMetadata metadata,
ColumnMetadata receiver) |
Operation |
Operation.Substraction.prepare(TableMetadata metadata,
ColumnMetadata receiver) |
Operation |
Operation.Prepend.prepare(TableMetadata metadata,
ColumnMetadata receiver) |
CQL3Type |
CQL3Type.Raw.prepareInternal(java.lang.String keyspace,
Types udts) |
protected java.util.List<ColumnMetadata> |
MultiColumnRelation.receivers(TableMetadata table) |
static ResultMessage.Prepared |
QueryProcessor.storePreparedStatement(java.lang.String queryString,
java.lang.String keyspace,
QueryHandler.Prepared prepared) |
protected Term |
MultiColumnRelation.toTerm(java.util.List<? extends ColumnSpecification> receivers,
Term.Raw raw,
java.lang.String keyspace,
VariableSpecifications boundNames) |
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) |
static void |
QueryProcessor.validateKey(java.nio.ByteBuffer key) |
Constructor and Description |
---|
UpdateParameters(TableMetadata metadata,
RegularAndStaticColumns updatedColumns,
QueryOptions options,
long timestamp,
int nowInSec,
int ttl,
java.util.Map<DecoratedKey,Partition> prefetchedRows) |
Modifier and Type | Method and Description |
---|---|
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(ProtocolVersion 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(ProtocolVersion protocolVersion)
Computes and returns the aggregate current value.
|
java.nio.ByteBuffer |
ScalarFunction.execute(ProtocolVersion protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters)
Applies this function to the specified parameter.
|
java.nio.ByteBuffer |
ToJsonFct.execute(ProtocolVersion protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters) |
java.nio.ByteBuffer |
TokenFct.execute(ProtocolVersion protocolVersion,
java.util.List<java.nio.ByteBuffer> parameters) |
static Function |
FunctionResolver.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 |
---|---|
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.EQRestriction.bounds(Bound b,
QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.SliceRestriction.bounds(Bound b,
QueryOptions options) |
protected abstract org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions |
TokenRestriction.doMergeWith(TokenRestriction otherRestriction)
Merges this restriction with the specified
TokenRestriction . |
protected org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions |
TokenRestriction.EQRestriction.doMergeWith(TokenRestriction otherRestriction) |
protected org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions |
TokenRestriction.SliceRestriction.doMergeWith(TokenRestriction otherRestriction) |
org.apache.cassandra.cql3.restrictions.PartitionKeyRestrictions |
TokenRestriction.mergeWith(Restriction otherRestriction) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.EQRestriction.values(QueryOptions options) |
java.util.List<java.nio.ByteBuffer> |
TokenRestriction.SliceRestriction.values(QueryOptions options) |
Modifier and Type | Method and Description |
---|---|
abstract void |
Selector.addInput(ProtocolVersion protocolVersion,
ResultSetBuilder rs)
Add the current value from the specified
ResultSetBuilder . |
void |
SimpleSelector.addInput(ProtocolVersion protocolVersion,
ResultSetBuilder rs) |
void |
TermSelector.addInput(ProtocolVersion protocolVersion,
ResultSetBuilder rs) |
abstract java.nio.ByteBuffer |
Selector.getOutput(ProtocolVersion protocolVersion)
Returns the selector output.
|
java.nio.ByteBuffer |
SimpleSelector.getOutput(ProtocolVersion protocolVersion) |
java.nio.ByteBuffer |
TermSelector.getOutput(ProtocolVersion protocolVersion) |
abstract Selector |
Selector.Factory.newInstance(QueryOptions options)
Creates a new
Selector instance. |
Selector.Factory |
Selectable.WithTerm.newSelectorFactory(TableMetadata table,
AbstractType<?> expectedType,
java.util.List<ColumnMetadata> defs,
VariableSpecifications boundNames) |
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(Clustering<?> clustering,
java.util.Collection<ColumnCondition> conds,
QueryOptions options) |
void |
ModificationStatement.addConditions(Clustering<?> clustering,
CQL3CasRequest request,
QueryOptions options) |
void |
CQL3CasRequest.addExist(Clustering<?> clustering) |
void |
CQL3CasRequest.addNotExist(Clustering<?> clustering) |
void |
DeleteStatement.addUpdateForKey(PartitionUpdate.Builder updateBuilder,
Clustering<?> clustering,
UpdateParameters params) |
boolean |
CQL3CasRequest.appliesTo(FilteredPartition current)
Checks whether the conditions represented by this object applies provided the current state of the partition on
which those conditions are.
|
void |
BatchStatement.authorize(ClientState state) |
void |
ListRolesStatement.authorize(ClientState state) |
void |
ModificationStatement.authorize(ClientState state) |
void |
SelectStatement.authorize(ClientState state) |
void |
TruncateStatement.authorize(ClientState state) |
java.util.List<java.nio.ByteBuffer> |
ModificationStatement.buildPartitionKeyNames(QueryOptions options) |
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 <T extends java.util.Collection<E>,E> |
RequestValidations.checkNotEmpty(T collection,
java.lang.String messageTemplate,
java.lang.Object... messageArgs)
Checks that the specified collections is NOT
empty . |
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 . |
java.util.NavigableSet<Clustering<?>> |
ModificationStatement.createClustering(QueryOptions options) |
ResultMessage |
TruncateStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
UseStatement.execute(QueryState state,
QueryOptions options,
long queryStartNanoTime) |
ResultMessage |
UseStatement.executeLocally(QueryState state,
QueryOptions options) |
RowFilter |
SelectStatement.getRowFilter(QueryOptions options)
May be used by custom QueryHandler implementations
|
long |
ModificationStatement.getTimestamp(long now,
QueryOptions options) |
int |
ModificationStatement.getTimeToLive(QueryOptions options) |
Slices |
SelectStatement.makeSlices(QueryOptions options) |
PartitionUpdate |
CQL3CasRequest.makeUpdates(FilteredPartition current) |
static IResource |
AuthorizationStatement.maybeCorrectResource(IResource resource,
ClientState state) |
SelectStatement |
SelectStatement.RawStatement.prepare(boolean forView) |
ResultSet |
SelectStatement.process(PartitionIterator partitions,
int nowInSec) |
void |
BatchStatement.Parsed.setKeyspace(ClientState state) |
void |
BatchStatement.validate() |
void |
BatchStatement.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) |
Modifier and Type | Class and Description |
---|---|
class |
KeyspaceNotDefinedException |
Modifier and Type | Method and Description |
---|---|
static void |
ExpirationDateOverflowHandling.maybeApplyExpirationDateOverflowPolicy(TableMetadata metadata,
int ttl,
boolean isDefaultTTL) |
void |
ConsistencyLevel.validateCounterForWrite(TableMetadata metadata) |
void |
ConsistencyLevel.validateForCas() |
void |
ConsistencyLevel.validateForCasCommit(AbstractReplicationStrategy replicationStrategy) |
void |
ConsistencyLevel.validateForRead() |
void |
ConsistencyLevel.validateForWrite() |
Modifier and Type | Method and Description |
---|---|
void |
Index.validate(PartitionUpdate update)
Called at write time to ensure that values present in the update
are valid according to the rules of all registered indexes which
will process it.
|
void |
SecondaryIndexManager.validate(PartitionUpdate update)
Called at write time to ensure that values present in the update
are valid according to the rules of all registered indexes which
will process it.
|
default void |
Index.validate(ReadCommand command)
Used to validate the various parameters of a supplied ReadCommand,
this is called prior to execution.
|
Modifier and Type | Method and Description |
---|---|
void |
CassandraIndex.validate(PartitionUpdate update) |
void |
CassandraIndex.validate(ReadCommand command) |
Modifier and Type | Method and Description |
---|---|
Index.Searcher |
SASIIndex.searcherFor(ReadCommand command) |
void |
SASIIndex.validate(PartitionUpdate update) |
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 |
---|---|
Selector.Factory |
ColumnMetadata.newSelectorFactory(TableMetadata table,
AbstractType<?> expectedType,
java.util.List<ColumnMetadata> defs,
VariableSpecifications boundNames) |
Modifier and Type | Method and Description |
---|---|
boolean |
CASRequest.appliesTo(FilteredPartition current)
Returns whether the provided CF, that represents the values fetched using the
readFilter(), match the CAS conditions this object stands for.
|
static RowIterator |
StorageProxy.cas(java.lang.String keyspaceName,
java.lang.String cfName,
DecoratedKey key,
CASRequest request,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit,
ClientState state,
int nowInSeconds,
long queryStartNanoTime)
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
|
java.util.List<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<TokenRange> |
StorageService.describeRing(java.lang.String keyspace)
The TokenRange for a given keyspace.
|
java.lang.String |
ClientState.getKeyspace() |
PartitionUpdate |
CASRequest.makeUpdates(FilteredPartition current)
The updates to perform of a CAS success.
|
static void |
StorageProxy.mutateWithTriggers(java.util.List<? extends IMutation> mutations,
ConsistencyLevel consistencyLevel,
boolean mutateAtomically,
long queryStartNanoTime) |
static PartitionIterator |
StorageProxy.read(SinglePartitionReadCommand.Group group,
ConsistencyLevel consistencyLevel,
ClientState state,
long queryStartNanoTime)
Performs the actual reading of a row out of the StorageService, fetching
a specific set of column names from a given column family.
|
static PartitionIterator |
StorageProxy.read(SinglePartitionReadCommand.Group group,
ConsistencyLevel consistencyLevel,
long queryStartNanoTime) |
static RowIterator |
StorageProxy.readOne(SinglePartitionReadCommand command,
ConsistencyLevel consistencyLevel,
ClientState state,
long queryStartNanoTime) |
static RowIterator |
StorageProxy.readOne(SinglePartitionReadCommand command,
ConsistencyLevel consistencyLevel,
long queryStartNanoTime) |
Modifier and Type | Method and Description |
---|---|
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.
|
PartitionUpdate |
TriggerExecutor.execute(PartitionUpdate updates)
Augment a partition update by executing triggers to generate an intermediate
set of mutations, then merging the update from each mutation with those
supplied.
|
Copyright © 2009- The Apache Software Foundation