name
stringlengths 12
178
| code_snippet
stringlengths 8
36.5k
| score
float64 3.26
3.68
|
---|---|---|
hbase_RegionServerObserver_postRollWALWriterRequest_rdh | /**
* This will be called after executing user request to roll a region server WAL.
*
* @param ctx
* the environment to interact with the framework and region server.
*/
default void postRollWALWriterRequest(final ObserverContext<RegionServerCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_RegionServerObserver_postExecuteProcedures_rdh | /**
* This will be called after executing procedures
*
* @param ctx
* the environment to interact with the framework and region server.
*/
default void postExecuteProcedures(ObserverContext<RegionServerCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_RegionServerObserver_m0_rdh | /**
* This will be called before executing procedures
*
* @param ctx
* the environment to interact with the framework and region server.
*/
default void m0(ObserverContext<RegionServerCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_RegionServerObserver_postCreateReplicationEndPoint_rdh | /**
* This will be called after the replication endpoint is instantiated.
*
* @param ctx
* the environment to interact with the framework and region server.
* @param endpoint
* - the base endpoint for replication
* @return the endpoint to use during replication.
*/
default ReplicationEndpoint postCreateReplicationEndPoint(ObserverContext<RegionServerCoprocessorEnvironment> ctx, ReplicationEndpoint endpoint) {
return endpoint;
} | 3.26 |
hbase_RegionServerObserver_preReplicationSinkBatchMutate_rdh | /**
* This will be called before replication sink mutations are executed on the sink table as part of
* batch call.
*
* @param ctx
* the environment to interact with the framework and region server.
* @param walEntry
* wal entry from which mutation is formed.
* @param mutation
* mutation to be applied at sink cluster.
* @throws IOException
* if something goes wrong.
*/
default void preReplicationSinkBatchMutate(ObserverContext<RegionServerCoprocessorEnvironment> ctx, AdminProtos.WALEntry walEntry, Mutation mutation) throws IOException {
} | 3.26 |
hbase_RegionServerObserver_postReplicationSinkBatchMutate_rdh | /**
* This will be called after replication sink mutations are executed on the sink table as part of
* batch call.
*
* @param ctx
* the environment to interact with the framework and region server.
* @param walEntry
* wal entry from which mutation is formed.
* @param mutation
* mutation to be applied at sink cluster.
* @throws IOException
* if something goes wrong.
*/
default void postReplicationSinkBatchMutate(ObserverContext<RegionServerCoprocessorEnvironment> ctx, AdminProtos.WALEntry walEntry, Mutation mutation) throws IOException {
} | 3.26 |
hbase_RegionServerObserver_preClearCompactionQueues_rdh | /**
* This will be called before clearing compaction queues
*
* @param ctx
* the environment to interact with the framework and region server.
*/
default void preClearCompactionQueues(final ObserverContext<RegionServerCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_RegionServerObserver_preStopRegionServer_rdh | /**
* Called before stopping region server.
*
* @param ctx
* the environment to interact with the framework and region server.
*/
default void preStopRegionServer(final ObserverContext<RegionServerCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_WhileMatchFilter_areSerializedFieldsEqual_rdh | /**
* Return true if and only if the fields of the filter that are serialized are equal to the
* corresponding fields in other. Used for testing.
*/
@Override
boolean areSerializedFieldsEqual(Filter o) {
if (o == this) {
return true;
}
if (!(o instanceof WhileMatchFilter)) {
return false;
}
WhileMatchFilter other = ((WhileMatchFilter) (o));
return getFilter().areSerializedFieldsEqual(other.getFilter());
} | 3.26 |
hbase_WhileMatchFilter_toByteArray_rdh | /**
* Returns The filter serialized using pb
*/
@Override
public byte[] toByteArray() throws IOException {
FilterProtos.WhileMatchFilter.Builder builder = FilterProtos.WhileMatchFilter.newBuilder();
builder.setFilter(ProtobufUtil.toFilter(this.filter));
return builder.build().toByteArray();
}
/**
* Parse a serialized representation of {@link WhileMatchFilter}
*
* @param pbBytes
* A pb serialized {@link WhileMatchFilter} instance
* @return An instance of {@link WhileMatchFilter} | 3.26 |
hbase_CellArrayMap_createSubCellFlatMap_rdh | /* To be used by base class only to create a sub-CellFlatMap */
@Override
protected CellFlatMap createSubCellFlatMap(int min, int max, boolean descending) {
return new CellArrayMap(comparator(), this.block, min, max, descending);
} | 3.26 |
hbase_MasterObserver_preRenameRSGroup_rdh | /**
* Called before rename rsgroup.
*
* @param ctx
* the environment to interact with the framework and master
* @param oldName
* old rsgroup name
* @param newName
* new rsgroup name
*/
default void preRenameRSGroup(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String oldName, final String
newName) throws IOException {
} | 3.26 |
hbase_MasterObserver_preSwitchExceedThrottleQuota_rdh | /**
* Called before switching exceed throttle quota state.
*
* @param ctx
* the coprocessor instance's environment
* @param enable
* the exceed throttle quota value
*/
default void preSwitchExceedThrottleQuota(final ObserverContext<MasterCoprocessorEnvironment> ctx, final boolean enable) throws IOException {
} | 3.26 |
hbase_MasterObserver_m6_rdh | /**
* Called before the region is split.
*
* @param c
* the environment to interact with the framework and master
* @param tableName
* the table where the region belongs to
* @param splitRow
* split point
*/
default void m6(final ObserverContext<MasterCoprocessorEnvironment> c, final TableName tableName, final byte[] splitRow) throws IOException {
} | 3.26 |
hbase_MasterObserver_postTableFlush_rdh | /**
* Called after the table memstore is flushed to disk.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/default void postTableFlush(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_preTruncateRegion_rdh | /**
* Called before the truncate region procedure is called.
*
* @param c
* The environment to interact with the framework and master
* @param regionInfo
* The Region being truncated
*/
@SuppressWarnings("unused")
default void preTruncateRegion(final ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) {
} | 3.26 |
hbase_MasterObserver_postGetTableNames_rdh | /**
* Called after a getTableNames request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
* @param descriptors
* the list of descriptors about to be returned
* @param regex
* regular expression used for filtering the table names
*/
default void postGetTableNames(ObserverContext<MasterCoprocessorEnvironment> ctx, List<TableDescriptor> descriptors, String regex) throws IOException {
} | 3.26 |
hbase_MasterObserver_preCreateTable_rdh | /**
* Called before a new table is created by {@link org.apache.hadoop.hbase.master.HMaster}. Called
* as part of create table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param desc
* the TableDescriptor for the table
* @param regions
* the initial regions created for the table
*/
default void preCreateTable(final ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) throws IOException {
} | 3.26 |
hbase_MasterObserver_postAddRSGroup_rdh | /**
* Called after a new region server group is added
*
* @param ctx
* the environment to interact with the framework and master
* @param name
* group name
*/
default void postAddRSGroup(final ObserverContext<MasterCoprocessorEnvironment> ctx, String name) throws IOException {
} | 3.26 |
hbase_MasterObserver_preLockHeartbeat_rdh | /**
* Called before heartbeat to a lock.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void preLockHeartbeat(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tn, String description) throws IOException {
} | 3.26 |
hbase_MasterObserver_preRecommissionRegionServer_rdh | /**
* Called before recommission region server.
*/
default void preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx, ServerName server, List<byte[]> encodedRegionNames) throws IOException {
} | 3.26 |
hbase_MasterObserver_preListDecommissionedRegionServers_rdh | /**
* Called before list decommissioned region servers.
*/
default void preListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preDisableTableAction_rdh | /**
* Called prior to disabling a table. Called as part of disable table procedure and it is asyn to
* the disable table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/
default void preDisableTableAction(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_m2_rdh | /**
* Called after the region assignment has been requested.
*
* @param ctx
* the environment to interact with the framework and master
* @param regionInfo
* the regionInfo of the region
*/
default void m2(final
ObserverContext<MasterCoprocessorEnvironment> ctx, final RegionInfo regionInfo) throws IOException {
} | 3.26 |
hbase_MasterObserver_postRequestLock_rdh | /**
* Called after new LockProcedure is queued.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void postRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) throws IOException {
} | 3.26 |
hbase_MasterObserver_postRemoveReplicationPeer_rdh | /**
* Called after remove a replication peer
*
* @param peerId
* a short name that identifies the peer
*/
default void postRemoveReplicationPeer(final ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException {
} | 3.26 |
hbase_MasterObserver_postTransitReplicationPeerSyncReplicationState_rdh | /**
* Called after transit current cluster state for the specified synchronous replication peer
*
* @param ctx
* the environment to interact with the framework and master
* @param peerId
* a short name that identifies the peer
* @param from
* the old state
* @param to
* the new state
*/
default void postTransitReplicationPeerSyncReplicationState(final ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, SyncReplicationState from, SyncReplicationState to) throws IOException {
} | 3.26 |
hbase_MasterObserver_preIsRpcThrottleEnabled_rdh | /**
* Called before getting if is rpc throttle enabled.
*
* @param ctx
* the coprocessor instance's environment
*/
default void
preIsRpcThrottleEnabled(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preGetReplicationPeerConfig_rdh | /**
* Called before get the configured ReplicationPeerConfig for the specified peer
*
* @param peerId
* a short name that identifies the peer
*/
default void preGetReplicationPeerConfig(final ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException {
} | 3.26 |
hbase_MasterObserver_postRemoveServers_rdh | /**
* Called after servers are removed from rsgroup
*
* @param ctx
* the environment to interact with the framework and master
* @param servers
* set of servers to remove
*/
default void postRemoveServers(final ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers) throws IOException {
} | 3.26 |
hbase_MasterObserver_postDeleteSnapshot_rdh | /**
* Called after the delete snapshot operation has been requested. Called as part of deleteSnapshot
* RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor of the snapshot to delete
*/
default void postDeleteSnapshot(final ObserverContext<MasterCoprocessorEnvironment> ctx, final SnapshotDescription snapshot) throws IOException {
} | 3.26 |
hbase_MasterObserver_postBalanceRSGroup_rdh | /**
* Called after a region server group is removed
*
* @param ctx
* the environment to interact with the framework and master
* @param groupName
* group name
* @param request
* the request sent to the balancer
* @param response
* the response returned by the balancer
*/
default void postBalanceRSGroup(final ObserverContext<MasterCoprocessorEnvironment> ctx, String groupName, BalanceRequest request, BalanceResponse response) throws IOException {
} | 3.26 |
hbase_MasterObserver_postListSnapshot_rdh | /**
* Called after listSnapshots request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor of the snapshot to list
*/
default void postListSnapshot(final ObserverContext<MasterCoprocessorEnvironment> ctx, final SnapshotDescription snapshot) throws IOException {
} | 3.26 |
hbase_MasterObserver_preTruncateTable_rdh | /**
* Called before {@link org.apache.hadoop.hbase.master.HMaster} truncates a table. Called as part
* of truncate table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/
default void preTruncateTable(final
ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_postCompletedSnapshotAction_rdh | /**
* Called after the snapshot operation has been completed.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor for the snapshot
* @param tableDescriptor
* the TableDescriptor of the table to snapshot
*/default void postCompletedSnapshotAction(ObserverContext<MasterCoprocessorEnvironment> ctx, SnapshotDescription snapshot, TableDescriptor tableDescriptor) throws IOException {} | 3.26 |
hbase_MasterObserver_postGetProcedures_rdh | /**
* Called after a getProcedures request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void postGetProcedures(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {} | 3.26 |
hbase_MasterObserver_preModifyTable_rdh | /**
* Called prior to modifying a table's properties. Called as part of modify table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
* @param currentDescriptor
* current TableDescriptor of the table
* @param newDescriptor
* after modify operation, table will have this descriptor
*/
default TableDescriptor preModifyTable(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName, TableDescriptor currentDescriptor, TableDescriptor newDescriptor) throws IOException {
return newDescriptor;
} | 3.26 |
hbase_MasterObserver_postMergeRegionsCommitAction_rdh | /**
* This will be called after META step as part of regions merge transaction.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void postMergeRegionsCommitAction(final ObserverContext<MasterCoprocessorEnvironment> ctx, final RegionInfo[] regionsToMerge, final RegionInfo mergedRegion) throws IOException {
} | 3.26 |
hbase_MasterObserver_postGetRSGroupInfoOfTable_rdh | /**
* Called after getting region server group info of the passed tableName.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* name of the table to get RSGroupInfo for
*/
default void postGetRSGroupInfoOfTable(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_postDisableTable_rdh | /**
* Called after the disableTable operation has been requested. Called as part of disable table RPC
* call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/
default void postDisableTable(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_postSetUserQuota_rdh | /**
* Called after the quota for the user on the specified namespace is stored.
*
* @param ctx
* the environment to interact with the framework and master
* @param userName
* the name of user
* @param namespace
* the name of the namespace
* @param quotas
* the resulting quota for the user on the namespace
*/
default void postSetUserQuota(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String userName, final String namespace, final GlobalQuotaSettings quotas) throws IOException {
} | 3.26 |
hbase_MasterObserver_postTruncateRegionAction_rdh | /**
* Called post the region is truncated.
*
* @param c
* The environment to interact with the framework and master
* @param regionInfo
* The Region To be truncated
*/
@SuppressWarnings("unused")
default void postTruncateRegionAction(final ObserverContext<MasterCoprocessorEnvironment> c, final RegionInfo regionInfo) {
} | 3.26 |
hbase_MasterObserver_preUpdateRSGroupConfig_rdh | /**
* Called before update rsgroup config.
*
* @param ctx
* the environment to interact with the framework and master
* @param groupName
* the group name
* @param configuration
* new configuration of the group name to be set
*/
default void preUpdateRSGroupConfig(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String groupName, final Map<String, String> configuration) throws IOException {
} | 3.26 |
hbase_MasterObserver_postMoveServers_rdh | /**
* Called after servers are moved to target region server group
*
* @param ctx
* the environment to interact with the framework and master
* @param servers
* set of servers to move
* @param targetGroup
* name of group
*/
default void postMoveServers(final ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, String
targetGroup) throws IOException {
} | 3.26 |
hbase_MasterObserver_preGetNamespaceDescriptor_rdh | /**
* Called before a getNamespaceDescriptor request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
* @param namespace
* the name of the namespace
*/default void preGetNamespaceDescriptor(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace) throws IOException {
} | 3.26 |
hbase_MasterObserver_preListNamespaces_rdh | /**
* Called before a listNamespaces request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
* @param namespaces
* an empty list, can be filled with what to return if bypassing
* @throws IOException
* if something went wrong
*/
default void preListNamespaces(ObserverContext<MasterCoprocessorEnvironment> ctx, List<String> namespaces) throws IOException {
} | 3.26 |
hbase_MasterObserver_preSnapshot_rdh | /**
* Called before a new snapshot is taken. Called as part of snapshot RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor for the snapshot
* @param tableDescriptor
* the TableDescriptor of the table to snapshot
*/
default void preSnapshot(final ObserverContext<MasterCoprocessorEnvironment> ctx, final SnapshotDescription snapshot, final TableDescriptor tableDescriptor) throws IOException {
} | 3.26 |
hbase_MasterObserver_preModifyTableAction_rdh | /**
* Called prior to modifying a table's properties. Called as part of modify table procedure and it
* is async to the modify table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
* @param currentDescriptor
* current TableDescriptor of the table
* @param newDescriptor
* after modify operation, table will have this descriptor
*/
default void preModifyTableAction(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName, final TableDescriptor currentDescriptor, final TableDescriptor newDescriptor) throws IOException {
} | 3.26 |
hbase_MasterObserver_preListSnapshot_rdh | /**
* Called before listSnapshots request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor of the snapshot to list
*/
default void preListSnapshot(final ObserverContext<MasterCoprocessorEnvironment> ctx, final SnapshotDescription snapshot) throws IOException {
} | 3.26 |
hbase_MasterObserver_postListTablesInRSGroup_rdh | /**
* Called after listing all tables in the region server group.
*
* @param ctx
* the environment to interact with the framework and master
* @param groupName
* name of the region server group
*/
default void postListTablesInRSGroup(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String groupName) throws IOException {
} | 3.26 |
hbase_MasterObserver_preDisableTable_rdh | /**
* Called prior to disabling a table. Called as part of disable table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/
default void preDisableTable(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_preSetUserQuota_rdh | /**
* Called before the quota for the user on the specified namespace is stored.
*
* @param ctx
* the environment to interact with the framework and master
* @param userName
* the name of user
* @param namespace
* the name of the namespace
* @param quotas
* the current quota for the user on the namespace
*/
default void preSetUserQuota(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String
userName, final String namespace, final GlobalQuotaSettings quotas)
throws IOException {
} | 3.26 |
hbase_MasterObserver_postEnableReplicationPeer_rdh | /**
* Called after enable a replication peer
*
* @param peerId
* a short name that identifies the peer
*/
default void postEnableReplicationPeer(final ObserverContext<MasterCoprocessorEnvironment> ctx, String
peerId) throws IOException {
} | 3.26 |
hbase_MasterObserver_preSplitRegionAfterMETAAction_rdh | /**
* This will be called after update META step as part of split transaction
*
* @param ctx
* the environment to interact with the framework and master
*/
default void preSplitRegionAfterMETAAction(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preShutdown_rdh | /**
* Called prior to shutting down the full HBase cluster, including this
* {@link org.apache.hadoop.hbase.master.HMaster} process.
*/
default void preShutdown(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preDisableReplicationPeer_rdh | /**
* Called before disable a replication peer
*
* @param peerId
* a short name that identifies the peer
*/
default void preDisableReplicationPeer(final ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId) throws IOException {
} | 3.26 |
hbase_MasterObserver_preListRSGroups_rdh | /**
* Called before listing region server group information.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void preListRSGroups(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preUpdateReplicationPeerConfig_rdh | /**
* Called before update peerConfig for the specified peer
*
* @param peerId
* a short name that identifies the peer
*/
default void preUpdateReplicationPeerConfig(final ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) throws
IOException {
} | 3.26 |
hbase_MasterObserver_preGetLocks_rdh | /**
* Called before a getLocks request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
* @throws IOException
* if something went wrong
*/
default void preGetLocks(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {} | 3.26 |
hbase_MasterObserver_preGetRSGroupInfo_rdh | /**
* Called before getting region server group info of the passed groupName.
*
* @param ctx
* the environment to interact with the framework and master
* @param groupName
* name of the group to get RSGroupInfo for
*/
default void preGetRSGroupInfo(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String groupName) throws IOException {
} | 3.26 |
hbase_MasterObserver_postListNamespaceDescriptors_rdh | /**
* Called after a listNamespaceDescriptors request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
* @param descriptors
* the list of descriptors about to be returned
*/default void postListNamespaceDescriptors(ObserverContext<MasterCoprocessorEnvironment> ctx, List<NamespaceDescriptor> descriptors) throws IOException {
} | 3.26 |
hbase_MasterObserver_preGetClusterMetrics_rdh | /**
* Called before get cluster status.
*/
default void preGetClusterMetrics(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preStopMaster_rdh | /**
* Called immediately prior to stopping this {@link org.apache.hadoop.hbase.master.HMaster}
* process.
*/
default void preStopMaster(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preModifyNamespace_rdh | /**
* Called prior to modifying a namespace's properties.
*
* @param ctx
* the environment to interact with the framework and master
* @param currentNsDescriptor
* current NamespaceDescriptor of the namespace
* @param newNsDescriptor
* after modify operation, namespace will have this descriptor
*/
default void preModifyNamespace(final ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor currentNsDescriptor, NamespaceDescriptor newNsDescriptor)
throws
IOException {
} | 3.26 |
hbase_MasterObserver_preGrant_rdh | /**
* Called before granting user permissions.
*
* @param ctx
* the coprocessor instance's environment
* @param userPermission
* the user and permissions
* @param mergeExistingPermissions
* True if merge with previous granted permissions
*/
default void preGrant(ObserverContext<MasterCoprocessorEnvironment> ctx, UserPermission userPermission, boolean mergeExistingPermissions) throws IOException {
} | 3.26 |
hbase_MasterObserver_preClearDeadServers_rdh | /**
* Called before clear dead region servers.
*/
default void preClearDeadServers(ObserverContext<MasterCoprocessorEnvironment>
ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preListReplicationPeers_rdh | /**
* Called before list replication peers.
*
* @param ctx
* the environment to interact with the framework and master
* @param regex
* The regular expression to match peer id
*/
default void preListReplicationPeers(final ObserverContext<MasterCoprocessorEnvironment> ctx, String regex)
throws IOException {
} | 3.26 |
hbase_MasterObserver_postRemoveRSGroup_rdh | /**
* Called after a region server group is removed
*
* @param ctx
* the environment to interact with the framework and master
* @param name
* group name
*/
default void postRemoveRSGroup(final ObserverContext<MasterCoprocessorEnvironment> ctx, String name) throws IOException {
} | 3.26 |
hbase_MasterObserver_postModifyNamespace_rdh | /**
* Called after the modifyNamespace operation has been requested.
*
* @param ctx
* the environment to interact with the framework and master
* @param oldNsDescriptor
* descriptor of namespace before modify operation happened
* @param currentNsDescriptor
* current NamespaceDescriptor of the namespace
*/
default void postModifyNamespace(final ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor oldNsDescriptor, NamespaceDescriptor currentNsDescriptor) throws IOException {
} | 3.26 |
hbase_MasterObserver_preSetTableQuota_rdh | /**
* Called before the quota for the table is stored.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
* @param quotas
* the current quota for the table
*/
default void preSetTableQuota(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName, final GlobalQuotaSettings quotas) throws IOException {
} | 3.26 |
hbase_MasterObserver_preGetRSGroupInfoOfServer_rdh | /**
* Called before getting region server group info of the passed server.
*
* @param ctx
* the environment to interact with the framework and master
* @param server
* server to get RSGroupInfo for
*/
default void preGetRSGroupInfoOfServer(final ObserverContext<MasterCoprocessorEnvironment> ctx, final Address server) throws IOException {
} | 3.26 |
hbase_MasterObserver_preGetConfiguredNamespacesAndTablesInRSGroup_rdh | /**
* Called before getting the configured namespaces and tables in the region server group.
*
* @param ctx
* the environment to interact with the framework and master
* @param groupName
* name of the region server group
*/
default void preGetConfiguredNamespacesAndTablesInRSGroup(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String groupName) throws IOException {
} | 3.26 |
hbase_MasterObserver_postSetRegionServerQuota_rdh | /**
* Called after the quota for the region server is stored.
*
* @param ctx
* the environment to interact with the framework and master
* @param regionServer
* the name of the region server
* @param quotas
* the resulting quota for the region server
*/
default void postSetRegionServerQuota(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String regionServer, final GlobalQuotaSettings quotas) throws IOException {
} | 3.26 |
hbase_MasterObserver_postListRSGroups_rdh | /**
* Called after listing region server group information.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void postListRSGroups(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_postCloneSnapshot_rdh | /**
* Called after a snapshot clone operation has been requested. Called as part of restoreSnapshot
* RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor for the snapshot
* @param tableDescriptor
* the v of the table to create
*/default void postCloneSnapshot(final ObserverContext<MasterCoprocessorEnvironment> ctx, final SnapshotDescription snapshot, final TableDescriptor tableDescriptor) throws IOException {
} | 3.26 |
hbase_MasterObserver_postCompletedCreateTableAction_rdh | /**
* Called after the createTable operation has been requested. Called as part of create table RPC
* call. Called as part of create table procedure and it is async to the create RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param desc
* the TableDescriptor for the table
* @param regions
* the initial regions created for the table
*/
default void postCompletedCreateTableAction(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableDescriptor desc, final RegionInfo[] regions) throws IOException {} | 3.26 |
hbase_MasterObserver_postMoveServersAndTables_rdh | /**
* Called after servers are moved to target region server group
*
* @param ctx
* the environment to interact with the framework and master
* @param servers
* set of servers to move
* @param targetGroup
* name of group
*/
default void postMoveServersAndTables(final ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, Set<TableName> tables, String targetGroup) throws IOException {
} | 3.26 |
hbase_MasterObserver_postRevoke_rdh | /**
* Called after revoking user permissions.
*
* @param ctx
* the coprocessor instance's environment
* @param userPermission
* the user and permissions
*/
default void postRevoke(ObserverContext<MasterCoprocessorEnvironment> ctx, UserPermission userPermission) throws IOException {
} | 3.26 |
hbase_MasterObserver_postDecommissionRegionServers_rdh | /**
* Called after decommission region servers.
*/
default void postDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, boolean offload) throws IOException {
} | 3.26 |
hbase_MasterObserver_postAddReplicationPeer_rdh | /**
* Called after add a replication peer
*
* @param ctx
* the environment to interact with the framework and master
* @param peerId
* a short name that identifies the peer
* @param peerConfig
* configuration for the replication peer
*/
default void postAddReplicationPeer(final ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) throws IOException {
} | 3.26 |
hbase_MasterObserver_postModifyColumnFamilyStoreFileTracker_rdh | /**
* Called after modifying a family store file tracker. Called as part of modify family store file
* tracker RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
* @param family
* the column family
* @param dstSFT
* the store file tracker
*/
default void postModifyColumnFamilyStoreFileTracker(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName, final byte[] family, String dstSFT) throws IOException {
} | 3.26 |
hbase_MasterObserver_preMergeRegionsAction_rdh | /**
* Called before the regions merge.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void preMergeRegionsAction(final ObserverContext<MasterCoprocessorEnvironment> ctx, final RegionInfo[] regionsToMerge) throws IOException {
} | 3.26 |
hbase_MasterObserver_m7_rdh | /**
* This will be called after the roll back of the regions merge.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void m7(final ObserverContext<MasterCoprocessorEnvironment> ctx, final RegionInfo[] regionsToMerge) throws IOException {
} | 3.26 |
hbase_MasterObserver_postSwitchRpcThrottle_rdh | /**
* Called after switching rpc throttle enabled state.
*
* @param ctx
* the coprocessor instance's environment
* @param oldValue
* the previously rpc throttle value
* @param newValue
* the newly rpc throttle value
*/
default void postSwitchRpcThrottle(final ObserverContext<MasterCoprocessorEnvironment> ctx, final boolean oldValue, final boolean newValue) throws IOException {
} | 3.26 |
hbase_MasterObserver_postSetSplitOrMergeEnabled_rdh | /**
* Called after setting split / merge switch
*
* @param ctx
* the coprocessor instance's environment
* @param newValue
* the new value submitted in the call
* @param switchType
* type of switch
*/
default void postSetSplitOrMergeEnabled(final ObserverContext<MasterCoprocessorEnvironment> ctx, final boolean newValue, final MasterSwitchType switchType) throws IOException {
} | 3.26 |
hbase_MasterObserver_preMasterStoreFlush_rdh | /**
* Called before the master local region memstore is flushed to disk.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void preMasterStoreFlush(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preEnableTable_rdh | /**
* Called prior to enabling a table. Called as part of enable table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/
default void preEnableTable(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_postRestoreSnapshot_rdh | /**
* Called after a snapshot restore operation has been requested. Called as part of restoreSnapshot
* RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor for the snapshot
* @param tableDescriptor
* the TableDescriptor of the table to restore
*/
default void postRestoreSnapshot(final ObserverContext<MasterCoprocessorEnvironment> ctx, final SnapshotDescription snapshot, final TableDescriptor tableDescriptor) throws IOException {
} | 3.26 |
hbase_MasterObserver_postDeleteTable_rdh | /**
* Called after the deleteTable operation has been requested. Called as part of delete table RPC
* call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/
default void postDeleteTable(final ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_m3_rdh | /**
* Called prior to unassigning a given region.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void m3(final ObserverContext<MasterCoprocessorEnvironment> ctx, final RegionInfo regionInfo) throws IOException {
} | 3.26 |
hbase_MasterObserver_postRollBackSplitRegionAction_rdh | /**
* This will be called after the roll back of the split region is completed
*
* @param ctx
* the environment to interact with the framework and master
*/
default void postRollBackSplitRegionAction(final ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preBalanceSwitch_rdh | /**
* Called prior to modifying the flag used to enable/disable region balancing.
*
* @param ctx
* the coprocessor instance's environment
*/ default void preBalanceSwitch(final ObserverContext<MasterCoprocessorEnvironment> ctx, final boolean newValue) throws IOException {
} | 3.26 |
hbase_MasterObserver_preHasUserPermissions_rdh | /* Called before checking if user has permissions.
@param ctx the coprocessor instance's environment
@param userName the user name
@param permissions the permission list
*/
default void preHasUserPermissions(ObserverContext<MasterCoprocessorEnvironment> ctx, String userName, List<Permission> permissions) throws IOException {
} | 3.26 |
hbase_MasterObserver_postAbortProcedure_rdh | /**
* Called after a abortProcedure request has been processed.
*
* @param ctx
* the environment to interact with the framework and master
*/
default void postAbortProcedure(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException {
} | 3.26 |
hbase_MasterObserver_preSplitRegion_rdh | /**
* Called before the split region procedure is called.
*
* @param c
* the environment to interact with the framework and master
* @param tableName
* the table where the region belongs to
* @param splitRow
* split point
*/
default void preSplitRegion(final ObserverContext<MasterCoprocessorEnvironment> c, final TableName tableName, final byte[] splitRow) throws IOException {
} | 3.26 |
hbase_MasterObserver_preRestoreSnapshot_rdh | /**
* Called before a snapshot is restored. Called as part of restoreSnapshot RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param snapshot
* the SnapshotDescriptor for the snapshot
* @param tableDescriptor
* the TableDescriptor of the table to restore
*/
default void preRestoreSnapshot(final ObserverContext<MasterCoprocessorEnvironment> ctx, final SnapshotDescription snapshot, final TableDescriptor tableDescriptor) throws IOException {
} | 3.26 |
hbase_MasterObserver_postCompletedEnableTableAction_rdh | /**
* Called after the enableTable operation has been requested. Called as part of enable table
* procedure and it is async to the enable table RPC call.
*
* @param ctx
* the environment to interact with the framework and master
* @param tableName
* the name of the table
*/
default void postCompletedEnableTableAction(final ObserverContext<MasterCoprocessorEnvironment> ctx, final TableName tableName) throws IOException {
} | 3.26 |
hbase_MasterObserver_postSetNamespaceQuota_rdh | /**
* Called after the quota for the namespace is stored.
*
* @param ctx
* the environment to interact with the framework and master
* @param namespace
* the name of the namespace
* @param quotas
* the resulting quota for the namespace
*/
default void postSetNamespaceQuota(final ObserverContext<MasterCoprocessorEnvironment> ctx, final String namespace, final GlobalQuotaSettings quotas) throws IOException {
} | 3.26 |
hbase_MasterObserver_postCreateNamespace_rdh | /**
* Called after the createNamespace operation has been requested.
*
* @param ctx
* the environment to interact with the framework and master
* @param ns
* the NamespaceDescriptor for the table
*/
default void postCreateNamespace(final ObserverContext<MasterCoprocessorEnvironment> ctx, NamespaceDescriptor ns) throws IOException {
} | 3.26 |
hbase_MasterObserver_postListDecommissionedRegionServers_rdh | /**
* Called after list decommissioned region servers.
*/
default void postListDecommissionedRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx) throws
IOException {
} | 3.26 |
Subsets and Splits
No saved queries yet
Save your SQL queries to embed, download, and access them later. Queries will appear here once saved.