Uses of Class
org.apache.accumulo.core.data.Mutation

Packages that use Mutation
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.client.mapred   
org.apache.accumulo.core.client.mapreduce   
org.apache.accumulo.core.client.mock   
org.apache.accumulo.core.constraints   
org.apache.accumulo.core.data   
org.apache.accumulo.core.security   
org.apache.accumulo.core.util   
org.apache.accumulo.examples.simple.client   
org.apache.accumulo.examples.simple.constraints   
org.apache.accumulo.examples.simple.dirlist   
org.apache.accumulo.server.constraints   
org.apache.accumulo.server.data   
org.apache.accumulo.server.logger   
org.apache.accumulo.server.master.state   
org.apache.accumulo.server.tabletserver   
org.apache.accumulo.server.tabletserver.log   
org.apache.accumulo.server.util   
org.apache.accumulo.test   
org.apache.accumulo.test.continuous   
org.apache.accumulo.test.functional   
org.apache.accumulo.test.randomwalk.concurrent   
 

Uses of Mutation in org.apache.accumulo.core.client
 

Methods in org.apache.accumulo.core.client with parameters of type Mutation
 void BatchWriter.addMutation(Mutation m)
          Queues one mutation to write.
 

Method parameters in org.apache.accumulo.core.client with type arguments of type Mutation
 void BatchWriter.addMutations(Iterable<Mutation> iterable)
          Queues several mutations to write.
 

Uses of Mutation in org.apache.accumulo.core.client.impl
 

Methods in org.apache.accumulo.core.client.impl that return types with arguments of type Mutation
 Map<KeyExtent,List<Mutation>> TabletLocator.TabletServerMutations.getMutations()
           
 

Methods in org.apache.accumulo.core.client.impl with parameters of type Mutation
 void TabletLocator.TabletServerMutations.addMutation(KeyExtent ke, Mutation m)
           
 void BatchWriterImpl.addMutation(Mutation m)
           
 void TabletServerBatchWriter.addMutation(String table, Mutation m)
           
 void Writer.update(Mutation m)
           
 

Method parameters in org.apache.accumulo.core.client.impl with type arguments of type Mutation
 void TabletServerBatchWriter.addMutation(String table, Iterator<Mutation> iterator)
           
 void BatchWriterImpl.addMutations(Iterable<Mutation> iterable)
           
 void RootTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void RootTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TabletLocatorImpl.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TabletLocatorImpl.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
abstract  void TabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
abstract  void TabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TimeoutTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TimeoutTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 

Uses of Mutation in org.apache.accumulo.core.client.mapred
 

Methods in org.apache.accumulo.core.client.mapred that return types with arguments of type Mutation
 org.apache.hadoop.mapred.RecordWriter<org.apache.hadoop.io.Text,Mutation> AccumuloOutputFormat.getRecordWriter(org.apache.hadoop.fs.FileSystem ignored, org.apache.hadoop.mapred.JobConf job, String name, org.apache.hadoop.util.Progressable progress)
           
 

Methods in org.apache.accumulo.core.client.mapred with parameters of type Mutation
 void AccumuloOutputFormat.AccumuloRecordWriter.write(org.apache.hadoop.io.Text table, Mutation mutation)
          Push a mutation into a table.
 

Uses of Mutation in org.apache.accumulo.core.client.mapreduce
 

Methods in org.apache.accumulo.core.client.mapreduce that return types with arguments of type Mutation
 org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.Text,Mutation> AccumuloOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext attempt)
           
 

Methods in org.apache.accumulo.core.client.mapreduce with parameters of type Mutation
 void AccumuloOutputFormat.AccumuloRecordWriter.write(org.apache.hadoop.io.Text table, Mutation mutation)
          Push a mutation into a table.
 

Uses of Mutation in org.apache.accumulo.core.client.mock
 

Methods in org.apache.accumulo.core.client.mock with parameters of type Mutation
 void MockBatchWriter.addMutation(Mutation m)
           
 void MockAccumulo.addMutation(String table, Mutation m)
           
 

Method parameters in org.apache.accumulo.core.client.mock with type arguments of type Mutation
 void MockBatchWriter.addMutations(Iterable<Mutation> iterable)
           
 void MockTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void MockTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 

Uses of Mutation in org.apache.accumulo.core.constraints
 

