@InterfaceAudience.Private public class MasterRpcServices extends RSRpcServices implements MasterProtos.MasterService.BlockingInterface, RegionServerStatusProtos.RegionServerStatusService.BlockingInterface, LockServiceProtos.LockService.BlockingInterface, MasterProtos.HbckService.BlockingInterface
accessChecker, MASTER_RPC_SCHEDULER_FACTORY_CLASS, 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 |
---|---|
MasterProtos.AbortProcedureResponse |
abortProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
MasterProtos.AbortProcedureRequest request) |
MasterProtos.AddColumnResponse |
addColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.AddColumnRequest req) |
ReplicationProtos.AddReplicationPeerResponse |
addReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ReplicationProtos.AddReplicationPeerRequest request) |
MasterProtos.AssignRegionResponse |
assignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.AssignRegionRequest req) |
MasterProtos.AssignsResponse |
assigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.AssignsRequest request)
A 'raw' version of assign that does bulk and skirts Master state checks (assigns can be made
during Master startup).
|
MasterProtos.BalanceResponse |
balance(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.BalanceRequest request) |
MasterProtos.BypassProcedureResponse |
bypassProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.BypassProcedureRequest request)
Bypass specified procedure to completion.
|
MasterProtos.ClearDeadServersResponse |
clearDeadServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ClearDeadServersRequest request) |
AdminProtos.CompactRegionResponse |
compactRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
AdminProtos.CompactRegionRequest request)
Compact a region on the master.
|
MasterProtos.CreateNamespaceResponse |
createNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.CreateNamespaceRequest request) |
protected PriorityFunction |
createPriority() |
protected RpcServerInterface |
createRpcServer(Server server,
org.apache.hadoop.conf.Configuration conf,
RpcSchedulerFactory rpcSchedulerFactory,
InetSocketAddress bindAddress,
String name) |
MasterProtos.CreateTableResponse |
createTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.CreateTableRequest req) |
MasterProtos.DecommissionRegionServersResponse |
decommissionRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.DecommissionRegionServersRequest request) |
MasterProtos.DeleteColumnResponse |
deleteColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.DeleteColumnRequest req) |
MasterProtos.DeleteNamespaceResponse |
deleteNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.DeleteNamespaceRequest request) |
MasterProtos.DeleteSnapshotResponse |
deleteSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.DeleteSnapshotRequest request)
Execute Delete Snapshot operation.
|
MasterProtos.DeleteTableResponse |
deleteTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.DeleteTableRequest request) |
ReplicationProtos.DisableReplicationPeerResponse |
disableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ReplicationProtos.DisableReplicationPeerRequest request) |
MasterProtos.DisableTableResponse |
disableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.DisableTableRequest request) |
MasterProtos.EnableCatalogJanitorResponse |
enableCatalogJanitor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.EnableCatalogJanitorRequest req) |
ReplicationProtos.EnableReplicationPeerResponse |
enableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ReplicationProtos.EnableReplicationPeerRequest request) |
MasterProtos.EnableTableResponse |
enableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.EnableTableRequest request) |
ClientProtos.CoprocessorServiceResponse |
execMasterService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ClientProtos.CoprocessorServiceRequest request) |
MasterProtos.ExecProcedureResponse |
execProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ExecProcedureRequest request)
Triggers an asynchronous attempt to run a distributed procedure.
|
MasterProtos.ExecProcedureResponse |
execProcedureWithRet(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ExecProcedureRequest request)
Triggers a synchronous attempt to run a distributed procedure and sets
return data in response.
|
MasterProtos.GetClusterStatusResponse |
getClusterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetClusterStatusRequest req) |
MasterProtos.GetCompletedSnapshotsResponse |
getCompletedSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetCompletedSnapshotsRequest request)
List the currently available/stored snapshots.
|
RegionServerStatusProtos.GetLastFlushedSequenceIdResponse |
getLastFlushedSequenceId(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
RegionServerStatusProtos.GetLastFlushedSequenceIdRequest request) |
MasterProtos.MajorCompactionTimestampResponse |
getLastMajorCompactionTimestamp(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.MajorCompactionTimestampRequest request) |
MasterProtos.MajorCompactionTimestampResponse |
getLastMajorCompactionTimestampForRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.MajorCompactionTimestampForRegionRequest request) |
MasterProtos.GetLocksResponse |
getLocks(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetLocksRequest request) |
MasterProtos.GetNamespaceDescriptorResponse |
getNamespaceDescriptor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetNamespaceDescriptorRequest request) |
MasterProtos.GetProcedureResultResponse |
getProcedureResult(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetProcedureResultRequest request) |
MasterProtos.GetProceduresResponse |
getProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
MasterProtos.GetProceduresRequest request) |
QuotaProtos.GetQuotaStatesResponse |
getQuotaStates(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
QuotaProtos.GetQuotaStatesRequest request) |
AdminProtos.GetRegionInfoResponse |
getRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
AdminProtos.GetRegionInfoRequest request) |
ReplicationProtos.GetReplicationPeerConfigResponse |
getReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ReplicationProtos.GetReplicationPeerConfigRequest request) |
protected Class<?> |
getRpcSchedulerFactoryClass() |
MasterProtos.GetSchemaAlterStatusResponse |
getSchemaAlterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetSchemaAlterStatusRequest req)
Get the number of regions of the table that have been updated by the alter.
|
MasterProtos.SecurityCapabilitiesResponse |
getSecurityCapabilities(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.SecurityCapabilitiesRequest request)
Returns the security capabilities in effect on the cluster
|
protected List<RpcServer.BlockingServiceAndInterface> |
getServices()
By default, put up an Admin and a Client Service.
|
QuotaProtos.GetSpaceQuotaRegionSizesResponse |
getSpaceQuotaRegionSizes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
QuotaProtos.GetSpaceQuotaRegionSizesRequest request) |
MasterProtos.GetTableDescriptorsResponse |
getTableDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.GetTableDescriptorsRequest req)
Get list of TableDescriptors for requested tables.
|
MasterProtos.GetTableNamesResponse |
getTableNames(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetTableNamesRequest req)
Get list of userspace table names
|
MasterProtos.GetTableStateResponse |
getTableState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.GetTableStateRequest request) |
MasterProtos.IsBalancerEnabledResponse |
isBalancerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.IsBalancerEnabledRequest request) |
MasterProtos.IsCatalogJanitorEnabledResponse |
isCatalogJanitorEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.IsCatalogJanitorEnabledRequest req) |
MasterProtos.IsCleanerChoreEnabledResponse |
isCleanerChoreEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.IsCleanerChoreEnabledRequest req) |
MasterProtos.IsInMaintenanceModeResponse |
isMasterInMaintenanceMode(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.IsInMaintenanceModeRequest request) |
MasterProtos.IsMasterRunningResponse |
isMasterRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.IsMasterRunningRequest req) |
MasterProtos.IsNormalizerEnabledResponse |
isNormalizerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.IsNormalizerEnabledRequest request) |
MasterProtos.IsProcedureDoneResponse |
isProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.IsProcedureDoneRequest request)
Checks if the specified procedure is done.
|
MasterProtos.IsSnapshotDoneResponse |
isSnapshotDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.IsSnapshotDoneRequest request)
Checks if the specified snapshot is done.
|
MasterProtos.IsSplitOrMergeEnabledResponse |
isSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.IsSplitOrMergeEnabledRequest request) |
MasterProtos.ListDecommissionedRegionServersResponse |
listDecommissionedRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ListDecommissionedRegionServersRequest request) |
MasterProtos.ListNamespaceDescriptorsResponse |
listNamespaceDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.ListNamespaceDescriptorsRequest request) |
ReplicationProtos.ListReplicationPeersResponse |
listReplicationPeers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ReplicationProtos.ListReplicationPeersRequest request) |
MasterProtos.ListTableDescriptorsByNamespaceResponse |
listTableDescriptorsByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.ListTableDescriptorsByNamespaceRequest request) |
MasterProtos.ListTableNamesByNamespaceResponse |
listTableNamesByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.ListTableNamesByNamespaceRequest request) |
LockServiceProtos.LockHeartbeatResponse |
lockHeartbeat(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
LockServiceProtos.LockHeartbeatRequest request) |
MasterProtos.MergeTableRegionsResponse |
mergeTableRegions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.MergeTableRegionsRequest request) |
MasterProtos.ModifyColumnResponse |
modifyColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ModifyColumnRequest req) |
MasterProtos.ModifyNamespaceResponse |
modifyNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ModifyNamespaceRequest request) |
MasterProtos.ModifyTableResponse |
modifyTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ModifyTableRequest req) |
MasterProtos.MoveRegionResponse |
moveRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.MoveRegionRequest req) |
MasterProtos.NormalizeResponse |
normalize(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.NormalizeRequest request) |
MasterProtos.OfflineRegionResponse |
offlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.OfflineRegionRequest request)
Offline specified region from master's in-memory state.
|
MasterProtos.RecommissionRegionServerResponse |
recommissionRegionServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.RecommissionRegionServerRequest request) |
RegionServerStatusProtos.RegionServerReportResponse |
regionServerReport(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
RegionServerStatusProtos.RegionServerReportRequest request) |
RegionServerStatusProtos.RegionServerStartupResponse |
regionServerStartup(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
RegionServerStatusProtos.RegionServerStartupRequest request) |
ReplicationProtos.RemoveReplicationPeerResponse |
removeReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ReplicationProtos.RemoveReplicationPeerRequest request) |
RegionServerStatusProtos.ReportProcedureDoneResponse |
reportProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
RegionServerStatusProtos.ReportProcedureDoneRequest request) |
RegionServerStatusProtos.RegionSpaceUseReportResponse |
reportRegionSpaceUse(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
RegionServerStatusProtos.RegionSpaceUseReportRequest request) |
RegionServerStatusProtos.ReportRegionStateTransitionResponse |
reportRegionStateTransition(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
RegionServerStatusProtos.ReportRegionStateTransitionRequest req) |
RegionServerStatusProtos.ReportRSFatalErrorResponse |
reportRSFatalError(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
RegionServerStatusProtos.ReportRSFatalErrorRequest request) |
LockServiceProtos.LockResponse |
requestLock(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
LockServiceProtos.LockRequest request) |
MasterProtos.RestoreSnapshotResponse |
restoreSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.RestoreSnapshotRequest request)
Execute Restore/Clone snapshot operation.
|
MasterProtos.RunCatalogScanResponse |
runCatalogScan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.RunCatalogScanRequest req) |
MasterProtos.RunCleanerChoreResponse |
runCleanerChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.RunCleanerChoreRequest req) |
MasterProtos.ScheduleServerCrashProcedureResponse |
scheduleServerCrashProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ScheduleServerCrashProcedureRequest request) |
MasterProtos.SetBalancerRunningResponse |
setBalancerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.SetBalancerRunningRequest req) |
MasterProtos.SetCleanerChoreRunningResponse |
setCleanerChoreRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.SetCleanerChoreRunningRequest req) |
MasterProtos.SetNormalizerRunningResponse |
setNormalizerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.SetNormalizerRunningRequest request) |
MasterProtos.SetQuotaResponse |
setQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
MasterProtos.SetQuotaRequest req) |
MasterProtos.SetSplitOrMergeEnabledResponse |
setSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.SetSplitOrMergeEnabledRequest request) |
MasterProtos.GetTableStateResponse |
setTableStateInMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.SetTableStateInMetaRequest request)
Update state of the table in meta only.
|
MasterProtos.ShutdownResponse |
shutdown(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.ShutdownRequest request) |
MasterProtos.SnapshotResponse |
snapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.SnapshotRequest request)
Triggers an asynchronous attempt to take a snapshot.
|
MasterProtos.SplitTableRegionResponse |
splitRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.SplitTableRegionRequest request) |
MasterProtos.StopMasterResponse |
stopMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.StopMasterRequest request) |
MasterProtos.TruncateTableResponse |
truncateTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.TruncateTableRequest request) |
MasterProtos.UnassignRegionResponse |
unassignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.UnassignRegionRequest req) |
MasterProtos.UnassignsResponse |
unassigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
MasterProtos.UnassignsRequest request)
A 'raw' version of unassign that does bulk and skirts Master state checks (unassigns can be
made during Master startup).
|
ReplicationProtos.UpdateReplicationPeerConfigResponse |
updateReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
ReplicationProtos.UpdateReplicationPeerConfigRequest request) |
bulkLoadHFile, checkOOME, checkOpen, cleanupBulkLoad, clearCompactionQueues, clearRegionBlockCache, closeRegion, execRegionServerService, execService, executeProcedures, exitIfOOME, flushRegion, get, getConfiguration, getDeadline, getHostname, getOnlineRegion, getPriority, getPriority, getRegion, getRegionLoad, getRpcScheduler, getScanDetailsWithId, getScanner, getScannersCount, getServerInfo, getSocketAddress, getSpaceQuotaSnapshots, getStoreFile, multi, mutate, onConfigurationChange, openRegion, prepareBulkLoad, replay, replicateWALEntry, requirePermission, rollWALWriter, scan, stopServer, updateConfiguration, updateFavoredNodes, warmupRegion
public MasterRpcServices(HMaster m) throws IOException
IOException
protected Class<?> getRpcSchedulerFactoryClass()
getRpcSchedulerFactoryClass
in class RSRpcServices
protected RpcServerInterface createRpcServer(Server server, org.apache.hadoop.conf.Configuration conf, RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name) throws IOException
createRpcServer
in class RSRpcServices
IOException
protected PriorityFunction createPriority()
createPriority
in class RSRpcServices
protected List<RpcServer.BlockingServiceAndInterface> getServices()
RSRpcServices
hbase.regionserver.admin.executorService
and
hbase.regionserver.client.executorService
if you want to enable/disable services.
Default is that both are enabled.getServices
in class RSRpcServices
public RegionServerStatusProtos.GetLastFlushedSequenceIdResponse getLastFlushedSequenceId(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLastFlushedSequenceId
in interface RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public RegionServerStatusProtos.RegionServerReportResponse regionServerReport(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, RegionServerStatusProtos.RegionServerReportRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
regionServerReport
in interface RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public RegionServerStatusProtos.RegionServerStartupResponse regionServerStartup(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, RegionServerStatusProtos.RegionServerStartupRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
regionServerStartup
in interface RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public RegionServerStatusProtos.ReportRSFatalErrorResponse reportRSFatalError(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, RegionServerStatusProtos.ReportRSFatalErrorRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportRSFatalError
in interface RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.AddColumnResponse addColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.AddColumnRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
addColumn
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.AssignRegionResponse assignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.AssignRegionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
assignRegion
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.BalanceResponse balance(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.BalanceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
balance
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.CreateNamespaceResponse createNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.CreateNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
createNamespace
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.CreateTableResponse createTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.CreateTableRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
createTable
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.DeleteColumnResponse deleteColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.DeleteColumnRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteColumn
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.DeleteNamespaceResponse deleteNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.DeleteNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteNamespace
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.DeleteSnapshotResponse deleteSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.DeleteSnapshotRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteSnapshot
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- wrapping SnapshotDoesNotExistException if specified snapshot did not
exist.public MasterProtos.DeleteTableResponse deleteTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.DeleteTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteTable
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.TruncateTableResponse truncateTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.TruncateTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
truncateTable
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.DisableTableResponse disableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.DisableTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
disableTable
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.EnableCatalogJanitorResponse enableCatalogJanitor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.EnableCatalogJanitorRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
enableCatalogJanitor
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SetCleanerChoreRunningResponse setCleanerChoreRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.SetCleanerChoreRunningRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setCleanerChoreRunning
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.EnableTableResponse enableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.EnableTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
enableTable
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.MergeTableRegionsResponse mergeTableRegions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.MergeTableRegionsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
mergeTableRegions
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SplitTableRegionResponse splitRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.SplitTableRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
splitRegion
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ClientProtos.CoprocessorServiceResponse execMasterService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ClientProtos.CoprocessorServiceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
execMasterService
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ExecProcedureResponse execProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ExecProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
execProcedure
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ExecProcedureResponse execProcedureWithRet(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ExecProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
execProcedureWithRet
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetClusterStatusResponse getClusterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetClusterStatusRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getClusterStatus
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetCompletedSnapshotsResponse getCompletedSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetCompletedSnapshotsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getCompletedSnapshots
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetNamespaceDescriptorResponse getNamespaceDescriptor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetNamespaceDescriptorRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getNamespaceDescriptor
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetSchemaAlterStatusResponse getSchemaAlterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetSchemaAlterStatusRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getSchemaAlterStatus
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetTableDescriptorsResponse getTableDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.GetTableDescriptorsRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getTableDescriptors
in interface MasterProtos.MasterService.BlockingInterface
c
- Unused (set to null).req
- GetTableDescriptorsRequest that contains:
- tableNames: requested tables, or if empty, all are requestedorg.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetTableNamesResponse getTableNames(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetTableNamesRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getTableNames
in interface MasterProtos.MasterService.BlockingInterface
controller
- Unused (set to null).req
- GetTableNamesRequestorg.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetTableStateResponse getTableState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetTableStateRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getTableState
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsCatalogJanitorEnabledResponse isCatalogJanitorEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.IsCatalogJanitorEnabledRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isCatalogJanitorEnabled
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsCleanerChoreEnabledResponse isCleanerChoreEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.IsCleanerChoreEnabledRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isCleanerChoreEnabled
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsMasterRunningResponse isMasterRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.IsMasterRunningRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isMasterRunning
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsProcedureDoneResponse isProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.IsProcedureDoneRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isProcedureDone
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- if invalid procedure or failed procedure with progress failure reason.public MasterProtos.IsSnapshotDoneResponse isSnapshotDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.IsSnapshotDoneRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isSnapshotDone
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- wrapping UnknownSnapshotException if invalid snapshot, or
a wrapped HBaseSnapshotException with progress failure reason.public MasterProtos.GetProcedureResultResponse getProcedureResult(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetProcedureResultRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getProcedureResult
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.AbortProcedureResponse abortProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, MasterProtos.AbortProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
abortProcedure
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ListNamespaceDescriptorsResponse listNamespaceDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.ListNamespaceDescriptorsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listNamespaceDescriptors
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetProceduresResponse getProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, MasterProtos.GetProceduresRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getProcedures
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetLocksResponse getLocks(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.GetLocksRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLocks
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ListTableDescriptorsByNamespaceResponse listTableDescriptorsByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.ListTableDescriptorsByNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listTableDescriptorsByNamespace
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ListTableNamesByNamespaceResponse listTableNamesByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.ListTableNamesByNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listTableNamesByNamespace
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ModifyColumnResponse modifyColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ModifyColumnRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyColumn
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ModifyNamespaceResponse modifyNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ModifyNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyNamespace
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ModifyTableResponse modifyTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ModifyTableRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyTable
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.MoveRegionResponse moveRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.MoveRegionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
moveRegion
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.OfflineRegionResponse offlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.OfflineRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
offlineRegion
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.RestoreSnapshotResponse restoreSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.RestoreSnapshotRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.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.
restoreSnapshot
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.RunCatalogScanResponse runCatalogScan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.RunCatalogScanRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
runCatalogScan
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.RunCleanerChoreResponse runCleanerChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.RunCleanerChoreRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
runCleanerChore
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SetBalancerRunningResponse setBalancerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.SetBalancerRunningRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setBalancerRunning
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ShutdownResponse shutdown(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ShutdownRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
shutdown
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SnapshotResponse snapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.SnapshotRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
snapshot
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.StopMasterResponse stopMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.StopMasterRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
stopMaster
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsInMaintenanceModeResponse isMasterInMaintenanceMode(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.IsInMaintenanceModeRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isMasterInMaintenanceMode
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.UnassignRegionResponse unassignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.UnassignRegionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
unassignRegion
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public RegionServerStatusProtos.ReportRegionStateTransitionResponse reportRegionStateTransition(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, RegionServerStatusProtos.ReportRegionStateTransitionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportRegionStateTransition
in interface RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SetQuotaResponse setQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, MasterProtos.SetQuotaRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setQuota
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.MajorCompactionTimestampResponse getLastMajorCompactionTimestamp(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.MajorCompactionTimestampRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLastMajorCompactionTimestamp
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.MajorCompactionTimestampResponse getLastMajorCompactionTimestampForRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.MajorCompactionTimestampForRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLastMajorCompactionTimestampForRegion
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public AdminProtos.CompactRegionResponse compactRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, AdminProtos.CompactRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
compactRegion
in interface AdminProtos.AdminService.BlockingInterface
compactRegion
in class RSRpcServices
controller
- the RPC controllerrequest
- the requestorg.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public AdminProtos.GetRegionInfoResponse getRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, AdminProtos.GetRegionInfoRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getRegionInfo
in interface AdminProtos.AdminService.BlockingInterface
getRegionInfo
in class RSRpcServices
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsBalancerEnabledResponse isBalancerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.IsBalancerEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isBalancerEnabled
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SetSplitOrMergeEnabledResponse setSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.SetSplitOrMergeEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setSplitOrMergeEnabled
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsSplitOrMergeEnabledResponse isSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.IsSplitOrMergeEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isSplitOrMergeEnabled
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.NormalizeResponse normalize(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.NormalizeRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
normalize
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SetNormalizerRunningResponse setNormalizerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.SetNormalizerRunningRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setNormalizerRunning
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.IsNormalizerEnabledResponse isNormalizerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.IsNormalizerEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isNormalizerEnabled
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.SecurityCapabilitiesResponse getSecurityCapabilities(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.SecurityCapabilitiesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getSecurityCapabilities
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ReplicationProtos.AddReplicationPeerResponse addReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ReplicationProtos.AddReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
addReplicationPeer
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ReplicationProtos.RemoveReplicationPeerResponse removeReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ReplicationProtos.RemoveReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
removeReplicationPeer
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ReplicationProtos.EnableReplicationPeerResponse enableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ReplicationProtos.EnableReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
enableReplicationPeer
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ReplicationProtos.DisableReplicationPeerResponse disableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ReplicationProtos.DisableReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
disableReplicationPeer
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ReplicationProtos.GetReplicationPeerConfigResponse getReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ReplicationProtos.GetReplicationPeerConfigRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getReplicationPeerConfig
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ReplicationProtos.UpdateReplicationPeerConfigResponse updateReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ReplicationProtos.UpdateReplicationPeerConfigRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
updateReplicationPeerConfig
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public ReplicationProtos.ListReplicationPeersResponse listReplicationPeers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, ReplicationProtos.ListReplicationPeersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listReplicationPeers
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ListDecommissionedRegionServersResponse listDecommissionedRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ListDecommissionedRegionServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listDecommissionedRegionServers
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.DecommissionRegionServersResponse decommissionRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.DecommissionRegionServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
decommissionRegionServers
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.RecommissionRegionServerResponse recommissionRegionServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.RecommissionRegionServerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
recommissionRegionServer
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public LockServiceProtos.LockResponse requestLock(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, LockServiceProtos.LockRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
requestLock
in interface LockServiceProtos.LockService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public LockServiceProtos.LockHeartbeatResponse lockHeartbeat(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, LockServiceProtos.LockHeartbeatRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
lockHeartbeat
in interface LockServiceProtos.LockService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- if given proc id is found but it is not a LockProcedure.public RegionServerStatusProtos.RegionSpaceUseReportResponse reportRegionSpaceUse(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, RegionServerStatusProtos.RegionSpaceUseReportRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportRegionSpaceUse
in interface RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public QuotaProtos.GetSpaceQuotaRegionSizesResponse getSpaceQuotaRegionSizes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, QuotaProtos.GetSpaceQuotaRegionSizesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getSpaceQuotaRegionSizes
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public QuotaProtos.GetQuotaStatesResponse getQuotaStates(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, QuotaProtos.GetQuotaStatesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getQuotaStates
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ClearDeadServersResponse clearDeadServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ClearDeadServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
clearDeadServers
in interface MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public RegionServerStatusProtos.ReportProcedureDoneResponse reportProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, RegionServerStatusProtos.ReportProcedureDoneRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportProcedureDone
in interface RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.GetTableStateResponse setTableStateInMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.SetTableStateInMetaRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setTableStateInMeta
in interface MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.AssignsResponse assigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.AssignsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
assigns
in interface MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.UnassignsResponse unassigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.UnassignsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
unassigns
in interface MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.BypassProcedureResponse bypassProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.BypassProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
bypassProcedure
in interface MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public MasterProtos.ScheduleServerCrashProcedureResponse scheduleServerCrashProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, MasterProtos.ScheduleServerCrashProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
scheduleServerCrashProcedure
in interface MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
Copyright © 2007–2019 Cloudera. All rights reserved.