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 org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.Append
Performs Append operations on a single row.class
org.apache.hadoop.hbase.client.Delete
Used to perform Delete operations on a single row.class
org.apache.hadoop.hbase.client.Increment
Used to perform Increment operations on a single row.class
org.apache.hadoop.hbase.client.Put
Used to perform Put operations for a single row.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Mutation
Mutation.setACL
(String user, org.apache.hadoop.hbase.security.access.Permission perms) Set the ACL for this operation.org.apache.hadoop.hbase.client.Mutation
Set the ACL for this operation.org.apache.hadoop.hbase.client.Mutation
Mutation.setCellVisibility
(org.apache.hadoop.hbase.security.visibility.CellVisibility expression) Sets the visibility expression associated with cells in this Mutation.org.apache.hadoop.hbase.client.Mutation
Marks that the clusters with the given clusterIds have consumed the mutationorg.apache.hadoop.hbase.client.Mutation
Mutation.setDurability
(org.apache.hadoop.hbase.client.Durability d) Set the durability for this mutationorg.apache.hadoop.hbase.client.Mutation
Mutation.setFamilyCellMap
(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.protected org.apache.hadoop.hbase.client.Mutation
Mutation.setReturnResults
(boolean returnResults) org.apache.hadoop.hbase.client.Mutation
Mutation.setTimestamp
(long timestamp) Set the timestamp of the delete.org.apache.hadoop.hbase.client.Mutation
Mutation.setTTL
(long ttl) Set the TTL desired for the result of the mutation, in milliseconds.Modifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.client.Mutation>
RowMutations.getMutations()
Returns An unmodifiable list of the current mutations.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.RowMutations
RowMutations.add
(org.apache.hadoop.hbase.client.Mutation mutation) Currently only supportsPut
andDelete
mutations.default CompletableFuture<Void>
AsyncBufferedMutator.mutate
(org.apache.hadoop.hbase.client.Mutation mutation) Sends aMutation
to the table.void
BufferedMutator.mutate
(org.apache.hadoop.hbase.client.Mutation mutation) Sends aMutation
to the table.void
BufferedMutatorImpl.mutate
(org.apache.hadoop.hbase.client.Mutation m) Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.RowMutations
RowMutations.add
(List<? extends org.apache.hadoop.hbase.client.Mutation> mutations) Add a list of mutationsAsyncBufferedMutator.mutate
(List<? extends org.apache.hadoop.hbase.client.Mutation> mutations) Send someMutation
s to the table.void
BufferedMutator.mutate
(List<? extends org.apache.hadoop.hbase.client.Mutation> mutations) Send someMutation
s to the table.void
BufferedMutatorImpl.mutate
(List<? extends org.apache.hadoop.hbase.client.Mutation> ms) static org.apache.hadoop.hbase.client.RowMutations
RowMutations.of
(List<? extends org.apache.hadoop.hbase.client.Mutation> mutations) Create aRowMutations
with the specified mutations.ModifierConstructorDescriptionprotected
Mutation
(org.apache.hadoop.hbase.client.Mutation clone) -
Uses of org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.Cell
RegionObserver.postMutationBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType opType, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell oldCell, org.apache.hadoop.hbase.Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.default void
RegionServerObserver.postReplicationSinkBatchMutate
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, org.apache.hadoop.hbase.client.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
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell cell, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Deprecated.Since hbase-2.0.0.default void
RegionServerObserver.preReplicationSinkBatchMutate
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, org.apache.hadoop.hbase.client.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
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<org.apache.hadoop.hbase.client.Mutation> miniBatchOp) This will be called after applying a batch of Mutations on a region.default void
RegionObserver.postBatchMutateIndispensably
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<org.apache.hadoop.hbase.client.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
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<org.apache.hadoop.hbase.client.Mutation> miniBatchOp) This will be called for every batch mutation operation happening at the server.default void
MasterObserver.preMergeRegionsCommitAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, List<org.apache.hadoop.hbase.client.Mutation> metaEntries) This will be called before update META step as part of regions merge transaction.default void
MasterObserver.preSplitRegionBeforeMETAAction
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, byte[] splitKey, List<org.apache.hadoop.hbase.client.Mutation> metaEntries) This will be called before update META step as part of split transaction. -
Uses of org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionorg.apache.hadoop.io.serializer.Deserializer<org.apache.hadoop.hbase.client.Mutation>
MutationSerialization.getDeserializer
(Class<org.apache.hadoop.hbase.client.Mutation> c) org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.client.Mutation> MultiTableOutputFormat.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) org.apache.hadoop.mapreduce.RecordWriter<KEY,
org.apache.hadoop.hbase.client.Mutation> TableOutputFormat.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) Creates a new record writer.org.apache.hadoop.io.serializer.Serializer<org.apache.hadoop.hbase.client.Mutation>
MutationSerialization.getSerializer
(Class<org.apache.hadoop.hbase.client.Mutation> c) Modifier and TypeMethodDescriptionvoid
MultiTableOutputFormat.MultiTableRecordWriter.write
(org.apache.hadoop.hbase.io.ImmutableBytesWritable tableName, org.apache.hadoop.hbase.client.Mutation action) Writes an action (Put or Delete) to the specified table.void
TableOutputFormat.TableRecordWriter.write
(KEY key, org.apache.hadoop.hbase.client.Mutation value) Writes a key/value pair into the table.Modifier and TypeMethodDescriptionorg.apache.hadoop.io.serializer.Deserializer<org.apache.hadoop.hbase.client.Mutation>
MutationSerialization.getDeserializer
(Class<org.apache.hadoop.hbase.client.Mutation> c) org.apache.hadoop.io.serializer.Serializer<org.apache.hadoop.hbase.client.Mutation>
MutationSerialization.getSerializer
(Class<org.apache.hadoop.hbase.client.Mutation> c) void
IdentityTableReducer.reduce
(org.apache.hadoop.io.Writable key, Iterable<org.apache.hadoop.hbase.client.Mutation> values, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.io.Writable, org.apache.hadoop.hbase.client.Mutation, org.apache.hadoop.io.Writable, org.apache.hadoop.hbase.client.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 org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionvoid
MasterCoprocessorHost.preMergeRegionsCommit
(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, List<org.apache.hadoop.hbase.client.Mutation> metaEntries, org.apache.hadoop.hbase.security.User user) Invoked before merge regions operation writes the new region to hbase:metavoid
MasterCoprocessorHost.preSplitBeforeMETAAction
(byte[] splitKey, List<org.apache.hadoop.hbase.client.Mutation> metaEntries, org.apache.hadoop.hbase.security.User user) This will be called before update META step as part of split table region procedure. -
Uses of org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionvoid
DefaultOperationQuota.addMutation
(org.apache.hadoop.hbase.client.Mutation mutation) void
OperationQuota.addMutation
(org.apache.hadoop.hbase.client.Mutation mutation) Add a mutation result.static long
QuotaUtil.calculateMutationSize
(org.apache.hadoop.hbase.client.Mutation mutation) void
SpaceViolationPolicyEnforcement.check
(org.apache.hadoop.hbase.client.Mutation m) Checks the givenMutation
againstthis
policy. -
Uses of org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.quotas.policies
Modifier and TypeMethodDescriptionvoid
DefaultViolationPolicyEnforcement.check
(org.apache.hadoop.hbase.client.Mutation m) void
DisableTableViolationPolicyEnforcement.check
(org.apache.hadoop.hbase.client.Mutation m) void
MissingSnapshotViolationPolicyEnforcement.check
(org.apache.hadoop.hbase.client.Mutation m) void
NoInsertsViolationPolicyEnforcement.check
(org.apache.hadoop.hbase.client.Mutation m) void
NoWritesViolationPolicyEnforcement.check
(org.apache.hadoop.hbase.client.Mutation m) -
Uses of org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Mutation[]
MiniBatchOperationInProgress.getOperationsFromCoprocessors
(int index) Modifier and TypeMethodDescriptionvoid
MiniBatchOperationInProgress.addOperationsFromCP
(int index, org.apache.hadoop.hbase.client.Mutation[] newOperations) Add more Mutations corresponding to the Mutation at the given index to be committed atomically in the same batch.org.apache.hadoop.hbase.regionserver.OperationStatus[]
HRegion.batchMutate
(org.apache.hadoop.hbase.client.Mutation[] mutations) org.apache.hadoop.hbase.regionserver.OperationStatus[]
HRegion.batchMutate
(org.apache.hadoop.hbase.client.Mutation[] mutations, boolean atomic, long nonceGroup, long nonce) org.apache.hadoop.hbase.regionserver.OperationStatus[]
Region.batchMutate
(org.apache.hadoop.hbase.client.Mutation[] mutations) Perform a batch of mutations.boolean
HRegion.checkAndMutate
(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation) Deprecated.boolean
HRegion.checkAndMutate
(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation) Deprecated.default boolean
Region.checkAndMutate
(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.client.Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.boolean
Region.checkAndMutate
(byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.default boolean
Region.checkAndMutate
(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.client.Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.boolean
Region.checkAndMutate
(byte[] row, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation) Deprecated.since 2.4.0 and will be removed in 4.0.0.List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) void
RegionServerCoprocessorHost.postReplicationSinkBatchMutate
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, org.apache.hadoop.hbase.client.Mutation mutation) boolean
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion
(org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell kv, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Deprecated.In hbase-2.0.0.void
RegionServerCoprocessorHost.preReplicationSinkBatchMutate
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, org.apache.hadoop.hbase.client.Mutation mutation) Modifier and TypeMethodDescriptionvoid
HRegion.mutateRowsWithLocks
(Collection<org.apache.hadoop.hbase.client.Mutation> mutations, Collection<byte[]> rowsToLock, long nonceGroup, long nonce) Perform atomic (all or none) mutations within the region.void
Region.mutateRowsWithLocks
(Collection<org.apache.hadoop.hbase.client.Mutation> mutations, Collection<byte[]> rowsToLock, long nonceGroup, long nonce) Perform atomic mutations within the region.void
RegionCoprocessorHost.postBatchMutate
(org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<org.apache.hadoop.hbase.client.Mutation> miniBatchOp) void
RegionCoprocessorHost.postBatchMutateIndispensably
(org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<org.apache.hadoop.hbase.client.Mutation> miniBatchOp, boolean success) void
RegionCoprocessorHost.preBatchMutate
(org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<org.apache.hadoop.hbase.client.Mutation> miniBatchOp) void
RowProcessor.process
(long now, org.apache.hadoop.hbase.regionserver.HRegion region, List<org.apache.hadoop.hbase.client.Mutation> mutations, org.apache.hadoop.hbase.wal.WALEdit walEdit) Deprecated.HRegion handles the locks and MVCC and invokes this method properly. -
Uses of org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Mutation
ProtobufUtil.toMutation
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto proto) Convert a MutateRequest to MutationModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest
RequestConverter.buildMutateRequest
(byte[] regionName, byte[] row, byte[] family, byte[] qualifier, org.apache.hadoop.hbase.CompareOperator op, byte[] value, org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.io.TimeRange timeRange, org.apache.hadoop.hbase.client.Mutation mutation, long nonceGroup, long nonce) Create a protocol buffer MutateRequest for a conditioned put/delete/increment/appendstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto
ProtobufUtil.toMutation
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation) static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto
ProtobufUtil.toMutation
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation, long nonce) Create a protocol buffer Mutate based on a client Mutationstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto
ProtobufUtil.toMutation
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.Builder builder) static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto
ProtobufUtil.toMutation
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.Builder builder, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto
ProtobufUtil.toMutationNoData
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation) Create a protocol buffer MutationProto based on a client Mutation.static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto
ProtobufUtil.toMutationNoData
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.Builder builder) Create a protocol buffer MutationProto based on a client Mutation.static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto
ProtobufUtil.toMutationNoData
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.Builder builder, long nonce) Modifier and TypeMethodDescriptionstatic CheckAndMutate
ProtobufUtil.toCheckAndMutate
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Condition condition, List<org.apache.hadoop.hbase.client.Mutation> mutations) -
Uses of org.apache.hadoop.hbase.client.Mutation in org.apache.hadoop.hbase.wal
Modifier and TypeFieldDescriptionfinal org.apache.hadoop.hbase.client.Mutation
WALSplitUtil.MutationReplay.mutation
ModifierConstructorDescriptionMutationReplay
(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, org.apache.hadoop.hbase.client.Mutation mutation, long nonceGroup, long nonce)