Uses of Interface
org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
Packages that use RegionServerCoprocessorEnvironment
Package
Description
Table of Contents
-
Uses of RegionServerCoprocessorEnvironment in org.apache.hadoop.hbase.coprocessor
Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type RegionServerCoprocessorEnvironmentModifier and TypeMethodDescriptiondefault voidRegionServerObserver.postClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment> ctx) This will be called after clearing compaction queuesdefault voidRegionServerObserver.postClearRegionBlockCache(ObserverContext<RegionServerCoprocessorEnvironment> ctx, CacheEvictionStats stats) Called after clearing the block caches for one or more regionsdefault ReplicationEndpointRegionServerObserver.postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx, ReplicationEndpoint endpoint) This will be called after the replication endpoint is instantiated.default voidRegionServerObserver.postExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment> ctx) This will be called after executing proceduresdefault voidRegionServerObserver.postReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx) Deprecated.As of release 2.0.0 with out any replacement, plan to remove in 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 voidRegionServerObserver.postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx) This will be called after executing user request to roll a region server WAL.default voidRegionServerObserver.postUpdateRegionServerConfiguration(ObserverContext<RegionServerCoprocessorEnvironment> ctx, org.apache.hadoop.conf.Configuration postReloadConf) Called after reloading the RegionServer'sConfigurationfrom diskdefault voidRegionServerObserver.preClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment> ctx) This will be called before clearing compaction queuesdefault voidRegionServerObserver.preClearRegionBlockCache(ObserverContext<RegionServerCoprocessorEnvironment> ctx) Called before clearing the block caches for one or more regionsdefault voidRegionServerObserver.preExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment> ctx) This will be called before executing proceduresdefault voidRegionServerObserver.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx) Deprecated.As of release 2.0.0 with out any replacement, plan to remove in 4.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.default voidRegionServerObserver.preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx) This will be called before executing user request to roll a region server WAL.default voidRegionServerObserver.preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment> ctx) Called before stopping region server.default voidRegionServerObserver.preUpdateRegionServerConfiguration(ObserverContext<RegionServerCoprocessorEnvironment> ctx, org.apache.hadoop.conf.Configuration preReloadConf) Called before reloading the RegionServer'sConfigurationfrom disk -
Uses of RegionServerCoprocessorEnvironment in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver that implement RegionServerCoprocessorEnvironmentModifier and TypeClassDescriptionprivate static classCoprocessor environment extension providing access to region server related services.private static classSpecial version of RegionServerEnvironment that exposes RegionServerServices for Core Coprocessors only. -
Uses of RegionServerCoprocessorEnvironment in org.apache.hadoop.hbase.security.access
Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type RegionServerCoprocessorEnvironmentModifier and TypeMethodDescriptionAccessController.postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx, ReplicationEndpoint endpoint) voidAccessController.postRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx) voidAccessController.preClearCompactionQueues(ObserverContext<RegionServerCoprocessorEnvironment> ctx) voidAccessController.preClearRegionBlockCache(ObserverContext<RegionServerCoprocessorEnvironment> ctx) voidAccessController.preExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment> ctx) voidAccessController.preReplicateLogEntries(ObserverContext<RegionServerCoprocessorEnvironment> ctx) voidAccessController.preRollWALWriterRequest(ObserverContext<RegionServerCoprocessorEnvironment> ctx) voidAccessController.preStopRegionServer(ObserverContext<RegionServerCoprocessorEnvironment> ctx) voidAccessController.preUpdateRegionServerConfiguration(ObserverContext<RegionServerCoprocessorEnvironment> ctx, org.apache.hadoop.conf.Configuration preReloadConf) -
Uses of RegionServerCoprocessorEnvironment in org.apache.hadoop.hbase.security.visibility
Method parameters in org.apache.hadoop.hbase.security.visibility with type arguments of type RegionServerCoprocessorEnvironmentModifier and TypeMethodDescriptionVisibilityReplication.postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx, ReplicationEndpoint endpoint)