Uses of Interface
org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
Packages that use RegionCoprocessorEnvironment
Package
Description
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
Table of Contents
-
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.backup
Method parameters in org.apache.hadoop.hbase.backup with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionvoidBackupObserver.postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[], String>> stagingFamilyPaths, Map<byte[], List<org.apache.hadoop.fs.Path>> finalPaths) voidBackupObserver.preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment> ctx, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.constraint
Method parameters in org.apache.hadoop.hbase.constraint with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionvoidConstraintProcessor.prePut(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.coprocessor
Fields in org.apache.hadoop.hbase.coprocessor declared as RegionCoprocessorEnvironmentModifier and TypeFieldDescriptionprivate RegionCoprocessorEnvironmentBaseRowProcessorEndpoint.envprivate RegionCoprocessorEnvironmentMultiRowMutationEndpoint.envMethod parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionprivate booleanMetaTableMetrics.ExampleRegionObserverMeta.isMetaTableOp(ObserverContext<RegionCoprocessorEnvironment> e) default ResultRegionObserver.postAppend(ObserverContext<RegionCoprocessorEnvironment> c, Append append, Result result) Deprecated.since 2.5.0 and will be removed in 4.0.0.default ResultRegionObserver.postAppend(ObserverContext<RegionCoprocessorEnvironment> c, Append append, Result result, WALEdit edit) Called after AppendRegionObserver.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.default voidRegionObserver.postBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) This will be called after applying a batch of Mutations on a region.default voidRegionObserver.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 voidRegionObserver.postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[], String>> stagingFamilyPaths, Map<byte[], List<org.apache.hadoop.fs.Path>> finalPaths) Called after bulkLoadHFile.default booleanRegionObserver.postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.postCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default CheckAndMutateResultRegionObserver.postCheckAndMutate(ObserverContext<RegionCoprocessorEnvironment> c, CheckAndMutate checkAndMutate, CheckAndMutateResult result) Called after checkAndMutatedefault booleanRegionObserver.postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.postCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default voidRegionObserver.postClose(ObserverContext<RegionCoprocessorEnvironment> c, boolean abortRequested) Called after the region is reported as closed to the master.default voidRegionObserver.postCloseRegionOperation(ObserverContext<RegionCoprocessorEnvironment> ctx, Region.Operation operation) Called after releasing read lock inRegion.closeRegionOperation().default voidRegionObserver.postCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment> ctx, byte[] family, org.apache.hadoop.fs.Path srcPath, org.apache.hadoop.fs.Path dstPath) Called after moving bulk loaded hfile to region directory.default voidRegionObserver.postCompact(ObserverContext<RegionCoprocessorEnvironment> c, Store store, StoreFile resultFile, CompactionLifeCycleTracker tracker, CompactionRequest request) Called after compaction has completed and the new store file has been moved in to place.default voidRegionObserver.postCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c, Store store, List<? extends StoreFile> selected, CompactionLifeCycleTracker tracker, CompactionRequest request) Called after theStoreFiles to compact have been selected from the available candidates.default voidRegionObserver.postDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called after the client deletes a value.default voidRegionObserver.postDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default voidEndpointObserver.postEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment> ctx, com.google.protobuf.Service service, String methodName, com.google.protobuf.Message request, com.google.protobuf.Message.Builder responseBuilder) Called after an Endpoint service method is invoked.default booleanRegionObserver.postExists(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) Called after the client tests for existence using a Get.default voidRegionObserver.postFlush(ObserverContext<RegionCoprocessorEnvironment> c, FlushLifeCycleTracker tracker) Called after the memstore is flushed to disk.default voidRegionObserver.postFlush(ObserverContext<RegionCoprocessorEnvironment> c, Store store, StoreFile resultFile, FlushLifeCycleTracker tracker) Called after a Store's memstore is flushed to disk.default voidRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called after the client performs a Getdefault ResultRegionObserver.postIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment, Result result) Deprecated.since 2.5.0 and will be removed in 4.0.0.default ResultRegionObserver.postIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment, Result result, WALEdit edit) Called after incrementRegionObserver.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 DeleteTrackerRegionObserver.postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment> ctx, DeleteTracker delTracker) Deprecated.Since 2.0 with out any replacement and will be removed in 3.0default voidRegionObserver.postMemStoreCompaction(ObserverContext<RegionCoprocessorEnvironment> c, Store store) Called after the in memory compaction is finished.default CellRegionObserver.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 voidRegionObserver.postOpen(ObserverContext<RegionCoprocessorEnvironment> c) Called after the region is reported as open to the master.default voidRegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called after the client stores a value.default voidRegionObserver.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default voidRegionObserver.postReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, org.apache.hadoop.fs.Path edits) Called after replaying WALs for this region.default voidRegionObserver.postScannerClose(ObserverContext<RegionCoprocessorEnvironment> ctx, InternalScanner s) Called after the client closes a scanner.default booleanRegionObserver.postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s, Cell curRowCell, boolean hasMore) This will be called by the scan flow when the current scanned row is being filtered out by the filter.default booleanRegionObserver.postScannerNext(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s, List<Result> result, int limit, boolean hasNext) Called after the client asks for the next row on a scanner.default RegionScannerRegionObserver.postScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Scan scan, RegionScanner s) Called after the client opens a new scanner.default voidRegionObserver.postStartRegionOperation(ObserverContext<RegionCoprocessorEnvironment> ctx, Region.Operation operation) This will be called for region operations where read lock is acquired inRegion.startRegionOperation().default StoreFileReaderRegionObserver.postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path p, FSDataInputStreamWrapper in, long size, CacheConfig cacheConf, Reference r, StoreFileReader reader) Deprecated.For Phoenix only, StoreFileReader is not a stable interface.default voidRegionObserver.postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEditreplayed for this region.default ResultRegionObserver.preAppend(ObserverContext<RegionCoprocessorEnvironment> c, Append append) Deprecated.since 2.5.0 and will be removed in 4.0.0.default ResultRegionObserver.preAppend(ObserverContext<RegionCoprocessorEnvironment> c, Append append, WALEdit edit) Called before Append.default ResultRegionObserver.preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, Append append) Deprecated.since 2.5.0 and will be removed in 4.0.0.default voidRegionObserver.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) This will be called for every batch mutation operation happening at the server.default voidRegionObserver.preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[], String>> familyPaths) Called before bulkLoadHFile.default booleanRegionObserver.preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Delete delete, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default CheckAndMutateResultRegionObserver.preCheckAndMutate(ObserverContext<RegionCoprocessorEnvironment> c, CheckAndMutate checkAndMutate, CheckAndMutateResult result) Called before checkAndMutatedefault CheckAndMutateResultRegionObserver.preCheckAndMutateAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, CheckAndMutate checkAndMutate, CheckAndMutateResult result) Called before checkAndDelete but after acquiring rowlock.default booleanRegionObserver.preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default booleanRegionObserver.preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, Filter filter, Put put, boolean result) Deprecated.since 2.4.0 and will be removed in 4.0.0.default voidBulkLoadObserver.preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment> ctx) Called as part of SecureBulkLoadEndpoint.cleanupBulkLoad() RPC call.default voidRegionObserver.preClose(ObserverContext<RegionCoprocessorEnvironment> c, boolean abortRequested) Called before the region is reported as closed to the master.default voidRegionObserver.preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment> ctx, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) Called before moving bulk loaded hfile to region directory.default InternalScannerRegionObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) Called prior to writing theStoreFiles selected for compaction into a newStoreFile.default voidRegionObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanType scanType, ScanOptions options, CompactionLifeCycleTracker tracker, CompactionRequest request) Called before we open store scanner for compaction.default voidRegionObserver.preCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c, Store store, List<? extends StoreFile> candidates, CompactionLifeCycleTracker tracker) Called prior to selecting theStoreFilesto compact from the list of available candidates.voidMetaTableMetrics.ExampleRegionObserverMeta.preDelete(ObserverContext<RegionCoprocessorEnvironment> e, Delete delete, WALEdit edit, Durability durability) default voidRegionObserver.preDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit) Called before the client deletes a value.default voidRegionObserver.preDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default com.google.protobuf.MessageEndpointObserver.preEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment> ctx, com.google.protobuf.Service service, String methodName, com.google.protobuf.Message request) Called before an Endpoint service method is invoked.default booleanRegionObserver.preExists(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) Called before the client tests for existence using a Get.default voidRegionObserver.preFlush(ObserverContext<RegionCoprocessorEnvironment> c, FlushLifeCycleTracker tracker) Called before the memstore is flushed to disk.default InternalScannerRegionObserver.preFlush(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, FlushLifeCycleTracker tracker) Called before a Store's memstore is flushed to disk.default voidRegionObserver.preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanOptions options, FlushLifeCycleTracker tracker) Called before we open store scanner for flush.voidMetaTableMetrics.ExampleRegionObserverMeta.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) default voidRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called before the client performs a Getdefault ResultRegionObserver.preIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment) Deprecated.since 2.5.0 and will be removed in 4.0.0.default ResultRegionObserver.preIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment, WALEdit edit) Called before Increment.default ResultRegionObserver.preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment) Deprecated.since 2.5.0 and will be removed in 4.0.0.default voidRegionObserver.preMemStoreCompaction(ObserverContext<RegionCoprocessorEnvironment> c, Store store) Called before in memory compaction started.default InternalScannerRegionObserver.preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner) Called before we do in memory compaction.default voidRegionObserver.preMemStoreCompactionCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanOptions options) Called before we open store scanner for in memory compaction.default voidRegionObserver.preOpen(ObserverContext<RegionCoprocessorEnvironment> c) Called before the region is reported as open to the master.default voidBulkLoadObserver.prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment> ctx) Called as part of SecureBulkLoadEndpoint.prepareBulkLoad() RPC call.default voidRegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> c, Mutation mutation, Cell cell, byte[] byteNow, Get get) Deprecated.Since hbase-2.0.0.voidMetaTableMetrics.ExampleRegionObserverMeta.prePut(ObserverContext<RegionCoprocessorEnvironment> e, Put put, WALEdit edit, Durability durability) default voidRegionObserver.prePut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit) Called before the client stores a value.default voidRegionObserver.prePut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) Deprecated.since 2.5.0 and will be removed in 4.0.0.default voidRegionObserver.preReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, org.apache.hadoop.fs.Path edits) Called before replaying WALs for this region.default voidRegionObserver.preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s) Called before the client closes a scanner.default booleanRegionObserver.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s, List<Result> result, int limit, boolean hasNext) Called before the client asks for the next row on a scanner.default voidRegionObserver.preScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Scan scan) Called before the client opens a new scanner.default StoreFileReaderRegionObserver.preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path p, FSDataInputStreamWrapper in, long size, CacheConfig cacheConf, Reference r, StoreFileReader reader) Deprecated.For Phoenix only, StoreFileReader is not a stable interface.default voidRegionObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> ctx, Store store, ScanOptions options) Called before a store opens a new scanner.default voidRegionObserver.preWALAppend(ObserverContext<RegionCoprocessorEnvironment> ctx, WALKey key, WALEdit edit) Called just before the WAL Entry is appended to the WAL.default voidRegionObserver.preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called before aWALEditreplayed for this region.private voidMetaTableMetrics.ExampleRegionObserverMeta.registerAndMarkMetrics(ObserverContext<RegionCoprocessorEnvironment> e, Row row) -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.coprocessor.example
Fields in org.apache.hadoop.hbase.coprocessor.example declared as RegionCoprocessorEnvironmentModifier and TypeFieldDescriptionprivate RegionCoprocessorEnvironmentBulkDeleteEndpoint.envprivate RegionCoprocessorEnvironmentRefreshHFilesEndpoint.envprivate RegionCoprocessorEnvironmentRowCountEndpoint.envMethod parameters in org.apache.hadoop.hbase.coprocessor.example with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionvoidExampleRegionObserverWithMetrics.ExampleRegionObserver.postCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c, Store store, List<? extends StoreFile> selected, CompactionLifeCycleTracker tracker, CompactionRequest request) voidExampleRegionObserverWithMetrics.ExampleRegionObserver.postFlush(ObserverContext<RegionCoprocessorEnvironment> c, FlushLifeCycleTracker tracker) voidExampleRegionObserverWithMetrics.ExampleRegionObserver.postFlush(ObserverContext<RegionCoprocessorEnvironment> c, Store store, StoreFile resultFile, FlushLifeCycleTracker tracker) voidExampleRegionObserverWithMetrics.ExampleRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) ValueRewritingObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) WriteHeavyIncrementObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) voidWriteHeavyIncrementObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanType scanType, ScanOptions options, CompactionLifeCycleTracker tracker, CompactionRequest request) voidZooKeeperScanPolicyObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanType scanType, ScanOptions options, CompactionLifeCycleTracker tracker, CompactionRequest request) WriteHeavyIncrementObserver.preFlush(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, FlushLifeCycleTracker tracker) voidWriteHeavyIncrementObserver.preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanOptions options, FlushLifeCycleTracker tracker) voidZooKeeperScanPolicyObserver.preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanOptions options, FlushLifeCycleTracker tracker) voidExampleRegionObserverWithMetrics.ExampleRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) voidWriteHeavyIncrementObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) WriteHeavyIncrementObserver.preIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment) WriteHeavyIncrementObserver.preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner) voidWriteHeavyIncrementObserver.preMemStoreCompactionCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Store store, ScanOptions options) voidScanModifyingObserver.preScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Scan scan) voidWriteHeavyIncrementObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> ctx, Store store, ScanOptions options) -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver that implement RegionCoprocessorEnvironmentModifier and TypeClassDescriptionprivate static classEncapsulation of the environment of each coprocessorprivate static classSpecial version of RegionEnvironment that exposes RegionServerServices for Core Coprocessors only. -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.replication.regionserver
Method parameters in org.apache.hadoop.hbase.replication.regionserver with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionvoidReplicationObserver.preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment> ctx, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.security.access
Fields in org.apache.hadoop.hbase.security.access declared as RegionCoprocessorEnvironmentModifier and TypeFieldDescriptionprivate RegionCoprocessorEnvironmentAccessController.regionEnvdefined only for Endpoint implementation, so it can have way to access region servicesMethods in org.apache.hadoop.hbase.security.access with parameters of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionprivate booleanAccessController.checkCoveringPermission(User user, AccessController.OpType request, RegionCoprocessorEnvironment e, byte[] row, Map<byte[], ? extends Collection<?>> familyMap, long opTs, Permission.Action... actions) Determine if cell ACLs covered by the operation grant access.private RegionAccessController.getRegion(RegionCoprocessorEnvironment e) private TableNameAccessController.getTableName(RegionCoprocessorEnvironment e) private booleanAccessController.hasFamilyQualifierPermission(User user, Permission.Action perm, RegionCoprocessorEnvironment env, Map<byte[], ? extends Collection<byte[]>> familyMap) Returnstrueif the current user is allowed the given action over at least one of the column qualifiers in the given column families.private voidAccessController.initialize(RegionCoprocessorEnvironment e) private AuthResultAccessController.permissionGranted(AccessController.OpType opType, User user, RegionCoprocessorEnvironment e, Map<byte[], ? extends Collection<?>> families, Permission.Action... actions) Check the current user for authorization to perform a specific action against the given set of row data.private voidAccessController.updateACL(RegionCoprocessorEnvironment e, Map<byte[], List<Cell>> familyMap) Writes all table ACLs for the tables in the given Map up into ZooKeeper znodes.Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionprivate voidAccessController.internalPreRead(ObserverContext<RegionCoprocessorEnvironment> c, Query query, AccessController.OpType opType) AccessController.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) voidAccessController.postDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) voidAccessController.postEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment> ctx, com.google.protobuf.Service service, String methodName, com.google.protobuf.Message request, com.google.protobuf.Message.Builder responseBuilder) AccessController.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) voidAccessController.postOpen(ObserverContext<RegionCoprocessorEnvironment> c) voidAccessController.postPut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) voidAccessController.postScannerClose(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s) AccessController.postScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Scan scan, RegionScanner s) AccessController.preAppend(ObserverContext<RegionCoprocessorEnvironment> c, Append append) voidAccessController.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) voidAccessController.preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx, List<Pair<byte[], String>> familyPaths) Verifies user has CREATE or ADMIN privileges on the Column Families involved in the bulkLoadHFile request.booleanAccessController.preCheckAndDelete(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) booleanAccessController.preCheckAndDeleteAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Delete delete, boolean result) booleanAccessController.preCheckAndPut(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator op, ByteArrayComparable comparator, Put put, boolean result) booleanAccessController.preCheckAndPutAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c, byte[] row, byte[] family, byte[] qualifier, CompareOperator opp, ByteArrayComparable comparator, Put put, boolean result) voidAccessController.preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment> ctx) Authorization security check for SecureBulkLoadProtocol.cleanupBulkLoad()voidAccessController.preClose(ObserverContext<RegionCoprocessorEnvironment> c, boolean abortRequested) AccessController.preCompact(ObserverContext<RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) voidAccessController.preDelete(ObserverContext<RegionCoprocessorEnvironment> c, Delete delete, WALEdit edit, Durability durability) com.google.protobuf.MessageAccessController.preEndpointInvocation(ObserverContext<RegionCoprocessorEnvironment> ctx, com.google.protobuf.Service service, String methodName, com.google.protobuf.Message request) booleanAccessController.preExists(ObserverContext<RegionCoprocessorEnvironment> c, Get get, boolean exists) voidAccessController.preFlush(ObserverContext<RegionCoprocessorEnvironment> c, FlushLifeCycleTracker tracker) voidAccessController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) AccessController.preIncrement(ObserverContext<RegionCoprocessorEnvironment> c, Increment increment) voidAccessController.preOpen(ObserverContext<RegionCoprocessorEnvironment> c) voidAccessController.prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment> ctx) Authorization check for SecureBulkLoadProtocol.prepareBulkLoad()voidAccessController.prePut(ObserverContext<RegionCoprocessorEnvironment> c, Put put, WALEdit edit, Durability durability) voidAccessController.preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s) booleanAccessController.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s, List<Result> result, int limit, boolean hasNext) voidAccessController.preScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Scan scan) -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.security.visibility
Methods in org.apache.hadoop.hbase.security.visibility with parameters of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionvoidDefaultVisibilityLabelServiceImpl.init(RegionCoprocessorEnvironment e) voidVisibilityLabelService.init(RegionCoprocessorEnvironment e) System calls this after opening of regions.private voidVisibilityController.initVisibilityLabelService(RegionCoprocessorEnvironment env) Method parameters in org.apache.hadoop.hbase.security.visibility with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionVisibilityController.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment> ctx, DeleteTracker delTracker) voidVisibilityController.postOpen(ObserverContext<RegionCoprocessorEnvironment> e) Region related hooksvoidVisibilityController.postScannerClose(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s) VisibilityController.postScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Scan scan, RegionScanner s) voidVisibilityController.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) voidVisibilityController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) voidVisibilityController.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) voidVisibilityController.preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s) booleanVisibilityController.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s, List<Result> result, int limit, boolean hasNext) voidVisibilityController.preScannerOpen(ObserverContext<RegionCoprocessorEnvironment> e, Scan scan) -
Uses of RegionCoprocessorEnvironment in org.apache.hadoop.hbase.tool
Method parameters in org.apache.hadoop.hbase.tool with type arguments of type RegionCoprocessorEnvironmentModifier and TypeMethodDescriptionvoidWriteSinkCoprocessor.preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) voidWriteSinkCoprocessor.preOpen(ObserverContext<RegionCoprocessorEnvironment> e)