| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.constraint | Restrict the domain of a data attribute, often times to fulfill business rules/requirements. | 
| org.apache.hadoop.hbase.coprocessor | Table of Contents | 
| org.apache.hadoop.hbase.coprocessor.example | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.security.visibility | |
| org.apache.hadoop.hbase.tool | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | ConstraintProcessor. postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> e,
                    InternalScanner s,
                    Cell curRowCell,
                    boolean hasMore) | 
| void | ConstraintProcessor. prePut(ObserverContext<RegionCoprocessorEnvironment> e,
      Put put,
      WALEdit edit,
      Durability durability) | 
| Modifier and Type | Field and Description | 
|---|---|
| private RegionCoprocessorEnvironment | MultiRowMutationEndpoint. env | 
| private RegionCoprocessorEnvironment | BaseRowProcessorEndpoint. env | 
| Modifier and Type | Method and Description | 
|---|---|
| private boolean | MetaTableMetrics.ExampleRegionObserverMeta. isMetaTableOp(ObserverContext<RegionCoprocessorEnvironment> e) | 
| default Result | RegionObserver. postAppend(ObserverContext<RegionCoprocessorEnvironment> c,
          Append append,
          Result result)Called after Append | 
| default List<Pair<Cell,Cell>> | RegionObserver. 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 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/increment/append and will be called even if
 the batch operation fails. | 
| default void | RegionObserver. postBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                 List<Pair<byte[],String>> stagingFamilyPaths,
                 Map<byte[],List<org.apache.hadoop.fs.Path>> finalPaths)Called after bulkLoadHFile. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default CheckAndMutateResult | RegionObserver. postCheckAndMutate(ObserverContext<RegionCoprocessorEnvironment> c,
                  CheckAndMutate checkAndMutate,
                  CheckAndMutateResult result)Called after checkAndMutate | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.postCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default void | RegionObserver. postClose(ObserverContext<RegionCoprocessorEnvironment> c,
         boolean abortRequested)Called after the region is reported as closed to the master. | 
| default void | RegionObserver. postCloseRegionOperation(ObserverContext<RegionCoprocessorEnvironment> ctx,
                        Region.Operation operation)Called after releasing read lock in  Region.closeRegionOperation(). | 
| default void | RegionObserver. 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 void | RegionObserver. 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 void | RegionObserver. postCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
                    Store store,
                    List<? extends StoreFile> selected,
                    CompactionLifeCycleTracker tracker,
                    CompactionRequest request)Called after the  StoreFiles to compact have been selected from the available
 candidates. | 
| default void | RegionObserver. postDelete(ObserverContext<RegionCoprocessorEnvironment> c,
          Delete delete,
          WALEdit edit,
          Durability durability)Called after the client deletes a value. | 
| default void | EndpointObserver. 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 boolean | RegionObserver. postExists(ObserverContext<RegionCoprocessorEnvironment> c,
          Get get,
          boolean exists)Called after the client tests for existence using a Get. | 
| default void | RegionObserver. postFlush(ObserverContext<RegionCoprocessorEnvironment> c,
         FlushLifeCycleTracker tracker)Called after the memstore is flushed to disk. | 
| default void | RegionObserver. postFlush(ObserverContext<RegionCoprocessorEnvironment> c,
         Store store,
         StoreFile resultFile,
         FlushLifeCycleTracker tracker)Called after a Store's memstore is flushed to disk. | 
| default void | RegionObserver. postGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
         Get get,
         List<Cell> result)Called after the client performs a Get | 
| default Result | RegionObserver. postIncrement(ObserverContext<RegionCoprocessorEnvironment> c,
             Increment increment,
             Result result)Called after increment | 
| default List<Pair<Cell,Cell>> | RegionObserver. 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 DeleteTracker | RegionObserver. postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment> ctx,
                            DeleteTracker delTracker)Deprecated. 
 Since 2.0 with out any replacement and will be removed in 3.0 | 
| default void | RegionObserver. postMemStoreCompaction(ObserverContext<RegionCoprocessorEnvironment> c,
                      Store store)Called after the in memory compaction is finished. | 
| default Cell | RegionObserver. 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. Use
    RegionObserver.postIncrementBeforeWAL(ObserverContext, Mutation, List)orRegionObserver.postAppendBeforeWAL(ObserverContext, Mutation, List)instead. | 
| default void | RegionObserver. postOpen(ObserverContext<RegionCoprocessorEnvironment> c)Called after the region is reported as open to the master. | 
| default void | RegionObserver. postPut(ObserverContext<RegionCoprocessorEnvironment> c,
       Put put,
       WALEdit edit,
       Durability durability)Called after the client stores a value. | 
| default void | RegionObserver. postReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
              RegionInfo info,
              org.apache.hadoop.fs.Path edits)Called after replaying WALs for this region. | 
| default void | RegionObserver. postScannerClose(ObserverContext<RegionCoprocessorEnvironment> ctx,
                InternalScanner s)Called after the client closes a scanner. | 
