@InterfaceAudience.Private public class MasterRpcServices extends RSRpcServices implements org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
Modifier and Type | Class and Description |
---|---|
(package private) static class |
MasterRpcServices.BalanceSwitchMode |
Modifier and Type | Field and Description |
---|---|
private static org.slf4j.Logger |
AUDITLOG |
private static org.slf4j.Logger |
LOG |
private HMaster |
master |
CLIENT_BOOTSTRAP_NODE_LIMIT, DEFAULT_CLIENT_BOOTSTRAP_NODE_LIMIT, MASTER_RPC_SCHEDULER_FACTORY_CLASS, REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS, regionServer, REGIONSERVER_ADMIN_SERVICE_CONFIG, REGIONSERVER_CLIENT_META_SERVICE_CONFIG, REGIONSERVER_CLIENT_SERVICE_CONFIG
Constructor and Description |
---|
MasterRpcServices(HMaster m) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureResponse |
abortProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnResponse |
addColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequest req) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder |
addConfig(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder resp,
String key) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerResponse |
addReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignRegionResponse |
assignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignRegionRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignsResponse |
assigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignsRequest request)
A 'raw' version of assign that does bulk and can skirt Master state checks if override is set;
i.e.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalanceResponse |
balance(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalanceRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BypassProcedureResponse |
bypassProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BypassProcedureRequest request)
Bypass specified procedure to completion.
|
(package private) boolean |
checkCoprocessorWithService(List<MasterCoprocessor> coprocessorsToCheck,
Class<?> service)
Determines if there is a coprocessor implementation in the provided argument which extends or
implements the provided
service . |
private void |
checkHFileFormatVersionForMob()
check configured hfile format version before to do compaction
|
private void |
checkMasterProcedureExecutor() |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersResponse |
clearDeadServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionResponse |
compactRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionRequest request)
Compact a region on the master.
|
private boolean |
containMetaWals(ServerName serverName) |
private MasterSwitchType |
convert(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterSwitchType switchType) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder |
createConfigurationSubset() |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateNamespaceResponse |
createNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateNamespaceRequest request) |
protected PriorityFunction |
createPriority() |
protected RpcServerInterface |
createRpcServer(Server server,
RpcSchedulerFactory rpcSchedulerFactory,
InetSocketAddress bindAddress,
String name) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableResponse |
createTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DecommissionRegionServersResponse |
decommissionRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DecommissionRegionServersRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnResponse |
deleteColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteNamespaceResponse |
deleteNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteNamespaceRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteSnapshotResponse |
deleteSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteSnapshotRequest request)
Execute Delete Snapshot operation.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableResponse |
deleteTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.DisableReplicationPeerResponse |
disableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.DisableReplicationPeerRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableResponse |
disableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse |
enableCatalogJanitor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.EnableReplicationPeerResponse |
enableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.EnableReplicationPeerRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableResponse |
enableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse |
execMasterService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureResponse |
execProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureRequest request)
Triggers an asynchronous attempt to run a distributed procedure.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureResponse |
execProcedureWithRet(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureRequest request)
Triggers a synchronous attempt to run a distributed procedure and sets return data in response.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FixMetaResponse |
fixMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FixMetaRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushMasterStoreResponse |
flushMasterStore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushMasterStoreRequest request) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsResponse |
getBalancerDecisions(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsRequest request) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsResponse |
getBalancerRejections(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusResponse |
getClusterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse |
getCompletedSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest request)
List the currently available/stored snapshots.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse |
getLastFlushedSequenceId(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse |
getLastMajorCompactionTimestamp(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse |
getLastMajorCompactionTimestampForRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetLocksResponse |
getLocks(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetLocksRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogEntry |
getLogEntries(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse |
getNamespaceDescriptor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProcedureResultResponse |
getProcedureResult(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProcedureResultRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProceduresResponse |
getProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProceduresRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse |
getQuotaStates(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesRequest request) |
private RegionInfo |
getRegionInfo(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier rs)
Get RegionInfo from Master using content of RegionSpecifier as key.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse |
getRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoRequest request)
This method implements Admin getRegionInfo.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerConfigResponse |
getReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerConfigRequest request) |
protected Class<?> |
getRpcSchedulerFactoryClass() |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse |
getSchemaAlterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest req)
Get the number of regions of the table that have been updated by the alter.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SecurityCapabilitiesResponse |
getSecurityCapabilities(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SecurityCapabilitiesRequest request)
Returns the security capabilities in effect on the cluster
|
protected List<RpcServer.BlockingServiceAndInterface> |
getServices()
Returns list of blocking services and their security info classes that this server supports
|
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesResponse |
getSpaceQuotaRegionSizes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsResponse |
getTableDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest req)
Get list of TableDescriptors for requested tables.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesResponse |
getTableNames(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesRequest req)
Get list of userspace table names
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateResponse |
getTableState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse |
getUserPermissions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GrantResponse |
grant(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GrantRequest request) |
(package private) boolean |
hasAccessControlServiceCoprocessor(MasterCoprocessorHost cpHost)
Determines if there is a MasterCoprocessor deployed which implements
AccessControlProtos.AccessControlService.Interface . |
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.HasUserPermissionsResponse |
hasUserPermissions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.HasUserPermissionsRequest request) |
(package private) boolean |
hasVisibilityLabelsServiceCoprocessor(MasterCoprocessorHost cpHost)
Determines if there is a MasterCoprocessor deployed which implements
VisibilityLabelsProtos.VisibilityLabelsService.Interface . |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledResponse |
isBalancerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse |
isCatalogJanitorEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledResponse |
isCleanerChoreEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsInMaintenanceModeResponse |
isMasterInMaintenanceMode(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsInMaintenanceModeRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningResponse |
isMasterRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse |
isNormalizerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsProcedureDoneResponse |
isProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsProcedureDoneRequest request)
Checks if the specified procedure is done.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsRpcThrottleEnabledResponse |
isRpcThrottleEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsRpcThrottleEnabledRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotCleanupEnabledResponse |
isSnapshotCleanupEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotCleanupEnabledRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotDoneResponse |
isSnapshotDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotDoneRequest request)
Checks if the specified snapshot is done.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSplitOrMergeEnabledResponse |
isSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSplitOrMergeEnabledRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListDecommissionedRegionServersResponse |
listDecommissionedRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListDecommissionedRegionServersRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse |
listNamespaceDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespacesResponse |
listNamespaces(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespacesRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersResponse |
listReplicationPeers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse |
listTableDescriptorsByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse |
listTableNamesByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockHeartbeatResponse |
lockHeartbeat(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockHeartbeatRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsResponse |
mergeTableRegions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnResponse |
modifyColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerResponse |
modifyColumnStoreFileTracker(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyNamespaceResponse |
modifyNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyNamespaceRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableResponse |
modifyTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerResponse |
modifyTableStoreFileTracker(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MoveRegionResponse |
moveRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MoveRegionRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.NormalizeResponse |
normalize(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.NormalizeRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.OfflineRegionResponse |
offlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.OfflineRegionRequest request)
Offline specified region from master's in-memory state.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RecommissionRegionServerResponse |
recommissionRegionServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RecommissionRegionServerRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse |
regionServerReport(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse |
regionServerStartup(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.RemoveReplicationPeerResponse |
removeReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.RemoveReplicationPeerRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationResponse |
reportFileArchival(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportProcedureDoneResponse |
reportProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportProcedureDoneRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionSpaceUseReportResponse |
reportRegionSpaceUse(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionSpaceUseReportRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse |
reportRegionStateTransition(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse |
reportRSFatalError(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockResponse |
requestLock(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RestoreSnapshotResponse |
restoreSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RestoreSnapshotRequest request)
Execute Restore/Clone snapshot operation.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.RevokeResponse |
revoke(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.RevokeRequest request) |
private void |
rpcPreCheck(String requestName)
Checks for the following pre-checks in order:
Master is initialized
Rpc caller has admin permissions
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanResponse |
runCatalogScan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreResponse |
runCleanerChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunHbckChoreResponse |
runHbckChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunHbckChoreRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleSCPsForUnknownServersResponse |
scheduleSCPsForUnknownServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleSCPsForUnknownServersRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleServerCrashProcedureResponse |
scheduleServerCrashProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleServerCrashProcedureRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningResponse |
setBalancerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningResponse |
setCleanerChoreRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetNormalizerRunningResponse |
setNormalizerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetNormalizerRunningRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaResponse |
setQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetRegionStateInMetaResponse |
setRegionStateInMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetRegionStateInMetaRequest request)
Update state of the region in meta only.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSplitOrMergeEnabledResponse |
setSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSplitOrMergeEnabledRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateResponse |
setTableStateInMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetTableStateInMetaRequest request)
Update state of the table in meta only.
|
private boolean |
shouldSubmitSCP(ServerName serverName) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ShutdownResponse |
shutdown(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ShutdownRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SnapshotResponse |
snapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SnapshotRequest request)
Triggers an asynchronous attempt to take a snapshot.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionResponse |
splitRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.StopMasterResponse |
stopMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.StopMasterRequest request) |
(package private) boolean |
switchBalancer(boolean b,
MasterRpcServices.BalanceSwitchMode mode)
Assigns balancer switch according to BalanceSwitchMode
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchExceedThrottleQuotaResponse |
switchExceedThrottleQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchExceedThrottleQuotaRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchRpcThrottleResponse |
switchRpcThrottle(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchRpcThrottleRequest request) |
private boolean |
switchSnapshotCleanup(boolean enabledNewVal,
boolean synchronous)
Turn on/off snapshot auto-cleanup based on TTL
|
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSnapshotCleanupResponse |
switchSnapshotCleanup(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSnapshotCleanupRequest request) |
(package private) boolean |
synchronousBalanceSwitch(boolean b) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableResponse |
truncateTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignRegionResponse |
unassignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignRegionRequest req) |
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignsResponse |
unassigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignsRequest request)
A 'raw' version of unassign that does bulk and can skirt Master state checks if override is
set; i.e.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigResponse |
updateReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest request) |
bulkLoadHFile, checkOOME, checkOpen, cleanupBulkLoad, clearCompactionQueues, clearRegionBlockCache, clearSlowLogsResponses, closeRegion, compactionSwitch, execRegionServerService, execService, executeProcedures, exitIfOOME, flushRegion, get, getAccessChecker, getActiveMaster, getBootstrapNodes, getClusterId, getConfiguration, getDeadline, getLargeLogResponses, getMasters, getMetaRegionLocations, getOnlineRegion, getPriority, getPriority, getRegion, getRegionLoad, getRpcScheduler, getScanDetailsWithId, getScanDetailsWithRequest, getScannersCount, getServerInfo, getSlowLogResponses, getSocketAddress, getSpaceQuotaSnapshots, getStoreFile, getZkPermissionWatcher, multi, mutate, onConfigurationChange, openRegion, prepareBulkLoad, replay, replicateWALEntry, requirePermission, rollWALWriter, scan, stopServer, updateConfiguration, updateFavoredNodes, warmupRegion
private static final org.slf4j.Logger LOG
private static final org.slf4j.Logger AUDITLOG
public MasterRpcServices(HMaster m) throws IOException
IOException
private org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder createConfigurationSubset()
private org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder addConfig(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder resp, String key)
protected Class<?> getRpcSchedulerFactoryClass()
getRpcSchedulerFactoryClass
in class RSRpcServices
protected RpcServerInterface createRpcServer(Server server, RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name) throws IOException
createRpcServer
in class RSRpcServices
IOException
protected PriorityFunction createPriority()
createPriority
in class RSRpcServices
private void rpcPreCheck(String requestName) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
requestName
- name of rpc request. Used in reporting failures to provide context.org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- If any of the above listed pre-check fails.boolean switchBalancer(boolean b, MasterRpcServices.BalanceSwitchMode mode) throws IOException
b
- new balancer switchmode
- BalanceSwitchModeIOException
boolean synchronousBalanceSwitch(boolean b) throws IOException
IOException
protected List<RpcServer.BlockingServiceAndInterface> getServices()
getServices
in class RSRpcServices
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse getLastFlushedSequenceId(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLastFlushedSequenceId
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse regionServerReport(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
regionServerReport
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse regionServerStartup(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
regionServerStartup
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse reportRSFatalError(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportRSFatalError
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnResponse addColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
addColumn
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignRegionResponse assignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignRegionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
assignRegion
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalanceResponse balance(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalanceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
balance
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateNamespaceResponse createNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
createNamespace
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableResponse createTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
createTable
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnResponse deleteColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteColumn
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteNamespaceResponse deleteNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteNamespace
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteSnapshotResponse deleteSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteSnapshotRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteSnapshot
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- wrapping SnapshotDoesNotExistException if specified snapshot did not
exist.public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableResponse deleteTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
deleteTable
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableResponse truncateTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
truncateTable
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableResponse disableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
disableTable
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse enableCatalogJanitor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
enableCatalogJanitor
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningResponse setCleanerChoreRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setCleanerChoreRunning
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableResponse enableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
enableTable
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsResponse mergeTableRegions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
mergeTableRegions
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionResponse splitRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
splitRegion
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse execMasterService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
execMasterService
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureResponse execProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
execProcedure
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureResponse execProcedureWithRet(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
execProcedureWithRet
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusResponse getClusterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getClusterStatus
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse getCompletedSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getCompletedSnapshots
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespacesResponse listNamespaces(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespacesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listNamespaces
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse getNamespaceDescriptor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getNamespaceDescriptor
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse getSchemaAlterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getSchemaAlterStatus
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsResponse getTableDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getTableDescriptors
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
c
- Unused (set to null).req
- GetTableDescriptorsRequest that contains: - tableNames: requested tables, or if
empty, all are requested. nnorg.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesResponse getTableNames(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getTableNames
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
controller
- Unused (set to null).req
- GetTableNamesRequest nnorg.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateResponse getTableState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getTableState
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse isCatalogJanitorEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isCatalogJanitorEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledResponse isCleanerChoreEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isCleanerChoreEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningResponse isMasterRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isMasterRunning
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsProcedureDoneResponse isProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsProcedureDoneRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isProcedureDone
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- if invalid procedure or failed procedure with progress failure reason.public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotDoneResponse isSnapshotDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotDoneRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isSnapshotDone
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.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 org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProcedureResultResponse getProcedureResult(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProcedureResultRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getProcedureResult
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureResponse abortProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
abortProcedure
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse listNamespaceDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listNamespaceDescriptors
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProceduresResponse getProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProceduresRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getProcedures
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetLocksResponse getLocks(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetLocksRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLocks
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse listTableDescriptorsByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listTableDescriptorsByNamespace
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse listTableNamesByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listTableNamesByNamespace
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnResponse modifyColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyColumn
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerResponse modifyColumnStoreFileTracker(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnStoreFileTrackerRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyColumnStoreFileTracker
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushMasterStoreResponse flushMasterStore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushMasterStoreRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
flushMasterStore
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyNamespaceResponse modifyNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyNamespace
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableResponse modifyTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyTable
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerResponse modifyTableStoreFileTracker(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableStoreFileTrackerRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
modifyTableStoreFileTracker
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MoveRegionResponse moveRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MoveRegionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
moveRegion
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.OfflineRegionResponse offlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.OfflineRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
offlineRegion
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RestoreSnapshotResponse restoreSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.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 org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSnapshotCleanupResponse switchSnapshotCleanup(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSnapshotCleanupRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
switchSnapshotCleanup
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotCleanupEnabledResponse isSnapshotCleanupEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotCleanupEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isSnapshotCleanupEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
private boolean switchSnapshotCleanup(boolean enabledNewVal, boolean synchronous)
enabledNewVal
- Set to true
to enable, false
to disablesynchronous
- If true
, it waits until current snapshot cleanup is
completed, if outstandingpublic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanResponse runCatalogScan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
runCatalogScan
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreResponse runCleanerChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
runCleanerChore
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningResponse setBalancerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setBalancerRunning
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ShutdownResponse shutdown(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ShutdownRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
shutdown
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SnapshotResponse snapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SnapshotRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
snapshot
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.StopMasterResponse stopMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.StopMasterRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
stopMaster
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsInMaintenanceModeResponse isMasterInMaintenanceMode(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsInMaintenanceModeRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isMasterInMaintenanceMode
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignRegionResponse unassignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignRegionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
unassignRegion
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse reportRegionStateTransition(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportRegionStateTransition
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaResponse setQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setQuota
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse getLastMajorCompactionTimestamp(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLastMajorCompactionTimestamp
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse getLastMajorCompactionTimestampForRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLastMajorCompactionTimestampForRegion
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionResponse compactRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
compactRegion
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
compactRegion
in class RSRpcServices
controller
- the RPC controllerrequest
- the request norg.apache.hbase.thirdparty.com.google.protobuf.ServiceException
private void checkHFileFormatVersionForMob() throws IOException
IOException
- throw IOExceptionpublic org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse getRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getRegionInfo
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
getRegionInfo
in class RSRpcServices
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledResponse isBalancerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isBalancerEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSplitOrMergeEnabledResponse setSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSplitOrMergeEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setSplitOrMergeEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSplitOrMergeEnabledResponse isSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSplitOrMergeEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isSplitOrMergeEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.NormalizeResponse normalize(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.NormalizeRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
normalize
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetNormalizerRunningResponse setNormalizerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetNormalizerRunningRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setNormalizerRunning
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse isNormalizerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest request)
isNormalizerEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SecurityCapabilitiesResponse getSecurityCapabilities(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SecurityCapabilitiesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getSecurityCapabilities
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
boolean hasAccessControlServiceCoprocessor(MasterCoprocessorHost cpHost)
AccessControlProtos.AccessControlService.Interface
.boolean hasVisibilityLabelsServiceCoprocessor(MasterCoprocessorHost cpHost)
VisibilityLabelsProtos.VisibilityLabelsService.Interface
.boolean checkCoprocessorWithService(List<MasterCoprocessor> coprocessorsToCheck, Class<?> service)
service
.private MasterSwitchType convert(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterSwitchType switchType)
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerResponse addReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
addReplicationPeer
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.RemoveReplicationPeerResponse removeReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.RemoveReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
removeReplicationPeer
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.EnableReplicationPeerResponse enableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.EnableReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
enableReplicationPeer
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.DisableReplicationPeerResponse disableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.DisableReplicationPeerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
disableReplicationPeer
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerConfigResponse getReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerConfigRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getReplicationPeerConfig
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigResponse updateReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
updateReplicationPeerConfig
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersResponse listReplicationPeers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listReplicationPeers
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListDecommissionedRegionServersResponse listDecommissionedRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListDecommissionedRegionServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
listDecommissionedRegionServers
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DecommissionRegionServersResponse decommissionRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DecommissionRegionServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
decommissionRegionServers
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RecommissionRegionServerResponse recommissionRegionServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RecommissionRegionServerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
recommissionRegionServer
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockResponse requestLock(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
requestLock
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockHeartbeatResponse lockHeartbeat(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockHeartbeatRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
lockHeartbeat
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- if given proc id is found but it is not a LockProcedure.public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionSpaceUseReportResponse reportRegionSpaceUse(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionSpaceUseReportRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportRegionSpaceUse
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesResponse getSpaceQuotaRegionSizes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getSpaceQuotaRegionSizes
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse getQuotaStates(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getQuotaStates
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersResponse clearDeadServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
clearDeadServers
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportProcedureDoneResponse reportProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportProcedureDoneRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportProcedureDone
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunHbckChoreResponse runHbckChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController c, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunHbckChoreRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
runHbckChore
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateResponse setTableStateInMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetTableStateInMetaRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setTableStateInMeta
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetRegionStateInMetaResponse setRegionStateInMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetRegionStateInMetaRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
setRegionStateInMeta
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
private RegionInfo getRegionInfo(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier rs) throws UnknownRegionException
rs
or null if none foundUnknownRegionException
private void checkMasterProcedureExecutor() throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
- If no MasterProcedureExecutorpublic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignsResponse assigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
assigns
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignsResponse unassigns(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
unassigns
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BypassProcedureResponse bypassProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BypassProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
bypassProcedure
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleServerCrashProcedureResponse scheduleServerCrashProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleServerCrashProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
scheduleServerCrashProcedure
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleSCPsForUnknownServersResponse scheduleSCPsForUnknownServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ScheduleSCPsForUnknownServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
scheduleSCPsForUnknownServers
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FixMetaResponse fixMeta(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FixMetaRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
fixMeta
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchRpcThrottleResponse switchRpcThrottle(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchRpcThrottleRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
switchRpcThrottle
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsRpcThrottleEnabledResponse isRpcThrottleEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsRpcThrottleEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
isRpcThrottleEnabled
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchExceedThrottleQuotaResponse switchExceedThrottleQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchExceedThrottleQuotaRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
switchExceedThrottleQuota
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationResponse reportFileArchival(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
reportFileArchival
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GrantResponse grant(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GrantRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
grant
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.RevokeResponse revoke(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.RevokeRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
revoke
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse getUserPermissions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getUserPermissions
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.HasUserPermissionsResponse hasUserPermissions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.HasUserPermissionsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
hasUserPermissions
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
private boolean containMetaWals(ServerName serverName) throws IOException
IOException
private boolean shouldSubmitSCP(ServerName serverName)
public org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogEntry getLogEntries(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getLogEntries
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
getLogEntries
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
getLogEntries
in class RSRpcServices
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsResponse getBalancerDecisions(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsRequest request)
private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsResponse getBalancerRejections(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsRequest request)
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.