Methods in org.apache.accumulo.core.constraints with parameters of type Mutation
 List<Short> Constraint.check(Constraint.Environment env, Mutation mutation)
          Checks a mutation for constrain violations.
 

Uses of Mutation in org.apache.accumulo.core.data
 

Methods in org.apache.accumulo.core.data that return Mutation
 Mutation KeyExtent.getPrevRowUpdateMutation()
          Returns a String representing the previous extent's entry in the Metadata table
static Mutation KeyExtent.getPrevRowUpdateMutation(KeyExtent ke)
           
 

Methods in org.apache.accumulo.core.data with parameters of type Mutation
 boolean Mutation.equals(Mutation m)
           
 

Constructors in org.apache.accumulo.core.data with parameters of type Mutation
Mutation(Mutation m)
           
 

Uses of Mutation in org.apache.accumulo.core.security
 

Methods in org.apache.accumulo.core.security with parameters of type Mutation
 List<Short> VisibilityConstraint.check(Constraint.Environment env, Mutation mutation)
           
 

Uses of Mutation in org.apache.accumulo.core.util
 

Methods in org.apache.accumulo.core.util with parameters of type Mutation
static void ColumnFQ.put(Mutation m, ColumnFQ cfq, Value v)
          Deprecated. since 1.5, use ColumnFQ.put(Mutation, Value) instead
 void ColumnFQ.put(Mutation m, Value v)
           
 void ColumnFQ.putDelete(Mutation m)
           
static void ColumnFQ.putDelete(Mutation m, ColumnFQ cfq)
          Deprecated. since 1.5, use ColumnFQ.putDelete(Mutation) instead
 

Uses of Mutation in org.apache.accumulo.examples.simple.client
 

Methods in org.apache.accumulo.examples.simple.client that return Mutation
static Mutation RandomBatchWriter.createMutation(long rowid, int dataSize, ColumnVisibility visibility)
          Creates a mutation on a specified row with column family "foo", column qualifier "1", specified visibility, and a random value of specified size.
 

Uses of Mutation in org.apache.accumulo.examples.simple.constraints
 

Methods in org.apache.accumulo.examples.simple.constraints with parameters of type Mutation
 List<Short> AlphaNumKeyConstraint.check(Constraint.Environment env, Mutation mutation)
           
 List<Short> MaxMutationSize.check(Constraint.Environment env, Mutation mutation)
           
 List<Short> NumericValueConstraint.check(Constraint.Environment env, Mutation mutation)
           
 

Uses of Mutation in org.apache.accumulo.examples.simple.dirlist
 

Methods in org.apache.accumulo.examples.simple.dirlist that return Mutation
static Mutation Ingest.buildMutation(ColumnVisibility cv, String path, boolean isDir, boolean isHidden, boolean canExec, long length, long lastmod, String hash)
           
 

Uses of Mutation in org.apache.accumulo.server.constraints
 

Methods in org.apache.accumulo.server.constraints with parameters of type Mutation
 Violations ConstraintChecker.check(Constraint.Environment env, Mutation m)
           
 List<Short> MetadataConstraints.check(Constraint.Environment env, Mutation mutation)
           
 List<Short> UnsatisfiableConstraint.check(Constraint.Environment env, Mutation mutation)
           
 

Uses of Mutation in org.apache.accumulo.server.data
 

Subclasses of Mutation in org.apache.accumulo.server.data
 class ServerMutation
          Mutation that holds system time as computed by the tablet server when not provided by the user.
 

Uses of Mutation in org.apache.accumulo.server.logger
 

Fields in org.apache.accumulo.server.logger with type parameters of type Mutation
 List<Mutation> LogFileValue.mutations
           
 

Uses of Mutation in org.apache.accumulo.server.master.state
 

Methods in org.apache.accumulo.server.master.state with parameters of type Mutation
 void TServerInstance.clearLastLocation(Mutation m)
           
 void TServerInstance.putFutureLocation(Mutation m)
           
 void TServerInstance.putLastLocation(Mutation m)
           
 void TServerInstance.putLocation(Mutation m)
           
 

Uses of Mutation in org.apache.accumulo.server.tabletserver
 

Methods in org.apache.accumulo.server.tabletserver that return types with arguments of type Mutation
 List<Mutation> TabletMutations.getMutations()
           
static Iterator<Mutation> MutationLog.replay(org.apache.hadoop.fs.Path logfile, Tablet t, long min_timestamp)
           
 

