public class RSGroupAdminEndpoint extends RSGroupAdminProtos.RSGroupAdminService implements CoprocessorService, Coprocessor, MasterObserver
RSGroupAdminProtos.RSGroupAdminService.BlockingInterface, RSGroupAdminProtos.RSGroupAdminService.Interface, RSGroupAdminProtos.RSGroupAdminService.StubCoprocessor.StatePRIORITY_HIGHEST, PRIORITY_LOWEST, PRIORITY_SYSTEM, PRIORITY_USER, VERSION| Constructor and Description |
|---|
RSGroupAdminEndpoint() |
| Modifier and Type | Method and Description |
|---|---|
void |
addRSGroup(RpcController controller,
RSGroupAdminProtos.AddRSGroupRequest request,
<any> done)
rpc AddRSGroup(.hbase.pb.AddRSGroupRequest) returns (.hbase.pb.AddRSGroupResponse); |
void |
balanceRSGroup(RpcController controller,
RSGroupAdminProtos.BalanceRSGroupRequest request,
<any> done)
rpc BalanceRSGroup(.hbase.pb.BalanceRSGroupRequest) returns (.hbase.pb.BalanceRSGroupResponse); |
RSGroupInfoManager |
getGroupInfoManager() |
void |
getRSGroupInfo(RpcController controller,
RSGroupAdminProtos.GetRSGroupInfoRequest request,
<any> done)
rpc GetRSGroupInfo(.hbase.pb.GetRSGroupInfoRequest) returns (.hbase.pb.GetRSGroupInfoResponse); |
void |
getRSGroupInfoOfServer(RpcController controller,
RSGroupAdminProtos.GetRSGroupInfoOfServerRequest request,
<any> done)
rpc GetRSGroupInfoOfServer(.hbase.pb.GetRSGroupInfoOfServerRequest) returns (.hbase.pb.GetRSGroupInfoOfServerResponse); |
void |
getRSGroupInfoOfTable(RpcController controller,
RSGroupAdminProtos.GetRSGroupInfoOfTableRequest request,
<any> done)
rpc GetRSGroupInfoOfTable(.hbase.pb.GetRSGroupInfoOfTableRequest) returns (.hbase.pb.GetRSGroupInfoOfTableResponse); |
Service |
getService() |
void |
listRSGroupInfos(RpcController controller,
RSGroupAdminProtos.ListRSGroupInfosRequest request,
<any> done)
rpc ListRSGroupInfos(.hbase.pb.ListRSGroupInfosRequest) returns (.hbase.pb.ListRSGroupInfosResponse); |
void |
moveServers(RpcController controller,
RSGroupAdminProtos.MoveServersRequest request,
<any> done)
rpc MoveServers(.hbase.pb.MoveServersRequest) returns (.hbase.pb.MoveServersResponse); |
void |
moveTables(RpcController controller,
RSGroupAdminProtos.MoveTablesRequest request,
<any> done)
rpc MoveTables(.hbase.pb.MoveTablesRequest) returns (.hbase.pb.MoveTablesResponse); |
void |
postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called after a abortProcedure request has been processed.
|
void |
postAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called after the new column family has been created.
|
void |
postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called after the new column family has been created.
|
void |
postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String name)
Called after a new region server group is added
|
void |
postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called after the region assignment has been requested.
|
void |
postBalance(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<RegionPlan> plans)
Called after the balancing plan has been submitted.
|
void |
postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String groupName,
boolean balancerRan)
Called after a region server group is removed
|
void |
postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean oldValue,
boolean newValue)
Called after the flag to enable/disable balancing has changed.
|
void |
postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor)
Called after a snapshot clone operation has been requested.
|
void |
postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called after the createNamespace operation has been requested.
|
void |
postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called after the createTable operation has been requested.
|
void |
postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called after the createTable operation has been requested.
|
void |
postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] columnFamily)
Called after the column family has been deleted.
|
void |
postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] columnFamily)
Called after the column family has been deleted.
|
void |
postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String namespace)
Called after the deleteNamespace operation has been requested.
|
void |
postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot)
Called after the delete snapshot operation has been requested.
|
void |
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the deleteTable operation has been requested.
|
void |
postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster deletes a
table. |
void |
postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
void |
postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
void |
postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
void |
postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
void |
postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called after a getNamespaceDescriptor request has been processed.
|
void |
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<HTableDescriptor> descriptors)
Called after a getTableDescriptors request has been processed.
|
void |
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<TableName> tableNamesList,
java.util.List<HTableDescriptor> descriptors,
java.lang.String regex)
Called after a getTableDescriptors request has been processed.
|
void |
postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<HTableDescriptor> descriptors,
java.lang.String regex)
Called after a getTableNames request has been processed.
|
void |
postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<NamespaceDescriptor> descriptors)
Called after a listNamespaceDescriptors request has been processed.
|
void |
postListProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<ProcedureInfo> procInfoList)
Called after a listProcedures request has been processed.
|
void |
postListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot)
Called after listSnapshots request has been processed.
|
void |
postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called after the column family has been updated.
|
void |
postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called after the column family has been updated.
|
void |
postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called after the modifyNamespace operation has been requested.
|
void |
postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HTableDescriptor htd)
Called after the modifyTable operation has been requested.
|
void |
postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HTableDescriptor htd)
Called after to modifying a table's properties.
|
void |
postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
Called after the region move has been requested.
|
void |
postMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.Set<HostAndPort> servers,
java.lang.String targetGroup)
Called after servers are moved to target region server group
|
void |
postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.Set<TableName> tables,
java.lang.String targetGroup)
Called after servers are moved to target region server group
|
void |
postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called after the region has been marked offline.
|
void |
postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String name)
Called after a region server group is removed
|
void |
postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor)
Called after a snapshot restore operation has been requested.
|
void |
postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String namespace,
QuotaProtos.Quotas quotas)
Called after the quota for the namespace is stored.
|
void |
postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
QuotaProtos.Quotas quotas)
Called after the quota for the table is stored.
|
void |
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String userName,
QuotaProtos.Quotas quotas)
Called after the quota for the user is stored.
|
void |
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String userName,
java.lang.String namespace,
QuotaProtos.Quotas quotas)
Called after the quota for the user on the specified namespace is stored.
|
void |
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String userName,
TableName tableName,
QuotaProtos.Quotas quotas)
Called after the quota for the user on the specified table is stored.
|
void |
postSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor)
Called after the snapshot operation has been requested.
|
void |
postStartMaster(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called immediately after an active master instance has completed
initialization.
|
void |
postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the table memstore is flushed to disk.
|
void |
postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the truncateTable operation has been requested.
|
void |
postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster truncates a
table. |
void |
postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
Called after the region unassignment has been requested.
|
void |
preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx,
ProcedureExecutor<MasterProcedureEnv> procEnv,
long procId)
Called before a abortProcedure request has been processed.
|
void |
preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called prior to adding a new column family to the table.
|
void |
preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called prior to adding a new column family to the table.
|
void |
preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String name)
Called before a new region server group is added
|
void |
preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called prior to assigning a specific region.
|
void |
preBalance(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called prior to requesting rebalancing of the cluster regions, though after
the initial checks for regions in transition and the balance switch flag.
|
void |
preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String groupName)
Called before a region server group is removed
|
boolean |
preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean newValue)
Called prior to modifying the flag used to enable/disable region balancing.
|
void |
preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor)
Called before a snapshot is cloned.
|
void |
preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called before a new namespace is created by
HMaster. |
void |
preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called before a new table is created by
HMaster. |
void |
preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called before a new table is created by
HMaster. |
void |
preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] columnFamily)
Called prior to deleting the entire column family.
|
void |
preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] columnFamily)
Called prior to deleting the entire column family.
|
void |
preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String namespace)
Called before
HMaster deletes a
namespace
It can't bypass the default action, e.g., ctx.bypass() won't have effect. |
void |
preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot)
Called before a snapshot is deleted.
|
void |
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster deletes a
table. |
void |
preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster deletes a
table. |
void |
preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to disabling a table.
|
void |
preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to disabling a table.
|
void |
preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to enabling a table.
|
void |
preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to enabling a table.
|
void |
preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String namespace)
Called before a getNamespaceDescriptor request has been processed.
|
void |
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<TableName> tableNamesList,
java.util.List<HTableDescriptor> descriptors)
Called before a getTableDescriptors request has been processed.
|
void |
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<TableName> tableNamesList,
java.util.List<HTableDescriptor> descriptors,
java.lang.String regex)
Called before a getTableDescriptors request has been processed.
|
void |
preGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<HTableDescriptor> descriptors,
java.lang.String regex)
Called before a getTableNames request has been processed.
|
void |
preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.List<NamespaceDescriptor> descriptors)
Called before a listNamespaceDescriptors request has been processed.
|
void |
preListProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before a listProcedures request has been processed.
|
void |
preListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot)
Called before listSnapshots request has been processed.
|
void |
preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment> ctx)
Call before the master initialization is set to true.
|
void |
preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called prior to modifying a column family's attributes.
|
void |
preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HColumnDescriptor columnFamily)
Called prior to modifying a column family's attributes.
|
void |
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called prior to modifying a namespace's properties.
|
void |
preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HTableDescriptor htd)
Called prior to modifying a table's properties.
|
void |
preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
HTableDescriptor htd)
Called prior to modifying a table's properties.
|
void |
preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
Called prior to moving a given region from one region server to another.
|
void |
preMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.Set<HostAndPort> servers,
java.lang.String targetGroup)
Called before servers are moved to target region server group
|
void |
preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.util.Set<TableName> tables,
java.lang.String targetGroup)
Called before tables are moved to target region server group
|
void |
preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called prior to marking a given region as offline.
|
void |
preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String name)
Called before a region server group is removed
|
void |
preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor)
Called before a snapshot is restored.
|
void |
preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String namespace,
QuotaProtos.Quotas quotas)
Called before the quota for the namespace is stored.
|
void |
preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
QuotaProtos.Quotas quotas)
Called before the quota for the table is stored.
|
void |
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String userName,
QuotaProtos.Quotas quotas)
Called before the quota for the user is stored.
|
void |
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String userName,
java.lang.String namespace,
QuotaProtos.Quotas quotas)
Called before the quota for the user on the specified namespace is stored.
|
void |
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
java.lang.String userName,
TableName tableName,
QuotaProtos.Quotas quotas)
Called before the quota for the user on the specified table is stored.
|
void |
preShutdown(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called prior to shutting down the full HBase cluster, including this
HMaster process. |
void |
preSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor)
Called before a new snapshot is taken.
|
void |
preStopMaster(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called immediately prior to stopping this
HMaster process. |
void |
preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before the table memstore is flushed to disk.
|
void |
preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster truncates a
table. |
void |
preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster truncates a
table. |
void |
preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
Called prior to unassigning a given region.
|
void |
removeRSGroup(RpcController controller,
RSGroupAdminProtos.RemoveRSGroupRequest request,
<any> done)
rpc RemoveRSGroup(.hbase.pb.RemoveRSGroupRequest) returns (.hbase.pb.RemoveRSGroupResponse); |
void |
start(CoprocessorEnvironment env) |
void |
stop(CoprocessorEnvironment env) |
callMethod, getDescriptor, getDescriptorForType, getRequestPrototype, getResponsePrototype, newBlockingStub, newReflectiveBlockingService, newReflectiveService, newStubpublic void start(CoprocessorEnvironment env) throws java.io.IOException
start in interface Coprocessorjava.io.IOExceptionpublic void stop(CoprocessorEnvironment env) throws java.io.IOException
stop in interface Coprocessorjava.io.IOExceptionpublic Service getService()
getService in interface CoprocessorServicepublic RSGroupInfoManager getGroupInfoManager()
public void getRSGroupInfo(RpcController controller,
RSGroupAdminProtos.GetRSGroupInfoRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc GetRSGroupInfo(.hbase.pb.GetRSGroupInfoRequest) returns (.hbase.pb.GetRSGroupInfoResponse);getRSGroupInfo in class RSGroupAdminProtos.RSGroupAdminServicepublic void getRSGroupInfoOfTable(RpcController controller,
RSGroupAdminProtos.GetRSGroupInfoOfTableRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc GetRSGroupInfoOfTable(.hbase.pb.GetRSGroupInfoOfTableRequest) returns (.hbase.pb.GetRSGroupInfoOfTableResponse);getRSGroupInfoOfTable in class RSGroupAdminProtos.RSGroupAdminServicepublic void moveServers(RpcController controller,
RSGroupAdminProtos.MoveServersRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc MoveServers(.hbase.pb.MoveServersRequest) returns (.hbase.pb.MoveServersResponse);moveServers in class RSGroupAdminProtos.RSGroupAdminServicepublic void moveTables(RpcController controller,
RSGroupAdminProtos.MoveTablesRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc MoveTables(.hbase.pb.MoveTablesRequest) returns (.hbase.pb.MoveTablesResponse);moveTables in class RSGroupAdminProtos.RSGroupAdminServicepublic void addRSGroup(RpcController controller,
RSGroupAdminProtos.AddRSGroupRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc AddRSGroup(.hbase.pb.AddRSGroupRequest) returns (.hbase.pb.AddRSGroupResponse);addRSGroup in class RSGroupAdminProtos.RSGroupAdminServicepublic void removeRSGroup(RpcController controller,
RSGroupAdminProtos.RemoveRSGroupRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc RemoveRSGroup(.hbase.pb.RemoveRSGroupRequest) returns (.hbase.pb.RemoveRSGroupResponse);removeRSGroup in class RSGroupAdminProtos.RSGroupAdminServicepublic void balanceRSGroup(RpcController controller,
RSGroupAdminProtos.BalanceRSGroupRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc BalanceRSGroup(.hbase.pb.BalanceRSGroupRequest) returns (.hbase.pb.BalanceRSGroupResponse);balanceRSGroup in class RSGroupAdminProtos.RSGroupAdminServicepublic void listRSGroupInfos(RpcController controller,
RSGroupAdminProtos.ListRSGroupInfosRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc ListRSGroupInfos(.hbase.pb.ListRSGroupInfosRequest) returns (.hbase.pb.ListRSGroupInfosResponse);listRSGroupInfos in class RSGroupAdminProtos.RSGroupAdminServicepublic void getRSGroupInfoOfServer(RpcController controller,
RSGroupAdminProtos.GetRSGroupInfoOfServerRequest request,
<any> done)
RSGroupAdminProtos.RSGroupAdminServicerpc GetRSGroupInfoOfServer(.hbase.pb.GetRSGroupInfoOfServerRequest) returns (.hbase.pb.GetRSGroupInfoOfServerResponse);getRSGroupInfoOfServer in class RSGroupAdminProtos.RSGroupAdminServicepublic void preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, HTableDescriptor desc, HRegionInfo[] regions) throws java.io.IOException
MasterObserverHMaster. Called as part of create
table RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preCreateTable in interface MasterObserverctx - the environment to interact with the framework and masterdesc - the HTableDescriptor for the tableregions - the initial regions created for the tablejava.io.IOExceptionpublic void postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpostDeleteTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws java.io.IOException
MasterObserverHMaster.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preCreateNamespace in interface MasterObserverctx - the environment to interact with the framework and masterns - the NamespaceDescriptor for the tablejava.io.IOExceptionpublic void preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws java.io.IOException
MasterObserverpreModifyNamespace in interface MasterObserverctx - the environment to interact with the framework and masterns - the NamespaceDescriptorjava.io.IOExceptionpublic void postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, HTableDescriptor desc, HRegionInfo[] regions) throws java.io.IOException
MasterObserverpostCreateTable in interface MasterObserverctx - the environment to interact with the framework and masterdesc - the HTableDescriptor for the tableregions - the initial regions created for the tablejava.io.IOExceptionpublic void preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, HTableDescriptor desc, HRegionInfo[] regions) throws java.io.IOException
MasterObserverHMaster. Called as part of create
table handler and it is async to the create RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preCreateTableHandler in interface MasterObserverctx - the environment to interact with the framework and masterdesc - the HTableDescriptor for the tableregions - the initial regions created for the tablejava.io.IOExceptionpublic void postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, HTableDescriptor desc, HRegionInfo[] regions) throws java.io.IOException
MasterObserverpostCreateTableHandler in interface MasterObserverctx - the environment to interact with the framework and masterdesc - the HTableDescriptor for the tableregions - the initial regions created for the tablejava.io.IOExceptionpublic void preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverHMaster deletes a
table. Called as part of delete table RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preDeleteTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverHMaster deletes a
table. Called as part of delete table handler and
it is async to the delete RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preDeleteTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postDeleteTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverHMaster deletes a
table. Called as part of delete table handler and it is async to the
delete RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.postDeleteTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverHMaster truncates a
table. Called as part of truncate table RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preTruncateTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpostTruncateTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverHMaster truncates a
table. Called as part of truncate table handler and it is sync
to the truncate RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preTruncateTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postTruncateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverHMaster truncates a
table. Called as part of truncate table handler and it is sync to the
truncate RPC call.
It can't bypass the default action, e.g., ctx.bypass() won't have effect.postTruncateTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd) throws java.io.IOException
MasterObserverpreModifyTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablehtd - the HTableDescriptorjava.io.IOExceptionpublic void postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd) throws java.io.IOException
MasterObserverpostModifyTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablehtd - the HTableDescriptorjava.io.IOExceptionpublic void preModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd) throws java.io.IOException
MasterObserverpreModifyTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablehtd - the HTableDescriptorjava.io.IOExceptionpublic void postModifyTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd) throws java.io.IOException
MasterObserverpostModifyTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablehtd - the HTableDescriptorjava.io.IOExceptionpublic void preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpreAddColumn in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void postAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpostAddColumn in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void preAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpreAddColumnHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void postAddColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpostAddColumnHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpreModifyColumn in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void postModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpostModifyColumn in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void preModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpreModifyColumnHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void postModifyColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor columnFamily) throws java.io.IOException
MasterObserverpostModifyColumnHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the HColumnDescriptorjava.io.IOExceptionpublic void preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] columnFamily) throws java.io.IOException
MasterObserverpreDeleteColumn in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the columnjava.io.IOExceptionpublic void postDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] columnFamily) throws java.io.IOException
MasterObserverpostDeleteColumn in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the columnjava.io.IOExceptionpublic void preDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] columnFamily) throws java.io.IOException
MasterObserverpreDeleteColumnHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the columnjava.io.IOExceptionpublic void postDeleteColumnHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] columnFamily) throws java.io.IOException
MasterObserverpostDeleteColumnHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumnFamily - the columnjava.io.IOExceptionpublic void preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpreEnableTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpostEnableTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpreEnableTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postEnableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpostEnableTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpreDisableTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpostDisableTable in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpreDisableTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postDisableTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpostDisableTableHandler in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preMove(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo region, ServerName srcServer, ServerName destServer) throws java.io.IOException
MasterObserverpreMove in interface MasterObserverctx - the environment to interact with the framework and masterregion - the HRegionInfosrcServer - the source ServerNamedestServer - the destination ServerNamejava.io.IOExceptionpublic void postMove(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo region, ServerName srcServer, ServerName destServer) throws java.io.IOException
MasterObserverpostMove in interface MasterObserverctx - the environment to interact with the framework and masterregion - the HRegionInfosrcServer - the source ServerNamedestServer - the destination ServerNamejava.io.IOExceptionpublic void preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo regionInfo) throws java.io.IOException
MasterObserverpreAssign in interface MasterObserverctx - the environment to interact with the framework and masterregionInfo - the regionInfo of the regionjava.io.IOExceptionpublic void postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo regionInfo) throws java.io.IOException
MasterObserverpostAssign in interface MasterObserverctx - the environment to interact with the framework and masterregionInfo - the regionInfo of the regionjava.io.IOExceptionpublic void preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo regionInfo, boolean force) throws java.io.IOException
MasterObserverpreUnassign in interface MasterObserverctx - the environment to interact with the framework and masterforce - whether to force unassignment or notjava.io.IOExceptionpublic void postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo regionInfo, boolean force) throws java.io.IOException
MasterObserverpostUnassign in interface MasterObserverctx - the environment to interact with the framework and masterforce - whether to force unassignment or notjava.io.IOExceptionpublic void preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo regionInfo) throws java.io.IOException
MasterObserverctx.bypass() will not have any
impact on this hook.preRegionOffline in interface MasterObserverctx - the environment to interact with the framework and masterjava.io.IOExceptionpublic void postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo regionInfo) throws java.io.IOException
MasterObserverpostRegionOffline in interface MasterObserverctx - the environment to interact with the framework and masterjava.io.IOExceptionpublic void preBalance(ObserverContext<MasterCoprocessorEnvironment> ctx) throws java.io.IOException
MasterObserverpreBalance in interface MasterObserverctx - the environment to interact with the framework and masterjava.io.IOExceptionpublic void postBalance(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<RegionPlan> plans) throws java.io.IOException
MasterObserverpostBalance in interface MasterObserverctx - the environment to interact with the framework and masterplans - the RegionPlans which master has executed. RegionPlan serves as hint
as for the final destination for the underlying region but may not represent the
final state of assignmentjava.io.IOExceptionpublic boolean preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean newValue) throws java.io.IOException
MasterObserverpreBalanceSwitch in interface MasterObserverctx - the coprocessor instance's environmentnewValue - the new flag value submitted in the calljava.io.IOExceptionpublic void postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean oldValue, boolean newValue) throws java.io.IOException
MasterObserverpostBalanceSwitch in interface MasterObserverctx - the coprocessor instance's environmentoldValue - the previously set balanceSwitch valuenewValue - the newly set balanceSwitch valuejava.io.IOExceptionpublic void preShutdown(ObserverContext<MasterCoprocessorEnvironment> ctx) throws java.io.IOException
MasterObserverHMaster process.preShutdown in interface MasterObserverjava.io.IOExceptionpublic void preStopMaster(ObserverContext<MasterCoprocessorEnvironment> ctx) throws java.io.IOException
MasterObserverHMaster process.preStopMaster in interface MasterObserverjava.io.IOExceptionpublic void postStartMaster(ObserverContext<MasterCoprocessorEnvironment> ctx) throws java.io.IOException
MasterObserverpostStartMaster in interface MasterObserverjava.io.IOExceptionpublic void preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment> ctx) throws java.io.IOException
MasterObserverHMaster process.preMasterInitialization in interface MasterObserverjava.io.IOExceptionpublic void preSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws java.io.IOException
MasterObserverpreSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor for the snapshothTableDescriptor - the hTableDescriptor of the table to snapshotjava.io.IOExceptionpublic void postSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws java.io.IOException
MasterObserverpostSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor for the snapshothTableDescriptor - the hTableDescriptor of the table to snapshotjava.io.IOExceptionpublic void preListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot) throws java.io.IOException
MasterObserverpreListSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor of the snapshot to listjava.io.IOExceptionpublic void postListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot) throws java.io.IOException
MasterObserverpostListSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor of the snapshot to listjava.io.IOExceptionpublic void preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws java.io.IOException
MasterObserverpreCloneSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor for the snapshothTableDescriptor - the hTableDescriptor of the table to createjava.io.IOExceptionpublic void postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws java.io.IOException
MasterObserverpostCloneSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor for the snapshothTableDescriptor - the hTableDescriptor of the table to createjava.io.IOExceptionpublic void preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws java.io.IOException
MasterObserverpreRestoreSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor for the snapshothTableDescriptor - the hTableDescriptor of the table to restorejava.io.IOExceptionpublic void postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot, HTableDescriptor hTableDescriptor) throws java.io.IOException
MasterObserverpostRestoreSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor for the snapshothTableDescriptor - the hTableDescriptor of the table to restorejava.io.IOExceptionpublic void preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot) throws java.io.IOException
MasterObserverpreDeleteSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor of the snapshot to deletejava.io.IOExceptionpublic void postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, HBaseProtos.SnapshotDescription snapshot) throws java.io.IOException
MasterObserverpostDeleteSnapshot in interface MasterObserverctx - the environment to interact with the framework and mastersnapshot - the SnapshotDescriptor of the snapshot to deletejava.io.IOExceptionpublic void preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<TableName> tableNamesList, java.util.List<HTableDescriptor> descriptors, java.lang.String regex) throws java.io.IOException
MasterObserverpreGetTableDescriptors in interface MasterObserverctx - the environment to interact with the framework and mastertableNamesList - the list of table names, or null if querying for alldescriptors - an empty list, can be filled with what to return if bypassingregex - regular expression used for filtering the table namesjava.io.IOExceptionpublic void postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<TableName> tableNamesList, java.util.List<HTableDescriptor> descriptors, java.lang.String regex) throws java.io.IOException
MasterObserverpostGetTableDescriptors in interface MasterObserverctx - the environment to interact with the framework and mastertableNamesList - the list of table names, or null if querying for alldescriptors - the list of descriptors about to be returnedregex - regular expression used for filtering the table namesjava.io.IOExceptionpublic void preGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<HTableDescriptor> descriptors, java.lang.String regex) throws java.io.IOException
MasterObserverpreGetTableNames in interface MasterObserverctx - the environment to interact with the framework and masterdescriptors - an empty list, can be filled with what to return if bypassingregex - regular expression used for filtering the table namesjava.io.IOExceptionpublic void postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<HTableDescriptor> descriptors, java.lang.String regex) throws java.io.IOException
MasterObserverpostGetTableNames in interface MasterObserverctx - the environment to interact with the framework and masterdescriptors - the list of descriptors about to be returnedregex - regular expression used for filtering the table namesjava.io.IOExceptionpublic void postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws java.io.IOException
MasterObserverpostCreateNamespace in interface MasterObserverctx - the environment to interact with the framework and masterns - the NamespaceDescriptor for the tablejava.io.IOExceptionpublic void preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String namespace) throws java.io.IOException
MasterObserverHMaster deletes a
namespace
It can't bypass the default action, e.g., ctx.bypass() won't have effect.preDeleteNamespace in interface MasterObserverctx - the environment to interact with the framework and masternamespace - the name of the namespacejava.io.IOExceptionpublic void postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String namespace) throws java.io.IOException
MasterObserverpostDeleteNamespace in interface MasterObserverctx - the environment to interact with the framework and masternamespace - the name of the namespacejava.io.IOExceptionpublic void postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws java.io.IOException
MasterObserverpostModifyNamespace in interface MasterObserverctx - the environment to interact with the framework and masterns - the NamespaceDescriptorjava.io.IOExceptionpublic void preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String namespace) throws java.io.IOException
MasterObserverpreGetNamespaceDescriptor in interface MasterObserverctx - the environment to interact with the framework and masternamespace - the name of the namespacejava.io.IOExceptionpublic void postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws java.io.IOException
MasterObserverpostGetNamespaceDescriptor in interface MasterObserverctx - the environment to interact with the framework and masterns - the NamespaceDescriptorjava.io.IOExceptionpublic void preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<NamespaceDescriptor> descriptors) throws java.io.IOException
MasterObserverpreListNamespaceDescriptors in interface MasterObserverctx - the environment to interact with the framework and masterdescriptors - an empty list, can be filled with what to return if bypassingjava.io.IOExceptionpublic void postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<NamespaceDescriptor> descriptors) throws java.io.IOException
MasterObserverpostListNamespaceDescriptors in interface MasterObserverctx - the environment to interact with the framework and masterdescriptors - the list of descriptors about to be returnedjava.io.IOExceptionpublic void preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpreTableFlush in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws java.io.IOException
MasterObserverpostTableFlush in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablejava.io.IOExceptionpublic void preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String userName, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpreSetUserQuota in interface MasterObserverctx - the environment to interact with the framework and masteruserName - the name of userquotas - the quota settingsjava.io.IOExceptionpublic void postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String userName, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpostSetUserQuota in interface MasterObserverctx - the environment to interact with the framework and masteruserName - the name of userquotas - the quota settingsjava.io.IOExceptionpublic void preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String userName, TableName tableName, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpreSetUserQuota in interface MasterObserverctx - the environment to interact with the framework and masteruserName - the name of usertableName - the name of the tablequotas - the quota settingsjava.io.IOExceptionpublic void postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String userName, TableName tableName, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpostSetUserQuota in interface MasterObserverctx - the environment to interact with the framework and masteruserName - the name of usertableName - the name of the tablequotas - the quota settingsjava.io.IOExceptionpublic void preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String userName, java.lang.String namespace, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpreSetUserQuota in interface MasterObserverctx - the environment to interact with the framework and masteruserName - the name of usernamespace - the name of the namespacequotas - the quota settingsjava.io.IOExceptionpublic void postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String userName, java.lang.String namespace, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpostSetUserQuota in interface MasterObserverctx - the environment to interact with the framework and masteruserName - the name of usernamespace - the name of the namespacequotas - the quota settingsjava.io.IOExceptionpublic void preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpreSetTableQuota in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablequotas - the quota settingsjava.io.IOExceptionpublic void postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpostSetTableQuota in interface MasterObserverctx - the environment to interact with the framework and mastertableName - the name of the tablequotas - the quota settingsjava.io.IOExceptionpublic void preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String namespace, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpreSetNamespaceQuota in interface MasterObserverctx - the environment to interact with the framework and masternamespace - the name of the namespacequotas - the quota settingsjava.io.IOExceptionpublic void postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String namespace, QuotaProtos.Quotas quotas) throws java.io.IOException
MasterObserverpostSetNamespaceQuota in interface MasterObserverctx - the environment to interact with the framework and masternamespace - the name of the namespacequotas - the quota settingsjava.io.IOExceptionpublic void preMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.Set<HostAndPort> servers, java.lang.String targetGroup) throws java.io.IOException
MasterObserverpreMoveServers in interface MasterObserverctx - the environment to interact with the framework and masterservers - set of servers to movetargetGroup - destination groupjava.io.IOException - on failurepublic void postMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.Set<HostAndPort> servers, java.lang.String targetGroup) throws java.io.IOException
MasterObserverpostMoveServers in interface MasterObserverctx - the environment to interact with the framework and masterservers - set of servers to movetargetGroup - name of groupjava.io.IOException - on failurepublic void preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.Set<TableName> tables, java.lang.String targetGroup) throws java.io.IOException
MasterObserverpreMoveTables in interface MasterObserverctx - the environment to interact with the framework and mastertables - set of tables to movetargetGroup - name of groupjava.io.IOException - on failurepublic void postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.Set<TableName> tables, java.lang.String targetGroup) throws java.io.IOException
MasterObserverpostMoveTables in interface MasterObserverctx - the environment to interact with the framework and mastertables - set of tables to movetargetGroup - name of groupjava.io.IOException - on failurepublic void preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String name) throws java.io.IOException
MasterObserverpreAddRSGroup in interface MasterObserverctx - the environment to interact with the framework and mastername - group namejava.io.IOException - on failurepublic void postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String name) throws java.io.IOException
MasterObserverpostAddRSGroup in interface MasterObserverctx - the environment to interact with the framework and mastername - group namejava.io.IOException - on failurepublic void preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String name) throws java.io.IOException
MasterObserverpreRemoveRSGroup in interface MasterObserverctx - the environment to interact with the framework and mastername - group namejava.io.IOException - on failurepublic void postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String name) throws java.io.IOException
MasterObserverpostRemoveRSGroup in interface MasterObserverctx - the environment to interact with the framework and mastername - group namejava.io.IOException - on failurepublic void preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String groupName) throws java.io.IOException
MasterObserverpreBalanceRSGroup in interface MasterObserverctx - the environment to interact with the framework and mastergroupName - group namejava.io.IOException - on failurepublic void postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, java.lang.String groupName, boolean balancerRan) throws java.io.IOException
MasterObserverpostBalanceRSGroup in interface MasterObserverctx - the environment to interact with the framework and mastergroupName - group namejava.io.IOException - on failurepublic void preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx, ProcedureExecutor<MasterProcedureEnv> procEnv, long procId) throws java.io.IOException
MasterObserverpreAbortProcedure in interface MasterObserverctx - the environment to interact with the framework and masterjava.io.IOExceptionpublic void postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx) throws java.io.IOException
MasterObserverpostAbortProcedure in interface MasterObserverctx - the environment to interact with the framework and masterjava.io.IOExceptionpublic void preListProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx) throws java.io.IOException
MasterObserverpreListProcedures in interface MasterObserverctx - the environment to interact with the framework and masterjava.io.IOExceptionpublic void postListProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<ProcedureInfo> procInfoList) throws java.io.IOException
MasterObserverpostListProcedures in interface MasterObserverctx - the environment to interact with the framework and masterprocInfoList - the list of procedures about to be returnedjava.io.IOExceptionpublic void preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<TableName> tableNamesList, java.util.List<HTableDescriptor> descriptors) throws java.io.IOException
MasterObserverpreGetTableDescriptors in interface MasterObserverctx - the environment to interact with the framework and mastertableNamesList - the list of table names, or null if querying for alldescriptors - an empty list, can be filled with what to return if bypassingjava.io.IOExceptionpublic void postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, java.util.List<HTableDescriptor> descriptors) throws java.io.IOException
MasterObserverpostGetTableDescriptors in interface MasterObserverctx - the environment to interact with the framework and masterdescriptors - the list of descriptors about to be returnedjava.io.IOException