Uses of Class
org.apache.hadoop.hbase.client.Mutation
Package
Description
Provides HBase Client
Table of Contents
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
-
Uses of Mutation in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionprivate static void
MetaTableAccessor.debugLogMutation
(Mutation p) private static void
MetaTableAccessor.multiMutate
(Table table, byte[] row, Mutation... mutations) Modifier and TypeMethodDescriptionprivate static void
MetaTableAccessor.debugLogMutations
(List<? extends Mutation> mutations) (package private) static void
MetaTableAccessor.multiMutate
(Table table, byte[] row, List<Mutation> mutations) Performs an atomic multi-mutate operation against the given table. -
Uses of Mutation in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
Performs Append operations on a single row.class
Used to perform Delete operations on a single row.class
Used to perform Increment operations on a single row.class
Used to perform Put operations for a single row.Modifier and TypeFieldDescriptionAsyncBufferedMutatorImpl.mutations
RowMutations.mutations
private final ConcurrentLinkedQueue<Mutation>
BufferedMutatorImpl.writeAsyncBuffer
Modifier and TypeMethodDescription(package private) Mutation
Mutation.setACL
(String user, Permission perms) Set the ACL for this operation.Mutation.setACL
(Map<String, Permission> perms) Set the ACL for this operation.Mutation.setCellVisibility
(CellVisibility expression) Sets the visibility expression associated with cells in this Mutation.Mutation.setClusterIds
(List<UUID> clusterIds) Marks that the clusters with the given clusterIds have consumed the mutationMutation.setDurability
(Durability d) Set the durability for this mutationMutation.setFamilyCellMap
(NavigableMap<byte[], List<Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.protected Mutation
Mutation.setReturnResults
(boolean returnResults) Mutation.setTimestamp
(long timestamp) Set the timestamp of the delete.Mutation.setTTL
(long ttl) Set the TTL desired for the result of the mutation, in milliseconds.Modifier and TypeMethodDescriptionRowMutations.getMutations()
Returns An unmodifiable list of the current mutations.Modifier and TypeMethodDescription(package private) static void
ConnectionUtils.checkHasFamilies
(Mutation mutation) private CheckAndMutateResult
HTable.doCheckAndMutate
(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, byte[] value, Filter filter, TimeRange timeRange, Mutation mutation) default CompletableFuture<Void>
Sends aMutation
to the table.void
Sends aMutation
to the table.void
Modifier and TypeMethodDescriptionAdd a list of mutationsSend someMutation
s to the table.void
Send someMutation
s to the table.void
static RowMutations
Create aRowMutations
with the specified mutations. -
Uses of Mutation in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionRegionObserver.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.RegionObserver.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.default Cell
RegionObserver.postMutationBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.default void
RegionServerObserver.postReplicationSinkBatchMutate
(ObserverContext<RegionServerCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, Mutation mutation) This will be called after replication sink mutations are executed on the sink table as part of batch call.default void
RegionObserver.prePrepareTimeStampForDeleteVersion
(ObserverContext<RegionCoprocessorEnvironment> c, Mutation mutation, Cell cell, byte[] byteNow, Get get) Deprecated.Since hbase-2.0.0.default void
RegionServerObserver.preReplicationSinkBatchMutate
(ObserverContext<RegionServerCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, Mutation mutation) This will be called before replication sink mutations are executed on the sink table as part of batch call.Modifier and TypeMethodDescriptiondefault void
RegionObserver.postBatchMutate
(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) This will be called after applying a batch of Mutations on a region.default void
RegionObserver.postBatchMutateIndispensably
(ObserverContext<RegionCoprocessorEnvironment> ctx, MiniBatchOperationInProgress<Mutation> miniBatchOp, boolean success) Called after the completion of batch put/delete/increment/append and will be called even if the batch operation fails.default void
RegionObserver.preBatchMutate
(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) This will be called for every batch mutation operation happening at the server.default void
MasterObserver.preMergeRegionsCommitAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, List<Mutation> metaEntries) This will be called before update META step as part of regions merge transaction.default void
MasterObserver.preSplitRegionBeforeMETAAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, byte[] splitKey, List<Mutation> metaEntries) This will be called before update META step as part of split transaction. -
Uses of Mutation in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionMutationSerialization.MutationDeserializer.deserialize
(Mutation mutation) Modifier and TypeMethodDescriptionorg.apache.hadoop.io.serializer.Deserializer<Mutation>
MutationSerialization.getDeserializer
(Class<Mutation> c) org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,
Mutation> MultiTableOutputFormat.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) TableOutputFormat.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) Creates a new record writer.org.apache.hadoop.io.serializer.Serializer<Mutation>
MutationSerialization.getSerializer
(Class<Mutation> c) Modifier and TypeMethodDescriptionMutationSerialization.MutationDeserializer.deserialize
(Mutation mutation) void
void
MultiTableOutputFormat.MultiTableRecordWriter.write
(ImmutableBytesWritable tableName, Mutation action) Writes an action (Put or Delete) to the specified table.void
Writes a key/value pair into the table.Modifier and TypeMethodDescriptionorg.apache.hadoop.io.serializer.Deserializer<Mutation>
MutationSerialization.getDeserializer
(Class<Mutation> c) org.apache.hadoop.io.serializer.Serializer<Mutation>
MutationSerialization.getSerializer
(Class<Mutation> c) void
IdentityTableReducer.reduce
(org.apache.hadoop.io.Writable key, Iterable<Mutation> values, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.io.Writable, Mutation, org.apache.hadoop.io.Writable, Mutation>.org.apache.hadoop.mapreduce.Reducer.Context context) Writes each given record, consisting of the row key and the given values, to the configuredOutputFormat
. -
Uses of Mutation in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionvoid
MasterCoprocessorHost.preMergeRegionsCommit
(RegionInfo[] regionsToMerge, List<Mutation> metaEntries, User user) Invoked before merge regions operation writes the new region to hbase:metavoid
MasterCoprocessorHost.preSplitBeforeMETAAction
(byte[] splitKey, List<Mutation> metaEntries, User user) This will be called before update META step as part of split table region procedure. -
Uses of Mutation in org.apache.hadoop.hbase.master.assignment
Modifier and TypeMethodDescriptionprivate static void
RegionStateStore.debugLogMutation
(Mutation p) Modifier and TypeMethodDescriptionprivate static void
RegionStateStore.debugLogMutations
(List<? extends Mutation> mutations) -
Uses of Mutation in org.apache.hadoop.hbase.procedure2.store.region
Modifier and TypeMethodDescriptionprivate void
RegionProcedureStore.serializeDelete
(long procId, List<Mutation> mutations, List<byte[]> rowsToLock) private void
RegionProcedureStore.serializePut
(Procedure<?> proc, List<Mutation> mutations, List<byte[]> rowsToLock) -
Uses of Mutation in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionvoid
DefaultOperationQuota.addMutation
(Mutation mutation) void
NoopOperationQuota.addMutation
(Mutation mutation) void
OperationQuota.addMutation
(Mutation mutation) Add a mutation result.static long
QuotaUtil.calculateMutationSize
(Mutation mutation) void
Checks the givenMutation
againstthis
policy. -
Uses of Mutation in org.apache.hadoop.hbase.quotas.policies
Modifier and TypeMethodDescriptionvoid
void
void
void
void
-
Uses of Mutation in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate Mutation[][]
MiniBatchOperationInProgress.operationsFromCoprocessors
Modifier and TypeMethodDescriptionabstract Mutation
HRegion.BatchOperation.getMutation
(int index) HRegion.MutationBatchOperation.getMutation
(int index) HRegion.ReplayBatchOperation.getMutation
(int index) abstract Mutation[]
HRegion.BatchOperation.getMutationsForCoprocs()
This method is potentially expensive and useful mostly for non-replay CP path.Mutation[]
HRegion.MutationBatchOperation.getMutationsForCoprocs()
Mutation[]
HRegion.ReplayBatchOperation.getMutationsForCoprocs()
Mutation[]
MiniBatchOperationInProgress.getOperationsFromCoprocessors
(int index) Modifier and TypeMethodDescriptionprotected MiniBatchOperationInProgress<Mutation>
HRegion.BatchOperation.createMiniBatch
(int lastIndexExclusive, int readyToWriteCount) HRegion.BatchOperation.lockRowsAndBuildMiniBatch
(List<Region.RowLock> acquiredRowLocks) Creates Mini-batch of all operations [nextIndexToProcess, lastIndexExclusive) for which a row lock can be acquired.Modifier and TypeMethodDescriptionvoid
MiniBatchOperationInProgress.addOperationsFromCP
(int index, Mutation[] newOperations) Add more Mutations corresponding to the Mutation at the given index to be committed atomically in the same batch.HRegion.batchMutate
(Mutation[] mutations) (package private) OperationStatus[]
HRegion.batchMutate
(Mutation[] mutations, boolean atomic) HRegion.batchMutate
(Mutation[] mutations, boolean atomic, long nonceGroup, long nonce) Region.batchMutate
(Mutation[] mutations) Perform a batch of mutations.boolean
HRegion.checkAndMutate
(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, TimeRange timeRange, Mutation mutation) Deprecated.boolean
HRegion.checkAndMutate
(byte[] row, Filter filter, TimeRange timeRange, Mutation mutation) Deprecated.default boolean
Region.checkAndMutate
(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.boolean
Region.checkAndMutate
(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, TimeRange timeRange, Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
Region.checkAndMutate
(byte[] row, Filter filter, Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.boolean
Region.checkAndMutate
(byte[] row, Filter filter, TimeRange timeRange, Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.protected void
HRegion.BatchOperation.checkAndPrepareMutation
(Mutation mutation, long timestamp) Helper method that checks and prepares only one mutation.private void
RSRpcServices.checkCellSizeLimit
(HRegion r, Mutation m) private void
HRegion.checkMutationType
(Mutation mutation) private OperationStatus
private OperationStatus
private OperationStatus
void
RegionServerCoprocessorHost.postReplicationSinkBatchMutate
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, Mutation mutation) private void
HRegion.prepareDeleteTimestamps
(Mutation mutation, Map<byte[], List<Cell>> familyMap, byte[] byteNow) Set up correct timestamps in the KVs in Delete object.boolean
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion
(Mutation mutation, Cell kv, byte[] byteNow, Get get) Deprecated.In hbase-2.0.0.void
RegionServerCoprocessorHost.preReplicationSinkBatchMutate
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, Mutation mutation) private static Cell
HRegion.MutationBatchOperation.reckonDelta
(Cell delta, Cell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<Cell, byte[]> supplier) HRegion.MutationBatchOperation.reckonDeltas
(Mutation mutation, List<Cell> results, long now) HRegion.MutationBatchOperation.reckonDeltasByStore
(HStore store, Mutation mutation, long now, List<Cell> deltas, List<Cell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.private void
HRegion.rewriteCellTags
(Map<byte[], List<Cell>> familyMap, Mutation m) Possibly rewrite incoming cell tags.private static Get
Modifier and TypeMethodDescriptionHRegion.BatchOperation.buildWALEdits
(MiniBatchOperationInProgress<Mutation> miniBatchOp) Builds separate WALEdit per nonce by applying input mutations.HRegion.MutationBatchOperation.buildWALEdits
(MiniBatchOperationInProgress<Mutation> miniBatchOp) private void
HRegion.MutationBatchOperation.checkAndMergeCPMutations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Region.RowLock> acquiredRowLocks, long timestamp) void
HRegion.BatchOperation.completeMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) This method completes mini-batch operations by calling postBatchMutate() CP hook (if required) and completing mvcc.void
HRegion.MutationBatchOperation.completeMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) void
HRegion.ReplayBatchOperation.completeMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) private void
HRegion.BatchOperation.doFinishHotnessProtector
(MiniBatchOperationInProgress<Mutation> miniBatchOp) void
HRegion.BatchOperation.doPostOpCleanupForMiniBatch
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) void
HRegion.MutationBatchOperation.doPostOpCleanupForMiniBatch
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) private void
HRegion.doProcessRowWithTimeout
(RowProcessor<?, ?> processor, long now, HRegion region, List<Mutation> mutations, WALEdit walEdit, long timeout) void
HRegion.mutateRowsWithLocks
(Collection<Mutation> mutations, Collection<byte[]> rowsToLock, long nonceGroup, long nonce) Perform atomic (all or none) mutations within the region.void
Region.mutateRowsWithLocks
(Collection<Mutation> mutations, Collection<byte[]> rowsToLock, long nonceGroup, long nonce) Perform atomic mutations within the region.void
RegionCoprocessorHost.postBatchMutate
(MiniBatchOperationInProgress<Mutation> miniBatchOp) void
RegionCoprocessorHost.postBatchMutateIndispensably
(MiniBatchOperationInProgress<Mutation> miniBatchOp, boolean success) void
RegionCoprocessorHost.preBatchMutate
(MiniBatchOperationInProgress<Mutation> miniBatchOp) abstract void
HRegion.BatchOperation.prepareMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, long timestamp, List<Region.RowLock> acquiredRowLocks) If necessary, calls preBatchMutate() CP hook for a mini-batch and updates metrics, cell count, tags and timestamp for all cells of all operations in a mini-batch.void
HRegion.MutationBatchOperation.prepareMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, long timestamp, List<Region.RowLock> acquiredRowLocks) void
HRegion.ReplayBatchOperation.prepareMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, long timestamp, List<Region.RowLock> acquiredRowLocks) void
Deprecated.HRegion handles the locks and MVCC and invokes this method properly.protected void
HRegion.BatchOperation.writeMiniBatchOperationsToMemStore
(MiniBatchOperationInProgress<Mutation> miniBatchOp, long writeNumber) HRegion.BatchOperation.writeMiniBatchOperationsToMemStore
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) Write mini-batch operations to MemStoreHRegion.MutationBatchOperation.writeMiniBatchOperationsToMemStore
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) HRegion.ReplayBatchOperation.writeMiniBatchOperationsToMemStore
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) ModifierConstructorDescriptionMutationBatchOperation
(HRegion region, Mutation[] operations, boolean atomic, long nonceGroup, long nonce) -
Uses of Mutation in org.apache.hadoop.hbase.rsgroup
Modifier and TypeMethodDescriptionprivate void
RSGroupInfoManagerImpl.multiMutate
(List<Mutation> mutations) -
Uses of Mutation in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionprivate void
AccessController.checkForReservedTagPresence
(User user, Mutation m) private Cell
AccessController.createNewCellWithTags
(Mutation mutation, Cell oldCell, Cell newCell) AccessController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Modifier and TypeMethodDescriptionvoid
AccessController.preBatchMutate
(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) -
Uses of Mutation in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionprivate Cell
VisibilityController.createNewCellWithTags
(Mutation mutation, Cell newCell) VisibilityController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) void
VisibilityController.prePrepareTimeStampForDeleteVersion
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) Modifier and TypeMethodDescriptionprivate boolean
DefaultVisibilityLabelServiceImpl.mutateLabelsRegion
(List<Mutation> mutations, OperationStatus[] finalOpStatus) Adds the mutations to labels region and set the results to the finalOpStatus.void
VisibilityController.preBatchMutate
(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) -
Uses of Mutation in org.apache.hadoop.hbase.tool
Modifier and TypeMethodDescriptionvoid
WriteSinkCoprocessor.preBatchMutate
(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) -
Uses of Mutation in org.apache.hadoop.hbase.wal
ModifierConstructorDescriptionMutationReplay
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, Mutation mutation, long nonceGroup, long nonce)