| default boolean | RegionObserver. 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 boolean | RegionObserver. 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 RegionScanner | RegionObserver. postScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
               Scan scan,
               RegionScanner s)Called after the client opens a new scanner. | 
| default void | RegionObserver. postStartRegionOperation(ObserverContext<RegionCoprocessorEnvironment> ctx,
                        Region.Operation operation)This will be called for region operations where read lock is acquired in
  Region.startRegionOperation(). | 
| default StoreFileReader | RegionObserver. 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 void | RegionObserver. postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
              RegionInfo info,
              WALKey logKey,
              WALEdit logEdit)Called after a  WALEditreplayed for this region. | 
| default Result | RegionObserver. preAppend(ObserverContext<RegionCoprocessorEnvironment> c,
         Append append)Called before Append. | 
| default Result | RegionObserver. preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                     Append append)Called before Append but after acquiring rowlock. | 
| default void | RegionObserver. preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp)This will be called for every batch mutation operation happening at the server. | 
| default void | RegionObserver. preBulkLoadHFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                List<Pair<byte[],String>> familyPaths)Called before bulkLoadHFile. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)instead. | 
| default CheckAndMutateResult | RegionObserver. preCheckAndMutate(ObserverContext<RegionCoprocessorEnvironment> c,
                 CheckAndMutate checkAndMutate,
                 CheckAndMutateResult result)Called before checkAndMutate | 
| default CheckAndMutateResult | RegionObserver. preCheckAndMutateAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                             CheckAndMutate checkAndMutate,
                             CheckAndMutateResult result)Called before checkAndDelete but after acquiring rowlock. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutate(ObserverContext, CheckAndMutate, CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)instead. | 
| default boolean | RegionObserver. 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. Use
    RegionObserver.preCheckAndMutateAfterRowLock(ObserverContext, CheckAndMutate,CheckAndMutateResult)instead. | 
| default void | BulkLoadObserver. preCleanupBulkLoad(ObserverContext<RegionCoprocessorEnvironment> ctx)Called as part of SecureBulkLoadEndpoint.cleanupBulkLoad() RPC call. | 
| default void | RegionObserver. preClose(ObserverContext<RegionCoprocessorEnvironment> c,
        boolean abortRequested)Called before the region is reported as closed to the master. | 
| default void | RegionObserver. 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 InternalScanner | RegionObserver. preCompact(ObserverContext<RegionCoprocessorEnvironment> c,
          Store store,
          InternalScanner scanner,
          ScanType scanType,
          CompactionLifeCycleTracker tracker,
          CompactionRequest request)Called prior to writing the  StoreFiles selected for compaction into a newStoreFile. | 
| default void | RegionObserver. preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
                     Store store,
                     ScanType scanType,
                     ScanOptions options,
                     CompactionLifeCycleTracker tracker,
                     CompactionRequest request)Called before we open store scanner for compaction. | 
| default void | RegionObserver. preCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
                   Store store,
                   List<? extends StoreFile> candidates,
                   CompactionLifeCycleTracker tracker)Called prior to selecting the  StoreFilesto compact from the list of
 available candidates. | 
| default void | RegionObserver. preDelete(ObserverContext<RegionCoprocessorEnvironment> c,
         Delete delete,
         WALEdit edit,
         Durability durability)Called before the client deletes a value. | 
| void | MetaTableMetrics.ExampleRegionObserverMeta. preDelete(ObserverContext<RegionCoprocessorEnvironment> e,
         Delete delete,
         WALEdit edit,
         Durability durability) | 
| default com.google.protobuf.Message | EndpointObserver. 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 boolean | RegionObserver. preExists(ObserverContext<RegionCoprocessorEnvironment> c,
         Get get,
         boolean exists)Called before the client tests for existence using a Get. | 
| default void | RegionObserver. preFlush(ObserverContext<RegionCoprocessorEnvironment> c,
        FlushLifeCycleTracker tracker)Called before the memstore is flushed to disk. | 
| default InternalScanner | RegionObserver. preFlush(ObserverContext<RegionCoprocessorEnvironment> c,
        Store store,
        InternalScanner scanner,
        FlushLifeCycleTracker tracker)Called before a Store's memstore is flushed to disk. | 
| default void | RegionObserver. preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
                   Store store,
                   ScanOptions options,
                   FlushLifeCycleTracker tracker)Called before we open store scanner for flush. | 
| default void | RegionObserver. preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
        Get get,
        List<Cell> result)Called before the client performs a Get | 
| void | MetaTableMetrics.ExampleRegionObserverMeta. preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
        Get get,
        List<Cell> results) | 
| default Result | RegionObserver. preIncrement(ObserverContext<RegionCoprocessorEnvironment> c,
            Increment increment)Called before Increment. | 
| default Result | RegionObserver. preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                        Increment increment)Called before Increment but after acquiring rowlock. | 
| default void | RegionObserver. preMemStoreCompaction(ObserverContext<RegionCoprocessorEnvironment> c,
                     Store store)Called before in memory compaction started. | 
| default InternalScanner | RegionObserver. preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment> c,
                            Store store,
                            InternalScanner scanner)Called before we do in memory compaction. | 
| default void | RegionObserver. preMemStoreCompactionCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
                                       Store store,
                                       ScanOptions options)Called before we open store scanner for in memory compaction. | 
| default void | RegionObserver. preOpen(ObserverContext<RegionCoprocessorEnvironment> c)Called before the region is reported as open to the master. | 
| default void | BulkLoadObserver. prePrepareBulkLoad(ObserverContext<RegionCoprocessorEnvironment> ctx)Called as part of SecureBulkLoadEndpoint.prepareBulkLoad() RPC call. | 
| default void | RegionObserver. prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> c,
                                   Mutation mutation,
                                   Cell cell,
                                   byte[] byteNow,
                                   Get get)Deprecated. 
 Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
 with something that doesn't expose IntefaceAudience.Private classes. | 
| default void | RegionObserver. prePut(ObserverContext<RegionCoprocessorEnvironment> c,
      Put put,
      WALEdit edit,
      Durability durability)Called before the client stores a value. | 
| void | MetaTableMetrics.ExampleRegionObserverMeta. prePut(ObserverContext<RegionCoprocessorEnvironment> e,
      Put put,
      WALEdit edit,
      Durability durability) | 
| default void | RegionObserver. preReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
             RegionInfo info,
             org.apache.hadoop.fs.Path edits)Called before replaying WALs for this region. | 
| default void | RegionObserver. preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
               InternalScanner s)Called before the client closes a scanner. | 
| default boolean | RegionObserver. 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 void | RegionObserver. preScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
              Scan scan)Called before the client opens a new scanner. | 
| default StoreFileReader | RegionObserver. 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 void | RegionObserver. preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> ctx,
                   Store store,
                   ScanOptions options)Called before a store opens a new scanner. | 
| default void | RegionObserver. preWALAppend(ObserverContext<RegionCoprocessorEnvironment> ctx,
            WALKey key,
            WALEdit edit)Called just before the WAL Entry is appended to the WAL. | 
| default void | RegionObserver. preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
             RegionInfo info,
             WALKey logKey,
             WALEdit logEdit)Called before a  WALEditreplayed for this region. | 
| private void | MetaTableMetrics.ExampleRegionObserverMeta. registerAndMarkMetrics(ObserverContext<RegionCoprocessorEnvironment> e,
                      Row row) | 
| Modifier and Type | Field and Description | 
|---|---|
| private RegionCoprocessorEnvironment | RefreshHFilesEndpoint. env | 
| private RegionCoprocessorEnvironment | BulkDeleteEndpoint. env | 
| private RegionCoprocessorEnvironment | RowCountEndpoint. env | 
| Modifier and Type | Class and Description | 
|---|---|
| private static class  | RegionCoprocessorHost.RegionEnvironmentEncapsulation of the environment of each coprocessor | 
| private static class  | RegionCoprocessorHost.RegionEnvironmentForCoreCoprocessorsSpecial version of RegionEnvironment that exposes RegionServerServices for Core
 Coprocessors only. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationObserver. preCommitStoreFile(ObserverContext<RegionCoprocessorEnvironment> ctx,
                  byte[] family,
                  List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) | 
| Modifier and Type | Field and Description | 
|---|---|
| private RegionCoprocessorEnvironment | AccessController. regionEnvdefined only for Endpoint implementation, so it can have way to
   access region services | 
| Modifier and Type | Method and Description | 
|---|---|
| private boolean | AccessController. 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 Region | AccessController. getRegion(RegionCoprocessorEnvironment e) | 
| private TableName | AccessController. getTableName(RegionCoprocessorEnvironment e) | 
| private boolean | AccessController. hasFamilyQualifierPermission(User user,
                            Permission.Action perm,
                            RegionCoprocessorEnvironment env,
                            Map<byte[],? extends Collection<byte[]>> familyMap)Returns  trueif the current user is allowed the given action
 over at least one of the column qualifiers in the given column families. | 
| private void | AccessController. initialize(RegionCoprocessorEnvironment e) | 
| private AuthResult | AccessController. 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 void | AccessController. updateACL(RegionCoprocessorEnvironment e,
         Map<byte[],List<Cell>> familyMap)Writes all table ACLs for the tables in the given Map up into ZooKeeper
 znodes. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DefaultVisibilityLabelServiceImpl. init(RegionCoprocessorEnvironment e) | 
| void | VisibilityLabelService. init(RegionCoprocessorEnvironment e)System calls this after opening of regions. | 
| private void | VisibilityController. initVisibilityLabelService(RegionCoprocessorEnvironment env) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WriteSinkCoprocessor. preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp) | 
| void | WriteSinkCoprocessor. preOpen(ObserverContext<RegionCoprocessorEnvironment> e) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.