Methods in org.apache.accumulo.server.tabletserver with parameters of type Mutation
 void MutationLog.log(Mutation m)
           
 void NativeMap.mutate(Mutation mutation, int mutationCount)
           
protected  void TabletTime.setSystemTimes(Mutation mutation, long lastCommitTime)
           
 

Method parameters in org.apache.accumulo.server.tabletserver with type arguments of type Mutation
 void Tablet.CommitSession.abortCommit(List<Mutation> value)
           
 void Tablet.abortCommit(Tablet.CommitSession commitSession, List<Mutation> value)
           
 void Tablet.CommitSession.commit(List<Mutation> mutations)
           
 void Tablet.commit(Tablet.CommitSession commitSession, List<Mutation> mutations)
           
 void InMemoryMap.mutate(List<Mutation> mutations)
          Applies changes to a row in the InMemoryMap
 void NativeMap.mutate(List<Mutation> mutations, int mutationCount)
           
 Tablet.CommitSession Tablet.prepareMutationsForCommit(org.apache.accumulo.server.tabletserver.TabletServer.TservConstraintEnv cenv, List<Mutation> mutations)
           
 

Constructor parameters in org.apache.accumulo.server.tabletserver with type arguments of type Mutation
TabletMutations(int tid, int seq, List<Mutation> mutations)
           
 

Uses of Mutation in org.apache.accumulo.server.tabletserver.log
 

Methods in org.apache.accumulo.server.tabletserver.log with parameters of type Mutation
 DfsLogger.LoggerOperation DfsLogger.log(int seq, int tid, Mutation mutation)
           
 int TabletServerLogger.log(Tablet.CommitSession commitSession, int tabletSeq, Mutation m)
           
 void MutationReceiver.receive(Mutation m)
           
 

Method parameters in org.apache.accumulo.server.tabletserver.log with type arguments of type Mutation
 int TabletServerLogger.logManyTablets(Map<Tablet.CommitSession,List<Mutation>> mutations)
           
 

Uses of Mutation in org.apache.accumulo.server.util
 

Methods in org.apache.accumulo.server.util that return Mutation
static Mutation MetadataTable.createDeleteMutation(String tableId, String pathToRemove)
           
 Mutation RandomWriter.RandomMutationGenerator.next()
           
 

Methods in org.apache.accumulo.server.util that return types with arguments of type Mutation
 Iterator<Mutation> RandomWriter.RandomMutationGenerator.iterator()
           
 

Methods in org.apache.accumulo.server.util with parameters of type Mutation
static void MetadataTable.putLockID(ZooLock zooLock, Mutation m)
           
static void MetadataTable.update(TCredentials credentials, Mutation m)
           
static void MetadataTable.update(TCredentials credentials, ZooLock zooLock, Mutation m)
           
 

Uses of Mutation in org.apache.accumulo.test
 

Methods in org.apache.accumulo.test with parameters of type Mutation
 void NullBatchWriter.addMutation(Mutation m)
           
 

Method parameters in org.apache.accumulo.test with type arguments of type Mutation
 void NullBatchWriter.addMutations(Iterable<Mutation> iterable)
           
 

Uses of Mutation in org.apache.accumulo.test.continuous
 

Methods in org.apache.accumulo.test.continuous that return Mutation
static Mutation ContinuousIngest.genMutation(long rowLong, int cfInt, int cqInt, ColumnVisibility cv, byte[] ingestInstanceId, long count, byte[] prevRow, Random r, boolean checksum)
           
 

Uses of Mutation in org.apache.accumulo.test.functional
 

Methods in org.apache.accumulo.test.functional with parameters of type Mutation
 List<Short> SlowConstraint.check(Constraint.Environment env, Mutation mutation)
           
 

Uses of Mutation in org.apache.accumulo.test.randomwalk.concurrent
 

Methods in org.apache.accumulo.test.randomwalk.concurrent with parameters of type Mutation
 void BulkImport.RFileBatchWriter.addMutation(Mutation m)
           
 

Method parameters in org.apache.accumulo.test.randomwalk.concurrent with type arguments of type Mutation
 void BulkImport.RFileBatchWriter.addMutations(Iterable<Mutation> iterable)
           
 



Copyright © 2013 Apache Accumulo Project. All Rights Reserved.