Package org.apache.hadoop.hbase.master
Class MasterCoprocessorHost
java.lang.Object
org.apache.hadoop.hbase.coprocessor.CoprocessorHost<MasterCoprocessor,MasterCoprocessorEnvironment>
org.apache.hadoop.hbase.master.MasterCoprocessorHost
@Private
public class MasterCoprocessorHost
extends CoprocessorHost<MasterCoprocessor,MasterCoprocessorEnvironment>
Provides the coprocessor framework and environment for master oriented operations.
HMaster interacts with the loaded coprocessors through this class.-
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionprivate static classCoprocessor environment extension providing access to master related services.private static classSpecial version of MasterEnvironment that exposes MasterServices for Core Coprocessors only.(package private) classNested classes/interfaces inherited from class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
CoprocessorHost.ObserverGetter<C,O>, CoprocessorHost.ObserverOperationWithoutResult<O>, CoprocessorHost.ObserverOperationWithResult<O, R> -
Field Summary
FieldsFields inherited from class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
ABORT_ON_ERROR_KEY, abortable, conf, coprocEnvironments, COPROCESSORS_ENABLED_CONF_KEY, DEFAULT_ABORT_ON_ERROR, DEFAULT_COPROCESSORS_ENABLED, DEFAULT_SKIP_LOAD_DUPLICATE_TABLE_COPROCESSOR, DEFAULT_USER_COPROCESSORS_ENABLED, loadSequence, MASTER_COPROCESSOR_CONF_KEY, pathPrefix, REGION_COPROCESSOR_CONF_KEY, REGIONSERVER_COPROCESSOR_CONF_KEY, RPC_COPROCESSOR_CONF_KEY, SKIP_LOAD_DUPLICATE_TABLE_COPROCESSOR, USER_COPROCESSORS_ENABLED_CONF_KEY, USER_REGION_COPROCESSOR_CONF_KEY, WAL_COPROCESSOR_CONF_KEY -
Constructor Summary
ConstructorsConstructorDescriptionMasterCoprocessorHost(MasterServices services, org.apache.hadoop.conf.Configuration conf) -
Method Summary
Modifier and TypeMethodDescriptioncheckAndGetInstance(Class<?> implClass) Called when a new Coprocessor class needs to be loaded.createEnvironment(MasterCoprocessor instance, int priority, int seq, org.apache.hadoop.conf.Configuration conf) Called when a new Coprocessor class is loadedvoidvoidpostAddReplicationPeer(String peerId, ReplicationPeerConfig peerConfig) voidpostAddRSGroup(String name) voidpostAssign(RegionInfo regionInfo) voidpostBalance(BalanceRequest request, List<RegionPlan> plans) voidpostBalanceRSGroup(String name, BalanceRequest request, BalanceResponse response) voidpostBalanceSwitch(boolean oldValue, boolean newValue) voidpostClearDeadServers(List<ServerName> servers, List<ServerName> notClearedServers) voidpostCloneSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidpostCompletedCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) voidpostCompletedDeleteTableAction(TableName tableName, User user) voidpostCompletedDisableTableAction(TableName tableName, User user) voidpostCompletedEnableTableAction(TableName tableName, User user) voidpostCompletedMergeRegionsAction(RegionInfo[] regionsToMerge, RegionInfo mergedRegion, User user) Invoked after completing merge regions operationvoidpostCompletedModifyTableAction(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor, User user) voidpostCompletedSnapshotAction(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidpostCompletedSplitRegionAction(RegionInfo regionInfoA, RegionInfo regionInfoB, User user) Invoked just after a splitvoidpostCompletedTruncateTableAction(TableName tableName, User user) voidvoidpostCreateTable(TableDescriptor htd, RegionInfo[] regions) voidpostDecommissionRegionServers(List<ServerName> servers, boolean offload) voidpostDeleteNamespace(String namespaceName) voidpostDeleteSnapshot(SnapshotDescription snapshot) voidpostDeleteTable(TableName tableName) voidpostDisableReplicationPeer(String peerId) voidpostDisableTable(TableName tableName) voidpostEnableReplicationPeer(String peerId) voidpostEnableTable(TableName tableName) voidpostGetClusterMetrics(ClusterMetrics status) voidvoidpostGetLocks(List<LockedResource> lockedResources) voidvoidpostGetProcedures(List<Procedure<?>> procInfoList) voidpostGetReplicationPeerConfig(String peerId) voidpostGetRSGroupInfo(String groupName) voidpostGetRSGroupInfoOfServer(Address server) voidpostGetRSGroupInfoOfTable(TableName tableName) voidpostGetTableDescriptors(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) voidpostGetTableNames(List<TableDescriptor> descriptors, String regex) voidpostGetUserPermissions(String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) voidpostGrant(UserPermission userPermission, boolean mergeExistingPermissions) voidpostHasUserPermissions(String userName, List<Permission> permissions) voidpostIsRpcThrottleEnabled(boolean enabled) voidvoidpostListNamespaceDescriptors(List<NamespaceDescriptor> descriptors) voidpostListNamespaces(List<String> namespaces) voidpostListReplicationPeers(String regex) voidvoidpostListSnapshot(SnapshotDescription snapshot) voidpostListTablesInRSGroup(String groupName) voidpostLockHeartbeat(LockProcedure proc, boolean keepAlive) voidvoidpostMergeRegions(RegionInfo[] regionsToMerge) voidpostMergeRegionsCommit(RegionInfo[] regionsToMerge, RegionInfo mergedRegion, User user) Invoked after merge regions operation writes the new region to hbase:metavoidpostModifyColumnFamilyStoreFileTracker(TableName tableName, byte[] family, String dstSFT) voidpostModifyNamespace(NamespaceDescriptor oldNsDescriptor, NamespaceDescriptor currentNsDescriptor) voidpostModifyTable(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) voidpostModifyTableStoreFileTracker(TableName tableName, String dstSFT) voidpostMove(RegionInfo region, ServerName srcServer, ServerName destServer) voidpostMoveServers(Set<Address> servers, String targetGroup) voidvoidpostMoveTables(Set<TableName> tables, String targetGroup) voidpostRecommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) voidpostRegionOffline(RegionInfo regionInfo) voidpostRemoveReplicationPeer(String peerId) voidpostRemoveRSGroup(String name) voidpostRemoveServers(Set<Address> servers) voidpostRenameRSGroup(String oldName, String newName) voidpostRequestLock(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) voidpostRestoreSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidpostRevoke(UserPermission userPermission) voidpostRollBackMergeRegionsAction(RegionInfo[] regionsToMerge, User user) Invoked after rollback merge regions operationvoidInvoked just after the rollback of a failed splitvoidpostSetNamespaceQuota(String namespace, GlobalQuotaSettings quotas) voidpostSetRegionServerQuota(String regionServer, GlobalQuotaSettings quotas) voidpostSetSplitOrMergeEnabled(boolean newValue, MasterSwitchType switchType) voidpostSetTableQuota(TableName table, GlobalQuotaSettings quotas) voidpostSetUserQuota(String user, String namespace, GlobalQuotaSettings quotas) voidpostSetUserQuota(String user, GlobalQuotaSettings quotas) voidpostSetUserQuota(String user, TableName table, GlobalQuotaSettings quotas) voidpostSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) voidvoidpostSwitchExceedThrottleQuota(boolean oldValue, boolean newValue) voidpostSwitchRpcThrottle(boolean oldValue, boolean newValue) voidpostTableFlush(TableName tableName) voidpostTransitReplicationPeerSyncReplicationState(String peerId, SyncReplicationState from, SyncReplicationState to) voidpostTruncateRegion(RegionInfo regionInfo) Invoked after calling the truncate region procedurevoidpostTruncateRegionAction(RegionInfo region, User user) Invoked after calling the truncate region procedurevoidpostTruncateTable(TableName tableName) voidpostUnassign(RegionInfo regionInfo) voidpostUpdateConfiguration(org.apache.hadoop.conf.Configuration postReloadConf) voidpostUpdateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig) voidpostUpdateRSGroupConfig(String groupName, Map<String, String> configuration) voidpreAbortProcedure(ProcedureExecutor<MasterProcedureEnv> procEnv, long procId) voidpreAddReplicationPeer(String peerId, ReplicationPeerConfig peerConfig) voidpreAddRSGroup(String name) voidpreAssign(RegionInfo regionInfo) booleanpreBalance(BalanceRequest request) voidpreBalanceRSGroup(String name, BalanceRequest request) voidpreBalanceSwitch(boolean b) voidvoidpreCloneSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidvoidpreCreateTable(TableDescriptor htd, RegionInfo[] regions) voidpreCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) voidpreDecommissionRegionServers(List<ServerName> servers, boolean offload) voidpreDeleteNamespace(String namespaceName) voidpreDeleteSnapshot(SnapshotDescription snapshot) voidpreDeleteTable(TableName tableName) voidpreDeleteTableAction(TableName tableName, User user) voidpreDisableReplicationPeer(String peerId) voidpreDisableTable(TableName tableName) voidpreDisableTableAction(TableName tableName, User user) voidpreEnableReplicationPeer(String peerId) voidpreEnableTable(TableName tableName) voidpreEnableTableAction(TableName tableName, User user) voidvoidvoidvoidpreGetNamespaceDescriptor(String namespaceName) voidvoidpreGetReplicationPeerConfig(String peerId) voidpreGetRSGroupInfo(String groupName) voidpreGetRSGroupInfoOfServer(Address server) voidpreGetRSGroupInfoOfTable(TableName tableName) voidpreGetTableDescriptors(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) voidpreGetTableNames(List<TableDescriptor> descriptors, String regex) voidpreGetUserPermissions(String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) voidpreGrant(UserPermission userPermission, boolean mergeExistingPermissions) voidpreHasUserPermissions(String userName, List<Permission> permissions) voidvoidvoidpreListNamespaceDescriptors(List<NamespaceDescriptor> descriptors) voidpreListNamespaces(List<String> namespaces) voidpreListReplicationPeers(String regex) voidvoidpreListSnapshot(SnapshotDescription snapshot) voidpreListTablesInRSGroup(String groupName) voidpreLockHeartbeat(LockProcedure proc, boolean keepAlive) voidvoidvoidpreMergeRegions(RegionInfo[] regionsToMerge) voidpreMergeRegionsAction(RegionInfo[] regionsToMerge, User user) Invoked just before a mergevoidpreMergeRegionsCommit(RegionInfo[] regionsToMerge, List<Mutation> metaEntries, User user) Invoked before merge regions operation writes the new region to hbase:metapreModifyColumnFamilyStoreFileTracker(TableName tableName, byte[] family, String dstSFT) voidpreModifyNamespace(NamespaceDescriptor currentNsDescriptor, NamespaceDescriptor newNsDescriptor) preModifyTable(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) voidpreModifyTableAction(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor, User user) preModifyTableStoreFileTracker(TableName tableName, String dstSFT) voidpreMove(RegionInfo region, ServerName srcServer, ServerName destServer) voidpreMoveServers(Set<Address> servers, String targetGroup) voidvoidpreMoveTables(Set<TableName> tables, String targetGroup) voidpreRecommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) voidpreRegionOffline(RegionInfo regionInfo) voidpreRemoveReplicationPeer(String peerId) voidpreRemoveRSGroup(String name) voidpreRemoveServers(Set<Address> servers) voidpreRenameRSGroup(String oldName, String newName) voidpreRequestLock(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) voidpreRestoreSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) voidpreRevoke(UserPermission userPermission) voidpreSetNamespaceQuota(String namespace, GlobalQuotaSettings quotas) voidpreSetRegionServerQuota(String regionServer, GlobalQuotaSettings quotas) voidpreSetSplitOrMergeEnabled(boolean newValue, MasterSwitchType switchType) voidpreSetTableQuota(TableName table, GlobalQuotaSettings quotas) voidpreSetUserQuota(String user, String namespace, GlobalQuotaSettings quotas) voidpreSetUserQuota(String user, GlobalQuotaSettings quotas) voidpreSetUserQuota(String user, TableName table, GlobalQuotaSettings quotas) voidvoidpreSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) voidpreSplitAfterMETAAction(User user) This will be called after update META step as part of split table region procedure.voidpreSplitBeforeMETAAction(byte[] splitKey, List<Mutation> metaEntries, User user) This will be called before update META step as part of split table region procedure.voidpreSplitRegion(TableName tableName, byte[] splitRow) Invoked just before calling the split region procedurevoidpreSplitRegionAction(TableName tableName, byte[] splitRow, User user) Invoked just before a splitvoidvoidpreSwitchExceedThrottleQuota(boolean enable) voidpreSwitchRpcThrottle(boolean enable) voidpreTableFlush(TableName tableName) voidvoidpreTruncateRegion(RegionInfo regionInfo) Invoked just before calling the truncate region procedurevoidpreTruncateRegionAction(RegionInfo region, User user) Invoked just before calling the truncate region procedurevoidpreTruncateTable(TableName tableName) voidpreTruncateTableAction(TableName tableName, User user) voidpreUnassign(RegionInfo regionInfo) voidpreUpdateConfiguration(org.apache.hadoop.conf.Configuration preReloadConf) voidpreUpdateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig) voidpreUpdateRSGroupConfig(String groupName, Map<String, String> configuration) Methods inherited from class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
abortServer, abortServer, checkAndLoadInstance, execOperation, execOperationWithResult, execShutdown, findCoprocessor, findCoprocessor, findCoprocessorEnvironment, findCoprocessors, getCoprocessors, getLoadedCoprocessors, handleCoprocessorThrowable, load, load, load, loadSystemCoprocessors, shutdown
-
Field Details
-
LOG
-
masterServices
-
masterObserverGetter
-
-
Constructor Details
-
MasterCoprocessorHost
-
-
Method Details
-
createEnvironment
public MasterCoprocessorHost.MasterEnvironment createEnvironment(MasterCoprocessor instance, int priority, int seq, org.apache.hadoop.conf.Configuration conf) Description copied from class:CoprocessorHostCalled when a new Coprocessor class is loaded- Specified by:
createEnvironmentin classCoprocessorHost<MasterCoprocessor,MasterCoprocessorEnvironment>
-
checkAndGetInstance
public MasterCoprocessor checkAndGetInstance(Class<?> implClass) throws InstantiationException, IllegalAccessException Description copied from class:CoprocessorHostCalled when a new Coprocessor class needs to be loaded. Checks if type of the given class is what the corresponding host implementation expects. If it is of correct type, returns an instance of the coprocessor to be loaded. If not, returns null. If an exception occurs when trying to create instance of a coprocessor, it's passed up and eventually results into server aborting.- Specified by:
checkAndGetInstancein classCoprocessorHost<MasterCoprocessor,MasterCoprocessorEnvironment> - Throws:
InstantiationExceptionIllegalAccessException
-
preCreateNamespace
- Throws:
IOException
-
postCreateNamespace
- Throws:
IOException
-
preDeleteNamespace
- Throws:
IOException
-
postDeleteNamespace
- Throws:
IOException
-
preModifyNamespace
public void preModifyNamespace(NamespaceDescriptor currentNsDescriptor, NamespaceDescriptor newNsDescriptor) throws IOException - Throws:
IOException
-
postModifyNamespace
public void postModifyNamespace(NamespaceDescriptor oldNsDescriptor, NamespaceDescriptor currentNsDescriptor) throws IOException - Throws:
IOException
-
preGetNamespaceDescriptor
- Throws:
IOException
-
postGetNamespaceDescriptor
- Throws:
IOException
-
preListNamespaces
- Throws:
IOException
-
postListNamespaces
- Throws:
IOException
-
preListNamespaceDescriptors
- Throws:
IOException
-
postListNamespaceDescriptors
- Throws:
IOException
-
preCreateTableRegionsInfos
- Throws:
IOException
-
preCreateTable
- Throws:
IOException
-
postCreateTable
- Throws:
IOException
-
preCreateTableAction
public void preCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) throws IOException - Throws:
IOException
-
postCompletedCreateTableAction
public void postCompletedCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) throws IOException - Throws:
IOException
-
preDeleteTable
- Throws:
IOException
-
postDeleteTable
- Throws:
IOException
-
preDeleteTableAction
- Throws:
IOException
-
postCompletedDeleteTableAction
- Throws:
IOException
-
preTruncateTable
- Throws:
IOException
-
postTruncateTable
- Throws:
IOException
-
preTruncateTableAction
- Throws:
IOException
-
postCompletedTruncateTableAction
- Throws:
IOException
-
preModifyTable
public TableDescriptor preModifyTable(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) throws IOException - Throws:
IOException
-
postModifyTable
public void postModifyTable(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) throws IOException - Throws:
IOException
-
preModifyTableStoreFileTracker
- Throws:
IOException
-
postModifyTableStoreFileTracker
- Throws:
IOException
-
preModifyColumnFamilyStoreFileTracker
public String preModifyColumnFamilyStoreFileTracker(TableName tableName, byte[] family, String dstSFT) throws IOException - Throws:
IOException
-
postModifyColumnFamilyStoreFileTracker
public void postModifyColumnFamilyStoreFileTracker(TableName tableName, byte[] family, String dstSFT) throws IOException - Throws:
IOException
-
preModifyTableAction
public void preModifyTableAction(TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor, User user) throws IOException - Throws:
IOException
-
postCompletedModifyTableAction
public void postCompletedModifyTableAction(TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor, User user) throws IOException - Throws:
IOException
-
preEnableTable
- Throws:
IOException
-
postEnableTable
- Throws:
IOException
-
preEnableTableAction
- Throws:
IOException
-
postCompletedEnableTableAction
- Throws:
IOException
-
preDisableTable
- Throws:
IOException
-
postDisableTable
- Throws:
IOException
-
preDisableTableAction
- Throws:
IOException
-
postCompletedDisableTableAction
- Throws:
IOException
-
preAbortProcedure
public void preAbortProcedure(ProcedureExecutor<MasterProcedureEnv> procEnv, long procId) throws IOException - Throws:
IOException
-
postAbortProcedure
- Throws:
IOException
-
preGetProcedures
- Throws:
IOException
-
postGetProcedures
- Throws:
IOException
-
preGetLocks
- Throws:
IOException
-
postGetLocks
- Throws:
IOException
-
preMove
public void preMove(RegionInfo region, ServerName srcServer, ServerName destServer) throws IOException - Throws:
IOException
-
postMove
public void postMove(RegionInfo region, ServerName srcServer, ServerName destServer) throws IOException - Throws:
IOException
-
preAssign
- Throws:
IOException
-
postAssign
- Throws:
IOException
-
preUnassign
- Throws:
IOException
-
postUnassign
- Throws:
IOException
-
preRegionOffline
- Throws:
IOException
-
postRegionOffline
- Throws:
IOException
-
preMergeRegions
- Throws:
IOException
-
postMergeRegions
- Throws:
IOException
-
preBalance
- Throws:
IOException
-
postBalance
- Throws:
IOException
-
preSetSplitOrMergeEnabled
public void preSetSplitOrMergeEnabled(boolean newValue, MasterSwitchType switchType) throws IOException - Throws:
IOException
-
postSetSplitOrMergeEnabled
public void postSetSplitOrMergeEnabled(boolean newValue, MasterSwitchType switchType) throws IOException - Throws:
IOException
-
preSplitRegion
Invoked just before calling the split region procedure- Parameters:
tableName- the table where the region belongs tosplitRow- the split point- Throws:
IOException
-
preSplitRegionAction
public void preSplitRegionAction(TableName tableName, byte[] splitRow, User user) throws IOException Invoked just before a split- Parameters:
tableName- the table where the region belongs tosplitRow- the split pointuser- the user- Throws:
IOException
-
postCompletedSplitRegionAction
public void postCompletedSplitRegionAction(RegionInfo regionInfoA, RegionInfo regionInfoB, User user) throws IOException Invoked just after a split- Parameters:
regionInfoA- the new left-hand daughter regionregionInfoB- the new right-hand daughter regionuser- the user- Throws:
IOException
-
preTruncateRegion
Invoked just before calling the truncate region procedure- Parameters:
regionInfo- region being truncated- Throws:
IOException
-
postTruncateRegion
Invoked after calling the truncate region procedure- Parameters:
regionInfo- region being truncated- Throws:
IOException
-
preTruncateRegionAction
Invoked just before calling the truncate region procedure- Parameters:
region- Region to be truncateduser- The user- Throws:
IOException
-
postTruncateRegionAction
Invoked after calling the truncate region procedure- Parameters:
region- Region which was truncateduser- The user- Throws:
IOException
-
preSplitBeforeMETAAction
public void preSplitBeforeMETAAction(byte[] splitKey, List<Mutation> metaEntries, User user) throws IOException This will be called before update META step as part of split table region procedure.- Parameters:
user- the user- Throws:
IOException
-
preSplitAfterMETAAction
This will be called after update META step as part of split table region procedure.- Parameters:
user- the user- Throws:
IOException
-
postRollBackSplitRegionAction
Invoked just after the rollback of a failed split- Parameters:
user- the user- Throws:
IOException
-
preMergeRegionsAction
Invoked just before a merge- Parameters:
regionsToMerge- the regions to mergeuser- the user- Throws:
IOException
-
postCompletedMergeRegionsAction
public void postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge, RegionInfo mergedRegion, User user) throws IOException Invoked after completing merge regions operation- Parameters:
regionsToMerge- the regions to mergemergedRegion- the new merged regionuser- the user- Throws:
IOException
-
preMergeRegionsCommit
public void preMergeRegionsCommit(RegionInfo[] regionsToMerge, @MetaMutationAnnotation List<Mutation> metaEntries, User user) throws IOException Invoked before merge regions operation writes the new region to hbase:meta- Parameters:
regionsToMerge- the regions to mergemetaEntries- the meta entryuser- the user- Throws:
IOException
-
postMergeRegionsCommit
public void postMergeRegionsCommit(RegionInfo[] regionsToMerge, RegionInfo mergedRegion, User user) throws IOException Invoked after merge regions operation writes the new region to hbase:meta- Parameters:
regionsToMerge- the regions to mergemergedRegion- the new merged regionuser- the user- Throws:
IOException
-
postRollBackMergeRegionsAction
public void postRollBackMergeRegionsAction(RegionInfo[] regionsToMerge, User user) throws IOException Invoked after rollback merge regions operation- Parameters:
regionsToMerge- the regions to mergeuser- the user- Throws:
IOException
-
preBalanceSwitch
- Throws:
IOException
-
postBalanceSwitch
- Throws:
IOException
-
preShutdown
- Throws:
IOException
-
preStopMaster
- Throws:
IOException
-
preMasterInitialization
- Throws:
IOException
-
postStartMaster
- Throws:
IOException
-
preSnapshot
public void preSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) throws IOException - Throws:
IOException
-
postSnapshot
public void postSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor, User user) throws IOException - Throws:
IOException
-
postCompletedSnapshotAction
public void postCompletedSnapshotAction(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException - Throws:
IOException
-
preListSnapshot
- Throws:
IOException
-
postListSnapshot
- Throws:
IOException
-
preCloneSnapshot
public void preCloneSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException - Throws:
IOException
-
postCloneSnapshot
public void postCloneSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException - Throws:
IOException
-
preRestoreSnapshot
public void preRestoreSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException - Throws:
IOException
-
postRestoreSnapshot
public void postRestoreSnapshot(SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException - Throws:
IOException
-
preDeleteSnapshot
- Throws:
IOException
-
postDeleteSnapshot
- Throws:
IOException
-
preGetTableDescriptors
public void preGetTableDescriptors(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) throws IOException - Throws:
IOException
-
postGetTableDescriptors
public void postGetTableDescriptors(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) throws IOException - Throws:
IOException
-
preGetTableNames
- Throws:
IOException
-
postGetTableNames
- Throws:
IOException
-
preTableFlush
- Throws:
IOException
-
postTableFlush
- Throws:
IOException
-
preMasterStoreFlush
- Throws:
IOException
-
postMasterStoreFlush
- Throws:
IOException
-
preSetUserQuota
- Throws:
IOException
-
postSetUserQuota
- Throws:
IOException
-
preSetUserQuota
public void preSetUserQuota(String user, TableName table, GlobalQuotaSettings quotas) throws IOException - Throws:
IOException
-
postSetUserQuota
public void postSetUserQuota(String user, TableName table, GlobalQuotaSettings quotas) throws IOException - Throws:
IOException
-
preSetUserQuota
public void preSetUserQuota(String user, String namespace, GlobalQuotaSettings quotas) throws IOException - Throws:
IOException
-
postSetUserQuota
public void postSetUserQuota(String user, String namespace, GlobalQuotaSettings quotas) throws IOException - Throws:
IOException
-
preSetTableQuota
- Throws:
IOException
-
postSetTableQuota
- Throws:
IOException
-
preSetNamespaceQuota
- Throws:
IOException
-
postSetNamespaceQuota
- Throws:
IOException
-
preSetRegionServerQuota
public void preSetRegionServerQuota(String regionServer, GlobalQuotaSettings quotas) throws IOException - Throws:
IOException
-
postSetRegionServerQuota
public void postSetRegionServerQuota(String regionServer, GlobalQuotaSettings quotas) throws IOException - Throws:
IOException
-
preMoveServersAndTables
public void preMoveServersAndTables(Set<Address> servers, Set<TableName> tables, String targetGroup) throws IOException - Throws:
IOException
-
postMoveServersAndTables
public void postMoveServersAndTables(Set<Address> servers, Set<TableName> tables, String targetGroup) throws IOException - Throws:
IOException
-
preMoveServers
- Throws:
IOException
-
postMoveServers
- Throws:
IOException
-
preMoveTables
- Throws:
IOException
-
postMoveTables
- Throws:
IOException
-
preAddRSGroup
- Throws:
IOException
-
postAddRSGroup
- Throws:
IOException
-
preRemoveRSGroup
- Throws:
IOException
-
postRemoveRSGroup
- Throws:
IOException
-
preBalanceRSGroup
- Throws:
IOException
-
postBalanceRSGroup
public void postBalanceRSGroup(String name, BalanceRequest request, BalanceResponse response) throws IOException - Throws:
IOException
-
preRemoveServers
- Throws:
IOException
-
postRemoveServers
- Throws:
IOException
-
preGetRSGroupInfo
- Throws:
IOException
-
postGetRSGroupInfo
- Throws:
IOException
-
preGetRSGroupInfoOfTable
- Throws:
IOException
-
postGetRSGroupInfoOfTable
- Throws:
IOException
-
preListRSGroups
- Throws:
IOException
-
postListRSGroups
- Throws:
IOException
-
preListTablesInRSGroup
- Throws:
IOException
-
postListTablesInRSGroup
- Throws:
IOException
-
preRenameRSGroup
- Throws:
IOException
-
postRenameRSGroup
- Throws:
IOException
-
preUpdateRSGroupConfig
public void preUpdateRSGroupConfig(String groupName, Map<String, String> configuration) throws IOException- Throws:
IOException
-
postUpdateRSGroupConfig
public void postUpdateRSGroupConfig(String groupName, Map<String, String> configuration) throws IOException- Throws:
IOException
-
preGetConfiguredNamespacesAndTablesInRSGroup
- Throws:
IOException
-
postGetConfiguredNamespacesAndTablesInRSGroup
- Throws:
IOException
-
preGetRSGroupInfoOfServer
- Throws:
IOException
-
postGetRSGroupInfoOfServer
- Throws:
IOException
-
preAddReplicationPeer
public void preAddReplicationPeer(String peerId, ReplicationPeerConfig peerConfig) throws IOException - Throws:
IOException
-
postAddReplicationPeer
public void postAddReplicationPeer(String peerId, ReplicationPeerConfig peerConfig) throws IOException - Throws:
IOException
-
preRemoveReplicationPeer
- Throws:
IOException
-
postRemoveReplicationPeer
- Throws:
IOException
-
preEnableReplicationPeer
- Throws:
IOException
-
postEnableReplicationPeer
- Throws:
IOException
-
preDisableReplicationPeer
- Throws:
IOException
-
postDisableReplicationPeer
- Throws:
IOException
-
preGetReplicationPeerConfig
- Throws:
IOException
-
postGetReplicationPeerConfig
- Throws:
IOException
-
preUpdateReplicationPeerConfig
public void preUpdateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig) throws IOException - Throws:
IOException
-
postUpdateReplicationPeerConfig
public void postUpdateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig) throws IOException - Throws:
IOException
-
preListReplicationPeers
- Throws:
IOException
-
postListReplicationPeers
- Throws:
IOException
-
preTransitReplicationPeerSyncReplicationState
public void preTransitReplicationPeerSyncReplicationState(String peerId, SyncReplicationState state) throws IOException - Throws:
IOException
-
postTransitReplicationPeerSyncReplicationState
public void postTransitReplicationPeerSyncReplicationState(String peerId, SyncReplicationState from, SyncReplicationState to) throws IOException - Throws:
IOException
-
preRequestLock
public void preRequestLock(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) throws IOException - Throws:
IOException
-
postRequestLock
public void postRequestLock(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) throws IOException - Throws:
IOException
-
preLockHeartbeat
- Throws:
IOException
-
postLockHeartbeat
- Throws:
IOException
-
preGetClusterMetrics
- Throws:
IOException
-
postGetClusterMetrics
- Throws:
IOException
-
preClearDeadServers
- Throws:
IOException
-
postClearDeadServers
public void postClearDeadServers(List<ServerName> servers, List<ServerName> notClearedServers) throws IOException - Throws:
IOException
-
preDecommissionRegionServers
public void preDecommissionRegionServers(List<ServerName> servers, boolean offload) throws IOException - Throws:
IOException
-
postDecommissionRegionServers
public void postDecommissionRegionServers(List<ServerName> servers, boolean offload) throws IOException - Throws:
IOException
-
preListDecommissionedRegionServers
- Throws:
IOException
-
postListDecommissionedRegionServers
- Throws:
IOException
-
preRecommissionRegionServer
public void preRecommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) throws IOException - Throws:
IOException
-
postRecommissionRegionServer
public void postRecommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) throws IOException - Throws:
IOException
-
preSwitchRpcThrottle
- Throws:
IOException
-
postSwitchRpcThrottle
- Throws:
IOException
-
preIsRpcThrottleEnabled
- Throws:
IOException
-
postIsRpcThrottleEnabled
- Throws:
IOException
-
preSwitchExceedThrottleQuota
- Throws:
IOException
-
postSwitchExceedThrottleQuota
- Throws:
IOException
-
preGrant
public void preGrant(UserPermission userPermission, boolean mergeExistingPermissions) throws IOException - Throws:
IOException
-
postGrant
public void postGrant(UserPermission userPermission, boolean mergeExistingPermissions) throws IOException - Throws:
IOException
-
preRevoke
- Throws:
IOException
-
postRevoke
- Throws:
IOException
-
preGetUserPermissions
public void preGetUserPermissions(String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) throws IOException - Throws:
IOException
-
postGetUserPermissions
public void postGetUserPermissions(String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) throws IOException - Throws:
IOException
-
preHasUserPermissions
- Throws:
IOException
-
postHasUserPermissions
public void postHasUserPermissions(String userName, List<Permission> permissions) throws IOException - Throws:
IOException
-
preUpdateConfiguration
public void preUpdateConfiguration(org.apache.hadoop.conf.Configuration preReloadConf) throws IOException - Throws:
IOException
-
postUpdateConfiguration
public void postUpdateConfiguration(org.apache.hadoop.conf.Configuration postReloadConf) throws IOException - Throws:
IOException
-