Class ShortCircuitMasterConnection

java.lang.Object
org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
All Implemented Interfaces:
MasterKeepAliveConnection, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface

@Private public class ShortCircuitMasterConnection extends Object implements MasterKeepAliveConnection
A short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local master
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    private final org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
     
  • Constructor Summary

    Constructors
    Constructor
    Description
    ShortCircuitMasterConnection(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface stub)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureResponse
    abortProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnResponse
    addColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AddColumnRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerResponse
    addReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignRegionResponse
    assignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AssignRegionRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalanceResponse
    balance(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.BalanceRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersResponse
    clearDeadServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ClearDeadServersRequest request)
     
    void
     
    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)
     
    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 request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DecommissionRegionServersResponse
    decommissionRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DecommissionRegionServersRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnResponse
    deleteColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteColumnRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteNamespaceResponse
    deleteNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteNamespaceRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteSnapshotResponse
    deleteSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteSnapshotRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableResponse
    deleteTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DeleteTableRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.DisableReplicationPeerResponse
    disableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.DisableReplicationPeerRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableResponse
    disableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.DisableTableRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
    enableCatalogJanitor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.EnableReplicationPeerResponse
    enableReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.EnableReplicationPeerRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableResponse
    enableTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableTableRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse
    execMasterService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureResponse
    execProcedure(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ExecProcedureRequest request)
     
    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)
     
    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)
     
    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 request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusResponse
    getClusterStatus(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetClusterStatusRequest request)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
    getLastMajorCompactionTimestamp(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
    getLastMajorCompactionTimestampForRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetLocksResponse
    getLocks(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetLocksRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogEntry
    getLogEntries(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.LogRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
    getNamespaceDescriptor(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProcedureResultResponse
    getProcedureResult(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProcedureResultRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProceduresResponse
    getProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProceduresRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesResponse
    getQuotaStates(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetQuotaStatesRequest request)
     
    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)
     
    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)
     
    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 request)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesResponse
    getSpaceQuotaRegionSizes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaRegionSizesRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
    getTableDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest request)
     
    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 request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateResponse
    getTableState(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableStateRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
    getUserPermissions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GrantResponse
    grant(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AccessControlProtos.GrantRequest request)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
    isBalancerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsBalancerEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
    isCatalogJanitorEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledResponse
    isCleanerChoreEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsInMaintenanceModeResponse
    isMasterInMaintenanceMode(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsInMaintenanceModeRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningResponse
    isMasterRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse
    isNormalizerEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsProcedureDoneResponse
    isProcedureDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsProcedureDoneRequest request)
     
    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)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsRpcThrottleEnabledResponse
    isRpcThrottleEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsRpcThrottleEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotCleanupEnabledResponse
    isSnapshotCleanupEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotCleanupEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
    isSnapshotDone(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSnapshotDoneRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSplitOrMergeEnabledResponse
    isSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsSplitOrMergeEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListDecommissionedRegionServersResponse
    listDecommissionedRegionServers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListDecommissionedRegionServersRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
    listNamespaceDescriptors(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespacesResponse
    listNamespaces(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespacesRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersResponse
    listReplicationPeers(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
    listTableDescriptorsByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest request)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
    listTableNamesByNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest request)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsResponse
    mergeTableRegions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnResponse
    modifyColumn(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyColumnRequest request)
     
    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 request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyNamespaceResponse
    modifyNamespace(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyNamespaceRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableResponse
    modifyTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ModifyTableRequest request)
     
    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 request)
     
    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 request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.NormalizeResponse
    normalize(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.NormalizeRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.OfflineRegionResponse
    offlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.OfflineRegionRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RecommissionRegionServerResponse
    recommissionRegionServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RecommissionRegionServerRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.RemoveReplicationPeerResponse
    removeReplicationPeer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.RemoveReplicationPeerRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeerModificationSwitchResponse
    replicationPeerModificationSwitch(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.MasterProtos.RestoreSnapshotResponse
    restoreSnapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RestoreSnapshotRequest request)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanResponse
    runCatalogScan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreResponse
    runCleanerChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningResponse
    setBalancerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningResponse
    setCleanerChoreRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetNormalizerRunningResponse
    setNormalizerRunning(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetNormalizerRunningRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaResponse
    setQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSplitOrMergeEnabledResponse
    setSplitOrMergeEnabled(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetSplitOrMergeEnabledRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ShutdownResponse
    shutdown(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ShutdownRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SnapshotResponse
    snapshot(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SnapshotRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionResponse
    splitRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.StopMasterResponse
    stopMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.StopMasterRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchExceedThrottleQuotaResponse
    switchExceedThrottleQuota(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchExceedThrottleQuotaRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchRpcThrottleResponse
    switchRpcThrottle(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SwitchRpcThrottleRequest request)
     
    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)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableResponse
    truncateTable(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateTableRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignRegionResponse
    unassignRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.UnassignRegionRequest request)
     
    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)
     

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Field Details

    • stub

      private final org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface stub
  • Constructor Details

    • ShortCircuitMasterConnection

      public ShortCircuitMasterConnection(org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface stub)
  • Method Details

    • 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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      unassignRegion in interface org.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:
      truncateTable in interface org.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:
      stopMaster in interface org.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
      Specified by:
      snapshot in interface org.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:
      shutdown in interface org.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:
      setSplitOrMergeEnabled in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetQuotaRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      setQuota in interface org.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:
      setNormalizerRunning in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetBalancerRunningRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      setBalancerRunning in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • runCatalogScan

      public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanResponse runCatalogScan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCatalogScanRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      runCatalogScan in interface org.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
      Specified by:
      restoreSnapshot in interface org.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:
      switchSnapshotCleanup in interface org.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:
      isSnapshotCleanupEnabled in interface org.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:
      removeReplicationPeer in interface org.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:
      recommissionRegionServer in interface org.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
      Specified by:
      offlineRegion in interface org.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:
      normalize in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      moveRegion in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      modifyTable in interface org.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:
      modifyNamespace in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      modifyColumn in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      mergeTableRegions in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      listTableNamesByNamespace in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      listTableDescriptorsByNamespace in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetProceduresRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getProcedures in interface org.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:
      getLocks in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      listNamespaceDescriptors in interface org.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:
      listDecommissionedRegionServers in interface org.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:
      isSplitOrMergeEnabled in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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
      Specified by:
      isSnapshotDone in interface org.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
      Specified by:
      isProcedureDone in interface org.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) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      isNormalizerEnabled in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsMasterRunningRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      isMasterRunning in interface org.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:
      isMasterInMaintenanceMode in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      isCatalogJanitorEnabled in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      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:
      isBalancerEnabled in interface org.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:
      getTableState in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getTableNames in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      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:
      listTableNamesByState in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.GetTableDescriptorsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getTableDescriptors in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      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:
      listTableDescriptorsByState in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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
      Specified by:
      getSecurityCapabilities in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getSchemaAlterStatus in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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:
      getProcedureResult in interface org.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:
      getNamespaceDescriptor in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      flushTable in interface org.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:
      listNamespaces in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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:
      getLogEntries in interface org.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:
      getLastMajorCompactionTimestampForRegion in interface org.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:
      getLastMajorCompactionTimestamp in interface org.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
      Specified by:
      getCompletedSnapshots in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getClusterStatus in interface org.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
      Specified by:
      execProcedureWithRet in interface org.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
      Specified by:
      execProcedure in interface org.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:
      execMasterService in interface org.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:
      enableTable in interface org.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:
      enableReplicationPeer in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      enableCatalogJanitor in interface org.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:
      decommissionRegionServers in interface org.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:
      disableTable in interface org.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:
      disableReplicationPeer in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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:
      deleteTable in interface org.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
      Specified by:
      deleteSnapshot in interface org.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:
      deleteNamespace in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      deleteColumn in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      createTable in interface org.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:
      createNamespace in interface org.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:
      balance in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      assignRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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:
      addReplicationPeer in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      addColumn in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.AbortProcedureRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      abortProcedure in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • close

      public void close()
      Specified by:
      close in interface MasterKeepAliveConnection
    • runCleanerChore

      public org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreResponse runCleanerChore(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.RunCleanerChoreRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      runCleanerChore in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SetCleanerChoreRunningRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      setCleanerChoreRunning in interface org.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 controller, org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.IsCleanerChoreEnabledRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      isCleanerChoreEnabled in interface org.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:
      getReplicationPeerConfig in interface org.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:
      updateReplicationPeerConfig in interface org.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:
      listReplicationPeers in interface org.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:
      isReplicationPeerEnabled in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.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:
      getSpaceQuotaRegionSizes in interface org.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:
      getQuotaStates in interface org.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:
      clearDeadServers in interface org.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:
      splitRegion in interface org.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:
      truncateRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.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:
      switchRpcThrottle in interface org.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:
      isRpcThrottleEnabled in interface org.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:
      switchExceedThrottleQuota in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.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:
      grant in interface org.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:
      revoke in interface org.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:
      getUserPermissions in interface org.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:
      hasUserPermissions in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      modifyTableStoreFileTracker in interface org.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 request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      modifyColumnStoreFileTracker in interface org.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:
      flushMasterStore in interface org.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:
      replicationPeerModificationSwitch in interface org.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:
      getReplicationPeerModificationProcedures in interface org.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:
      isReplicationPeerModificationEnabled in interface org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException