Package | Description |
---|---|
org.apache.cassandra.batchlog | |
org.apache.cassandra.db | |
org.apache.cassandra.db.commitlog | |
org.apache.cassandra.db.view | |
org.apache.cassandra.hints |
Hints subsystem consists of several components.
|
org.apache.cassandra.net | |
org.apache.cassandra.schema | |
org.apache.cassandra.service | |
org.apache.cassandra.service.paxos | |
org.apache.cassandra.triggers |
Modifier and Type | Method and Description |
---|---|
static void |
LegacyBatchlogMigrator.handleLegacyMutation(Mutation mutation) |
static boolean |
LegacyBatchlogMigrator.isLegacyBatchlogMutation(Mutation mutation) |
Modifier and Type | Method and Description |
---|---|
static Batch |
Batch.createLocal(java.util.UUID id,
long creationTime,
java.util.Collection<Mutation> mutations)
Creates a 'local' batch - with all enclosed mutations in decoded form (as Mutation instances)
|
Modifier and Type | Method and Description |
---|---|
Mutation |
Mutation.add(PartitionUpdate update) |
Mutation |
CounterMutation.apply()
Applies the counter mutation, returns the result Mutation (for replication to other nodes).
|
Mutation |
RowUpdateBuilder.build() |
Mutation |
Mutation.copy() |
static Mutation |
RowUpdateBuilder.deleteRow(CFMetaData metadata,
long timestamp,
Mutation mutation,
java.lang.Object... clusteringValues) |
static Mutation |
RowUpdateBuilder.deleteRow(CFMetaData metadata,
long timestamp,
java.lang.Object key,
java.lang.Object... clusteringValues) |
static Mutation |
RowUpdateBuilder.deleteRowAt(CFMetaData metadata,
long timestamp,
int localDeletionTime,
java.lang.Object key,
java.lang.Object... clusteringValues) |
Mutation |
Mutation.MutationSerializer.deserialize(DataInputPlus in,
int version) |
Mutation |
Mutation.MutationSerializer.deserialize(DataInputPlus in,
int version,
SerializationHelper.Flag flag) |
Mutation |
CounterMutation.getMutation() |
static Mutation |
Mutation.merge(java.util.List<Mutation> mutations)
Creates a new mutation that merges all the provided mutations.
|
Mutation |
Mutation.without(java.util.Set<java.util.UUID> cfIds) |
Mutation |
Mutation.without(java.util.UUID cfId) |
Modifier and Type | Method and Description |
---|---|
MessageOut<Mutation> |
Mutation.createMessage() |
MessageOut<Mutation> |
Mutation.createMessage(MessagingService.Verb verb) |
Modifier and Type | Method and Description |
---|---|
void |
Keyspace.apply(Mutation mutation,
boolean writeCommitLog) |
void |
Keyspace.apply(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes) |
void |
Keyspace.apply(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes,
boolean isDroppable)
If apply is blocking, apply must not be deferred
Otherwise there is a race condition where ALL mutation workers are beeing blocked ending
in a complete deadlock of the mutation stage.
|
java.util.concurrent.CompletableFuture<?> |
Keyspace.apply(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes,
boolean isClReplay,
boolean isDeferrable,
java.util.concurrent.CompletableFuture<?> future)
Deprecated.
Use
this#applyFuture(Mutation, boolean, boolean, boolean, boolean) instead |
java.util.concurrent.CompletableFuture<?> |
Keyspace.applyFuture(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes) |
java.util.concurrent.CompletableFuture<?> |
Keyspace.applyFuture(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes,
boolean isDroppable,
boolean isDeferrable) |
static Mutation |
RowUpdateBuilder.deleteRow(CFMetaData metadata,
long timestamp,
Mutation mutation,
java.lang.Object... clusteringValues) |
void |
Mutation.MutationSerializer.serialize(Mutation mutation,
DataOutputPlus out,
int version) |
long |
Mutation.MutationSerializer.serializedSize(Mutation mutation,
int version) |
Modifier and Type | Method and Description |
---|---|
void |
DefinitionsUpdateVerbHandler.doVerb(MessageIn<java.util.Collection<Mutation>> message,
int id) |
void |
MutationVerbHandler.doVerb(MessageIn<Mutation> message,
int id) |
void |
ReadRepairVerbHandler.doVerb(MessageIn<Mutation> message,
int id) |
static Mutation |
Mutation.merge(java.util.List<Mutation> mutations)
Creates a new mutation that merges all the provided mutations.
|
Constructor and Description |
---|
CounterMutation(Mutation mutation,
ConsistencyLevel consistency) |
RowUpdateBuilder(CFMetaData metadata,
long timestamp,
int ttl,
Mutation mutation) |
RowUpdateBuilder(CFMetaData metadata,
long timestamp,
Mutation mutation) |
Modifier and Type | Method and Description |
---|---|
ReplayPosition |
CommitLog.add(Mutation mutation)
Add a Mutation to the commit log.
|
org.apache.cassandra.db.commitlog.CommitLogSegment.Allocation |
CommitLogSegmentManager.allocate(Mutation mutation,
int size)
Reserve space in the current segment for the provided mutation or, if there isn't space available,
create a new segment.
|
protected boolean |
CommitLogReplayer.pointInTimeExceeded(Mutation fm) |
Modifier and Type | Method and Description |
---|---|
java.util.Iterator<java.util.Collection<Mutation>> |
TableViews.generateViewUpdates(java.util.Collection<View> views,
UnfilteredRowIterator updates,
UnfilteredRowIterator existings,
int nowInSec,
boolean separateUpdates)
Given some updates on the base table of this object and the existing values for the rows affected by that update, generates the
mutation to be applied to the provided views.
|
Modifier and Type | Method and Description |
---|---|
static Hint |
Hint.create(Mutation mutation,
long creationTime) |
static Hint |
Hint.create(Mutation mutation,
long creationTime,
int gcgs) |
Modifier and Type | Method and Description |
---|---|
Mutation |
WriteCallbackInfo.mutation() |
Modifier and Type | Method and Description |
---|---|
static Mutation |
SchemaKeyspace.dropTypeFromSchemaMutation(KeyspaceMetadata keyspace,
UserType type,
long timestamp) |
static Mutation |
SchemaKeyspace.makeCreateAggregateMutation(KeyspaceMetadata keyspace,
UDAggregate aggregate,
long timestamp) |
static Mutation |
SchemaKeyspace.makeCreateFunctionMutation(KeyspaceMetadata keyspace,
UDFunction function,
long timestamp) |
static Mutation |
SchemaKeyspace.makeCreateKeyspaceMutation(KeyspaceMetadata keyspace,
long timestamp) |
static Mutation |
SchemaKeyspace.makeCreateKeyspaceMutation(java.lang.String name,
KeyspaceParams params,
long timestamp) |
static Mutation |
SchemaKeyspace.makeCreateTableMutation(KeyspaceMetadata keyspace,
CFMetaData table,
long timestamp) |
static Mutation |
SchemaKeyspace.makeCreateTypeMutation(KeyspaceMetadata keyspace,
UserType type,
long timestamp) |
static Mutation |
SchemaKeyspace.makeCreateViewMutation(KeyspaceMetadata keyspace,
ViewDefinition view,
long timestamp) |
static Mutation |
SchemaKeyspace.makeDropAggregateMutation(KeyspaceMetadata keyspace,
UDAggregate aggregate,
long timestamp) |
static Mutation |
SchemaKeyspace.makeDropFunctionMutation(KeyspaceMetadata keyspace,
UDFunction function,
long timestamp) |
static Mutation |
SchemaKeyspace.makeDropKeyspaceMutation(KeyspaceMetadata keyspace,
long timestamp) |
static Mutation |
SchemaKeyspace.makeDropTableMutation(KeyspaceMetadata keyspace,
CFMetaData table,
long timestamp) |
static Mutation |
SchemaKeyspace.makeDropViewMutation(KeyspaceMetadata keyspace,
ViewDefinition view,
long timestamp) |
static Mutation |
SchemaKeyspace.makeUpdateTableMutation(KeyspaceMetadata keyspace,
CFMetaData oldTable,
CFMetaData newTable,
long timestamp) |
static Mutation |
SchemaKeyspace.makeUpdateViewMutation(Mutation mutation,
ViewDefinition oldView,
ViewDefinition newView,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
static java.util.Collection<Mutation> |
SchemaKeyspace.convertSchemaToMutations() |
Modifier and Type | Method and Description |
---|---|
static void |
SchemaKeyspace.addTableToSchemaMutation(CFMetaData table,
long timestamp,
boolean withColumnsAndTriggers,
Mutation mutation) |
static Mutation |
SchemaKeyspace.makeUpdateViewMutation(Mutation mutation,
ViewDefinition oldView,
ViewDefinition newView,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
static void |
SchemaKeyspace.mergeSchema(java.util.Collection<Mutation> mutations) |
static void |
SchemaKeyspace.mergeSchemaAndAnnounceVersion(java.util.Collection<Mutation> mutations)
Merge remote schema in form of mutations with local and mutate ks/cf metadata objects
(which also involves fs operations on add/drop ks/cf)
|
Modifier and Type | Method and Description |
---|---|
java.util.Collection<Mutation> |
MigrationManager.MigrationsSerializer.deserialize(DataInputPlus in,
int version) |
Modifier and Type | Method and Description |
---|---|
boolean |
StorageProxy.appliesLocally(Mutation mutation) |
static void |
StorageProxy.sendToHintedEndpoints(Mutation mutation,
java.lang.Iterable<java.net.InetAddress> targets,
AbstractWriteResponseHandler<IMutation> responseHandler,
java.lang.String localDataCenter,
Stage stage)
Send the mutations to the right targets, write it locally if it corresponds or writes a hint when the node
is not available.
|
static java.util.concurrent.Future<java.lang.Void> |
StorageProxy.submitHint(Mutation mutation,
java.util.Collection<java.net.InetAddress> targets,
AbstractWriteResponseHandler<IMutation> responseHandler) |
static java.util.concurrent.Future<java.lang.Void> |
StorageProxy.submitHint(Mutation mutation,
java.net.InetAddress target,
AbstractWriteResponseHandler<IMutation> responseHandler) |
Modifier and Type | Method and Description |
---|---|
static void |
StorageProxy.mutateAtomically(java.util.Collection<Mutation> mutations,
ConsistencyLevel consistency_level,
boolean requireQuorumForRemove)
See mutate.
|
static void |
StorageProxy.mutateMV(java.nio.ByteBuffer dataKey,
java.util.Collection<Mutation> mutations,
boolean writeCommitLog,
java.util.concurrent.atomic.AtomicLong baseComplete)
Use this method to have these Mutations applied
across all replicas.
|
void |
MigrationManager.MigrationsSerializer.serialize(java.util.Collection<Mutation> schema,
DataOutputPlus out,
int version) |
long |
MigrationManager.MigrationsSerializer.serializedSize(java.util.Collection<Mutation> schema,
int version) |
Modifier and Type | Method and Description |
---|---|
Mutation |
Commit.makeMutation() |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<Mutation> |
ITrigger.augment(Partition update)
Called exactly once per CF update, returned mutations are atomically updated.
|
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 © 2020 The Apache Software Foundation