public class MasterRpcServices extends RSRpcServices
accessChecker, REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS, REGIONSERVER_ADMIN_SERVICE_CONFIG, REGIONSERVER_CLIENT_SERVICE_CONFIG, RESERVOIR_ENABLED_KEY| Constructor and Description |
|---|
MasterRpcServices(HMaster m) |
| Modifier and Type | Method and Description |
|---|---|
AbortProcedureResponse |
abortProcedure(RpcController rpcController,
AbortProcedureRequest request) |
AddColumnResponse |
addColumn(RpcController controller,
AddColumnRequest req) |
AddReplicationPeerResponse |
addReplicationPeer(RpcController controller,
AddReplicationPeerRequest request) |
AssignRegionResponse |
assignRegion(RpcController controller,
AssignRegionRequest req) |
BalanceResponse |
balance(RpcController controller,
BalanceRequest request) |
ClearDeadServersResponse |
clearDeadServers(RpcController controller,
ClearDeadServersRequest request) |
CompactRegionResponse |
compactRegion(RpcController controller,
CompactRegionRequest request)
Compact a region on the master.
|
CreateNamespaceResponse |
createNamespace(RpcController controller,
CreateNamespaceRequest request) |
protected PriorityFunction |
createPriority() |
protected RpcServerInterface |
createRpcServer(Server server,
Configuration conf,
RpcSchedulerFactory rpcSchedulerFactory,
java.net.InetSocketAddress bindAddress,
java.lang.String name) |
CreateTableResponse |
createTable(RpcController controller,
CreateTableRequest req) |
DecommissionRegionServersResponse |
decommissionRegionServers(RpcController controller,
DecommissionRegionServersRequest request) |
DeleteColumnResponse |
deleteColumn(RpcController controller,
DeleteColumnRequest req) |
DeleteNamespaceResponse |
deleteNamespace(RpcController controller,
DeleteNamespaceRequest request) |
DeleteSnapshotResponse |
deleteSnapshot(RpcController controller,
DeleteSnapshotRequest request)
Execute Delete Snapshot operation.
|
DeleteTableResponse |
deleteTable(RpcController controller,
DeleteTableRequest request) |
DisableReplicationPeerResponse |
disableReplicationPeer(RpcController controller,
DisableReplicationPeerRequest request) |
DisableTableResponse |
disableTable(RpcController controller,
DisableTableRequest request) |
EnableCatalogJanitorResponse |
enableCatalogJanitor(RpcController c,
EnableCatalogJanitorRequest req) |
EnableReplicationPeerResponse |
enableReplicationPeer(RpcController controller,
EnableReplicationPeerRequest request) |
EnableTableResponse |
enableTable(RpcController controller,
EnableTableRequest request) |
ClientProtos.CoprocessorServiceResponse |
execMasterService(RpcController controller,
ClientProtos.CoprocessorServiceRequest request) |
ExecProcedureResponse |
execProcedure(RpcController controller,
ExecProcedureRequest request)
Triggers an asynchronous attempt to run a distributed procedure.
|
ExecProcedureResponse |
execProcedureWithRet(RpcController controller,
ExecProcedureRequest request)
Triggers a synchronous attempt to run a distributed procedure and sets
return data in response.
|
GetClusterStatusResponse |
getClusterStatus(RpcController controller,
GetClusterStatusRequest req) |
GetCompletedSnapshotsResponse |
getCompletedSnapshots(RpcController controller,
GetCompletedSnapshotsRequest request)
List the currently available/stored snapshots.
|
GetLastFlushedSequenceIdResponse |
getLastFlushedSequenceId(RpcController controller,
GetLastFlushedSequenceIdRequest request) |
MajorCompactionTimestampResponse |
getLastMajorCompactionTimestamp(RpcController controller,
MajorCompactionTimestampRequest request) |
MajorCompactionTimestampResponse |
getLastMajorCompactionTimestampForRegion(RpcController controller,
MajorCompactionTimestampForRegionRequest request) |
GetLocksResponse |
getLocks(RpcController controller,
GetLocksRequest request) |
GetNamespaceDescriptorResponse |
getNamespaceDescriptor(RpcController controller,
GetNamespaceDescriptorRequest request) |
GetProcedureResultResponse |
getProcedureResult(RpcController controller,
GetProcedureResultRequest request) |
GetProceduresResponse |
getProcedures(RpcController rpcController,
GetProceduresRequest request) |
GetQuotaStatesResponse |
getQuotaStates(RpcController controller,
GetQuotaStatesRequest request) |
GetRegionInfoResponse |
getRegionInfo(RpcController controller,
GetRegionInfoRequest request) |
GetReplicationPeerConfigResponse |
getReplicationPeerConfig(RpcController controller,
GetReplicationPeerConfigRequest request) |
GetSchemaAlterStatusResponse |
getSchemaAlterStatus(RpcController controller,
GetSchemaAlterStatusRequest req)
Get the number of regions of the table that have been updated by the alter.
|
SecurityCapabilitiesResponse |
getSecurityCapabilities(RpcController controller,
SecurityCapabilitiesRequest request)
Returns the security capabilities in effect on the cluster
|
protected java.util.List<RpcServer.BlockingServiceAndInterface> |
getServices()
By default, put up an Admin and a Client Service.
|
GetSpaceQuotaRegionSizesResponse |
getSpaceQuotaRegionSizes(RpcController controller,
GetSpaceQuotaRegionSizesRequest request) |
GetTableDescriptorsResponse |
getTableDescriptors(RpcController c,
GetTableDescriptorsRequest req)
Get list of TableDescriptors for requested tables.
|
GetTableNamesResponse |
getTableNames(RpcController controller,
GetTableNamesRequest req)
Get list of userspace table names
|
GetTableStateResponse |
getTableState(RpcController controller,
GetTableStateRequest request) |
IsBalancerEnabledResponse |
isBalancerEnabled(RpcController controller,
IsBalancerEnabledRequest request) |
IsCatalogJanitorEnabledResponse |
isCatalogJanitorEnabled(RpcController c,
IsCatalogJanitorEnabledRequest req) |
IsCleanerChoreEnabledResponse |
isCleanerChoreEnabled(RpcController c,
IsCleanerChoreEnabledRequest req) |
IsInMaintenanceModeResponse |
isMasterInMaintenanceMode(RpcController controller,
IsInMaintenanceModeRequest request) |
IsMasterRunningResponse |
isMasterRunning(RpcController c,
IsMasterRunningRequest req) |
IsNormalizerEnabledResponse |
isNormalizerEnabled(RpcController controller,
IsNormalizerEnabledRequest request) |
IsProcedureDoneResponse |
isProcedureDone(RpcController controller,
IsProcedureDoneRequest request)
Checks if the specified procedure is done.
|
IsSnapshotDoneResponse |
isSnapshotDone(RpcController controller,
IsSnapshotDoneRequest request)
Checks if the specified snapshot is done.
|
IsSplitOrMergeEnabledResponse |
isSplitOrMergeEnabled(RpcController controller,
IsSplitOrMergeEnabledRequest request) |
ListDecommissionedRegionServersResponse |
listDecommissionedRegionServers(RpcController controller,
ListDecommissionedRegionServersRequest request) |
ListNamespaceDescriptorsResponse |
listNamespaceDescriptors(RpcController c,
ListNamespaceDescriptorsRequest request) |
ListReplicationPeersResponse |
listReplicationPeers(RpcController controller,
ListReplicationPeersRequest request) |
ListTableDescriptorsByNamespaceResponse |
listTableDescriptorsByNamespace(RpcController c,
ListTableDescriptorsByNamespaceRequest request) |
ListTableNamesByNamespaceResponse |
listTableNamesByNamespace(RpcController c,
ListTableNamesByNamespaceRequest request) |
LockHeartbeatResponse |
lockHeartbeat(RpcController controller,
LockHeartbeatRequest request) |
MergeTableRegionsResponse |
mergeTableRegions(RpcController c,
MergeTableRegionsRequest request) |
ModifyColumnResponse |
modifyColumn(RpcController controller,
ModifyColumnRequest req) |
ModifyNamespaceResponse |
modifyNamespace(RpcController controller,
ModifyNamespaceRequest request) |
ModifyTableResponse |
modifyTable(RpcController controller,
ModifyTableRequest req) |
MoveRegionResponse |
moveRegion(RpcController controller,
MoveRegionRequest req) |
NormalizeResponse |
normalize(RpcController controller,
NormalizeRequest request) |
OfflineRegionResponse |
offlineRegion(RpcController controller,
OfflineRegionRequest request)
Offline specified region from master's in-memory state.
|
RecommissionRegionServerResponse |
recommissionRegionServer(RpcController controller,
RecommissionRegionServerRequest request) |
RegionServerReportResponse |
regionServerReport(RpcController controller,
RegionServerReportRequest request) |
RegionServerStartupResponse |
regionServerStartup(RpcController controller,
RegionServerStartupRequest request) |
RemoveReplicationPeerResponse |
removeReplicationPeer(RpcController controller,
RemoveReplicationPeerRequest request) |
FileArchiveNotificationResponse |
reportFileArchival(RpcController controller,
FileArchiveNotificationRequest request) |
RegionSpaceUseReportResponse |
reportRegionSpaceUse(RpcController controller,
RegionSpaceUseReportRequest request) |
ReportRegionStateTransitionResponse |
reportRegionStateTransition(RpcController c,
ReportRegionStateTransitionRequest req) |
ReportRSFatalErrorResponse |
reportRSFatalError(RpcController controller,
ReportRSFatalErrorRequest request) |
LockResponse |
requestLock(RpcController controller,
LockRequest request) |
RestoreSnapshotResponse |
restoreSnapshot(RpcController controller,
RestoreSnapshotRequest request)
Execute Restore/Clone snapshot operation.
|
RunCatalogScanResponse |
runCatalogScan(RpcController c,
RunCatalogScanRequest req) |
RunCleanerChoreResponse |
runCleanerChore(RpcController c,
RunCleanerChoreRequest req) |
SetBalancerRunningResponse |
setBalancerRunning(RpcController c,
SetBalancerRunningRequest req) |
SetCleanerChoreRunningResponse |
setCleanerChoreRunning(RpcController c,
SetCleanerChoreRunningRequest req) |
SetNormalizerRunningResponse |
setNormalizerRunning(RpcController controller,
SetNormalizerRunningRequest request) |
SetQuotaResponse |
setQuota(RpcController c,
SetQuotaRequest req) |
SetSplitOrMergeEnabledResponse |
setSplitOrMergeEnabled(RpcController controller,
SetSplitOrMergeEnabledRequest request) |
ShutdownResponse |
shutdown(RpcController controller,
ShutdownRequest request) |
SnapshotResponse |
snapshot(RpcController controller,
SnapshotRequest request)
Triggers an asynchronous attempt to take a snapshot.
|
SplitTableRegionResponse |
splitRegion(RpcController controller,
SplitTableRegionRequest request) |
StopMasterResponse |
stopMaster(RpcController controller,
StopMasterRequest request) |
TruncateTableResponse |
truncateTable(RpcController controller,
TruncateTableRequest request) |
UnassignRegionResponse |
unassignRegion(RpcController controller,
UnassignRegionRequest req) |
UpdateReplicationPeerConfigResponse |
updateReplicationPeerConfig(RpcController controller,
UpdateReplicationPeerConfigRequest request) |
bulkLoadHFile, checkOOME, checkOpen, cleanupBulkLoad, clearCompactionQueues, clearRegionBlockCache, closeRegion, execRegionServerService, execService, executeProcedures, exitIfOOME, flushRegion, get, getConfiguration, getDeadline, getHostname, getOnlineRegion, getPriority, getPriority, getRegion, getRegionLoad, getScanDetailsWithId, getScanner, getScannersCount, getServerInfo, getSocketAddress, getSpaceQuotaSnapshots, getStoreFile, multi, mutate, onConfigurationChange, openRegion, prepareBulkLoad, replay, replicateWALEntry, requirePermission, rollWALWriter, scan, stopServer, updateConfiguration, updateFavoredNodes, warmupRegionpublic MasterRpcServices(HMaster m) throws java.io.IOException
java.io.IOExceptionprotected RpcServerInterface createRpcServer(Server server, Configuration conf, RpcSchedulerFactory rpcSchedulerFactory, java.net.InetSocketAddress bindAddress, java.lang.String name) throws java.io.IOException
createRpcServer in class RSRpcServicesjava.io.IOExceptionprotected PriorityFunction createPriority()
createPriority in class RSRpcServicesprotected java.util.List<RpcServer.BlockingServiceAndInterface> getServices()
RSRpcServiceshbase.regionserver.admin.executorService and
hbase.regionserver.client.executorService if you want to enable/disable services.
Default is that both are enabled.getServices in class RSRpcServicespublic GetLastFlushedSequenceIdResponse getLastFlushedSequenceId(RpcController controller,
GetLastFlushedSequenceIdRequest request)
throws ServiceException
ServiceExceptionpublic RegionServerReportResponse regionServerReport(RpcController controller,
RegionServerReportRequest request)
throws ServiceException
ServiceExceptionpublic RegionServerStartupResponse regionServerStartup(RpcController controller,
RegionServerStartupRequest request)
throws ServiceException
ServiceExceptionpublic ReportRSFatalErrorResponse reportRSFatalError(RpcController controller,
ReportRSFatalErrorRequest request)
throws ServiceException
ServiceExceptionpublic AddColumnResponse addColumn(RpcController controller,
AddColumnRequest req)
throws ServiceException
ServiceExceptionpublic AssignRegionResponse assignRegion(RpcController controller,
AssignRegionRequest req)
throws ServiceException
ServiceExceptionpublic BalanceResponse balance(RpcController controller,
BalanceRequest request)
throws ServiceException
ServiceExceptionpublic CreateNamespaceResponse createNamespace(RpcController controller,
CreateNamespaceRequest request)
throws ServiceException
ServiceExceptionpublic CreateTableResponse createTable(RpcController controller,
CreateTableRequest req)
throws ServiceException
ServiceExceptionpublic DeleteColumnResponse deleteColumn(RpcController controller,
DeleteColumnRequest req)
throws ServiceException
ServiceExceptionpublic DeleteNamespaceResponse deleteNamespace(RpcController controller,
DeleteNamespaceRequest request)
throws ServiceException
ServiceExceptionpublic DeleteSnapshotResponse deleteSnapshot(RpcController controller,
DeleteSnapshotRequest request)
throws ServiceException
ServiceException - wrapping SnapshotDoesNotExistException if specified snapshot did not
exist.public DeleteTableResponse deleteTable(RpcController controller,
DeleteTableRequest request)
throws ServiceException
ServiceExceptionpublic TruncateTableResponse truncateTable(RpcController controller,
TruncateTableRequest request)
throws ServiceException
ServiceExceptionpublic DisableTableResponse disableTable(RpcController controller,
DisableTableRequest request)
throws ServiceException
ServiceExceptionpublic EnableCatalogJanitorResponse enableCatalogJanitor(RpcController c,
EnableCatalogJanitorRequest req)
throws ServiceException
ServiceExceptionpublic SetCleanerChoreRunningResponse setCleanerChoreRunning(RpcController c,
SetCleanerChoreRunningRequest req)
throws ServiceException
ServiceExceptionpublic EnableTableResponse enableTable(RpcController controller,
EnableTableRequest request)
throws ServiceException
ServiceExceptionpublic MergeTableRegionsResponse mergeTableRegions(RpcController c,
MergeTableRegionsRequest request)
throws ServiceException
ServiceExceptionpublic SplitTableRegionResponse splitRegion(RpcController controller,
SplitTableRegionRequest request)
throws ServiceException
ServiceExceptionpublic ClientProtos.CoprocessorServiceResponse execMasterService(RpcController controller,
ClientProtos.CoprocessorServiceRequest request)
throws ServiceException
ServiceExceptionpublic ExecProcedureResponse execProcedure(RpcController controller,
ExecProcedureRequest request)
throws ServiceException
ServiceExceptionpublic ExecProcedureResponse execProcedureWithRet(RpcController controller,
ExecProcedureRequest request)
throws ServiceException
ServiceExceptionpublic GetClusterStatusResponse getClusterStatus(RpcController controller,
GetClusterStatusRequest req)
throws ServiceException
ServiceExceptionpublic GetCompletedSnapshotsResponse getCompletedSnapshots(RpcController controller,
GetCompletedSnapshotsRequest request)
throws ServiceException
ServiceExceptionpublic GetNamespaceDescriptorResponse getNamespaceDescriptor(RpcController controller,
GetNamespaceDescriptorRequest request)
throws ServiceException
ServiceExceptionpublic GetSchemaAlterStatusResponse getSchemaAlterStatus(RpcController controller,
GetSchemaAlterStatusRequest req)
throws ServiceException
ServiceExceptionpublic GetTableDescriptorsResponse getTableDescriptors(RpcController c,
GetTableDescriptorsRequest req)
throws ServiceException
c - Unused (set to null).req - GetTableDescriptorsRequest that contains:
- tableNames: requested tables, or if empty, all are requestedServiceExceptionpublic GetTableNamesResponse getTableNames(RpcController controller,
GetTableNamesRequest req)
throws ServiceException
controller - Unused (set to null).req - GetTableNamesRequestServiceExceptionpublic GetTableStateResponse getTableState(RpcController controller,
GetTableStateRequest request)
throws ServiceException
ServiceExceptionpublic IsCatalogJanitorEnabledResponse isCatalogJanitorEnabled(RpcController c,
IsCatalogJanitorEnabledRequest req)
throws ServiceException
ServiceExceptionpublic IsCleanerChoreEnabledResponse isCleanerChoreEnabled(RpcController c,
IsCleanerChoreEnabledRequest req)
throws ServiceException
ServiceExceptionpublic IsMasterRunningResponse isMasterRunning(RpcController c,
IsMasterRunningRequest req)
throws ServiceException
ServiceExceptionpublic IsProcedureDoneResponse isProcedureDone(RpcController controller,
IsProcedureDoneRequest request)
throws ServiceException
ServiceException - if invalid procedure or failed procedure with progress failure reason.public IsSnapshotDoneResponse isSnapshotDone(RpcController controller,
IsSnapshotDoneRequest request)
throws ServiceException
ServiceException - wrapping UnknownSnapshotException if invalid snapshot, or
a wrapped HBaseSnapshotException with progress failure reason.public GetProcedureResultResponse getProcedureResult(RpcController controller,
GetProcedureResultRequest request)
throws ServiceException
ServiceExceptionpublic AbortProcedureResponse abortProcedure(RpcController rpcController,
AbortProcedureRequest request)
throws ServiceException
ServiceExceptionpublic ListNamespaceDescriptorsResponse listNamespaceDescriptors(RpcController c,
ListNamespaceDescriptorsRequest request)
throws ServiceException
ServiceExceptionpublic GetProceduresResponse getProcedures(RpcController rpcController,
GetProceduresRequest request)
throws ServiceException
ServiceExceptionpublic GetLocksResponse getLocks(RpcController controller,
GetLocksRequest request)
throws ServiceException
ServiceExceptionpublic ListTableDescriptorsByNamespaceResponse listTableDescriptorsByNamespace(RpcController c,
ListTableDescriptorsByNamespaceRequest request)
throws ServiceException
ServiceExceptionpublic ListTableNamesByNamespaceResponse listTableNamesByNamespace(RpcController c,
ListTableNamesByNamespaceRequest request)
throws ServiceException
ServiceExceptionpublic ModifyColumnResponse modifyColumn(RpcController controller,
ModifyColumnRequest req)
throws ServiceException
ServiceExceptionpublic ModifyNamespaceResponse modifyNamespace(RpcController controller,
ModifyNamespaceRequest request)
throws ServiceException
ServiceExceptionpublic ModifyTableResponse modifyTable(RpcController controller,
ModifyTableRequest req)
throws ServiceException
ServiceExceptionpublic MoveRegionResponse moveRegion(RpcController controller,
MoveRegionRequest req)
throws ServiceException
ServiceExceptionpublic OfflineRegionResponse offlineRegion(RpcController controller,
OfflineRegionRequest request)
throws ServiceException
ServiceExceptionpublic RestoreSnapshotResponse restoreSnapshot(RpcController controller,
RestoreSnapshotRequest request)
throws ServiceException
If the specified table exists a "Restore" is executed, replacing the table schema and directory data with the content of the snapshot. The table must be disabled, or a UnsupportedOperationException will be thrown.
If the table doesn't exist a "Clone" is executed, a new table is created using the schema at the time of the snapshot, and the content of the snapshot.
The restore/clone operation does not require copying HFiles. Since HFiles are immutable the table can point to and use the same files as the original one.
ServiceExceptionpublic RunCatalogScanResponse runCatalogScan(RpcController c,
RunCatalogScanRequest req)
throws ServiceException
ServiceExceptionpublic RunCleanerChoreResponse runCleanerChore(RpcController c,
RunCleanerChoreRequest req)
throws ServiceException
ServiceExceptionpublic SetBalancerRunningResponse setBalancerRunning(RpcController c,
SetBalancerRunningRequest req)
throws ServiceException
ServiceExceptionpublic ShutdownResponse shutdown(RpcController controller,
ShutdownRequest request)
throws ServiceException
ServiceExceptionpublic SnapshotResponse snapshot(RpcController controller,
SnapshotRequest request)
throws ServiceException
ServiceExceptionpublic StopMasterResponse stopMaster(RpcController controller,
StopMasterRequest request)
throws ServiceException
ServiceExceptionpublic IsInMaintenanceModeResponse isMasterInMaintenanceMode(RpcController controller,
IsInMaintenanceModeRequest request)
throws ServiceException
ServiceExceptionpublic UnassignRegionResponse unassignRegion(RpcController controller,
UnassignRegionRequest req)
throws ServiceException
ServiceExceptionpublic ReportRegionStateTransitionResponse reportRegionStateTransition(RpcController c,
ReportRegionStateTransitionRequest req)
throws ServiceException
ServiceExceptionpublic SetQuotaResponse setQuota(RpcController c,
SetQuotaRequest req)
throws ServiceException
ServiceExceptionpublic MajorCompactionTimestampResponse getLastMajorCompactionTimestamp(RpcController controller,
MajorCompactionTimestampRequest request)
throws ServiceException
ServiceExceptionpublic MajorCompactionTimestampResponse getLastMajorCompactionTimestampForRegion(RpcController controller,
MajorCompactionTimestampForRegionRequest request)
throws ServiceException
ServiceExceptionpublic CompactRegionResponse compactRegion(RpcController controller,
CompactRegionRequest request)
throws ServiceException
compactRegion in class RSRpcServicescontroller - the RPC controllerrequest - the requestServiceExceptionpublic GetRegionInfoResponse getRegionInfo(RpcController controller,
GetRegionInfoRequest request)
throws ServiceException
getRegionInfo in class RSRpcServicesServiceExceptionpublic IsBalancerEnabledResponse isBalancerEnabled(RpcController controller,
IsBalancerEnabledRequest request)
throws ServiceException
ServiceExceptionpublic SetSplitOrMergeEnabledResponse setSplitOrMergeEnabled(RpcController controller,
SetSplitOrMergeEnabledRequest request)
throws ServiceException
ServiceExceptionpublic IsSplitOrMergeEnabledResponse isSplitOrMergeEnabled(RpcController controller,
IsSplitOrMergeEnabledRequest request)
throws ServiceException
ServiceExceptionpublic NormalizeResponse normalize(RpcController controller,
NormalizeRequest request)
throws ServiceException
ServiceExceptionpublic SetNormalizerRunningResponse setNormalizerRunning(RpcController controller,
SetNormalizerRunningRequest request)
throws ServiceException
ServiceExceptionpublic IsNormalizerEnabledResponse isNormalizerEnabled(RpcController controller,
IsNormalizerEnabledRequest request)
throws ServiceException
ServiceExceptionpublic SecurityCapabilitiesResponse getSecurityCapabilities(RpcController controller,
SecurityCapabilitiesRequest request)
throws ServiceException
ServiceExceptionpublic AddReplicationPeerResponse addReplicationPeer(RpcController controller,
AddReplicationPeerRequest request)
throws ServiceException
ServiceExceptionpublic RemoveReplicationPeerResponse removeReplicationPeer(RpcController controller,
RemoveReplicationPeerRequest request)
throws ServiceException
ServiceExceptionpublic EnableReplicationPeerResponse enableReplicationPeer(RpcController controller,
EnableReplicationPeerRequest request)
throws ServiceException
ServiceExceptionpublic DisableReplicationPeerResponse disableReplicationPeer(RpcController controller,
DisableReplicationPeerRequest request)
throws ServiceException
ServiceExceptionpublic GetReplicationPeerConfigResponse getReplicationPeerConfig(RpcController controller,
GetReplicationPeerConfigRequest request)
throws ServiceException
ServiceExceptionpublic UpdateReplicationPeerConfigResponse updateReplicationPeerConfig(RpcController controller,
UpdateReplicationPeerConfigRequest request)
throws ServiceException
ServiceExceptionpublic ListReplicationPeersResponse listReplicationPeers(RpcController controller,
ListReplicationPeersRequest request)
throws ServiceException
ServiceExceptionpublic ListDecommissionedRegionServersResponse listDecommissionedRegionServers(RpcController controller,
ListDecommissionedRegionServersRequest request)
throws ServiceException
ServiceExceptionpublic DecommissionRegionServersResponse decommissionRegionServers(RpcController controller,
DecommissionRegionServersRequest request)
throws ServiceException
ServiceExceptionpublic RecommissionRegionServerResponse recommissionRegionServer(RpcController controller,
RecommissionRegionServerRequest request)
throws ServiceException
ServiceExceptionpublic LockResponse requestLock(RpcController controller,
LockRequest request)
throws ServiceException
ServiceExceptionpublic LockHeartbeatResponse lockHeartbeat(RpcController controller,
LockHeartbeatRequest request)
throws ServiceException
ServiceException - if given proc id is found but it is not a LockProcedure.public RegionSpaceUseReportResponse reportRegionSpaceUse(RpcController controller,
RegionSpaceUseReportRequest request)
throws ServiceException
ServiceExceptionpublic GetSpaceQuotaRegionSizesResponse getSpaceQuotaRegionSizes(RpcController controller,
GetSpaceQuotaRegionSizesRequest request)
throws ServiceException
ServiceExceptionpublic GetQuotaStatesResponse getQuotaStates(RpcController controller,
GetQuotaStatesRequest request)
throws ServiceException
ServiceExceptionpublic ClearDeadServersResponse clearDeadServers(RpcController controller,
ClearDeadServersRequest request)
throws ServiceException
ServiceExceptionpublic FileArchiveNotificationResponse reportFileArchival(RpcController controller,
FileArchiveNotificationRequest request)
throws ServiceException
ServiceException