Modifier and Type | Method and Description |
---|---|
void |
BatchWriter.addMutation(Mutation m)
Queues one mutation to write.
|
Modifier and Type | Method and Description |
---|---|
void |
BatchWriter.addMutations(Iterable<Mutation> iterable)
Queues several mutations to write.
|
Modifier and Type | Method and Description |
---|---|
Map<KeyExtent,List<Mutation>> |
TabletLocator.TabletServerMutations.getMutations() |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
void |
AccumuloOutputFormat.AccumuloRecordWriter.write(org.apache.hadoop.io.Text table,
Mutation mutation)
Push a mutation into a table.
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.io.Text,Mutation> |
AccumuloOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext attempt) |
Modifier and Type | Method and Description |
---|---|
void |
AccumuloOutputFormat.AccumuloRecordWriter.write(org.apache.hadoop.io.Text table,
Mutation mutation)
Push a mutation into a table.
|
Modifier and Type | Method and Description |
---|---|
void |
MockBatchWriter.addMutation(Mutation m) |
void |
MockAccumulo.addMutation(String table,
Mutation m) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
List<Short> |
Constraint.check(Constraint.Environment env,
Mutation mutation)
Checks a mutation for constrain violations.
|
Modifier and Type | Method and Description |
---|---|
Mutation |
KeyExtent.getPrevRowUpdateMutation()
Returns a String representing the previous extent's entry in the Metadata table
|
static Mutation |
KeyExtent.getPrevRowUpdateMutation(KeyExtent ke) |
Modifier and Type | Method and Description |
---|---|
boolean |
Mutation.equals(Mutation m) |
Constructor and Description |
---|
Mutation(Mutation m) |
Modifier and Type | Method and Description |
---|---|
List<Short> |
VisibilityConstraint.check(Constraint.Environment env,
Mutation mutation) |
Modifier and Type | Method and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
static Mutation |
Ingest.buildMutation(ColumnVisibility cv,
String path,
boolean isDir,
boolean isHidden,
boolean canExec,
long length,
long lastmod,
String hash) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Class and Description |
---|---|
class |
ServerMutation
Mutation that holds system time as computed by the tablet server when not provided by the user.
|
Modifier and Type | Field and Description |
---|---|
List<Mutation> |
LogFileValue.mutations |
Modifier and Type | Method and Description |
---|---|
void |
TServerInstance.clearLastLocation(Mutation m) |
void |
TServerInstance.putFutureLocation(Mutation m) |
void |
TServerInstance.putLastLocation(Mutation m) |
void |
TServerInstance.putLocation(Mutation m) |
Modifier and Type | Method and Description |
---|---|
List<Mutation> |
TabletMutations.getMutations() |
static Iterator<Mutation> |
MutationLog.replay(org.apache.hadoop.fs.Path logfile,
Tablet t,
long min_timestamp) |
Modifier and Type | Method and Description |
---|---|
void |
MutationLog.log(Mutation m) |
void |
NativeMap.mutate(Mutation mutation,
int mutationCount) |
protected void |
TabletTime.setSystemTimes(Mutation mutation,
long lastCommitTime) |
Modifier and Type | Method and Description |
---|---|
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 and Description |
---|
TabletMutations(int tid,
int seq,
List<Mutation> mutations) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
int |
TabletServerLogger.logManyTablets(Map<Tablet.CommitSession,List<Mutation>> mutations) |
Modifier and Type | Method and Description |
---|---|
static Mutation |
MetadataTable.createDeleteMutation(String tableId,
String pathToRemove) |
Mutation |
RandomWriter.RandomMutationGenerator.next() |
Modifier and Type | Method and Description |
---|---|
Iterator<Mutation> |
RandomWriter.RandomMutationGenerator.iterator() |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
void |
NullBatchWriter.addMutation(Mutation m) |
Modifier and Type | Method and Description |
---|---|
void |
NullBatchWriter.addMutations(Iterable<Mutation> iterable) |
Modifier and Type | Method and Description |
---|---|
static Mutation |
ContinuousIngest.genMutation(long rowLong,
int cfInt,
int cqInt,
ColumnVisibility cv,
byte[] ingestInstanceId,
long count,
byte[] prevRow,
Random r,
boolean checksum) |
Modifier and Type | Method and Description |
---|---|
List<Short> |
SlowConstraint.check(Constraint.Environment env,
Mutation mutation) |
Modifier and Type | Method and Description |
---|---|
void |
BulkImport.RFileBatchWriter.addMutation(Mutation m) |
Modifier and Type | Method and Description |
---|---|
void |
BulkImport.RFileBatchWriter.addMutations(Iterable<Mutation> iterable) |
Modifier and Type | Method and Description |
---|---|
Mutation |
RandomMutations.next() |
Copyright © 2015 Apache Accumulo Project. All Rights Reserved.