Package | Description |
---|---|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.tool |
Modifier and Type | Method and Description |
---|---|
default 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 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.
|
Modifier and Type | Method and Description |
---|---|
protected MiniBatchOperationInProgress<Mutation> |
HRegion.BatchOperation.createMiniBatch(int lastIndexExclusive,
int readyToWriteCount) |
MiniBatchOperationInProgress<Mutation> |
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 Type | Method and Description |
---|---|
List<Pair<NonceKey,WALEdit>> |
HRegion.BatchOperation.buildWALEdits(MiniBatchOperationInProgress<Mutation> miniBatchOp)
Builds separate WALEdit per nonce by applying input mutations.
|
List<Pair<NonceKey,WALEdit>> |
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) |
void |
HRegion.BatchOperation.doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp,
WALEdit walEdit,
boolean success) |
void |
HRegion.MutationBatchOperation.doPostOpCleanupForMiniBatch(MiniBatchOperationInProgress<Mutation> miniBatchOp,
WALEdit walEdit,
boolean success) |
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) |
protected void |
HRegion.BatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp,
long writeNumber) |
abstract MultiVersionConcurrencyControl.WriteEntry |
HRegion.BatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp,
MultiVersionConcurrencyControl.WriteEntry writeEntry)
Write mini-batch operations to MemStore
|
MultiVersionConcurrencyControl.WriteEntry |
HRegion.MutationBatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp,
MultiVersionConcurrencyControl.WriteEntry writeEntry) |
MultiVersionConcurrencyControl.WriteEntry |
HRegion.ReplayBatchOperation.writeMiniBatchOperationsToMemStore(MiniBatchOperationInProgress<Mutation> miniBatchOp,
MultiVersionConcurrencyControl.WriteEntry writeEntry) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Mutation> miniBatchOp) |
Modifier and Type | Method and Description |
---|---|
void |
VisibilityController.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Mutation> miniBatchOp) |
Modifier and Type | Method and Description |
---|---|
void |
WriteSinkCoprocessor.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
MiniBatchOperationInProgress<Mutation> miniBatchOp) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.