Package org.apache.hadoop.hbase.master
Class MasterRpcServices
java.lang.Object
org.apache.hadoop.hbase.regionserver.RSRpcServices
org.apache.hadoop.hbase.master.MasterRpcServices
- All Implemented Interfaces:
ConfigurationObserver,HBaseRPCErrorHandler,PriorityFunction,org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface,org.apache.hadoop.hbase.shaded.protobuf.generated.BootstrapNodeProtos.BootstrapNodeService.BlockingInterface,org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface,org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface,org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface,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.RegistryProtos.ClientMetaService.BlockingInterface
@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
Implements the master RPC services.
-
Nested Class Summary
Nested ClassesModifier and TypeClassDescription(package private) static enum -
Field Summary
FieldsModifier and TypeFieldDescriptionprivate static final org.slf4j.Loggerprivate static final org.slf4j.Loggerprivate final HMasterFields inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices
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_BOOTSTRAP_NODES_SERVICE_CONFIG, REGIONSERVER_CLIENT_META_SERVICE_CONFIG, REGIONSERVER_CLIENT_SERVICE_CONFIG -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureResponseabortProcedure(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.AddColumnResponseaddColumn(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.BuilderaddConfig(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder resp, String key) org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerResponseaddReplicationPeer(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.AssignRegionResponseassignRegion(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.AssignsResponseassigns(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.BalanceResponsebalance(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.BypassProcedureResponsebypassProcedure(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) booleancheckCoprocessorWithService(List<MasterCoprocessor> coprocessorsToCheck, Class<?> service) Determines if there is a coprocessor implementation in the provided argument which extends or implements the providedservice.private voidcheck configured hfile format version before to do compactionprivate voidorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersResponseclearDeadServers(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.CompactRegionResponsecompactRegion(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 booleancontainMetaWals(ServerName serverName) private MasterSwitchTypeconvert(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterSwitchType switchType) private org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builderorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateNamespaceResponsecreateNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateNamespaceRequest request) protected PriorityFunctionprotected RpcServerInterfacecreateRpcServer(Server server, RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.CreateTableResponsecreateTable(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.DecommissionRegionServersResponsedecommissionRegionServers(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.DeleteColumnResponsedeleteColumn(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.DeleteNamespaceResponsedeleteNamespace(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.DeleteSnapshotResponsedeleteSnapshot(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.DeleteTableResponsedeleteTable(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.DisableReplicationPeerResponsedisableReplicationPeer(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.DisableTableResponsedisableTable(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.EnableCatalogJanitorResponseenableCatalogJanitor(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.EnableReplicationPeerResponseenableReplicationPeer(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.EnableTableResponseenableTable(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.CoprocessorServiceResponseexecMasterService(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.ExecProcedureResponseexecProcedure(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.ExecProcedureResponseexecProcedureWithRet(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.FixMetaResponsefixMeta(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.FlushMasterStoreResponseflushMasterStore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushMasterStoreRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableResponseflushTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableRequest req) private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsResponsegetBalancerDecisions(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsRequest request) private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsResponsegetBalancerRejections(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListResponsegetCachedFilesList(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusResponsegetClusterStatus(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.GetCompletedSnapshotsResponsegetCompletedSnapshots(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.GetLastFlushedSequenceIdResponsegetLastFlushedSequenceId(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.MajorCompactionTimestampResponsegetLastMajorCompactionTimestamp(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.MajorCompactionTimestampResponsegetLastMajorCompactionTimestampForRegion(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.RegionServerStatusProtos.GetLiveRegionServersResponsegetLiveRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLiveRegionServersRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetLocksResponsegetLocks(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.LogEntrygetLogEntries(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.GetNamespaceDescriptorResponsegetNamespaceDescriptor(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.GetProcedureResultResponsegetProcedureResult(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.GetProceduresResponsegetProcedures(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.GetQuotaStatesResponsegetQuotaStates(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesRequest request) private RegionInfogetRegionInfo(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier rs) GetRegionInfofrom Master using content ofHBaseProtos.RegionSpecifieras key.org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponsegetRegionInfo(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.GetReplicationPeerConfigResponsegetReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerConfigRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerModificationProceduresResponsegetReplicationPeerModificationProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerModificationProceduresRequest request) protected Class<?>org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponsegetSchemaAlterStatus(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.SecurityCapabilitiesResponsegetSecurityCapabilities(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 clusterprotected List<RpcServer.BlockingServiceAndInterface>Returns list of blocking services and their security info classes that this server supportsorg.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesResponsegetSpaceQuotaRegionSizes(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.GetTableDescriptorsResponsegetTableDescriptors(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.GetTableNamesResponsegetTableNames(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableNamesRequest req) Get list of userspace table namesorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateResponsegetTableState(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.GetUserPermissionsResponsegetUserPermissions(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.GrantResponsegrant(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GrantRequest request) (package private) booleanDetermines if there is a MasterCoprocessor deployed which implementsAccessControlProtos.AccessControlService.Interface.org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.HasUserPermissionsResponsehasUserPermissions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.HasUserPermissionsRequest request) (package private) booleanDetermines if there is a MasterCoprocessor deployed which implementsVisibilityLabelsProtos.VisibilityLabelsService.Interface.org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledResponseisBalancerEnabled(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.IsCatalogJanitorEnabledResponseisCatalogJanitorEnabled(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.IsCleanerChoreEnabledResponseisCleanerChoreEnabled(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.IsInMaintenanceModeResponseisMasterInMaintenanceMode(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.IsMasterRunningResponseisMasterRunning(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.IsNormalizerEnabledResponseisNormalizerEnabled(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.IsProcedureDoneResponseisProcedureDone(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.ReplicationProtos.GetReplicationPeerStateResponseisReplicationPeerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerStateRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.IsReplicationPeerModificationEnabledResponseisReplicationPeerModificationEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.IsReplicationPeerModificationEnabledRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsRpcThrottleEnabledResponseisRpcThrottleEnabled(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.IsSnapshotCleanupEnabledResponseisSnapshotCleanupEnabled(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.IsSnapshotDoneResponseisSnapshotDone(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.IsSplitOrMergeEnabledResponseisSplitOrMergeEnabled(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.ListDecommissionedRegionServersResponselistDecommissionedRegionServers(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.ListNamespaceDescriptorsResponselistNamespaceDescriptors(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.ListNamespacesResponselistNamespaces(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.ListReplicationPeersResponselistReplicationPeers(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.ListTableDescriptorsByNamespaceResponselistTableDescriptorsByNamespace(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.ListTableDescriptorsByStateResponselistTableDescriptorsByState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByStateRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponselistTableNamesByNamespace(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.MasterProtos.ListTableNamesByStateResponselistTableNamesByState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByStateRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockHeartbeatResponselockHeartbeat(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.MergeTableRegionsResponsemergeTableRegions(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.ModifyColumnResponsemodifyColumn(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.ModifyColumnStoreFileTrackerResponsemodifyColumnStoreFileTracker(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.ModifyNamespaceResponsemodifyNamespace(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.ModifyTableResponsemodifyTable(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.ModifyTableStoreFileTrackerResponsemodifyTableStoreFileTracker(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.MoveRegionResponsemoveRegion(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.NormalizeResponsenormalize(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.OfflineRegionResponseofflineRegion(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.RecommissionRegionServerResponserecommissionRegionServer(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.RegionServerReportResponseregionServerReport(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.RegionServerStartupResponseregionServerStartup(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.RemoveReplicationPeerResponseremoveReplicationPeer(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.ReplicationProtos.ReplicationPeerModificationSwitchResponsereplicationPeerModificationSwitch(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeerModificationSwitchRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.FileArchiveNotificationResponsereportFileArchival(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.ReportProcedureDoneResponsereportProcedureDone(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.RegionSpaceUseReportResponsereportRegionSpaceUse(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.ReportRegionStateTransitionResponsereportRegionStateTransition(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.ReportRSFatalErrorResponsereportRSFatalError(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.LockResponserequestLock(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.RestoreSnapshotResponserestoreSnapshot(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.RevokeResponserevoke(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.RevokeRequest request) private voidrpcPreCheck(String requestName) Checks for the following pre-checks in order: Master is initialized Rpc caller has admin permissionsorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanResponserunCatalogScan(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.RunCleanerChoreResponserunCleanerChore(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.RunHbckChoreResponserunHbckChore(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.ScheduleSCPsForUnknownServersResponsescheduleSCPsForUnknownServers(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.ScheduleServerCrashProcedureResponsescheduleServerCrashProcedure(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.SetBalancerRunningResponsesetBalancerRunning(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.SetCleanerChoreRunningResponsesetCleanerChoreRunning(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.SetNormalizerRunningResponsesetNormalizerRunning(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.SetQuotaResponsesetQuota(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.SetRegionStateInMetaResponsesetRegionStateInMeta(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.SetSplitOrMergeEnabledResponsesetSplitOrMergeEnabled(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.GetTableStateResponsesetTableStateInMeta(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 booleanshouldSubmitSCP(ServerName serverName) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ShutdownResponseshutdown(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.SnapshotResponsesnapshot(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.SplitTableRegionResponsesplitRegion(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.StopMasterResponsestopMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.StopMasterRequest request) (package private) booleanswitchBalancer(boolean b, MasterRpcServices.BalanceSwitchMode mode) Assigns balancer switch according to BalanceSwitchModeorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchExceedThrottleQuotaResponseswitchExceedThrottleQuota(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.SwitchRpcThrottleResponseswitchRpcThrottle(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchRpcThrottleRequest request) private booleanswitchSnapshotCleanup(boolean enabledNewVal, boolean synchronous) Turn on/off snapshot auto-cleanup based on TTLorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSnapshotCleanupResponseswitchSnapshotCleanup(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSnapshotCleanupRequest request) (package private) booleansynchronousBalanceSwitch(boolean b) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionResponsetruncateRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionRequest request) org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableResponsetruncateTable(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.UnassignRegionResponseunassignRegion(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.UnassignsResponseunassigns(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.UpdateReplicationPeerConfigResponseupdateReplicationPeerConfig(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest request) Methods inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices
bulkLoadHFile, checkOOME, checkOpen, cleanupBulkLoad, clearCompactionQueues, clearRegionBlockCache, clearSlowLogsResponses, closeRegion, compactionSwitch, execRegionServerService, execService, executeProcedures, exitIfOOME, flushRegion, get, getAccessChecker, getActiveMaster, getAllBootstrapNodes, 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
-
Field Details
-
LOG
-
AUDITLOG
-
master
-
-
Constructor Details
-
MasterRpcServices
- Throws:
IOException
-
-
Method Details
-
createConfigurationSubset
private org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder createConfigurationSubset()- Returns:
- Subset of configuration to pass initializing regionservers: e.g. the filesystem to use and root directory to use.
-
addConfig
-
getRpcSchedulerFactoryClass
- Overrides:
getRpcSchedulerFactoryClassin classRSRpcServices
-
createRpcServer
protected RpcServerInterface createRpcServer(Server server, RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name) throws IOException - Overrides:
createRpcServerin classRSRpcServices- Throws:
IOException
-
createPriority
- Overrides:
createPriorityin classRSRpcServices
-
rpcPreCheck
private void rpcPreCheck(String requestName) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException Checks for the following pre-checks in order:- Master is initialized
- Rpc caller has admin permissions
- Parameters:
requestName- name of rpc request. Used in reporting failures to provide context.- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- If any of the above listed pre-check fails.
-
switchBalancer
Assigns balancer switch according to BalanceSwitchMode- Parameters:
b- new balancer switchmode- BalanceSwitchMode- Returns:
- old balancer switch
- Throws:
IOException
-
synchronousBalanceSwitch
- Throws:
IOException
-
getServices
Returns list of blocking services and their security info classes that this server supports- Overrides:
getServicesin classRSRpcServices- Returns:
- immutable list of blocking services and the security info classes that this server supports
-
getLastFlushedSequenceId
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 - Specified by:
getLastFlushedSequenceIdin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
regionServerReport
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 - Specified by:
regionServerReportin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
regionServerStartup
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 - Specified by:
regionServerStartupin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
reportRSFatalError
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 - Specified by:
reportRSFatalErrorin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
addColumn
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 - Specified by:
addColumnin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
assignRegion
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 - Specified by:
assignRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
balance
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 - Specified by:
balancein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
createNamespace
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 - Specified by:
createNamespacein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
createTable
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 - Specified by:
createTablein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
deleteColumn
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 - Specified by:
deleteColumnin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
deleteNamespace
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 - Specified by:
deleteNamespacein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
deleteSnapshot
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 Execute Delete Snapshot operation.- Specified by:
deleteSnapshotin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Returns:
- DeleteSnapshotResponse (a protobuf wrapped void) if the snapshot existed and was deleted properly.
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- wrapping SnapshotDoesNotExistException if specified snapshot did not exist.
-
deleteTable
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 - Specified by:
deleteTablein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
truncateTable
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 - Specified by:
truncateTablein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
disableTable
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 - Specified by:
disableTablein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
enableCatalogJanitor
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 - Specified by:
enableCatalogJanitorin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
setCleanerChoreRunning
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 - Specified by:
setCleanerChoreRunningin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
enableTable
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 - Specified by:
enableTablein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
mergeTableRegions
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 - Specified by:
mergeTableRegionsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
splitRegion
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 - Specified by:
splitRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
truncateRegion
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionResponse truncateRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
truncateRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
execMasterService
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 - Specified by:
execMasterServicein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
execProcedure
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 Triggers an asynchronous attempt to run a distributed procedure.- Specified by:
execProcedurein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
execProcedureWithRet
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 Triggers a synchronous attempt to run a distributed procedure and sets return data in response.- Specified by:
execProcedureWithRetin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getClusterStatus
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 - Specified by:
getClusterStatusin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getCompletedSnapshots
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 List the currently available/stored snapshots. Any in-progress snapshots are ignored- Specified by:
getCompletedSnapshotsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listNamespaces
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 - Specified by:
listNamespacesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getNamespaceDescriptor
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 - Specified by:
getNamespaceDescriptorin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getSchemaAlterStatus
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 Get the number of regions of the table that have been updated by the alter.- Specified by:
getSchemaAlterStatusin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Returns:
- Pair indicating the number of regions updated Pair.getFirst is the regions that are yet to be updated Pair.getSecond is the total number of regions of the table
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getTableDescriptors
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 Get list of TableDescriptors for requested tables.- Specified by:
getTableDescriptorsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Parameters:
c- Unused (set to null).req- GetTableDescriptorsRequest that contains: - tableNames: requested tables, or if empty, all are requested.- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listTableDescriptorsByState
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByStateResponse listTableDescriptorsByState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByStateRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
listTableDescriptorsByStatein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getTableNames
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 Get list of userspace table names- Specified by:
getTableNamesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Parameters:
controller- Unused (set to null).req- GetTableNamesRequest- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listTableNamesByState
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByStateResponse listTableNamesByState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByStateRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
listTableNamesByStatein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getTableState
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 - Specified by:
getTableStatein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isCatalogJanitorEnabled
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 - Specified by:
isCatalogJanitorEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isCleanerChoreEnabled
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 - Specified by:
isCleanerChoreEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isMasterRunning
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 - Specified by:
isMasterRunningin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isProcedureDone
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 Checks if the specified procedure is done.- Specified by:
isProcedureDonein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Returns:
- true if the procedure is done, false if the procedure is in the process of completing
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- if invalid procedure or failed procedure with progress failure reason.
-
isSnapshotDone
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 Checks if the specified snapshot is done.- Specified by:
isSnapshotDonein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Returns:
- true if the snapshot is in file system ready to use, false if the snapshot is in the process of completing
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- wrapping UnknownSnapshotException if invalid snapshot, or a wrapped HBaseSnapshotException with progress failure reason.
-
getProcedureResult
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 - Specified by:
getProcedureResultin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
abortProcedure
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 - Specified by:
abortProcedurein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listNamespaceDescriptors
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 - Specified by:
listNamespaceDescriptorsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getProcedures
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 - Specified by:
getProceduresin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getLocks
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 - Specified by:
getLocksin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listTableDescriptorsByNamespace
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 - Specified by:
listTableDescriptorsByNamespacein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listTableNamesByNamespace
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 - Specified by:
listTableNamesByNamespacein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
modifyColumn
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 - Specified by:
modifyColumnin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
modifyColumnStoreFileTracker
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 - Specified by:
modifyColumnStoreFileTrackerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
flushMasterStore
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 - Specified by:
flushMasterStorein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
modifyNamespace
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 - Specified by:
modifyNamespacein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
modifyTable
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 - Specified by:
modifyTablein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
modifyTableStoreFileTracker
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 - Specified by:
modifyTableStoreFileTrackerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
moveRegion
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 - Specified by:
moveRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
offlineRegion
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 Offline specified region from master's in-memory state. It will not attempt to reassign the region as in unassign. This is a special method that should be used by experts or hbck.- Specified by:
offlineRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
restoreSnapshot
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 Execute Restore/Clone snapshot operation.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.
- Specified by:
restoreSnapshotin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
switchSnapshotCleanup
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 - Specified by:
switchSnapshotCleanupin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isSnapshotCleanupEnabled
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 - Specified by:
isSnapshotCleanupEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
switchSnapshotCleanup
private boolean switchSnapshotCleanup(boolean enabledNewVal, boolean synchronous) throws IOException Turn on/off snapshot auto-cleanup based on TTL- Parameters:
enabledNewVal- Set totrueto enable,falseto disablesynchronous- Iftrue, it waits until current snapshot cleanup is completed, if outstanding- Returns:
- previous snapshot auto-cleanup mode
- Throws:
IOException
-
runCatalogScan
public 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 - Specified by:
runCatalogScanin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
runCleanerChore
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 - Specified by:
runCleanerChorein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
setBalancerRunning
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 - Specified by:
setBalancerRunningin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
shutdown
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 - Specified by:
shutdownin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
snapshot
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 Triggers an asynchronous attempt to take a snapshot.- Specified by:
snapshotin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
stopMaster
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 - Specified by:
stopMasterin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isMasterInMaintenanceMode
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 - Specified by:
isMasterInMaintenanceModein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
unassignRegion
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 - Specified by:
unassignRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
reportRegionStateTransition
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 - Specified by:
reportRegionStateTransitionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
setQuota
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 - Specified by:
setQuotain interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getLastMajorCompactionTimestamp
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 - Specified by:
getLastMajorCompactionTimestampin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getLastMajorCompactionTimestampForRegion
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 - Specified by:
getLastMajorCompactionTimestampForRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
compactRegion
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 Compact a region on the master.- Specified by:
compactRegionin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Overrides:
compactRegionin classRSRpcServices- Parameters:
controller- the RPC controllerrequest- the request- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
checkHFileFormatVersionForMob
check configured hfile format version before to do compaction- Throws:
IOException- throw IOException
-
getRegionInfo
public 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 This method implements Admin getRegionInfo. On RegionServer, it is able to return RegionInfo and detail. On Master, it just returns RegionInfo. On Master it has been hijacked to return Mob detail. Master implementation is good for querying full region name if you only have the encoded name (useful around region replicas for example which do not have a row in hbase:meta).- Specified by:
getRegionInfoin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Overrides:
getRegionInfoin classRSRpcServices- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isBalancerEnabled
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 - Specified by:
isBalancerEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
setSplitOrMergeEnabled
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 - Specified by:
setSplitOrMergeEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isSplitOrMergeEnabled
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 - Specified by:
isSplitOrMergeEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
normalize
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 - Specified by:
normalizein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
setNormalizerRunning
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 - Specified by:
setNormalizerRunningin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isNormalizerEnabled
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) - Specified by:
isNormalizerEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
getSecurityCapabilities
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 Returns the security capabilities in effect on the cluster- Specified by:
getSecurityCapabilitiesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
hasAccessControlServiceCoprocessor
Determines if there is a MasterCoprocessor deployed which implementsAccessControlProtos.AccessControlService.Interface. -
hasVisibilityLabelsServiceCoprocessor
Determines if there is a MasterCoprocessor deployed which implementsVisibilityLabelsProtos.VisibilityLabelsService.Interface. -
checkCoprocessorWithService
Determines if there is a coprocessor implementation in the provided argument which extends or implements the providedservice. -
convert
private MasterSwitchType convert(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterSwitchType switchType) -
addReplicationPeer
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 - Specified by:
addReplicationPeerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
removeReplicationPeer
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 - Specified by:
removeReplicationPeerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
enableReplicationPeer
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 - Specified by:
enableReplicationPeerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
disableReplicationPeer
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 - Specified by:
disableReplicationPeerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getReplicationPeerConfig
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 - Specified by:
getReplicationPeerConfigin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
updateReplicationPeerConfig
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 - Specified by:
updateReplicationPeerConfigin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listReplicationPeers
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 - Specified by:
listReplicationPeersin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isReplicationPeerEnabled
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerStateResponse isReplicationPeerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerStateRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
isReplicationPeerEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
replicationPeerModificationSwitch
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeerModificationSwitchResponse replicationPeerModificationSwitch(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeerModificationSwitchRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
replicationPeerModificationSwitchin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getReplicationPeerModificationProcedures
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerModificationProceduresResponse getReplicationPeerModificationProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.GetReplicationPeerModificationProceduresRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getReplicationPeerModificationProceduresin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isReplicationPeerModificationEnabled
public org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.IsReplicationPeerModificationEnabledResponse isReplicationPeerModificationEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.IsReplicationPeerModificationEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
isReplicationPeerModificationEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
listDecommissionedRegionServers
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 - Specified by:
listDecommissionedRegionServersin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
decommissionRegionServers
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 - Specified by:
decommissionRegionServersin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
recommissionRegionServer
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 - Specified by:
recommissionRegionServerin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
requestLock
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 - Specified by:
requestLockin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
lockHeartbeat
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 - Specified by:
lockHeartbeatin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockService.BlockingInterface- Returns:
- LOCKED, if procedure is found and it has the lock; else UNLOCKED.
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- if given proc id is found but it is not a LockProcedure.
-
reportRegionSpaceUse
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 - Specified by:
reportRegionSpaceUsein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getSpaceQuotaRegionSizes
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 - Specified by:
getSpaceQuotaRegionSizesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getQuotaStates
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 - Specified by:
getQuotaStatesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
clearDeadServers
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 - Specified by:
clearDeadServersin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
reportProcedureDone
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 - Specified by:
reportProcedureDonein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
runHbckChore
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 - Specified by:
runHbckChorein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
setTableStateInMeta
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 Update state of the table in meta only. This is required by hbck in some situations to cleanup stuck assign/ unassign regions procedures for the table.- Specified by:
setTableStateInMetain interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Returns:
- previous state of the table
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
setRegionStateInMeta
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 Update state of the region in meta only. This is required by hbck in some situations to cleanup stuck assign/ unassign regions procedures for the table.- Specified by:
setRegionStateInMetain interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Returns:
- previous states of the regions
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getRegionInfo
private RegionInfo getRegionInfo(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier rs) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException GetRegionInfofrom Master using content ofHBaseProtos.RegionSpecifieras key.- Returns:
RegionInfofound by decodingrsornullifrsis unknown to the master.- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- If some error occurs while querying META or parsing results.
-
checkMasterProcedureExecutor
private void checkMasterProcedureExecutor() throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- If no MasterProcedureExecutor
-
assigns
public 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 A 'raw' version of assign that does bulk and can skirt Master state checks if override is set; i.e. assigns can be forced during Master startup or if RegionState is unclean. Used by HBCK2.- Specified by:
assignsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
unassigns
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 A 'raw' version of unassign that does bulk and can skirt Master state checks if override is set; i.e. unassigns can be forced during Master startup or if RegionState is unclean. Used by HBCK2.- Specified by:
unassignsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
bypassProcedure
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 Bypass specified procedure to completion. Procedure is marked completed but no actual work is done from the current state/ step onwards. Parents of the procedure are also marked for bypass. NOTE: this is a dangerous operation and may be used to unstuck buggy procedures. This may leave system in incoherent state. This may need to be followed by some cleanup steps/ actions by operator.- Specified by:
bypassProcedurein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Returns:
- BypassProcedureToCompletionResponse indicating success or failure
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
scheduleServerCrashProcedure
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 - Specified by:
scheduleServerCrashProcedurein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
scheduleSCPsForUnknownServers
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 - Specified by:
scheduleSCPsForUnknownServersin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
fixMeta
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 - Specified by:
fixMetain interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.HbckService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
switchRpcThrottle
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 - Specified by:
switchRpcThrottlein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
isRpcThrottleEnabled
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 - Specified by:
isRpcThrottleEnabledin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
switchExceedThrottleQuota
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 - Specified by:
switchExceedThrottleQuotain interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
reportFileArchival
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 - Specified by:
reportFileArchivalin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
grant
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 - Specified by:
grantin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
revoke
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 - Specified by:
revokein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getUserPermissions
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 - Specified by:
getUserPermissionsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
hasUserPermissions
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 - Specified by:
hasUserPermissionsin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
containMetaWals
- Throws:
IOException
-
shouldSubmitSCP
-
getLogEntries
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 - Specified by:
getLogEntriesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Specified by:
getLogEntriesin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Overrides:
getLogEntriesin classRSRpcServices- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getCachedFilesList
public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListResponse getCachedFilesList(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetCachedFilesListRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getCachedFilesListin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface- Overrides:
getCachedFilesListin classRSRpcServices- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
getBalancerDecisions
private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsResponse getBalancerDecisions(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerDecisionsRequest request) -
getBalancerRejections
private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsResponse getBalancerRejections(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalancerRejectionsRequest request) -
getLiveRegionServers
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLiveRegionServersResponse getLiveRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.GetLiveRegionServersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
getLiveRegionServersin interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
flushTable
public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableResponse flushTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.FlushTableRequest req) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
flushTablein interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-