@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, findCoprocessors, getCoprocessors, getLoadedCoprocessors, handleCoprocessorThrowable, legacyWarning, 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(HTableDescriptor htd, HRegionInfo[] regions) throws IOException
IOException
public void postCreateTable(HTableDescriptor htd, HRegionInfo[] regions) throws IOException
IOException
public void preCreateTableHandler(HTableDescriptor htd, HRegionInfo[] regions) throws IOException
IOException
public void postCreateTableHandler(HTableDescriptor htd, HRegionInfo[] regions) throws IOException
IOException
public void preDeleteTable(TableName tableName) throws IOException
IOException
public void postDeleteTable(TableName tableName) throws IOException
IOException
public void preDeleteTableHandler(TableName tableName) throws IOException
IOException
public void postDeleteTableHandler(TableName tableName) throws IOException
IOException
public void preTruncateTable(TableName tableName) throws IOException
IOException
public void postTruncateTable(TableName tableName) throws IOException
IOException
public void preTruncateTableHandler(TableName tableName) throws IOException
IOException
public void postTruncateTableHandler(TableName tableName) throws IOException
IOException
public void preModifyTable(TableName tableName, HTableDescriptor htd) throws IOException
IOException
public void postModifyTable(TableName tableName, HTableDescriptor htd) throws IOException
IOException
public void preModifyTableHandler(TableName tableName, HTableDescriptor htd) throws IOException
IOException
public void postModifyTableHandler(TableName tableName, HTableDescriptor htd) throws IOException
IOException
public boolean preAddColumn(TableName tableName, HColumnDescriptor column) throws IOException
IOException
public void postAddColumn(TableName tableName, HColumnDescriptor column) throws IOException
IOException
public boolean preAddColumnHandler(TableName tableName, HColumnDescriptor column) throws IOException
IOException
public void postAddColumnHandler(TableName tableName, HColumnDescriptor column) throws IOException
IOException
public boolean preModifyColumn(TableName tableName, HColumnDescriptor descriptor) throws IOException
IOException
public void postModifyColumn(TableName tableName, HColumnDescriptor descriptor) throws IOException
IOException
public boolean preModifyColumnHandler(TableName tableName, HColumnDescriptor descriptor) throws IOException
IOException
public void postModifyColumnHandler(TableName tableName, HColumnDescriptor descriptor) throws IOException
IOException
public boolean preDeleteColumn(TableName tableName, byte[] c) throws IOException
IOException
public void postDeleteColumn(TableName tableName, byte[] c) throws IOException
IOException
public boolean preDeleteColumnHandler(TableName tableName, byte[] c) throws IOException
IOException
public void postDeleteColumnHandler(TableName tableName, byte[] c) throws IOException
IOException
public void preEnableTable(TableName tableName) throws IOException
IOException
public void postEnableTable(TableName tableName) throws IOException
IOException
public void preEnableTableHandler(TableName tableName) throws IOException
IOException
public void postEnableTableHandler(TableName tableName) throws IOException
IOException
public void preDisableTable(TableName tableName) throws IOException
IOException
public void postDisableTable(TableName tableName) throws IOException
IOException
public void preDisableTableHandler(TableName tableName) throws IOException
IOException
public void postDisableTableHandler(TableName tableName) throws IOException
IOException
public boolean preAbortProcedure(ProcedureExecutor<MasterProcedureEnv> procEnv, long procId) throws IOException
IOException
public void postAbortProcedure() throws IOException
IOException
public boolean preListProcedures() throws IOException
IOException
public void postListProcedures(List<ProcedureInfo> procInfoList) 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 boolean preBalance() throws IOException
IOException
public void postBalance(List<RegionPlan> plans) throws IOException
IOException
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(HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws IOException
IOException
public void postSnapshot(HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws IOException
IOException
public void preListSnapshot(HBaseProtos.SnapshotDescription snapshot) throws IOException
IOException
public void postListSnapshot(HBaseProtos.SnapshotDescription snapshot) throws IOException
IOException
public void preCloneSnapshot(HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws IOException
IOException
public void postCloneSnapshot(HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws IOException
IOException
public void preRestoreSnapshot(HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws IOException
IOException
public void postRestoreSnapshot(HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws IOException
IOException
public void preDeleteSnapshot(HBaseProtos.SnapshotDescription snapshot) throws IOException
IOException
public void postDeleteSnapshot(HBaseProtos.SnapshotDescription snapshot) throws IOException
IOException
@Deprecated public boolean preGetTableDescriptors(List<TableName> tableNamesList, List<HTableDescriptor> descriptors) throws IOException
IOException
@Deprecated public void postGetTableDescriptors(List<HTableDescriptor> descriptors) throws IOException
IOException
public boolean preGetTableDescriptors(List<TableName> tableNamesList, List<HTableDescriptor> descriptors, String regex) throws IOException
IOException
public void postGetTableDescriptors(List<TableName> tableNamesList, List<HTableDescriptor> descriptors, String regex) throws IOException
IOException
public boolean preGetTableNames(List<HTableDescriptor> descriptors, String regex) throws IOException
IOException
public void postGetTableNames(List<HTableDescriptor> 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, QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetUserQuota(String user, QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetUserQuota(String user, TableName table, QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetUserQuota(String user, TableName table, QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetUserQuota(String user, String namespace, QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetUserQuota(String user, String namespace, QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetTableQuota(TableName table, QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetTableQuota(TableName table, QuotaProtos.Quotas quotas) throws IOException
IOException
public void preSetNamespaceQuota(String namespace, QuotaProtos.Quotas quotas) throws IOException
IOException
public void postSetNamespaceQuota(String namespace, QuotaProtos.Quotas quotas) throws IOException
IOException
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.