Class HRegion.ReplayBatchOperation
java.lang.Object
org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation<WALSplitUtil.MutationReplay>
org.apache.hadoop.hbase.regionserver.HRegion.ReplayBatchOperation
- Enclosing class:
- HRegion
@Deprecated
private static final class HRegion.ReplayBatchOperation
extends HRegion.BatchOperation<WALSplitUtil.MutationReplay>
Deprecated.
Since 3.0.0, will be removed in 4.0.0. Now we will not use this operation to apply
edits at secondary replica side.
Batch of mutations for replay. Base class is shared with
HRegion.MutationBatchOperation
as most
of the logic is same.-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
HRegion.BatchOperation.Visitor
-
Field Summary
Fields inherited from class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
atomic, durability, familyCellMaps, nextIndexToProcess, observedExceptions, operations, region, results, retCodeDetails, walEditsFromCoprocessors
-
Constructor Summary
ConstructorDescriptionReplayBatchOperation
(HRegion region, WALSplitUtil.MutationReplay[] operations, long origLogSeqNum) Deprecated. -
Method Summary
Modifier and TypeMethodDescriptionprotected void
cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.void
Deprecated.Validates each mutation and prepares a batch for write.protected void
Deprecated.During replay, there could exist column families which are removed between region server failure and replayvoid
Deprecated.void
completeMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) Deprecated.This method completes mini-batch operations by calling postBatchMutate() CP hook (if required) and completing mvcc.getMutation
(int index) Deprecated.Mutation[]
Deprecated.This method is potentially expensive and useful mostly for non-replay CP path.long
getNonce
(int index) Deprecated.long
getNonceGroup
(int index) Deprecated.long
Deprecated.boolean
Deprecated.void
prepareMiniBatchOperations
(MiniBatchOperationInProgress<Mutation> miniBatchOp, long timestamp, List<Region.RowLock> acquiredRowLocks) Deprecated.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
Deprecated.writeMiniBatchOperationsToMemStore
(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry, long now) Deprecated.Write mini-batch operations to MemStoreMethods inherited from class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
addNonSkipWALMutationsToWALEdit, applyFamilyMapToMemStore, buildWALEdits, checkAndPrepareMutation, checkAndPrepareMutation, createMiniBatch, createWALEdit, doAddCellsToWALEdit, doPostOpCleanupForMiniBatch, getClusterIds, isAtomic, isDone, isOperationPending, lockRowsAndBuildMiniBatch, size, visitBatchOperations, writeMiniBatchOperationsToMemStore
-
Field Details
-
origLogSeqNum
Deprecated.
-
-
Constructor Details
-
ReplayBatchOperation
public ReplayBatchOperation(HRegion region, WALSplitUtil.MutationReplay[] operations, long origLogSeqNum) Deprecated.
-
-
Method Details
-
getMutation
Deprecated.- Specified by:
getMutation
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
-
getNonceGroup
Deprecated.- Specified by:
getNonceGroup
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
-
getNonce
Deprecated.- Specified by:
getNonce
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
-
getMutationsForCoprocs
Deprecated.Description copied from class:HRegion.BatchOperation
This method is potentially expensive and useful mostly for non-replay CP path.- Specified by:
getMutationsForCoprocs
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
-
isInReplay
Deprecated.- Specified by:
isInReplay
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
-
getOrigLogSeqNum
Deprecated.- Specified by:
getOrigLogSeqNum
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
-
startRegionOperation
Deprecated.- Specified by:
startRegionOperation
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
- Throws:
IOException
-
closeRegionOperation
Deprecated.- Specified by:
closeRegionOperation
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
- Throws:
IOException
-
checkAndPreparePut
Deprecated.During replay, there could exist column families which are removed between region server failure and replay- Specified by:
checkAndPreparePut
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
- Throws:
IOException
-
checkAndPrepare
Deprecated.Description copied from class:HRegion.BatchOperation
Validates each mutation and prepares a batch for write. If necessary (non-replay case), runs CP prePut()/preDelete()/preIncrement()/preAppend() hooks for all mutations in a batch. This is intended to operate on entire batch and will be called from outside of class to check and prepare batch. This can be implemented by calling helper methodHRegion.BatchOperation.checkAndPrepareMutation(int, long)
in a 'for' loop over mutations.- Specified by:
checkAndPrepare
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
- Throws:
IOException
-
prepareMiniBatchOperations
public void prepareMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp, long timestamp, List<Region.RowLock> acquiredRowLocks) throws IOException Deprecated.Description copied from class:HRegion.BatchOperation
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.- Specified by:
prepareMiniBatchOperations
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
- Throws:
IOException
-
writeMiniBatchOperationsToMemStore
public MultiVersionConcurrencyControl.WriteEntry writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry, long now) throws IOException Deprecated.Description copied from class:HRegion.BatchOperation
Write mini-batch operations to MemStore- Specified by:
writeMiniBatchOperationsToMemStore
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
- Throws:
IOException
-
completeMiniBatchOperations
public void completeMiniBatchOperations(MiniBatchOperationInProgress<Mutation> miniBatchOp, MultiVersionConcurrencyControl.WriteEntry writeEntry) throws IOException Deprecated.Description copied from class:HRegion.BatchOperation
This method completes mini-batch operations by calling postBatchMutate() CP hook (if required) and completing mvcc.- Overrides:
completeMiniBatchOperations
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
- Throws:
IOException
-
cacheSkipWALMutationForRegionReplication
protected void cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.- Specified by:
cacheSkipWALMutationForRegionReplication
in classHRegion.BatchOperation<WALSplitUtil.MutationReplay>
-