@InterfaceAudience.LimitedPrivate(value="Coprocesssor") @InterfaceStability.Evolving public interface MasterObserver
HMaster
process. IOException
are reported back to client.CoprocessorHost.ABORT_ON_ERROR_KEY
is set to true, then the
server aborts.DoNotRetryIOException
is returned to the client.Modifier and Type | Method and Description |
---|---|
default void |
postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called after a abortProcedure request has been processed.
|
default void |
postAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called after add a replication peer
|
default void |
postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String name)
Called after a new region server group is added
|
default void |
postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called after the region assignment has been requested.
|
default void |
postBalance(ObserverContext<MasterCoprocessorEnvironment> ctx,
BalanceRequest request,
List<RegionPlan> plans)
Called after the balancing plan has been submitted.
|
default void |
postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String groupName,
BalanceRequest request,
BalanceResponse response)
Called after a region server group is removed
|
default void |
postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean oldValue,
boolean newValue)
Called after the flag to enable/disable balancing has changed.
|
default void |
postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
List<ServerName> notClearedServers)
Called after clear dead region servers.
|
default void |
postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called after a snapshot clone operation has been requested.
|
default void |
postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called after the createTable operation has been requested.
|
default void |
postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster deletes a table. |
default void |
postCompletedDisableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
default void |
postCompletedEnableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
default void |
postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
called after the regions merge.
|
default void |
postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor)
Called after to modifying a table's properties.
|
default void |
postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called after the snapshot operation has been completed.
|
default void |
postCompletedSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c,
RegionInfo regionInfoA,
RegionInfo regionInfoB)
Called after the region is split.
|
default void |
postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after
HMaster truncates a table. |
default void |
postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called after the createNamespace operation has been requested.
|
default void |
postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called after the createTable operation has been requested.
|
default void |
postDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
boolean offload)
Called after decommission region servers.
|
default void |
postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace)
Called after the deleteNamespace operation has been requested.
|
default void |
postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot)
Called after the delete snapshot operation has been requested.
|
default void |
postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the deleteTable operation has been requested.
|
default void |
postDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called after disable a replication peer n * @param peerId a short name that identifies the peer
|
default void |
postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the disableTable operation has been requested.
|
default void |
postEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called after enable a replication peer n * @param peerId a short name that identifies the peer
|
default void |
postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the enableTable operation has been requested.
|
default void |
postGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment> ctx,
ClusterMetrics status)
Called after get cluster status.
|
default void |
postGetLocks(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called after a getLocks request has been processed.
|
default void |
postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called after a getNamespaceDescriptor request has been processed.
|
default void |
postGetProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called after a getProcedures request has been processed.
|
default void |
postGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called after get the configured ReplicationPeerConfig for the specified peer n * @param peerId
a short name that identifies the peer
|
default void |
postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex)
Called after a getTableDescriptors request has been processed.
|
default void |
postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableDescriptor> descriptors,
String regex)
Called after a getTableNames request has been processed.
|
default void |
postGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier)
Called after getting user permissions.
|
default void |
postGrant(ObserverContext<MasterCoprocessorEnvironment> ctx,
UserPermission userPermission,
boolean mergeExistingPermissions)
Called after granting user permissions.
|
default void |
postHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
List<Permission> permissions)
Called after checking if user has permissions.
|
default void |
postIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean rpcThrottleEnabled)
Called after getting if is rpc throttle enabled.
|
default void |
postListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called after list decommissioned region servers.
|
default void |
postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<NamespaceDescriptor> descriptors)
Called after a listNamespaceDescriptors request has been processed.
|
default void |
postListNamespaces(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<String> namespaces)
Called after a listNamespaces request has been processed.
|
default void |
postListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment> ctx,
String regex)
Called after list replication peers.
|
default void |
postListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot)
Called after listSnapshots request has been processed.
|
default void |
postLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called after heartbeat to a lock.
|
default void |
postMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called after the master local region memstore is flushed to disk.
|
default void |
postMergeRegions(ObserverContext<MasterCoprocessorEnvironment> c,
RegionInfo[] regionsToMerge)
called after merge regions request.
|
default void |
postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
This will be called after META step as part of regions merge transaction.
|
default void |
postModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] family,
String dstSFT)
Called after modifying a family store file tracker.
|
default void |
postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor currentNsDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor oldNsDescriptor,
NamespaceDescriptor currentNsDescriptor)
Called after the modifyNamespace operation has been requested.
|
default void |
postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor oldDescriptor,
TableDescriptor currentDescriptor)
Called after the modifyTable operation has been requested.
|
default void |
postModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
String dstSFT)
Called after modifying a table's store file tracker.
|
default void |
postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called after the region move has been requested.
|
default void |
postMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers,
String targetGroup)
Called after servers are moved to target region server group
|
default void |
postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers,
Set<TableName> tables,
String targetGroup)
Called after servers are moved to target region server group
|
default void |
postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<TableName> tables,
String targetGroup)
Called after servers are moved to target region server group
|
default void |
postRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx,
ServerName server,
List<byte[]> encodedRegionNames)
Called after recommission region server.
|
default void |
postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called after the region has been marked offline.
|
default void |
postRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called after remove a replication peer n * @param peerId a short name that identifies the peer
|
default void |
postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String name)
Called after a region server group is removed
|
default void |
postRemoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers)
Called after servers are removed from rsgroup
|
default void |
postRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String oldName,
String newName)
Called after rename rsgroup.
|
default void |
postRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called after new LockProcedure is queued.
|
default void |
postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called after a snapshot restore operation has been requested.
|
default void |
postRevoke(ObserverContext<MasterCoprocessorEnvironment> ctx,
UserPermission userPermission)
Called after revoking user permissions.
|
default void |
postRollBackMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
This will be called after the roll back of the regions merge.
|
default void |
postRollBackSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> ctx)
This will be called after the roll back of the split region is completed
|
default void |
postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
GlobalQuotaSettings quotas)
Called after the quota for the namespace is stored.
|
default void |
postSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String regionServer,
GlobalQuotaSettings quotas)
Called after the quota for the region server is stored.
|
default void |
postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean newValue,
MasterSwitchType switchType)
Called after setting split / merge switch
|
default void |
postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
GlobalQuotaSettings quotas)
Called after the quota for the table is stored.
|
default void |
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
GlobalQuotaSettings quotas)
Called after the quota for the user is stored.
|
default void |
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
GlobalQuotaSettings quotas)
Called after the quota for the user on the specified namespace is stored.
|
default void |
postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
TableName tableName,
GlobalQuotaSettings quotas)
Called after the quota for the user on the specified table is stored.
|
default void |
postSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called after the snapshot operation has been requested.
|
default void |
postStartMaster(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called immediately after an active master instance has completed initialization.
|
default void |
postSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean oldValue,
boolean newValue)
Called after switching exceed throttle quota state.
|
default void |
postSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean oldValue,
boolean newValue)
Called after switching rpc throttle enabled state.
|
default void |
postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the table memstore is flushed to disk.
|
default void |
postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called after the truncateTable operation has been requested.
|
default void |
postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called after the region unassignment has been requested.
|
default void |
postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo,
boolean force)
Deprecated.
in 2.4.0. replaced by postUnassign(ctx, regionInfo). removed in hbase 3. until then
safe to either leave implementation here or move it to the new method. default impl
of that method calls this one.
|
default void |
postUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called after update peerConfig for the specified peer
|
default void |
postUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String groupName,
Map<String,String> configuration)
Called after update rsgroup config.
|
default void |
preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx,
long procId)
Called before a abortProcedure request has been processed.
|
default void |
preAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called before add a replication peer
|
default void |
preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String name)
Called before a new region server group is added
|
default void |
preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called prior to assigning a specific region.
|
default void |
preBalance(ObserverContext<MasterCoprocessorEnvironment> ctx,
BalanceRequest request)
Called prior to requesting rebalancing of the cluster regions, though after the initial checks
for regions in transition and the balance switch flag.
|
default void |
preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String groupName,
BalanceRequest request)
Called before a region server group is removed
|
default void |
preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean newValue)
Called prior to modifying the flag used to enable/disable region balancing.
|
default void |
preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before clear dead region servers.
|
default void |
preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called before a snapshot is cloned.
|
default void |
preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor ns)
Called before a new namespace is created by
HMaster . |
default void |
preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called before a new table is created by
HMaster . |
default void |
preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called before a new table is created by
HMaster . |
default TableDescriptor |
preCreateTableRegionsInfos(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc)
Called before we create the region infos for this table.
|
default void |
preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
boolean offload)
Called before decommission region servers.
|
default void |
preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace)
Called before
HMaster deletes a namespace |
default void |
preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot)
Called before a snapshot is deleted.
|
default void |
preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster deletes a table. |
default void |
preDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster deletes a table. |
default void |
preDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called before disable a replication peer n * @param peerId a short name that identifies the
peer
|
default void |
preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to disabling a table.
|
default void |
preDisableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to disabling a table.
|
default void |
preEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called before enable a replication peer n * @param peerId a short name that identifies the peer
|
default void |
preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to enabling a table.
|
default void |
preEnableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called prior to enabling a table.
|
default void |
preGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before get cluster status.
|
default void |
preGetLocks(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before a getLocks request has been processed.
|
default void |
preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace)
Called before a getNamespaceDescriptor request has been processed.
|
default void |
preGetProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before a getProcedures request has been processed.
|
default void |
preGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called before get the configured ReplicationPeerConfig for the specified peer n * @param peerId
a short name that identifies the peer
|
default void |
preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableName> tableNamesList,
List<TableDescriptor> descriptors,
String regex)
Called before a getTableDescriptors request has been processed.
|
default void |
preGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<TableDescriptor> descriptors,
String regex)
Called before a getTableNames request has been processed.
|
default void |
preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
TableName tableName,
byte[] family,
byte[] qualifier)
Called before getting user permissions.
|
default void |
preGrant(ObserverContext<MasterCoprocessorEnvironment> ctx,
UserPermission userPermission,
boolean mergeExistingPermissions)
Called before granting user permissions.
|
default void |
preHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
List<Permission> permissions) |
default void |
preIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before getting if is rpc throttle enabled.
|
default void |
preListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before list decommissioned region servers.
|
default void |
preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<NamespaceDescriptor> descriptors)
Called before a listNamespaceDescriptors request has been processed.
|
default void |
preListNamespaces(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<String> namespaces)
Called before a listNamespaces request has been processed.
|
default void |
preListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment> ctx,
String regex)
Called before list replication peers.
|
default void |
preListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot)
Called before listSnapshots request has been processed.
|
default void |
preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tn,
String description)
Called before heartbeat to a lock.
|
default void |
preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment> ctx)
Call before the master initialization is set to true.
|
default void |
preMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called before the master local region memstore is flushed to disk.
|
default void |
preMergeRegions(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
Called before merge regions request.
|
default void |
preMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
Called before the regions merge.
|
default void |
preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
List<Mutation> metaEntries)
This will be called before update META step as part of regions merge transaction.
|
default String |
preModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
byte[] family,
String dstSFT)
Called prior to modifying a family's store file tracker.
|
default void |
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor newNsDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx,
NamespaceDescriptor currentNsDescriptor,
NamespaceDescriptor newNsDescriptor)
Called prior to modifying a namespace's properties.
|
default void |
preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default TableDescriptor |
preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default void |
preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor newDescriptor)
Deprecated.
Since 2.1. Will be removed in 3.0.
|
default void |
preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
TableDescriptor currentDescriptor,
TableDescriptor newDescriptor)
Called prior to modifying a table's properties.
|
default String |
preModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
String dstSFT)
Called prior to modifying a table's store file tracker.
|
default void |
preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called prior to moving a given region from one region server to another.
|
default void |
preMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers,
String targetGroup)
Called before servers are moved to target region server group
|
default void |
preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers,
Set<TableName> tables,
String targetGroup)
Called before servers are moved to target region server group
|
default void |
preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<TableName> tables,
String targetGroup)
Called before tables are moved to target region server group
|
default void |
preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx,
ServerName server,
List<byte[]> encodedRegionNames)
Called before recommission region server.
|
default void |
preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called prior to marking a given region as offline.
|
default void |
preRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId)
Called before remove a replication peer n * @param peerId a short name that identifies the peer
|
default void |
preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String name)
Called before a region server group is removed
|
default void |
preRemoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
Set<Address> servers)
Called before servers are removed from rsgroup
|
default void |
preRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx,
String oldName,
String newName)
Called before rename rsgroup.
|
default void |
preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called before new LockProcedure is queued.
|
default void |
preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called before a snapshot is restored.
|
default void |
preRevoke(ObserverContext<MasterCoprocessorEnvironment> ctx,
UserPermission userPermission)
Called before revoking user permissions.
|
default void |
preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
GlobalQuotaSettings quotas)
Called before the quota for the namespace is stored.
|
default void |
preSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String regionServer,
GlobalQuotaSettings quotas)
Called before the quota for the region server is stored.
|
default void |
preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean newValue,
MasterSwitchType switchType)
Called prior to setting split / merge switch Supports Coprocessor 'bypass'.
|
default void |
preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName,
GlobalQuotaSettings quotas)
Called before the quota for the table is stored.
|
default void |
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
GlobalQuotaSettings quotas)
Called before the quota for the user is stored.
|
default void |
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
String namespace,
GlobalQuotaSettings quotas)
Called before the quota for the user on the specified namespace is stored.
|
default void |
preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
String userName,
TableName tableName,
GlobalQuotaSettings quotas)
Called before the quota for the user on the specified table is stored.
|
default void |
preShutdown(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called prior to shutting down the full HBase cluster, including this
HMaster process. |
default void |
preSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx,
SnapshotDescription snapshot,
TableDescriptor tableDescriptor)
Called before a new snapshot is taken.
|
default void |
preSplitRegion(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] splitRow)
Called before the split region procedure is called.
|
default void |
preSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c,
TableName tableName,
byte[] splitRow)
Called before the region is split.
|
default void |
preSplitRegionAfterMETAAction(ObserverContext<MasterCoprocessorEnvironment> ctx)
This will be called after update META step as part of split transaction
|
default void |
preSplitRegionBeforeMETAAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
byte[] splitKey,
List<Mutation> metaEntries)
This will be called before update META step as part of split transaction.
|
default void |
preStopMaster(ObserverContext<MasterCoprocessorEnvironment> ctx)
Called immediately prior to stopping this
HMaster
process. |
default void |
preSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean enable)
Called before switching exceed throttle quota state.
|
default void |
preSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment> ctx,
boolean enable)
Called before switching rpc throttle enabled state.
|
default void |
preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before the table memstore is flushed to disk.
|
default void |
preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster truncates a table. |
default void |
preTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableName tableName)
Called before
HMaster truncates a table. |
default void |
preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called prior to unassigning a given region.
|
default void |
preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo,
boolean force)
Deprecated.
in 2.4.0. replaced by preUnassign(ctx, regionInfo). removed in hbase 3. until then
safe to either leave implementation here or move it to the new method. default impl
of that method calls this one.
|
default void |
preUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called before update peerConfig for the specified peer n * @param peerId a short name that
identifies the peer
|
default void |
preUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String groupName,
Map<String,String> configuration)
Called before update rsgroup config.
|
default TableDescriptor preCreateTableRegionsInfos(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc) throws IOException
ctx
- the environment to interact with the framework and masterdesc
- the TableDescriptor for the tablenull
means cancel the creation.IOException
default void preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) throws IOException
HMaster
. Called
as part of create table RPC call.ctx
- the environment to interact with the framework and masterdesc
- the TableDescriptor for the tableregions
- the initial regions created for the tableIOException
default void postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) throws IOException
ctx
- the environment to interact with the framework and masterdesc
- the TableDescriptor for the tableregions
- the initial regions created for the tableIOException
default void preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) throws IOException
HMaster
. Called
as part of create table procedure and it is async to the create RPC call.ctx
- the environment to interact with the framework and masterdesc
- the TableDescriptor for the tableregions
- the initial regions created for the tableIOException
default void postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) throws IOException
ctx
- the environment to interact with the framework and masterdesc
- the TableDescriptor for the tableregions
- the initial regions created for the tableIOException
default void preDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
HMaster
deletes a table. Called as part of
delete table RPC call.ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postDeleteTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
HMaster
deletes a table. Called as part of
delete table procedure and it is async to the delete RPC call.ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postCompletedDeleteTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
HMaster
deletes a table. Called as part of
delete table procedure and it is async to the delete RPC call.ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
HMaster
truncates a table. Called as part
of truncate table RPC call.ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postTruncateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
HMaster
truncates a table. Called as part
of truncate table procedure and it is async to the truncate RPC call.ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postCompletedTruncateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
HMaster
truncates a table. Called as part
of truncate table procedure and it is async to the truncate RPC call.ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
@Deprecated default void preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor newDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablenewDescriptor
- after modify operation, table will have this descriptorIOException
default TableDescriptor preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablecurrentDescriptor
- current TableDescriptor of the tablenewDescriptor
- after modify operation, table will have this descriptorIOException
@Deprecated default void postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablecurrentDescriptor
- current TableDescriptor of the tableIOException
default void postModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableoldDescriptor
- descriptor of table before modify operation happenedcurrentDescriptor
- current TableDescriptor of the tableIOException
@Deprecated default void preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor newDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablenewDescriptor
- after modify operation, table will have this descriptorIOException
default String preModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, String dstSFT) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tabledstSFT
- the store file trackerIOException
default void postModifyTableStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, String dstSFT) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tabledstSFT
- the store file trackerIOException
default String preModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] family, String dstSFT) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablefamily
- the column familydstSFT
- the store file trackerIOException
default void postModifyColumnFamilyStoreFileTracker(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] family, String dstSFT) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablefamily
- the column familydstSFT
- the store file trackerIOException
default void preModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablecurrentDescriptor
- current TableDescriptor of the tablenewDescriptor
- after modify operation, table will have this descriptorIOException
@Deprecated default void postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor currentDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablecurrentDescriptor
- current TableDescriptor of the tableIOException
default void postCompletedModifyTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, TableDescriptor oldDescriptor, TableDescriptor currentDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableoldDescriptor
- descriptor of table before modify operation happenedcurrentDescriptor
- current TableDescriptor of the tableIOException
default void preEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postEnableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preEnableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postCompletedEnableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preDisableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postCompletedDisableTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx, long procId) throws IOException
ctx
- the environment to interact with the framework and masterprocId
- the Id of the procedureIOException
default void postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preGetProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void postGetProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preGetLocks(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
- if something went wrongdefault void postGetLocks(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
- if something went wrongdefault void preMove(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo region, ServerName srcServer, ServerName destServer) throws IOException
ctx
- the environment to interact with the framework and masterregion
- the RegionInfosrcServer
- the source ServerNamedestServer
- the destination ServerNameIOException
default void postMove(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo region, ServerName srcServer, ServerName destServer) throws IOException
ctx
- the environment to interact with the framework and masterregion
- the RegionInfosrcServer
- the source ServerNamedestServer
- the destination ServerNameIOException
default void preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) throws IOException
ctx
- the environment to interact with the framework and masterregionInfo
- the regionInfo of the regionIOException
default void postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) throws IOException
ctx
- the environment to interact with the framework and masterregionInfo
- the regionInfo of the regionIOException
default void preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo, boolean force) throws IOException
ctx
- the environment to interact with the framework and master n * @param force whether
to force unassignment or notIOException
default void preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) throws IOException
ctx
- the environment to interact with the framework and master nIOException
default void postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo, boolean force) throws IOException
ctx
- the environment to interact with the framework and master n * @param force whether
to force unassignment or notIOException
default void postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) throws IOException
ctx
- the environment to interact with the framework and master nIOException
default void preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) throws IOException
ctx
- the environment to interact with the framework and master nIOException
default void postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) throws IOException
ctx
- the environment to interact with the framework and master nIOException
default void preBalance(ObserverContext<MasterCoprocessorEnvironment> ctx, BalanceRequest request) throws IOException
ctx
- the environment to interact with the framework and masterrequest
- the request used to trigger the balancerIOException
default void postBalance(ObserverContext<MasterCoprocessorEnvironment> ctx, BalanceRequest request, List<RegionPlan> plans) throws IOException
ctx
- the environment to interact with the framework and masterrequest
- the request used to trigger the balanceplans
- 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 assignmentIOException
default void preSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean newValue, MasterSwitchType switchType) throws IOException
ctx
- the coprocessor instance's environmentnewValue
- the new value submitted in the callswitchType
- type of switchIOException
default void postSetSplitOrMergeEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean newValue, MasterSwitchType switchType) throws IOException
ctx
- the coprocessor instance's environmentnewValue
- the new value submitted in the callswitchType
- type of switchIOException
default void preSplitRegion(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] splitRow) throws IOException
c
- the environment to interact with the framework and mastertableName
- the table where the region belongs tosplitRow
- split pointIOException
default void preSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c, TableName tableName, byte[] splitRow) throws IOException
c
- the environment to interact with the framework and mastertableName
- the table where the region belongs tosplitRow
- split pointIOException
default void postCompletedSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfoA, RegionInfo regionInfoB) throws IOException
c
- the environment to interact with the framework and masterregionInfoA
- the left daughter regionregionInfoB
- the right daughter regionIOException
default void preSplitRegionBeforeMETAAction(ObserverContext<MasterCoprocessorEnvironment> ctx, byte[] splitKey, List<Mutation> metaEntries) throws IOException
ctx
- the environment to interact with the framework and master nnIOException
default void preSplitRegionAfterMETAAction(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void postRollBackSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, RegionInfo mergedRegion) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, @MetaMutationAnnotation List<Mutation> metaEntries) throws IOException
ctx
- the environment to interact with the framework and mastermetaEntries
- mutations to execute on hbase:meta atomically with regions merge updates.
Any puts or deletes to execute on hbase:meta can be added to the mutations.IOException
default void postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, RegionInfo mergedRegion) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void postRollBackMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean newValue) throws IOException
ctx
- the coprocessor instance's environmentIOException
default void postBalanceSwitch(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean oldValue, boolean newValue) throws IOException
ctx
- the coprocessor instance's environmentoldValue
- the previously set balanceSwitch valuenewValue
- the newly set balanceSwitch valueIOException
default void preShutdown(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
HMaster
process.IOException
default void preStopMaster(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
HMaster
process.IOException
default void postStartMaster(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
IOException
default void preMasterInitialization(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
HMaster
process.IOException
default void preSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor for the snapshottableDescriptor
- the TableDescriptor of the table to snapshotIOException
default void postSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor for the snapshottableDescriptor
- the TableDescriptor of the table to snapshotIOException
default void postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor for the snapshottableDescriptor
- the TableDescriptor of the table to snapshotIOException
default void preListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor of the snapshot to listIOException
default void postListSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor of the snapshot to listIOException
default void preCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor for the snapshottableDescriptor
- the TableDescriptor of the table to createIOException
default void postCloneSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor for the snapshottableDescriptor
- the v of the table to createIOException
default void preRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor for the snapshottableDescriptor
- the TableDescriptor of the table to restoreIOException
default void postRestoreSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor for the snapshottableDescriptor
- the TableDescriptor of the table to restoreIOException
default void preDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor of the snapshot to deleteIOException
default void postDeleteSnapshot(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot) throws IOException
ctx
- the environment to interact with the framework and mastersnapshot
- the SnapshotDescriptor of the snapshot to deleteIOException
default void preGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) throws IOException
ctx
- 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 in coprocessorregex
- regular expression used for filtering the table namesIOException
default void postGetTableDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableName> tableNamesList, List<TableDescriptor> descriptors, String regex) throws IOException
ctx
- 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 namesIOException
default void preGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) throws IOException
ctx
- the environment to interact with the framework and masterdescriptors
- an empty list, can be filled with what to return by coprocessorregex
- regular expression used for filtering the table namesIOException
default void postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) throws IOException
ctx
- the environment to interact with the framework and masterdescriptors
- the list of descriptors about to be returnedregex
- regular expression used for filtering the table namesIOException
default void preCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws IOException
HMaster
.ctx
- the environment to interact with the framework and masterns
- the NamespaceDescriptor for the tableIOException
default void postCreateNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws IOException
ctx
- the environment to interact with the framework and masterns
- the NamespaceDescriptor for the tableIOException
default void preDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace) throws IOException
HMaster
deletes a namespacectx
- the environment to interact with the framework and masternamespace
- the name of the namespaceIOException
default void postDeleteNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace) throws IOException
ctx
- the environment to interact with the framework and masternamespace
- the name of the namespaceIOException
@Deprecated default void preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor newNsDescriptor) throws IOException
ctx
- the environment to interact with the framework and masternewNsDescriptor
- after modify operation, namespace will have this descriptorIOException
default void preModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor currentNsDescriptor, NamespaceDescriptor newNsDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastercurrentNsDescriptor
- current NamespaceDescriptor of the namespacenewNsDescriptor
- after modify operation, namespace will have this descriptorIOException
@Deprecated default void postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor currentNsDescriptor) throws IOException
ctx
- the environment to interact with the framework and mastercurrentNsDescriptor
- current NamespaceDescriptor of the namespaceIOException
default void postModifyNamespace(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor oldNsDescriptor, NamespaceDescriptor currentNsDescriptor) throws IOException
ctx
- the environment to interact with the framework and masteroldNsDescriptor
- descriptor of namespace before modify operation happenedcurrentNsDescriptor
- current NamespaceDescriptor of the namespaceIOException
default void preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace) throws IOException
ctx
- the environment to interact with the framework and masternamespace
- the name of the namespaceIOException
default void postGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws IOException
ctx
- the environment to interact with the framework and masterns
- the NamespaceDescriptorIOException
default void preListNamespaces(ObserverContext<MasterCoprocessorEnvironment> ctx, List<String> namespaces) throws IOException
ctx
- the environment to interact with the framework and masternamespaces
- an empty list, can be filled with what to return if bypassingIOException
- if something went wrongdefault void postListNamespaces(ObserverContext<MasterCoprocessorEnvironment> ctx, List<String> namespaces) throws IOException
ctx
- the environment to interact with the framework and masternamespaces
- the list of namespaces about to be returnedIOException
- if something went wrongdefault void preListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<NamespaceDescriptor> descriptors) throws IOException
ctx
- the environment to interact with the framework and masterdescriptors
- an empty list, can be filled with what to return by coprocessorIOException
default void postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<NamespaceDescriptor> descriptors) throws IOException
ctx
- the environment to interact with the framework and masterdescriptors
- the list of descriptors about to be returnedIOException
default void preTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void postTableFlush(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tableIOException
default void preMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void postMasterStoreFlush(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masteruserName
- the name of userquotas
- the current quota for the userIOException
default void postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masteruserName
- the name of userquotas
- the resulting quota for the userIOException
default void preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, TableName tableName, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masteruserName
- the name of usertableName
- the name of the tablequotas
- the current quota for the user on the tableIOException
default void postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, TableName tableName, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masteruserName
- the name of usertableName
- the name of the tablequotas
- the resulting quota for the user on the tableIOException
default void preSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, String namespace, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masteruserName
- the name of usernamespace
- the name of the namespacequotas
- the current quota for the user on the namespaceIOException
default void postSetUserQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, String namespace, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masteruserName
- the name of usernamespace
- the name of the namespacequotas
- the resulting quota for the user on the namespaceIOException
default void preSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablequotas
- the current quota for the tableIOException
default void postSetTableQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and mastertableName
- the name of the tablequotas
- the resulting quota for the tableIOException
default void preSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masternamespace
- the name of the namespacequotas
- the current quota for the namespaceIOException
default void postSetNamespaceQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masternamespace
- the name of the namespacequotas
- the resulting quota for the namespaceIOException
default void preSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String regionServer, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masterregionServer
- the name of the region serverquotas
- the current quota for the region serverIOException
default void postSetRegionServerQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, String regionServer, GlobalQuotaSettings quotas) throws IOException
ctx
- the environment to interact with the framework and masterregionServer
- the name of the region serverquotas
- the resulting quota for the region serverIOException
default void preMergeRegions(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) throws IOException
ctx
- coprocessor environmentregionsToMerge
- regions to be mergedIOException
default void postMergeRegions(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo[] regionsToMerge) throws IOException
c
- coprocessor environmentregionsToMerge
- regions to be mergedIOException
default void preMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, Set<TableName> tables, String targetGroup) throws IOException
ctx
- the environment to interact with the framework and masterservers
- set of servers to movetargetGroup
- destination groupIOException
default void postMoveServersAndTables(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, Set<TableName> tables, String targetGroup) throws IOException
ctx
- the environment to interact with the framework and masterservers
- set of servers to movetargetGroup
- name of groupIOException
default void preMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, String targetGroup) throws IOException
ctx
- the environment to interact with the framework and masterservers
- set of servers to movetargetGroup
- destination groupIOException
default void postMoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, String targetGroup) throws IOException
ctx
- the environment to interact with the framework and masterservers
- set of servers to movetargetGroup
- name of groupIOException
default void preMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<TableName> tables, String targetGroup) throws IOException
ctx
- the environment to interact with the framework and mastertables
- set of tables to movetargetGroup
- name of groupIOException
default void postMoveTables(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<TableName> tables, String targetGroup) throws IOException
ctx
- the environment to interact with the framework and mastertables
- set of tables to movetargetGroup
- name of groupIOException
default void preAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String name) throws IOException
ctx
- the environment to interact with the framework and mastername
- group nameIOException
default void postAddRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String name) throws IOException
ctx
- the environment to interact with the framework and mastername
- group nameIOException
default void preRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String name) throws IOException
ctx
- the environment to interact with the framework and mastername
- group nameIOException
default void postRemoveRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String name) throws IOException
ctx
- the environment to interact with the framework and mastername
- group nameIOException
default void preBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String groupName, BalanceRequest request) throws IOException
ctx
- the environment to interact with the framework and mastergroupName
- group nameIOException
default void postBalanceRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String groupName, BalanceRequest request, BalanceResponse response) throws IOException
ctx
- the environment to interact with the framework and mastergroupName
- group namerequest
- the request sent to the balancerresponse
- the response returned by the balancerIOException
default void preRemoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers) throws IOException
ctx
- the environment to interact with the framework and masterservers
- set of decommissioned servers to removeIOException
default void postRemoveServers(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers) throws IOException
ctx
- the environment to interact with the framework and masterservers
- set of servers to removeIOException
default void preAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) throws IOException
ctx
- the environment to interact with the framework and masterpeerId
- a short name that identifies the peerpeerConfig
- configuration for the replication peerIOException
default void postAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) throws IOException
ctx
- the environment to interact with the framework and masterpeerId
- a short name that identifies the peerpeerConfig
- configuration for the replication peerIOException
default void preRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void postRemoveReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void preEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void postEnableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void preDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void postDisableReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void preGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void postGetReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException
IOException
default void preUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) throws IOException
IOException
default void postUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) throws IOException
ctx
- the environment to interact with the framework and masterpeerId
- a short name that identifies the peerIOException
default void preListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment> ctx, String regex) throws IOException
ctx
- the environment to interact with the framework and masterregex
- The regular expression to match peer idIOException
default void postListReplicationPeers(ObserverContext<MasterCoprocessorEnvironment> ctx, String regex) throws IOException
ctx
- the environment to interact with the framework and masterregex
- The regular expression to match peer idIOException
default void preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void postRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tn, String description) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void postLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the environment to interact with the framework and masterIOException
default void preGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
IOException
default void postGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment> ctx, ClusterMetrics status) throws IOException
IOException
default void preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
IOException
default void postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, List<ServerName> notClearedServers) throws IOException
IOException
default void preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, boolean offload) throws IOException
IOException
default void postDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, boolean offload) throws IOException
IOException
default void preListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
IOException
default void postListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
IOException
default void preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx, ServerName server, List<byte[]> encodedRegionNames) throws IOException
IOException
default void postRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx, ServerName server, List<byte[]> encodedRegionNames) throws IOException
IOException
default void preSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean enable) throws IOException
ctx
- the coprocessor instance's environmentenable
- the rpc throttle valueIOException
default void postSwitchRpcThrottle(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean oldValue, boolean newValue) throws IOException
ctx
- the coprocessor instance's environmentoldValue
- the previously rpc throttle valuenewValue
- the newly rpc throttle valueIOException
default void preIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
ctx
- the coprocessor instance's environmentIOException
default void postIsRpcThrottleEnabled(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean rpcThrottleEnabled) throws IOException
ctx
- the coprocessor instance's environmentrpcThrottleEnabled
- the rpc throttle enabled valueIOException
default void preSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean enable) throws IOException
ctx
- the coprocessor instance's environmentenable
- the exceed throttle quota valueIOException
default void postSwitchExceedThrottleQuota(ObserverContext<MasterCoprocessorEnvironment> ctx, boolean oldValue, boolean newValue) throws IOException
ctx
- the coprocessor instance's environmentoldValue
- the previously exceed throttle quota valuenewValue
- the newly exceed throttle quota valueIOException
default void preGrant(ObserverContext<MasterCoprocessorEnvironment> ctx, UserPermission userPermission, boolean mergeExistingPermissions) throws IOException
ctx
- the coprocessor instance's environmentuserPermission
- the user and permissionsmergeExistingPermissions
- True if merge with previous granted permissionsIOException
default void postGrant(ObserverContext<MasterCoprocessorEnvironment> ctx, UserPermission userPermission, boolean mergeExistingPermissions) throws IOException
ctx
- the coprocessor instance's environmentuserPermission
- the user and permissionsmergeExistingPermissions
- True if merge with previous granted permissionsIOException
default void preRevoke(ObserverContext<MasterCoprocessorEnvironment> ctx, UserPermission userPermission) throws IOException
ctx
- the coprocessor instance's environmentuserPermission
- the user and permissionsIOException
default void postRevoke(ObserverContext<MasterCoprocessorEnvironment> ctx, UserPermission userPermission) throws IOException
ctx
- the coprocessor instance's environmentuserPermission
- the user and permissionsIOException
default void preGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) throws IOException
ctx
- the coprocessor instance's environmentuserName
- the user name, null if get all user permissionsnamespace
- the namespace, null if don't get namespace permissiontableName
- the table name, null if don't get table permissionfamily
- the table column family, null if don't get table family permissionqualifier
- the table column qualifier, null if don't get table qualifier permissionIOException
- if something went wrongdefault void postGetUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, String namespace, TableName tableName, byte[] family, byte[] qualifier) throws IOException
ctx
- the coprocessor instance's environmentuserName
- the user name, null if get all user permissionsnamespace
- the namespace, null if don't get namespace permissiontableName
- the table name, null if don't get table permissionfamily
- the table column family, null if don't get table family permissionqualifier
- the table column qualifier, null if don't get table qualifier permissionIOException
- if something went wrongdefault void preHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, List<Permission> permissions) throws IOException
IOException
default void postHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, List<Permission> permissions) throws IOException
ctx
- the coprocessor instance's environmentuserName
- the user namepermissions
- the permission listIOException
default void preRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName) throws IOException
ctx
- the environment to interact with the framework and masteroldName
- old rsgroup namenewName
- new rsgroup nameIOException
- on failuredefault void postRenameRSGroup(ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName) throws IOException
ctx
- the environment to interact with the framework and masteroldName
- old rsgroup namenewName
- new rsgroup nameIOException
- on failuredefault void preUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment> ctx, String groupName, Map<String,String> configuration) throws IOException
ctx
- the environment to interact with the framework and mastergroupName
- the group nameconfiguration
- new configuration of the group name to be setIOException
default void postUpdateRSGroupConfig(ObserverContext<MasterCoprocessorEnvironment> ctx, String groupName, Map<String,String> configuration) throws IOException
ctx
- the environment to interact with the framework and mastergroupName
- the group nameconfiguration
- new configuration of the group name to be setIOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.