Uses of Class
org.apache.hadoop.hbase.client.Mutation
Packages that use 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
Methods in org.apache.hadoop.hbase with parameters of type MutationModifier and TypeMethodDescriptionprivate static voidMetaTableAccessor.debugLogMutation(Mutation p) Method parameters in org.apache.hadoop.hbase with type arguments of type MutationModifier and TypeMethodDescriptionprivate static voidMetaTableAccessor.debugLogMutations(List<? extends Mutation> mutations) -
Uses of Mutation in org.apache.hadoop.hbase.client
Subclasses of Mutation in org.apache.hadoop.hbase.clientModifier and TypeClassDescriptionclassPerforms Append operations on a single row.classUsed to perform Delete operations on a single row.classUsed to perform Increment operations on a single row.classUsed to perform Put operations for a single row.Fields in org.apache.hadoop.hbase.client with type parameters of type MutationModifier and TypeFieldDescriptionprivate final ConcurrentLinkedQueue<Pair<Mutation,Throwable>> BufferedMutatorOverAsyncBufferedMutator.errorsAsyncBufferedMutatorImpl.mutationsRowMutations.mutationsMethods in org.apache.hadoop.hbase.client that return MutationModifier and TypeMethodDescription(package private) MutationMutation.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 mutationprotected MutationMutation.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.Methods in org.apache.hadoop.hbase.client that return types with arguments of type MutationModifier and TypeMethodDescriptionRowMutations.getMutations()Returns An unmodifiable list of the current mutations.Methods in org.apache.hadoop.hbase.client with parameters of type MutationModifier and TypeMethodDescriptionAdd a mutation(package private) static voidConnectionUtils.checkHasFamilies(Mutation mutation) static NavigableMap<byte[],List<ExtendedCell>> ClientInternalHelper.getExtendedFamilyCellMap(Mutation m) default CompletableFuture<Void>Sends aMutationto the table.voidSends aMutationto the table.voidMethod parameters in org.apache.hadoop.hbase.client with type arguments of type MutationModifier and TypeMethodDescriptionAdd a list of mutationsSend someMutations to the table.voidSend someMutations to the table.voidstatic RowMutationsCreate aRowMutationswith the specified mutations.Constructors in org.apache.hadoop.hbase.client with parameters of type Mutation -
Uses of Mutation in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type MutationModifier and TypeMethodDescriptionRegionObserver.postAppendBeforeWAL(ObserverContext<? extends 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<? extends 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 CellRegionObserver.postMutationBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.default voidRegionServerObserver.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 voidRegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<? extends RegionCoprocessorEnvironment> c, Mutation mutation, Cell cell, byte[] byteNow, Get get) Deprecated.Since hbase-2.0.0.default voidRegionServerObserver.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.Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type MutationModifier and TypeMethodDescriptiondefault voidRegionObserver.postBatchMutate(ObserverContext<? extends RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) This will be called after applying a batch of Mutations on a region.default voidRegionObserver.postBatchMutateIndispensably(ObserverContext<? extends 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 voidRegionObserver.preBatchMutate(ObserverContext<? extends RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) This will be called for every batch mutation operation happening at the server.default voidMasterObserver.preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, List<Mutation> metaEntries) This will be called before update META step as part of regions merge transaction.default voidMasterObserver.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
Methods in org.apache.hadoop.hbase.mapreduce that return MutationModifier and TypeMethodDescriptionMutationSerialization.MutationDeserializer.deserialize(Mutation mutation) Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type MutationModifier 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) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type MutationModifier and TypeMethodDescriptionMutationSerialization.MutationDeserializer.deserialize(Mutation mutation) voidvoidMultiTableOutputFormat.MultiTableRecordWriter.write(ImmutableBytesWritable tableName, Mutation action) Writes an action (Put or Delete) to the specified table.voidWrites a key/value pair into the table.Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type MutationModifier 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) voidIdentityTableReducer.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
Method parameters in org.apache.hadoop.hbase.master with type arguments of type MutationModifier and TypeMethodDescriptionvoidMasterCoprocessorHost.preMergeRegionsCommit(RegionInfo[] regionsToMerge, List<Mutation> metaEntries, User user) Invoked before merge regions operation writes the new region to hbase:metavoidMasterCoprocessorHost.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
Methods in org.apache.hadoop.hbase.master.assignment with parameters of type MutationModifier and TypeMethodDescriptionprivate static voidRegionStateStore.debugLogMutation(Mutation p) Method parameters in org.apache.hadoop.hbase.master.assignment with type arguments of type MutationModifier and TypeMethodDescriptionprivate static voidRegionStateStore.debugLogMutations(List<? extends Mutation> mutations) private voidRegionStateStore.multiMutate(RegionInfo ri, List<Mutation> mutations) Performs an atomic multi-mutate operation against the given table. -
Uses of Mutation in org.apache.hadoop.hbase.procedure2.store.region
Method parameters in org.apache.hadoop.hbase.procedure2.store.region with type arguments of type MutationModifier and TypeMethodDescriptionprivate voidRegionProcedureStore.serializeDelete(long procId, List<Mutation> mutations, List<byte[]> rowsToLock) private voidRegionProcedureStore.serializePut(Procedure<?> proc, List<Mutation> mutations, List<byte[]> rowsToLock) -
Uses of Mutation in org.apache.hadoop.hbase.quotas
Methods in org.apache.hadoop.hbase.quotas with parameters of type MutationModifier and TypeMethodDescriptionvoidDefaultOperationQuota.addMutation(Mutation mutation) voidNoopOperationQuota.addMutation(Mutation mutation) voidOperationQuota.addMutation(Mutation mutation) Add a mutation result.static longQuotaUtil.calculateMutationSize(Mutation mutation) voidChecks the givenMutationagainstthispolicy. -
Uses of Mutation in org.apache.hadoop.hbase.quotas.policies
Methods in org.apache.hadoop.hbase.quotas.policies with parameters of type MutationModifier and TypeMethodDescriptionvoidvoidvoidvoidvoid -
Uses of Mutation in org.apache.hadoop.hbase.regionserver
Fields in org.apache.hadoop.hbase.regionserver declared as MutationModifier and TypeFieldDescriptionprivate Mutation[][]MiniBatchOperationInProgress.operationsFromCoprocessorsMethods in org.apache.hadoop.hbase.regionserver that return MutationModifier and TypeMethodDescriptionabstract MutationHRegion.BatchOperation.getMutation(int index) HRegion.MutationBatchOperation.getMutation(int index) HRegion.ReplayBatchOperation.getMutation(int index) Deprecated.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()Deprecated.Mutation[]MiniBatchOperationInProgress.getOperationsFromCoprocessors(int index) Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type MutationModifier 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.Methods in org.apache.hadoop.hbase.regionserver with parameters of type MutationModifier and TypeMethodDescriptionvoidMiniBatchOperationInProgress.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.booleanHRegion.checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, TimeRange timeRange, Mutation mutation) Deprecated.booleanHRegion.checkAndMutate(byte[] row, Filter filter, TimeRange timeRange, Mutation mutation) Deprecated.default booleanRegion.checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Mutation mutation) Deprecated.since 3.0.0 and will be removed in 4.0.0.booleanRegion.checkAndMutate(byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, TimeRange timeRange, Mutation mutation) Deprecated.since 3.0.0 and will be removed in 4.0.0.default booleanRegion.checkAndMutate(byte[] row, Filter filter, Mutation mutation) Deprecated.since 3.0.0 and will be removed in 4.0.0.booleanRegion.checkAndMutate(byte[] row, Filter filter, TimeRange timeRange, Mutation mutation) Deprecated.since 3.0.0 and will be removed in 4.0.0.protected voidHRegion.BatchOperation.checkAndPrepareMutation(Mutation mutation, long timestamp) Helper method that checks and prepares only one mutation.private voidRSRpcServices.checkCellSizeLimit(HRegion r, Mutation m) private voidHRegion.checkMutationType(Mutation mutation) private OperationStatusprivate OperationStatusprivate OperationStatusvoidRegionServerCoprocessorHost.postReplicationSinkBatchMutate(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, Mutation mutation) private voidHRegion.prepareDeleteTimestamps(Mutation mutation, Map<byte[], List<ExtendedCell>> familyMap, byte[] byteNow) Set up correct timestamps in the KVs in Delete object.booleanRegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation mutation, Cell kv, byte[] byteNow, Get get) Supports Coprocessor 'bypass'.voidRegionServerCoprocessorHost.preReplicationSinkBatchMutate(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry walEntry, Mutation mutation) private static ExtendedCellHRegion.MutationBatchOperation.reckonDelta(ExtendedCell delta, ExtendedCell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<ExtendedCell, byte[]> supplier) private Map<byte[],List<ExtendedCell>> HRegion.MutationBatchOperation.reckonDeltas(Mutation mutation, List<ExtendedCell> results, long now) private List<ExtendedCell>HRegion.MutationBatchOperation.reckonDeltasByStore(HStore store, Mutation mutation, long now, List<ExtendedCell> deltas, List<ExtendedCell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.private voidHRegion.rewriteCellTags(Map<byte[], List<ExtendedCell>> familyMap, Mutation m) Possibly rewrite incoming cell tags.private static GetMethod parameters in org.apache.hadoop.hbase.regionserver with type arguments of type MutationModifier and TypeMethodDescriptionprotected voidHRegion.BatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.MutationBatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) private voidHRegion.attachRegionReplicationInWALAppend(HRegion.BatchOperation<?> batchOp, MiniBatchOperationInProgress<Mutation> miniBatchOp, WALKeyImpl walKey, WALEdit walEdit, MultiVersionConcurrencyControl.WriteEntry writeEntry) AttachRegionReplicationSink.add(org.apache.hadoop.hbase.wal.WALKeyImpl, org.apache.hadoop.hbase.wal.WALEdit, org.apache.hadoop.hbase.ipc.ServerCall<?>)to the mvcc writeEntry for replicating to region replica.private voidHRegion.MutationBatchOperation.attachRegionReplicationToMVCCEntry(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry mvccWriteEntry, long now) CreateWALKeyImpland getWALEditfrom miniBatchOp and attachRegionReplicationSink.add(org.apache.hadoop.hbase.wal.WALKeyImpl, org.apache.hadoop.hbase.wal.WALEdit, org.apache.hadoop.hbase.ipc.ServerCall<?>)to the mvccWriteEntry.HRegion.BatchOperation.buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp) Builds separate WALEdit per nonce by applying input mutations.HRegion.MutationBatchOperation.buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp) protected abstract voidHRegion.BatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.MutationBatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Here is for HBASE-26993,in order to make the new framework for region replication could work for SKIP_WAL, we save theMutationwhichgetDurability()isDurability.SKIP_WALin miniBatchOp.protected voidHRegion.ReplayBatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.private voidHRegion.MutationBatchOperation.checkAndMergeCPMutations(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Region.RowLock> acquiredRowLocks, long timestamp) voidHRegion.BatchOperation.completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) This method completes mini-batch operations by calling postBatchMutate() CP hook (if required) and completing mvcc.voidHRegion.MutationBatchOperation.completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) voidHRegion.ReplayBatchOperation.completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) Deprecated.protected WALEditHRegion.BatchOperation.createWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp) private WALEditHRegion.MutationBatchOperation.createWALEditForReplicateSkipWAL(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits) private voidHRegion.BatchOperation.doFinishHotnessProtector(MiniBatchOperationInProgress<Mutation> miniBatchOp) voidHRegion.BatchOperation.doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) voidHRegion.MutationBatchOperation.doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, boolean success) HRegion.doWALAppend(WALEdit walEdit, HRegion.BatchOperation<?> batchOp, MiniBatchOperationInProgress<Mutation> miniBatchOp, long now, NonceKey nonceKey) Returns writeEntry associated with this appendvoidHRegion.mutateRowsWithLocks(Collection<Mutation> mutations, Collection<byte[]> rowsToLock, long nonceGroup, long nonce) Perform atomic (all or none) mutations within the region.voidRegion.mutateRowsWithLocks(Collection<Mutation> mutations, Collection<byte[]> rowsToLock, long nonceGroup, long nonce) Perform atomic mutations within the region.voidRegionCoprocessorHost.postBatchMutate(MiniBatchOperationInProgress<Mutation> miniBatchOp) voidRegionCoprocessorHost.postBatchMutateIndispensably(MiniBatchOperationInProgress<Mutation> miniBatchOp, boolean success) voidRegionCoprocessorHost.preBatchMutate(MiniBatchOperationInProgress<Mutation> miniBatchOp) abstract voidHRegion.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.voidHRegion.MutationBatchOperation.prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp, long timestamp, List<Region.RowLock> acquiredRowLocks) voidHRegion.ReplayBatchOperation.prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp, long timestamp, List<Region.RowLock> acquiredRowLocks) Deprecated.protected voidHRegion.BatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp, long writeNumber) HRegion.BatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry, long now) Write mini-batch operations to MemStoreHRegion.MutationBatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry, long now) HRegion.ReplayBatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry, long now) Deprecated.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type MutationModifierConstructorDescriptionMutationBatchOperation(HRegion region, Mutation[] operations, boolean atomic, long nonceGroup, long nonce) -
Uses of Mutation in org.apache.hadoop.hbase.rsgroup
Method parameters in org.apache.hadoop.hbase.rsgroup with type arguments of type MutationModifier and TypeMethodDescriptionprivate voidRSGroupInfoManagerImpl.multiMutate(List<Mutation> mutations) -
Uses of Mutation in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type MutationModifier and TypeMethodDescriptionprivate voidAccessController.checkForReservedTagPresence(User user, Mutation m) private CellAccessController.createNewCellWithTags(Mutation mutation, Cell oldCell, Cell newCell) AccessController.postAppendBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type MutationModifier and TypeMethodDescriptionvoidAccessController.preBatchMutate(ObserverContext<? extends RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) -
Uses of Mutation in org.apache.hadoop.hbase.security.visibility
Methods in org.apache.hadoop.hbase.security.visibility with parameters of type MutationModifier and TypeMethodDescriptionprivate CellVisibilityController.createNewCellWithTags(Mutation mutation, ExtendedCell newCell) VisibilityController.postAppendBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) voidVisibilityController.prePrepareTimeStampForDeleteVersion(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) Method parameters in org.apache.hadoop.hbase.security.visibility with type arguments of type MutationModifier and TypeMethodDescriptionprivate booleanDefaultVisibilityLabelServiceImpl.mutateLabelsRegion(List<Mutation> mutations, OperationStatus[] finalOpStatus) Adds the mutations to labels region and set the results to the finalOpStatus.voidVisibilityController.preBatchMutate(ObserverContext<? extends RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) -
Uses of Mutation in org.apache.hadoop.hbase.tool
Method parameters in org.apache.hadoop.hbase.tool with type arguments of type MutationModifier and TypeMethodDescriptionvoidWriteSinkCoprocessor.preBatchMutate(ObserverContext<? extends RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) -
Uses of Mutation in org.apache.hadoop.hbase.util
Fields in org.apache.hadoop.hbase.util declared as MutationModifier and TypeFieldDescriptionprivate MutationMultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.MutateAccessAction.mMethods in org.apache.hadoop.hbase.util that return MutationModifier and TypeMethodDescriptionLoadTestDataGeneratorWithTags.beforeMutate(long rowkeyBase, Mutation m) Methods in org.apache.hadoop.hbase.util with parameters of type MutationModifier and TypeMethodDescriptionLoadTestDataGeneratorWithTags.beforeMutate(long rowkeyBase, Mutation m) voidvoidMultiThreadedUpdater.HBaseUpdaterThread.mutate(Table table, Mutation m, long keyBase, byte[] row, byte[] cf, byte[] q, byte[] v) voidvoidMultiThreadedUpdater.mutate(Table table, Mutation m, long keyBase, byte[] row, byte[] cf, byte[] q, byte[] v) voidMultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.mutate(Table table, Mutation m, long keyBase, byte[] row, byte[] cf, byte[] q, byte[] v) private voidMultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.recordFailure(Mutation m, long keyBase, long start, IOException e) voidMultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL.MutateAccessAction.setMutation(Mutation m) -
Uses of Mutation in org.apache.hadoop.hbase.util.test
Methods in org.apache.hadoop.hbase.util.test that return MutationModifier and TypeMethodDescriptionLoadTestDataGenerator.beforeMutate(long rowkeyBase, Mutation m) Giving a chance for the LoadTestDataGenerator to change the Mutation load.LoadTestDataGeneratorWithACL.beforeMutate(long rowkeyBase, Mutation m) Methods in org.apache.hadoop.hbase.util.test with parameters of type MutationModifier and TypeMethodDescriptionLoadTestDataGenerator.beforeMutate(long rowkeyBase, Mutation m) Giving a chance for the LoadTestDataGenerator to change the Mutation load.LoadTestDataGeneratorWithACL.beforeMutate(long rowkeyBase, Mutation m) -
Uses of Mutation in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal declared as MutationConstructors in org.apache.hadoop.hbase.wal with parameters of type MutationModifierConstructorDescriptionMutationReplay(org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutationProto.MutationType type, Mutation mutation, long nonceGroup, long nonce)