@InterfaceAudience.Private public class MasterCoprocessorHost extends CoprocessorHost<org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment>
HMaster
interacts with the loaded coprocessors
through this class.CoprocessorHost.Environment
ABORT_ON_ERROR_KEY, abortable, conf, coprocessors, COPROCESSORS_ENABLED_CONF_KEY, DEFAULT_ABORT_ON_ERROR, DEFAULT_COPROCESSORS_ENABLED, DEFAULT_USER_COPROCESSORS_ENABLED, loadSequence, MASTER_COPROCESSOR_CONF_KEY, pathPrefix, REGION_COPROCESSOR_CONF_KEY, REGIONSERVER_COPROCESSOR_CONF_KEY, USER_COPROCESSORS_ENABLED_CONF_KEY, USER_REGION_COPROCESSOR_CONF_KEY, WAL_COPROCESSOR_CONF_KEY
Constructor and Description |
---|
MasterCoprocessorHost(MasterServices services,
org.apache.hadoop.conf.Configuration conf) |
abortServer, abortServer, findCoprocessor, findCoprocessorEnvironment, findCoprocessorEnvironment, findCoprocessors, getCoprocessors, getLoadedCoprocessors, handleCoprocessorThrowable, legacyWarning, load, load, load, loadInstance, loadSystemCoprocessors, shutdown, useLegacyMethod
public MasterCoprocessorHost(MasterServices services, org.apache.hadoop.conf.Configuration conf)
public org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment createEnvironment(Class<?> implClass, Coprocessor instance, int priority, int seq, org.apache.hadoop.conf.Configuration conf)
CoprocessorHost
createEnvironment
in class CoprocessorHost<org.apache.hadoop.hbase.master.MasterCoprocessorHost.MasterEnvironment>
public boolean preCreateNamespace(NamespaceDescriptor ns) throws IOException
IOException
public void postCreateNamespace(NamespaceDescriptor ns) throws IOException
IOException
public boolean preDeleteNamespace(String namespaceName) throws IOException
IOException
public void postDeleteNamespace(String namespaceName) throws IOException
IOException
public boolean preModifyNamespace(NamespaceDescriptor ns) throws IOException
IOException
public void postModifyNamespace(NamespaceDescriptor ns) throws IOException
IOException
public void preGetNamespaceDescriptor(String namespaceName) throws IOException
IOException
public void postGetNamespaceDescriptor(NamespaceDescriptor ns) throws IOException
IOException
public boolean preListNamespaceDescriptors(List<NamespaceDescriptor> descriptors) throws IOException
IOException
public void postListNamespaceDescriptors(List<NamespaceDescriptor> descriptors) throws IOException
IOException
public void preCreateTable(TableDescriptor htd, HRegionInfo[] regions) throws IOException
IOException
public void postCreateTable(TableDescriptor htd, HRegionInfo[] regions) throws IOException
IOException
public void preCreateTableAction(TableDescriptor htd, HRegionInfo[] regions, User user) throws IOException
IOException
public void postCompletedCreateTableAction(TableDescriptor htd, HRegionInfo[] regions, User user) throws IOException
IOException
public void preDeleteTable(TableName tableName) throws IOException
IOException
public void postDeleteTable(TableName tableName) throws IOException
IOException
public void preDeleteTableAction(TableName tableName, User user) throws IOException
IOException
public void postCompletedDeleteTableAction(TableName tableName, User user) throws IOException
IOException
public void preTruncateTable(TableName tableName) throws IOException
IOException
public void postTruncateTable(TableName tableName) throws IOException
IOException
public void preTruncateTableAction(TableName tableName, User user) throws IOException
IOException
public void postCompletedTruncateTableAction(TableName tableName, User user) throws IOException
IOException
public void preModifyTable(TableName tableName, TableDescriptor htd) throws IOException
IOException
public void postModifyTable(TableName tableName, TableDescriptor htd) throws IOException
IOException
public void preModifyTableAction(TableName tableName, TableDescriptor htd, User user) throws IOException
IOException
public void postCompletedModifyTableAction(TableName tableName, TableDescriptor htd, User user) throws IOException
IOException
public boolean preAddColumn(TableName tableName, ColumnFamilyDescriptor columnFamily) throws IOException
IOException
public void postAddColumn(TableName tableName, ColumnFamilyDescriptor columnFamily) throws IOException
IOException
public boolean preAddColumnFamilyAction(TableName tableName, ColumnFamilyDescriptor columnFamily, User user) throws IOException
IOException
public void postCompletedAddColumnFamilyAction(TableName tableName, ColumnFamilyDescriptor columnFamily, User user) throws IOException
IOException
public boolean preModifyColumn(TableName tableName, ColumnFamilyDescriptor columnFamily) throws IOException
IOException
public void postModifyColumn(TableName tableName, ColumnFamilyDescriptor columnFamily) throws IOException
IOException
public boolean preModifyColumnFamilyAction(TableName tableName, ColumnFamilyDescriptor columnFamily, User user) throws IOException
IOException
public void postCompletedModifyColumnFamilyAction(TableName tableName, ColumnFamilyDescriptor columnFamily, User user) throws IOException
IOException
public boolean preDeleteColumn(TableName tableName, byte[] columnFamily) throws IOException
IOException
public void postDeleteColumn(TableName tableName, byte[] columnFamily) throws IOException
IOException
public boolean preDeleteColumnFamilyAction(TableName tableName, byte[] columnFamily, User user) throws IOException
IOException
public void postCompletedDeleteColumnFamilyAction(TableName tableName, byte[] columnFamily, User user) throws IOException
IOException
public void preEnableTable(TableName tableName) throws IOException
IOException
public void postEnableTable(TableName tableName) throws IOException
IOException
public void preEnableTableAction(TableName tableName, User user) throws IOException
IOException
public void postCompletedEnableTableAction(TableName tableName, User user) throws IOException
IOException
public void preDisableTable(TableName tableName) throws IOException
IOException
public void postDisableTable(TableName tableName) throws IOException
IOException
public void preDisableTableAction(TableName tableName, User user) throws IOException
IOException
public void postCompletedDisableTableAction(TableName tableName, User user) throws IOException
IOException
public boolean preAbortProcedure(ProcedureExecutor<MasterProcedureEnv> procEnv, long procId) throws IOException
IOException
public void postAbortProcedure() throws IOException
IOException
public boolean preGetProcedures() throws IOException
IOException
public void postGetProcedures(List<Procedure<?>> procInfoList) throws IOException
IOException
public boolean preGetLocks() throws IOException
IOException
public void postGetLocks(List<LockedResource> lockedResources) throws IOException
IOException
public boolean preMove(HRegionInfo region, ServerName srcServer, ServerName destServer) throws IOException
IOException
public void postMove(HRegionInfo region, ServerName srcServer, ServerName destServer) throws IOException
IOException
public boolean preAssign(HRegionInfo regionInfo) throws IOException
IOException
public void postAssign(HRegionInfo regionInfo) throws IOException
IOException
public boolean preUnassign(HRegionInfo regionInfo, boolean force) throws IOException
IOException
public void postUnassign(HRegionInfo regionInfo, boolean force) throws IOException
IOException
public void preRegionOffline(HRegionInfo regionInfo) throws IOException
IOException
public void postRegionOffline(HRegionInfo regionInfo) throws IOException
IOException
public void preMergeRegions(HRegionInfo[] regionsToMerge) throws IOException
IOException
public void postMergeRegions(HRegionInfo[] regionsToMerge) throws IOException
IOException
public boolean preBalance() throws IOException
IOException
public void postBalance(List<RegionPlan> plans) throws IOException
IOException
public boolean preSetSplitOrMergeEnabled(boolean newValue, MasterSwitchType switchType) throws IOException
IOException
public void postSetSplitOrMergeEnabled(boolean newValue, MasterSwitchType switchType) throws IOException
IOException
public void preSplitRegion(TableName tableName, byte[] splitRow) throws IOException
tableName
- the table where the region belongs tosplitRow
- the split pointIOException
public void preSplitRegionAction(TableName tableName, byte[] splitRow, User user) throws IOException
tableName
- the table where the region belongs tosplitRow
- the split pointuser
- the userIOException
public void postCompletedSplitRegionAction(HRegionInfo regionInfoA, HRegionInfo regionInfoB, User user) throws IOException
regionInfoA
- the new left-hand daughter regionregionInfoB
- the new right-hand daughter regionuser
- the userIOException
public boolean preSplitBeforePONRAction(byte[] splitKey, List<Mutation> metaEntries, User user) throws IOException
splitKey
- metaEntries
- user
- the userIOException
public void preSplitAfterPONRAction(User user) throws IOException
user
- the userIOException
public void postRollBackSplitRegionAction(User user) throws IOException
user
- the userIOException
public boolean preMergeRegionsAction(HRegionInfo[] regionsToMerge, User user) throws IOException
regionsToMerge
- the regions to mergeuser
- the userIOException
public void postCompletedMergeRegionsAction(HRegionInfo[] regionsToMerge, HRegionInfo mergedRegion, User user) throws IOException
regionsToMerge
- the regions to mergemergedRegion
- the new merged regionuser
- the userIOException
public boolean preMergeRegionsCommit(HRegionInfo[] regionsToMerge, @MetaMutationAnnotation List<Mutation> metaEntries, User user) throws IOException
regionsToMerge
- the regions to mergemetaEntries
- the meta entryuser
- the userIOException
public void postMergeRegionsCommit(HRegionInfo[] regionsToMerge, HRegionInfo mergedRegion, User user) throws IOException
regionsToMerge
- the regions to mergemergedRegion
- the new merged regionuser
- the userIOException
public void postRollBackMergeRegionsAction(HRegionInfo[] regionsToMerge, User user) throws IOException
regionsToMerge
- the regions to mergeuser
- the userIOException
public boolean preBalanceSwitch(boolean b) throws IOException
IOException
public void postBalanceSwitch(boolean oldValue, boolean newValue) throws IOException
IOException
public void preShutdown() throws IOException
IOException
public void preStopMaster() throws IOException
IOException
public void preMasterInitialization() throws IOException
IOException
public void postStartMaster() throws IOException
IOException
public void preSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException
IOException
public void postSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException
IOException
public void preListSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) throws IOException
IOException
public void postListSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) throws IOException
IOException
public void preCloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException
IOException
public void postCloneSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException
IOException
public void preRestoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException
IOException
public void postRestoreSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, TableDescriptor hTableDescriptor) throws IOException
IOException
public void preDeleteSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) throws IOException
IOException
public void postDeleteSnapshot(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) throws IOException
IOException
public boolean preGetTableDescriptors(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) throws IOException
IOException
public void postGetTableDescriptors(List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) throws IOException
IOException
public boolean preGetTableNames(List<TableDescriptor> descriptors, String regex) throws IOException
IOException
public void postGetTableNames(List<TableDescriptor> descriptors, String regex) throws IOException
IOException
public void preTableFlush(TableName tableName) throws IOException
IOException
public void postTableFlush(TableName tableName) throws IOException
IOException
public void preSetUserQuota(String user, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetUserQuota(String user, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetUserQuota(String user, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetUserQuota(String user, TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetUserQuota(String user, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetUserQuota(String user, String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetTableQuota(TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetTableQuota(TableName table, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetNamespaceQuota(String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetNamespaceQuota(String namespace, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.Quotas quotas) throws IOException
IOException
public void preMoveServersAndTables(Set<Address> servers, Set<TableName> tables, String targetGroup) throws IOException
IOException
public void postMoveServersAndTables(Set<Address> servers, Set<TableName> tables, String targetGroup) throws IOException
IOException
public void preMoveServers(Set<Address> servers, String targetGroup) throws IOException
IOException
public void postMoveServers(Set<Address> servers, String targetGroup) throws IOException
IOException
public void preMoveTables(Set<TableName> tables, String targetGroup) throws IOException
IOException
public void postMoveTables(Set<TableName> tables, String targetGroup) throws IOException
IOException
public void preAddRSGroup(String name) throws IOException
IOException
public void postAddRSGroup(String name) throws IOException
IOException
public void preRemoveRSGroup(String name) throws IOException
IOException
public void postRemoveRSGroup(String name) throws IOException
IOException
public void preBalanceRSGroup(String name) throws IOException
IOException
public void postBalanceRSGroup(String name, boolean balanceRan) throws IOException
IOException
public void preAddReplicationPeer(String peerId, ReplicationPeerConfig peerConfig) throws IOException
IOException
public void postAddReplicationPeer(String peerId, ReplicationPeerConfig peerConfig) throws IOException
IOException
public void preRemoveReplicationPeer(String peerId) throws IOException
IOException
public void postRemoveReplicationPeer(String peerId) throws IOException
IOException
public void preEnableReplicationPeer(String peerId) throws IOException
IOException
public void postEnableReplicationPeer(String peerId) throws IOException
IOException
public void preDisableReplicationPeer(String peerId) throws IOException
IOException
public void postDisableReplicationPeer(String peerId) throws IOException
IOException
public void preGetReplicationPeerConfig(String peerId) throws IOException
IOException
public void postGetReplicationPeerConfig(String peerId) throws IOException
IOException
public void preUpdateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig) throws IOException
IOException
public void postUpdateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig) throws IOException
IOException
public void preListReplicationPeers(String regex) throws IOException
IOException
public void postListReplicationPeers(String regex) throws IOException
IOException
public void preRequestLock(String namespace, TableName tableName, HRegionInfo[] regionInfos, LockType type, String description) throws IOException
IOException
public void postRequestLock(String namespace, TableName tableName, HRegionInfo[] regionInfos, LockType type, String description) throws IOException
IOException
public void preLockHeartbeat(LockProcedure proc, boolean keepAlive) throws IOException
IOException
public void postLockHeartbeat(LockProcedure proc, boolean keepAlive) throws IOException
IOException
public void preListDeadServers() throws IOException
IOException
public void postListDeadServers() throws IOException
IOException
public void preClearDeadServers() throws IOException
IOException
public void postClearDeadServers() throws IOException
IOException
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.