Modifier and Type | Method and Description |
---|---|
Mutation |
CFMetaData.dropFromSchema(long timestamp)
Remove all CF attributes from schema
|
Mutation |
KSMetaData.dropFromSchema(long timestamp) |
static Mutation |
UTMetaData.dropFromSchema(UserType droppedType,
long timestamp) |
Mutation |
CFMetaData.toSchema(long timestamp)
Convert current metadata into schema mutation
|
Mutation |
KSMetaData.toSchema(long timestamp) |
Mutation |
UTMetaData.toSchema(Mutation mutation,
long timestamp) |
static Mutation |
UTMetaData.toSchema(Mutation mutation,
UserType newType,
long timestamp) |
static Mutation |
UTMetaData.toSchema(UserType newType,
long timestamp) |
Mutation |
CFMetaData.toSchemaUpdate(CFMetaData newState,
long modificationTimestamp,
boolean fromThrift)
Create schema mutations to update this metadata to provided new state.
|
Mutation |
KSMetaData.toSchemaUpdate(KSMetaData newState,
long modificationTimestamp) |
Modifier and Type | Method and Description |
---|---|
void |
ColumnDefinition.deleteFromSchema(Mutation mutation,
long timestamp)
Drop specified column from the schema using given mutation.
|
void |
TriggerDefinition.deleteFromSchema(Mutation mutation,
java.lang.String cfName,
long timestamp)
Drop specified trigger from the schema using given mutation.
|
void |
CFMetaData.toSchema(Mutation mutation,
long timestamp) |
void |
ColumnDefinition.toSchema(Mutation mutation,
long timestamp) |
Mutation |
UTMetaData.toSchema(Mutation mutation,
long timestamp) |
void |
TriggerDefinition.toSchema(Mutation mutation,
java.lang.String cfName,
long timestamp)
Add specified trigger to the schema using given mutation.
|
static Mutation |
UTMetaData.toSchema(Mutation mutation,
UserType newType,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
Mutation |
CounterMutation.apply()
Applies the counter mutation, returns the result Mutation (for replication to other nodes).
|
Mutation |
Mutation.copy() |
Mutation |
Mutation.MutationSerializer.deserialize(java.io.DataInput in,
int version) |
Mutation |
Mutation.MutationSerializer.deserialize(java.io.DataInput in,
int version,
ColumnSerializer.Flag flag) |
static Mutation |
BatchlogManager.getBatchlogMutationFor(java.util.Collection<Mutation> mutations,
java.util.UUID uuid,
int version) |
Mutation |
CounterMutation.getMutation() |
Mutation |
HintedHandOffManager.hintFor(Mutation mutation,
long now,
int ttl,
Pair<java.net.InetAddress,java.util.UUID> target)
Returns a mutation representing a Hint to be sent to
targetId
as soon as it becomes available again. |
Mutation |
Mutation.without(java.util.UUID cfId) |
Modifier and Type | Method and Description |
---|---|
MessageOut<Mutation> |
Mutation.createMessage() |
MessageOut<Mutation> |
Mutation.createMessage(MessagingService.Verb verb) |
static java.util.Collection<Mutation> |
SystemKeyspace.serializeSchema() |
Modifier and Type | Method and Description |
---|---|
void |
Keyspace.apply(Mutation mutation,
boolean writeCommitLog) |
void |
Keyspace.apply(Mutation mutation,
boolean writeCommitLog,
boolean updateIndexes)
This method appends a row to the global CommitLog, then updates memtables and indexes.
|
static int |
HintedHandOffManager.calculateHintTTL(Mutation mutation) |
Mutation |
HintedHandOffManager.hintFor(Mutation mutation,
long now,
int ttl,
Pair<java.net.InetAddress,java.util.UUID> target)
Returns a mutation representing a Hint to be sent to
targetId
as soon as it becomes available again. |
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 |
BatchlogManager.getBatchlogMutationFor(java.util.Collection<Mutation> mutations,
java.util.UUID uuid,
int version) |
static void |
DefsTables.mergeSchema(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)
|
static void |
DefsTables.mergeSchemaInternal(java.util.Collection<Mutation> mutations,
boolean doFlush) |
Constructor and Description |
---|
CounterMutation(Mutation mutation,
ConsistencyLevel consistency) |
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.Collection<Mutation> |
MigrationManager.MigrationsSerializer.deserialize(java.io.DataInput in,
int version) |
Modifier and Type | Method and Description |
---|---|
static void |
StorageProxy.sendToHintedEndpoints(Mutation mutation,
java.lang.Iterable<java.net.InetAddress> targets,
AbstractWriteResponseHandler responseHandler,
java.lang.String localDataCenter)
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.net.InetAddress target,
AbstractWriteResponseHandler responseHandler) |
static void |
StorageProxy.writeHintForMutation(Mutation mutation,
long now,
int ttl,
java.net.InetAddress target) |
Modifier and Type | Method and Description |
---|---|
static void |
StorageProxy.mutateAtomically(java.util.Collection<Mutation> mutations,
ConsistencyLevel consistency_level)
See mutate.
|
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(java.nio.ByteBuffer partitionKey,
ColumnFamily 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