Uses of Class
org.apache.cassandra.db.RowMutation

Packages that use RowMutation
org.apache.cassandra.config   
org.apache.cassandra.cql   
org.apache.cassandra.cql3.statements   
org.apache.cassandra.db   
org.apache.cassandra.db.commitlog   
org.apache.cassandra.service   
 

Uses of RowMutation in org.apache.cassandra.config
 

Methods in org.apache.cassandra.config that return RowMutation
 RowMutation CFMetaData.dropFromSchema(long timestamp)
          Remove all CF attributes from schema
 RowMutation KSMetaData.dropFromSchema(long timestamp)
           
 RowMutation CFMetaData.toSchema(long timestamp)
          Convert current metadata into schema mutation
 RowMutation KSMetaData.toSchema(long timestamp)
           
 RowMutation CFMetaData.toSchemaUpdate(CFMetaData newState, long modificationTimestamp)
          Create schema mutations to update this metadata to provided new state.
 RowMutation KSMetaData.toSchemaUpdate(KSMetaData newState, long modificationTimestamp)
           
 

Methods in org.apache.cassandra.config with parameters of type RowMutation
 void ColumnDefinition.deleteFromSchema(RowMutation rm, java.lang.String cfName, AbstractType<?> comparator, long timestamp)
          Drop specified column from the schema using given row.
 void CFMetaData.toSchema(RowMutation rm, long timestamp)
           
 void ColumnDefinition.toSchema(RowMutation rm, java.lang.String cfName, AbstractType<?> comparator, long timestamp)
           
 

Uses of RowMutation in org.apache.cassandra.cql
 

Methods in org.apache.cassandra.cql that return RowMutation
 RowMutation DeleteStatement.mutationForKey(java.nio.ByteBuffer key, java.lang.String keyspace, java.lang.Long timestamp, ClientState clientState, java.util.List<java.nio.ByteBuffer> variables, CFMetaData metadata)
           
 

Uses of RowMutation in org.apache.cassandra.cql3.statements
 

Methods in org.apache.cassandra.cql3.statements that return RowMutation
 RowMutation DeleteStatement.mutationForKey(CFDefinition cfDef, java.nio.ByteBuffer key, ColumnNameBuilder builder, boolean isRange, UpdateParameters params, ColumnGroupMap group)
           
 

Uses of RowMutation in org.apache.cassandra.db
 

Methods in org.apache.cassandra.db that return RowMutation
 RowMutation RowMutation.RowMutationSerializer.deserialize(java.io.DataInput dis, int version)
           
 RowMutation RowMutation.RowMutationSerializer.deserialize(java.io.DataInput dis, int version, IColumnSerializer.Flag flag)
           
static RowMutation RowMutation.fromBytes(byte[] raw, int version)
           
static RowMutation BatchlogManager.getBatchlogMutationFor(java.util.Collection<RowMutation> mutations, java.util.UUID uuid)
           
static RowMutation RowMutation.hintFor(RowMutation mutation, java.util.UUID targetId)
          Returns mutation representing a Hints to be sent to address as soon as it becomes available.
 RowMutation CounterMutation.makeReplicationMutation()
           
 RowMutation CounterMutation.rowMutation()
           
 

Methods in org.apache.cassandra.db that return types with arguments of type RowMutation
 MessageOut<RowMutation> RowMutation.createMessage()
           
 MessageOut<RowMutation> RowMutation.createMessage(MessagingService.Verb verb)
           
static java.util.Collection<RowMutation> SystemTable.serializeSchema()
           
 

Methods in org.apache.cassandra.db with parameters of type RowMutation
 void Table.apply(RowMutation mutation, boolean writeCommitLog)
           
 void Table.apply(RowMutation mutation, boolean writeCommitLog, boolean updateIndexes)
          This method appends a row to the global CommitLog, then updates memtables and indexes.
static RowMutation RowMutation.hintFor(RowMutation mutation, java.util.UUID targetId)
          Returns mutation representing a Hints to be sent to address as soon as it becomes available.
 void RowMutation.RowMutationSerializer.serialize(RowMutation rm, java.io.DataOutput dos, int version)
           
 long RowMutation.RowMutationSerializer.serializedSize(RowMutation rm, int version)
           
 

Method parameters in org.apache.cassandra.db with type arguments of type RowMutation
 void DefinitionsUpdateVerbHandler.doVerb(MessageIn<java.util.Collection<RowMutation>> message, java.lang.String id)
           
 void ReadRepairVerbHandler.doVerb(MessageIn<RowMutation> message, java.lang.String id)
           
 void RowMutationVerbHandler.doVerb(MessageIn<RowMutation> message, java.lang.String id)
           
static RowMutation BatchlogManager.getBatchlogMutationFor(java.util.Collection<RowMutation> mutations, java.util.UUID uuid)
           
static void DefsTable.mergeSchema(java.util.Collection<RowMutation> mutations)
          Merge remote schema in form of row mutations with local and mutate ks/cf metadata objects (which also involves fs operations on add/drop ks/cf)
 

Constructors in org.apache.cassandra.db with parameters of type RowMutation
CounterMutation(RowMutation rowMutation, ConsistencyLevel consistency)
           
 

Uses of RowMutation in org.apache.cassandra.db.commitlog
 

Methods in org.apache.cassandra.db.commitlog with parameters of type RowMutation
 void CommitLog.add(RowMutation rm)
          Add a RowMutation to the commit log.
 boolean CommitLogSegment.hasCapacityFor(RowMutation mutation)
           
protected  boolean CommitLogReplayer.pointInTimeExceeded(RowMutation frm)
           
 ReplayPosition CommitLogSegment.write(RowMutation rowMutation)
          Appends a row mutation onto the commit log.
 

Uses of RowMutation in org.apache.cassandra.service
 

Methods in org.apache.cassandra.service that return types with arguments of type RowMutation
 java.util.Collection<RowMutation> MigrationManager.MigrationsSerializer.deserialize(java.io.DataInput in, int version)
           
 

Methods in org.apache.cassandra.service with parameters of type RowMutation
static java.util.concurrent.Future<java.lang.Void> StorageProxy.scheduleLocalHint(RowMutation mutation, java.net.InetAddress target, IWriteResponseHandler responseHandler, ConsistencyLevel consistencyLevel)
           
static void StorageProxy.sendToHintedEndpoints(RowMutation rm, java.util.Collection<java.net.InetAddress> targets, IWriteResponseHandler responseHandler, java.lang.String localDataCenter, ConsistencyLevel consistency_level)
          Send the mutations to the right targets, write it locally if it corresponds or writes a hint when the node is not available.
static void StorageProxy.writeHintForMutation(RowMutation mutation, java.net.InetAddress target)
           
 

Method parameters in org.apache.cassandra.service with type arguments of type RowMutation
static void StorageProxy.mutateAtomically(java.util.List<RowMutation> mutations, ConsistencyLevel consistency_level)
          See mutate.
 void MigrationManager.MigrationsSerializer.serialize(java.util.Collection<RowMutation> schema, java.io.DataOutput out, int version)
           
 long MigrationManager.MigrationsSerializer.serializedSize(java.util.Collection<RowMutation> schema, int version)
           
 



Copyright © 2012 The Apache Software Foundation