public class MasterCoprocessorHost
extends <any>
HMaster interacts with the loaded coprocessors
through this class.| Constructor and Description |
|---|
MasterCoprocessorHost(MasterServices services,
Configuration conf) |
| Modifier and Type | Method and Description |
|---|---|
MasterCoprocessor |
checkAndGetInstance(java.lang.Class<?> implClass) |
org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment |
createEnvironment(MasterCoprocessor instance,
int priority,
int seq,
Configuration conf) |
void |
postAbortProcedure() |
void |
postAddReplicationPeer(java.lang.String peerId,
ReplicationPeerConfig peerConfig) |
void |
postAddRSGroup(java.lang.String name) |
void |
postAssign(RegionInfo regionInfo) |
void |
postBalance(java.util.List<RegionPlan> plans) |
void |
postBalanceRSGroup(java.lang.String name,
boolean balanceRan) |
void |
postBalanceSwitch(boolean oldValue,
boolean newValue) |
void |
postClearDeadServers(java.util.List<ServerName> servers,
java.util.List<ServerName> notClearedServers) |
void |
postCloneSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor) |
void |
postCompletedCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user) |
void |
postCompletedDeleteTableAction(TableName tableName,
User user) |
void |
postCompletedDisableTableAction(TableName tableName,
User user) |
void |
postCompletedEnableTableAction(TableName tableName,
User user) |
void |
postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after completing merge regions operation
|
void |
postCompletedModifyTableAction(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor,
User user) |
void |
postCompletedSplitRegionAction(RegionInfo regionInfoA,
RegionInfo regionInfoB,
User user)
Invoked just after a split
|
void |
postCompletedTruncateTableAction(TableName tableName,
User user) |
void |
postCreateNamespace(NamespaceDescriptor ns) |
void |
postCreateTable(TableDescriptor htd,
RegionInfo[] regions) |
void |
postDecommissionRegionServers(java.util.List<ServerName> servers,
boolean offload) |
void |
postDeleteNamespace(java.lang.String namespaceName) |
void |
postDeleteSnapshot(SnapshotDescription snapshot) |
void |
postDeleteTable(TableName tableName) |
void |
postDisableReplicationPeer(java.lang.String peerId) |
void |
postDisableTable(TableName tableName) |
void |
postEnableReplicationPeer(java.lang.String peerId) |
void |
postEnableTable(TableName tableName) |
void |
postGetClusterMetrics(ClusterMetrics status) |
void |
postGetLocks(java.util.List<LockedResource> lockedResources) |
void |
postGetNamespaceDescriptor(NamespaceDescriptor ns) |
void |
postGetProcedures(java.util.List<<any>> procInfoList) |
void |
postGetReplicationPeerConfig(java.lang.String peerId) |
void |
postGetTableDescriptors(java.util.List<TableName> tableNamesList,
java.util.List<TableDescriptor> descriptors,
java.lang.String regex) |
void |
postGetTableNames(java.util.List<TableDescriptor> descriptors,
java.lang.String regex) |
void |
postListDecommissionedRegionServers() |
void |
postListNamespaceDescriptors(java.util.List<NamespaceDescriptor> descriptors) |
void |
postListReplicationPeers(java.lang.String regex) |
void |
postListSnapshot(SnapshotDescription snapshot) |
void |
postLockHeartbeat(LockProcedure proc,
boolean keepAlive) |
void |
postMergeRegions(RegionInfo[] regionsToMerge) |
void |
postMergeRegionsCommit(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after merge regions operation writes the new region to hbase:meta
|
void |
postModifyNamespace(NamespaceDescriptor oldNsDescriptor,
NamespaceDescriptor currentNsDescriptor) |
void |
postModifyTable(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor) |
void |
postMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
postMoveServers(java.util.Set<Address> servers,
java.lang.String targetGroup) |
void |
postMoveServersAndTables(java.util.Set<Address> servers,
java.util.Set<TableName> tables,
java.lang.String targetGroup) |
void |
postMoveTables(java.util.Set<TableName> tables,
java.lang.String targetGroup) |
void |
postRecommissionRegionServer(ServerName server,
java.util.List<byte[]> encodedRegionNames) |
void |
postRegionOffline(RegionInfo regionInfo) |
void |
postRemoveReplicationPeer(java.lang.String peerId) |
void |
postRemoveRSGroup(java.lang.String name) |
void |
postRemoveServers(java.util.Set<Address> servers) |
void |
postRequestLock(java.lang.String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
java.lang.String description) |
void |
postRestoreSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor) |
void |
postRollBackMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
Invoked after rollback merge regions operation
|
void |
postRollBackSplitRegionAction(User user)
Invoked just after the rollback of a failed split
|
void |
postSetNamespaceQuota(java.lang.String namespace,
GlobalQuotaSettings quotas) |
void |
postSetSplitOrMergeEnabled(boolean newValue,
MasterSwitchType switchType) |
void |
postSetTableQuota(TableName table,
GlobalQuotaSettings quotas) |
void |
postSetUserQuota(java.lang.String user,
GlobalQuotaSettings quotas) |
void |
postSetUserQuota(java.lang.String user,
java.lang.String namespace,
GlobalQuotaSettings quotas) |
void |
postSetUserQuota(java.lang.String user,
TableName table,
GlobalQuotaSettings quotas) |
void |
postSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor) |
void |
postStartMaster() |
void |
postTableFlush(TableName tableName) |
void |
postTruncateTable(TableName tableName) |
void |
postUnassign(RegionInfo regionInfo,
boolean force) |
void |
postUpdateReplicationPeerConfig(java.lang.String peerId,
ReplicationPeerConfig peerConfig) |
void |
preAbortProcedure(<any> procEnv,
long procId) |
void |
preAddReplicationPeer(java.lang.String peerId,
ReplicationPeerConfig peerConfig) |
void |
preAddRSGroup(java.lang.String name) |
void |
preAssign(RegionInfo regionInfo) |
boolean |
preBalance() |
void |
preBalanceRSGroup(java.lang.String name) |
void |
preBalanceSwitch(boolean b) |
void |
preClearDeadServers() |
void |
preCloneSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor) |
void |
preCreateNamespace(NamespaceDescriptor ns) |
void |
preCreateTable(TableDescriptor htd,
RegionInfo[] regions) |
void |
preCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user) |
void |
preDecommissionRegionServers(java.util.List<ServerName> servers,
boolean offload) |
void |
preDeleteNamespace(java.lang.String namespaceName) |
void |
preDeleteSnapshot(SnapshotDescription snapshot) |
void |
preDeleteTable(TableName tableName) |
void |
preDeleteTableAction(TableName tableName,
User user) |
void |
preDisableReplicationPeer(java.lang.String peerId) |
void |
preDisableTable(TableName tableName) |
void |
preDisableTableAction(TableName tableName,
User user) |
void |
preEnableReplicationPeer(java.lang.String peerId) |
void |
preEnableTable(TableName tableName) |
void |
preEnableTableAction(TableName tableName,
User user) |
void |
preGetClusterMetrics() |
void |
preGetLocks() |
void |
preGetNamespaceDescriptor(java.lang.String namespaceName) |
void |
preGetProcedures() |
void |
preGetReplicationPeerConfig(java.lang.String peerId) |
void |
preGetTableDescriptors(java.util.List<TableName> tableNamesList,
java.util.List<TableDescriptor> descriptors,
java.lang.String regex) |
void |
preGetTableNames(java.util.List<TableDescriptor> descriptors,
java.lang.String regex) |
void |
preListDecommissionedRegionServers() |
void |
preListNamespaceDescriptors(java.util.List<NamespaceDescriptor> descriptors) |
void |
preListReplicationPeers(java.lang.String regex) |
void |
preListSnapshot(SnapshotDescription snapshot) |
void |
preLockHeartbeat(LockProcedure proc,
boolean keepAlive) |
void |
preMasterInitialization() |
void |
preMergeRegions(RegionInfo[] regionsToMerge) |
void |
preMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
Invoked just before a merge
|
void |
preMergeRegionsCommit(RegionInfo[] regionsToMerge,
java.util.List<Mutation> metaEntries,
User user)
Invoked before merge regions operation writes the new region to hbase:meta
|
void |
preModifyNamespace(NamespaceDescriptor currentNsDescriptor,
NamespaceDescriptor newNsDescriptor) |
void |
preModifyTable(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor) |
void |
preModifyTableAction(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor,
User user) |
void |
preMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
preMoveServers(java.util.Set<Address> servers,
java.lang.String targetGroup) |
void |
preMoveServersAndTables(java.util.Set<Address> servers,
java.util.Set<TableName> tables,
java.lang.String targetGroup) |
void |
preMoveTables(java.util.Set<TableName> tables,
java.lang.String targetGroup) |
void |
preRecommissionRegionServer(ServerName server,
java.util.List<byte[]> encodedRegionNames) |
void |
preRegionOffline(RegionInfo regionInfo) |
void |
preRemoveReplicationPeer(java.lang.String peerId) |
void |
preRemoveRSGroup(java.lang.String name) |
void |
preRemoveServers(java.util.Set<Address> servers) |
void |
preRequestLock(java.lang.String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
java.lang.String description) |
void |
preRestoreSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor) |
void |
preSetNamespaceQuota(java.lang.String namespace,
GlobalQuotaSettings quotas) |
void |
preSetSplitOrMergeEnabled(boolean newValue,
MasterSwitchType switchType) |
void |
preSetTableQuota(TableName table,
GlobalQuotaSettings quotas) |
void |
preSetUserQuota(java.lang.String user,
GlobalQuotaSettings quotas) |
void |
preSetUserQuota(java.lang.String user,
java.lang.String namespace,
GlobalQuotaSettings quotas) |
void |
preSetUserQuota(java.lang.String user,
TableName table,
GlobalQuotaSettings quotas) |
void |
preShutdown() |
void |
preSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor) |
void |
preSplitAfterMETAAction(User user)
This will be called after update META step as part of split table region procedure.
|
void |
preSplitBeforeMETAAction(byte[] splitKey,
java.util.List<Mutation> metaEntries,
User user)
This will be called before update META step as part of split table region procedure.
|
void |
preSplitRegion(TableName tableName,
byte[] splitRow)
Invoked just before calling the split region procedure
|
void |
preSplitRegionAction(TableName tableName,
byte[] splitRow,
User user)
Invoked just before a split
|
void |
preStopMaster() |
void |
preTableFlush(TableName tableName) |
void |
preTruncateTable(TableName tableName) |
void |
preTruncateTableAction(TableName tableName,
User user) |
void |
preUnassign(RegionInfo regionInfo,
boolean force) |
void |
preUpdateReplicationPeerConfig(java.lang.String peerId,
ReplicationPeerConfig peerConfig) |
public MasterCoprocessorHost(MasterServices services, Configuration conf)
public org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment createEnvironment(MasterCoprocessor instance,
int priority,
int seq,
Configuration conf)
public MasterCoprocessor checkAndGetInstance(java.lang.Class<?> implClass)
throws java.lang.InstantiationException,
java.lang.IllegalAccessException
java.lang.InstantiationExceptionjava.lang.IllegalAccessExceptionpublic void preCreateNamespace(NamespaceDescriptor ns)
throws java.io.IOException
java.io.IOExceptionpublic void postCreateNamespace(NamespaceDescriptor ns)
throws java.io.IOException
java.io.IOExceptionpublic void preDeleteNamespace(java.lang.String namespaceName)
throws java.io.IOException
java.io.IOExceptionpublic void postDeleteNamespace(java.lang.String namespaceName)
throws java.io.IOException
java.io.IOExceptionpublic void preModifyNamespace(NamespaceDescriptor currentNsDescriptor,
NamespaceDescriptor newNsDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void postModifyNamespace(NamespaceDescriptor oldNsDescriptor,
NamespaceDescriptor currentNsDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void preGetNamespaceDescriptor(java.lang.String namespaceName)
throws java.io.IOException
java.io.IOExceptionpublic void postGetNamespaceDescriptor(NamespaceDescriptor ns)
throws java.io.IOException
java.io.IOExceptionpublic void preListNamespaceDescriptors(java.util.List<NamespaceDescriptor> descriptors)
throws java.io.IOException
java.io.IOExceptionpublic void postListNamespaceDescriptors(java.util.List<NamespaceDescriptor> descriptors)
throws java.io.IOException
java.io.IOExceptionpublic void preCreateTable(TableDescriptor htd,
RegionInfo[] regions)
throws java.io.IOException
java.io.IOExceptionpublic void postCreateTable(TableDescriptor htd,
RegionInfo[] regions)
throws java.io.IOException
java.io.IOExceptionpublic void preCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void postCompletedCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void preDeleteTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void postDeleteTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void preDeleteTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void postCompletedDeleteTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void preTruncateTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void postTruncateTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void preTruncateTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void postCompletedTruncateTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void preModifyTable(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void postModifyTable(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void preModifyTableAction(TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void postCompletedModifyTableAction(TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void preEnableTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void postEnableTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void preEnableTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void postCompletedEnableTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void preDisableTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void postDisableTable(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void preDisableTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void postCompletedDisableTableAction(TableName tableName,
User user)
throws java.io.IOException
java.io.IOExceptionpublic void preAbortProcedure(<any> procEnv,
long procId)
throws java.io.IOException
java.io.IOExceptionpublic void postAbortProcedure()
throws java.io.IOException
java.io.IOExceptionpublic void preGetProcedures()
throws java.io.IOException
java.io.IOExceptionpublic void postGetProcedures(java.util.List<<any>> procInfoList)
throws java.io.IOException
java.io.IOExceptionpublic void preGetLocks()
throws java.io.IOException
java.io.IOExceptionpublic void postGetLocks(java.util.List<LockedResource> lockedResources)
throws java.io.IOException
java.io.IOExceptionpublic void preMove(RegionInfo region,
ServerName srcServer,
ServerName destServer)
throws java.io.IOException
java.io.IOExceptionpublic void postMove(RegionInfo region,
ServerName srcServer,
ServerName destServer)
throws java.io.IOException
java.io.IOExceptionpublic void preAssign(RegionInfo regionInfo)
throws java.io.IOException
java.io.IOExceptionpublic void postAssign(RegionInfo regionInfo)
throws java.io.IOException
java.io.IOExceptionpublic void preUnassign(RegionInfo regionInfo,
boolean force)
throws java.io.IOException
java.io.IOExceptionpublic void postUnassign(RegionInfo regionInfo,
boolean force)
throws java.io.IOException
java.io.IOExceptionpublic void preRegionOffline(RegionInfo regionInfo)
throws java.io.IOException
java.io.IOExceptionpublic void postRegionOffline(RegionInfo regionInfo)
throws java.io.IOException
java.io.IOExceptionpublic void preMergeRegions(RegionInfo[] regionsToMerge)
throws java.io.IOException
java.io.IOExceptionpublic void postMergeRegions(RegionInfo[] regionsToMerge)
throws java.io.IOException
java.io.IOExceptionpublic boolean preBalance()
throws java.io.IOException
java.io.IOExceptionpublic void postBalance(java.util.List<RegionPlan> plans) throws java.io.IOException
java.io.IOExceptionpublic void preSetSplitOrMergeEnabled(boolean newValue,
MasterSwitchType switchType)
throws java.io.IOException
java.io.IOExceptionpublic void postSetSplitOrMergeEnabled(boolean newValue,
MasterSwitchType switchType)
throws java.io.IOException
java.io.IOExceptionpublic void preSplitRegion(TableName tableName,
byte[] splitRow)
throws java.io.IOException
tableName - the table where the region belongs tosplitRow - the split pointjava.io.IOExceptionpublic void preSplitRegionAction(TableName tableName,
byte[] splitRow,
User user)
throws java.io.IOException
tableName - the table where the region belongs tosplitRow - the split pointuser - the userjava.io.IOExceptionpublic void postCompletedSplitRegionAction(RegionInfo regionInfoA,
RegionInfo regionInfoB,
User user)
throws java.io.IOException
regionInfoA - the new left-hand daughter regionregionInfoB - the new right-hand daughter regionuser - the userjava.io.IOExceptionpublic void preSplitBeforeMETAAction(byte[] splitKey,
java.util.List<Mutation> metaEntries,
User user)
throws java.io.IOException
splitKey - metaEntries - user - the userjava.io.IOExceptionpublic void preSplitAfterMETAAction(User user)
throws java.io.IOException
user - the userjava.io.IOExceptionpublic void postRollBackSplitRegionAction(User user)
throws java.io.IOException
user - the userjava.io.IOExceptionpublic void preMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
throws java.io.IOException
regionsToMerge - the regions to mergeuser - the userjava.io.IOExceptionpublic void postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
throws java.io.IOException
regionsToMerge - the regions to mergemergedRegion - the new merged regionuser - the userjava.io.IOExceptionpublic void preMergeRegionsCommit(RegionInfo[] regionsToMerge,
java.util.List<Mutation> metaEntries,
User user)
throws java.io.IOException
regionsToMerge - the regions to mergemetaEntries - the meta entryuser - the userjava.io.IOExceptionpublic void postMergeRegionsCommit(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
throws java.io.IOException
regionsToMerge - the regions to mergemergedRegion - the new merged regionuser - the userjava.io.IOExceptionpublic void postRollBackMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
throws java.io.IOException
regionsToMerge - the regions to mergeuser - the userjava.io.IOExceptionpublic void preBalanceSwitch(boolean b)
throws java.io.IOException
java.io.IOExceptionpublic void postBalanceSwitch(boolean oldValue,
boolean newValue)
throws java.io.IOException
java.io.IOExceptionpublic void preShutdown()
throws java.io.IOException
java.io.IOExceptionpublic void preStopMaster()
throws java.io.IOException
java.io.IOExceptionpublic void preMasterInitialization()
throws java.io.IOException
java.io.IOExceptionpublic void postStartMaster()
throws java.io.IOException
java.io.IOExceptionpublic void preSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void postSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void preListSnapshot(SnapshotDescription snapshot)
throws java.io.IOException
java.io.IOExceptionpublic void postListSnapshot(SnapshotDescription snapshot)
throws java.io.IOException
java.io.IOExceptionpublic void preCloneSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void postCloneSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void preRestoreSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void postRestoreSnapshot(SnapshotDescription snapshot,
TableDescriptor hTableDescriptor)
throws java.io.IOException
java.io.IOExceptionpublic void preDeleteSnapshot(SnapshotDescription snapshot)
throws java.io.IOException
java.io.IOExceptionpublic void postDeleteSnapshot(SnapshotDescription snapshot)
throws java.io.IOException
java.io.IOExceptionpublic void preGetTableDescriptors(java.util.List<TableName> tableNamesList,
java.util.List<TableDescriptor> descriptors,
java.lang.String regex)
throws java.io.IOException
java.io.IOExceptionpublic void postGetTableDescriptors(java.util.List<TableName> tableNamesList,
java.util.List<TableDescriptor> descriptors,
java.lang.String regex)
throws java.io.IOException
java.io.IOExceptionpublic void preGetTableNames(java.util.List<TableDescriptor> descriptors,
java.lang.String regex)
throws java.io.IOException
java.io.IOExceptionpublic void postGetTableNames(java.util.List<TableDescriptor> descriptors,
java.lang.String regex)
throws java.io.IOException
java.io.IOExceptionpublic void preTableFlush(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void postTableFlush(TableName tableName)
throws java.io.IOException
java.io.IOExceptionpublic void preSetUserQuota(java.lang.String user,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void postSetUserQuota(java.lang.String user,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void preSetUserQuota(java.lang.String user,
TableName table,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void postSetUserQuota(java.lang.String user,
TableName table,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void preSetUserQuota(java.lang.String user,
java.lang.String namespace,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void postSetUserQuota(java.lang.String user,
java.lang.String namespace,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void preSetTableQuota(TableName table,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void postSetTableQuota(TableName table,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void preSetNamespaceQuota(java.lang.String namespace,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void postSetNamespaceQuota(java.lang.String namespace,
GlobalQuotaSettings quotas)
throws java.io.IOException
java.io.IOExceptionpublic void preMoveServersAndTables(java.util.Set<Address> servers,
java.util.Set<TableName> tables,
java.lang.String targetGroup)
throws java.io.IOException
java.io.IOExceptionpublic void postMoveServersAndTables(java.util.Set<Address> servers,
java.util.Set<TableName> tables,
java.lang.String targetGroup)
throws java.io.IOException
java.io.IOExceptionpublic void preMoveServers(java.util.Set<Address> servers,
java.lang.String targetGroup)
throws java.io.IOException
java.io.IOExceptionpublic void postMoveServers(java.util.Set<Address> servers,
java.lang.String targetGroup)
throws java.io.IOException
java.io.IOExceptionpublic void preMoveTables(java.util.Set<TableName> tables,
java.lang.String targetGroup)
throws java.io.IOException
java.io.IOExceptionpublic void postMoveTables(java.util.Set<TableName> tables,
java.lang.String targetGroup)
throws java.io.IOException
java.io.IOExceptionpublic void preAddRSGroup(java.lang.String name)
throws java.io.IOException
java.io.IOExceptionpublic void postAddRSGroup(java.lang.String name)
throws java.io.IOException
java.io.IOExceptionpublic void preRemoveRSGroup(java.lang.String name)
throws java.io.IOException
java.io.IOExceptionpublic void postRemoveRSGroup(java.lang.String name)
throws java.io.IOException
java.io.IOExceptionpublic void preBalanceRSGroup(java.lang.String name)
throws java.io.IOException
java.io.IOExceptionpublic void postBalanceRSGroup(java.lang.String name,
boolean balanceRan)
throws java.io.IOException
java.io.IOExceptionpublic void preRemoveServers(java.util.Set<Address> servers)
throws java.io.IOException
java.io.IOExceptionpublic void postRemoveServers(java.util.Set<Address> servers)
throws java.io.IOException
java.io.IOExceptionpublic void preAddReplicationPeer(java.lang.String peerId,
ReplicationPeerConfig peerConfig)
throws java.io.IOException
java.io.IOExceptionpublic void postAddReplicationPeer(java.lang.String peerId,
ReplicationPeerConfig peerConfig)
throws java.io.IOException
java.io.IOExceptionpublic void preRemoveReplicationPeer(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void postRemoveReplicationPeer(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void preEnableReplicationPeer(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void postEnableReplicationPeer(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void preDisableReplicationPeer(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void postDisableReplicationPeer(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void preGetReplicationPeerConfig(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void postGetReplicationPeerConfig(java.lang.String peerId)
throws java.io.IOException
java.io.IOExceptionpublic void preUpdateReplicationPeerConfig(java.lang.String peerId,
ReplicationPeerConfig peerConfig)
throws java.io.IOException
java.io.IOExceptionpublic void postUpdateReplicationPeerConfig(java.lang.String peerId,
ReplicationPeerConfig peerConfig)
throws java.io.IOException
java.io.IOExceptionpublic void preListReplicationPeers(java.lang.String regex)
throws java.io.IOException
java.io.IOExceptionpublic void postListReplicationPeers(java.lang.String regex)
throws java.io.IOException
java.io.IOExceptionpublic void preRequestLock(java.lang.String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
java.lang.String description)
throws java.io.IOException
java.io.IOExceptionpublic void postRequestLock(java.lang.String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
java.lang.String description)
throws java.io.IOException
java.io.IOExceptionpublic void preLockHeartbeat(LockProcedure proc, boolean keepAlive) throws java.io.IOException
java.io.IOExceptionpublic void postLockHeartbeat(LockProcedure proc, boolean keepAlive) throws java.io.IOException
java.io.IOExceptionpublic void preGetClusterMetrics()
throws java.io.IOException
java.io.IOExceptionpublic void postGetClusterMetrics(ClusterMetrics status)
throws java.io.IOException
java.io.IOExceptionpublic void preClearDeadServers()
throws java.io.IOException
java.io.IOExceptionpublic void postClearDeadServers(java.util.List<ServerName> servers,
java.util.List<ServerName> notClearedServers)
throws java.io.IOException
java.io.IOExceptionpublic void preDecommissionRegionServers(java.util.List<ServerName> servers,
boolean offload)
throws java.io.IOException
java.io.IOExceptionpublic void postDecommissionRegionServers(java.util.List<ServerName> servers,
boolean offload)
throws java.io.IOException
java.io.IOExceptionpublic void preListDecommissionedRegionServers()
throws java.io.IOException
java.io.IOExceptionpublic void postListDecommissionedRegionServers()
throws java.io.IOException
java.io.IOExceptionpublic void preRecommissionRegionServer(ServerName server,
java.util.List<byte[]> encodedRegionNames)
throws java.io.IOException
java.io.IOExceptionpublic void postRecommissionRegionServer(ServerName server,
java.util.List<byte[]> encodedRegionNames)
throws java.io.IOException
java.io.IOException