Class MockRegionServer

java.lang.Object
org.apache.hadoop.hbase.master.MockRegionServer
All Implemented Interfaces:
org.apache.hadoop.hbase.Abortable, org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion, org.apache.hadoop.hbase.regionserver.MutableOnlineRegions, org.apache.hadoop.hbase.regionserver.OnlineRegions, org.apache.hadoop.hbase.regionserver.RegionServerServices, org.apache.hadoop.hbase.Server, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface, org.apache.hadoop.hbase.Stoppable

class MockRegionServer extends Object implements org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface, org.apache.hadoop.hbase.regionserver.RegionServerServices
A mock RegionServer implementation. Use this when you can't bend Mockito to your liking (e.g. return null result when 'scanning' until master timesout and then return a coherent meta row result thereafter. Have some facility for faking gets and scans. See setGetResult(byte[], byte[], Result) for how to fill the backing data store that the get pulls from.
  • Nested Class Summary

    Nested Classes
    Modifier and Type
    Class
    Description
    (package private) class 
    Data structure that holds regionname and index used scanning.

    Nested classes/interfaces inherited from interface org.apache.hadoop.hbase.regionserver.RegionServerServices

    org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext, org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    private final org.apache.hadoop.conf.Configuration
     
    private final Map<byte[],Map<byte[],org.apache.hadoop.hbase.client.Result>>
    Map of regions to map of rows and Result.
    private final Map<byte[],org.apache.hadoop.hbase.client.Result[]>
    Map of regions to results to return when scanning.
    Outstanding scanners and their offset into nexts
    private final org.apache.hadoop.hbase.ServerName
     
    private final org.apache.hadoop.hbase.zookeeper.ZKWatcher
     
  • Constructor Summary

    Constructors
    Constructor
    Description
    MockRegionServer(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ServerName sn)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    void
     
    void
    addRegion(org.apache.hadoop.hbase.regionserver.HRegion r)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileResponse
    bulkLoadHFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadResponse
    cleanupBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesResponse
    clearCompactionQueues(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheResponse
    clearRegionBlockCache(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponses
    clearSlowLogsResponses(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponseRequest request)
     
    void
    close(long scannerId)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionResponse
    closeRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchResponse
    compactionSwitch(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionResponse
    compactRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactRegionRequest request)
     
    org.apache.hadoop.hbase.client.Connection
    createConnection(org.apache.hadoop.conf.Configuration conf)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse
    execRegionServerService(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.ClientProtos.CoprocessorServiceResponse
    execService(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.AdminProtos.ExecuteProceduresResponse
    executeProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse
    flushRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetResponse
    get(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest request)
     
    org.apache.hadoop.hbase.security.access.AccessChecker
     
    org.apache.hadoop.hbase.client.AsyncClusterConnection
     
    Optional<org.apache.hadoop.hbase.io.hfile.BlockCache>
     
    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)
     
    org.apache.hadoop.hbase.ChoreService
     
    double
     
    org.apache.hadoop.hbase.regionserver.compactions.CompactionRequester
     
    org.apache.hadoop.conf.Configuration
     
    org.apache.hadoop.hbase.client.Connection
     
    org.apache.hadoop.hbase.CoordinatedStateManager
     
    org.apache.hadoop.hbase.executor.ExecutorService
     
    getFavoredNodesForRegion(String encodedRegionName)
     
    org.apache.hadoop.fs.FileSystem
     
    double
     
    org.apache.hadoop.hbase.regionserver.FlushRequester
     
    org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
     
    org.apache.hadoop.hbase.regionserver.HeapMemoryManager
     
    org.apache.hadoop.hbase.regionserver.LeaseManager
     
    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.regionserver.MetricsRegionServer
     
    Optional<org.apache.hadoop.hbase.mob.MobFileCache>
     
    org.apache.hadoop.hbase.regionserver.ServerNonceManager
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse
    getOnlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionRequest request)
     
    org.apache.hadoop.hbase.regionserver.HRegion
    getRegion(String encodedRegionName)
     
    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)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadResponse
    getRegionLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest request)
     
    org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
     
    List<org.apache.hadoop.hbase.regionserver.HRegion>
     
    List<org.apache.hadoop.hbase.regionserver.HRegion>
    getRegions(org.apache.hadoop.hbase.TableName tableName)
     
    org.apache.hadoop.hbase.regionserver.RegionServerAccounting
     
    org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
     
    org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
     
     
    org.apache.hadoop.hbase.regionserver.ReplicationSourceService
     
    org.apache.hadoop.hbase.ipc.RpcServerInterface
     
    org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoResponse
    getServerInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoRequest request)
     
    org.apache.hadoop.hbase.ServerName
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsResponse
    getSpaceQuotaSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileResponse
    getStoreFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileRequest request)
     
    org.apache.hadoop.hbase.TableDescriptors
     
    org.apache.hadoop.hbase.wal.WAL
    getWAL(org.apache.hadoop.hbase.client.RegionInfo regionInfo)
     
    List<org.apache.hadoop.hbase.wal.WAL>
     
    org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
     
    org.apache.hadoop.hbase.zookeeper.ZKWatcher
     
    boolean
     
    boolean
     
    boolean
     
    boolean
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse
    multi(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse
    mutate(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest request)
     
    org.apache.hadoop.hbase.client.Result
    next(long scannerId)
     
    org.apache.hadoop.hbase.client.Result[]
    next(long scannerId, int numberOfRows)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionResponse
    openRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request)
     
    long
    openScanner(byte[] regionName, org.apache.hadoop.hbase.client.Scan scan)
     
    void
    postOpenDeployTasks(org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext context)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadResponse
    prepareBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request)
     
    org.apache.hadoop.hbase.client.locking.EntityLock
    regionLock(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, org.apache.hadoop.hbase.Abortable abort)
     
    boolean
    registerService(org.apache.hbase.thirdparty.com.google.protobuf.Service service)
     
    boolean
    removeRegion(org.apache.hadoop.hbase.regionserver.HRegion r, org.apache.hadoop.hbase.ServerName destination)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
    replay(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
    replicateToReplica(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
    replicateWALEntry(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request)
     
    boolean
    reportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String,Long>> archivedFiles)
     
    boolean
    reportRegionSizesForQuotas(org.apache.hadoop.hbase.quotas.RegionSizeStore sizeStore)
     
    boolean
    reportRegionStateTransition(org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext context)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterResponse
    rollWALWriter(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse
    scan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request)
     
    (package private) void
    setGetResult(byte[] regionName, byte[] row, org.apache.hadoop.hbase.client.Result r)
    Use this method filling the backing data source used by get(RpcController, ClientProtos.GetRequest)
    (package private) void
    setNextResults(byte[] regionName, org.apache.hadoop.hbase.client.Result[] rs)
    Use this method to set what a scanner will reply as we next through
    void
    stop(String why)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerResponse
    stopServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerRequest request)
     
    void
    unassign(byte[] regionName)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationResponse
    updateConfiguration(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationRequest request)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
    updateFavoredNodes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest request)
     
    void
    updateRegionFavoredNodesMapping(String encodedRegionName, List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ServerName> favoredNodes)
     
    org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionResponse
    warmupRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionRequest request)
     

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    Methods inherited from interface org.apache.hadoop.hbase.Abortable

    abort

    Methods inherited from interface org.apache.hadoop.hbase.Server

    getAsyncConnection
  • Field Details

  • Constructor Details

    • MockRegionServer

      MockRegionServer(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ServerName sn) throws org.apache.hadoop.hbase.ZooKeeperConnectionException, IOException
      Parameters:
      sn - Name of this mock regionserver
      Throws:
      org.apache.hadoop.hbase.ZooKeeperConnectionException
      IOException
  • Method Details

    • setGetResult

      void setGetResult(byte[] regionName, byte[] row, org.apache.hadoop.hbase.client.Result r)
      Use this method filling the backing data source used by get(RpcController, ClientProtos.GetRequest)
      Parameters:
      regionName - the region name to assign
      row - the row key
      r - the single row result
    • setNextResults

      void setNextResults(byte[] regionName, org.apache.hadoop.hbase.client.Result[] rs)
      Use this method to set what a scanner will reply as we next through
    • isStopped

      public boolean isStopped()
      Specified by:
      isStopped in interface org.apache.hadoop.hbase.Stoppable
    • abort

      public void abort(String why, Throwable e)
      Specified by:
      abort in interface org.apache.hadoop.hbase.Abortable
    • isAborted

      public boolean isAborted()
      Specified by:
      isAborted in interface org.apache.hadoop.hbase.Abortable
    • openScanner

      public long openScanner(byte[] regionName, org.apache.hadoop.hbase.client.Scan scan) throws IOException
      Throws:
      IOException
    • next

      public org.apache.hadoop.hbase.client.Result next(long scannerId) throws IOException
      Throws:
      IOException
    • next

      public org.apache.hadoop.hbase.client.Result[] next(long scannerId, int numberOfRows) throws IOException
      Throws:
      IOException
    • close

      public void close(long scannerId) throws IOException
      Throws:
      IOException
    • stop

      public void stop(String why)
      Specified by:
      stop in interface org.apache.hadoop.hbase.Stoppable
    • addRegion

      public void addRegion(org.apache.hadoop.hbase.regionserver.HRegion r)
      Specified by:
      addRegion in interface org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
    • removeRegion

      public boolean removeRegion(org.apache.hadoop.hbase.regionserver.HRegion r, org.apache.hadoop.hbase.ServerName destination)
      Specified by:
      removeRegion in interface org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
    • getRegion

      public org.apache.hadoop.hbase.regionserver.HRegion getRegion(String encodedRegionName)
      Specified by:
      getRegion in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
      Specified by:
      getRegion in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getConfiguration

      public org.apache.hadoop.conf.Configuration getConfiguration()
      Specified by:
      getConfiguration in interface org.apache.hadoop.hbase.Server
    • getZooKeeper

      public org.apache.hadoop.hbase.zookeeper.ZKWatcher getZooKeeper()
      Specified by:
      getZooKeeper in interface org.apache.hadoop.hbase.Server
    • getCoordinatedStateManager

      public org.apache.hadoop.hbase.CoordinatedStateManager getCoordinatedStateManager()
      Specified by:
      getCoordinatedStateManager in interface org.apache.hadoop.hbase.Server
    • getConnection

      public org.apache.hadoop.hbase.client.Connection getConnection()
      Specified by:
      getConnection in interface org.apache.hadoop.hbase.Server
    • getServerName

      public org.apache.hadoop.hbase.ServerName getServerName()
      Specified by:
      getServerName in interface org.apache.hadoop.hbase.Server
    • isStopping

      public boolean isStopping()
      Specified by:
      isStopping in interface org.apache.hadoop.hbase.Server
    • getFlushRequester

      public org.apache.hadoop.hbase.regionserver.FlushRequester getFlushRequester()
      Specified by:
      getFlushRequester in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getCompactionRequestor

      public org.apache.hadoop.hbase.regionserver.compactions.CompactionRequester getCompactionRequestor()
      Specified by:
      getCompactionRequestor in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getRegionServerAccounting

      public org.apache.hadoop.hbase.regionserver.RegionServerAccounting getRegionServerAccounting()
      Specified by:
      getRegionServerAccounting in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getRegionServerRpcQuotaManager

      public org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager getRegionServerRpcQuotaManager()
      Specified by:
      getRegionServerRpcQuotaManager in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • postOpenDeployTasks

      public void postOpenDeployTasks(org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext context) throws IOException
      Specified by:
      postOpenDeployTasks in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
      Throws:
      IOException
    • getRpcServer

      public org.apache.hadoop.hbase.ipc.RpcServerInterface getRpcServer()
      Specified by:
      getRpcServer in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getRegionsInTransitionInRS

      Specified by:
      getRegionsInTransitionInRS in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getFileSystem

      public org.apache.hadoop.fs.FileSystem getFileSystem()
      Specified by:
      getFileSystem in interface org.apache.hadoop.hbase.Server
    • get

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetResponse get(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.GetRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      get in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • mutate

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse mutate(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      mutate in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • scan

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse scan(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      scan in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • bulkLoadHFile

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileResponse bulkLoadHFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.BulkLoadHFileRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      bulkLoadHFile in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • execService

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse execService(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:
      execService in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • multi

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse multi(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      multi in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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
      Specified by:
      getRegionInfo in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getRegionLoad

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadResponse getRegionLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getRegionLoad in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • clearCompactionQueues

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesResponse clearCompactionQueues(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearCompactionQueuesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      clearCompactionQueues in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getStoreFile

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileResponse getStoreFile(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetStoreFileRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getStoreFile in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getOnlineRegion

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse getOnlineRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getOnlineRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      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:
      getCachedFilesList in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getRegions

      public List<org.apache.hadoop.hbase.regionserver.HRegion> getRegions()
      Specified by:
      getRegions in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
      Specified by:
      getRegions in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • openRegion

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionResponse openRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      openRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • warmupRegion

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionResponse warmupRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WarmupRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      warmupRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • closeRegion

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionResponse closeRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      closeRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • flushRegion

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse flushRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      flushRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • compactionSwitch

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchResponse compactionSwitch(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CompactionSwitchRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      compactionSwitch in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.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
      Specified by:
      compactRegion in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • replicateWALEntry

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replicateWALEntry(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      replicateWALEntry in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • rollWALWriter

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterResponse rollWALWriter(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      rollWALWriter in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getServerInfo

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoResponse getServerInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetServerInfoRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getServerInfo in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • stopServer

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerResponse stopServer(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.StopServerRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      stopServer in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getRegions

      public List<org.apache.hadoop.hbase.regionserver.HRegion> getRegions(org.apache.hadoop.hbase.TableName tableName) throws IOException
      Specified by:
      getRegions in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
      Specified by:
      getRegions in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
      Throws:
      IOException
    • getLeaseManager

      public org.apache.hadoop.hbase.regionserver.LeaseManager getLeaseManager()
      Specified by:
      getLeaseManager in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getWALs

      public List<org.apache.hadoop.hbase.wal.WAL> getWALs() throws IOException
      Specified by:
      getWALs in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
      Throws:
      IOException
    • getWAL

      public org.apache.hadoop.hbase.wal.WAL getWAL(org.apache.hadoop.hbase.client.RegionInfo regionInfo) throws IOException
      Specified by:
      getWAL in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
      Throws:
      IOException
    • getExecutorService

      public org.apache.hadoop.hbase.executor.ExecutorService getExecutorService()
      Specified by:
      getExecutorService in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getChoreService

      public org.apache.hadoop.hbase.ChoreService getChoreService()
      Specified by:
      getChoreService in interface org.apache.hadoop.hbase.Server
    • updateRegionFavoredNodesMapping

      public void updateRegionFavoredNodesMapping(String encodedRegionName, List<org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.ServerName> favoredNodes)
      Specified by:
      updateRegionFavoredNodesMapping in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
    • getFavoredNodesForRegion

      public InetSocketAddress[] getFavoredNodesForRegion(String encodedRegionName)
      Specified by:
      getFavoredNodesForRegion in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
    • replay

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replay(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      replay in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • updateFavoredNodes

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse updateFavoredNodes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      updateFavoredNodes in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getNonceManager

      public org.apache.hadoop.hbase.regionserver.ServerNonceManager getNonceManager()
      Specified by:
      getNonceManager in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • reportRegionStateTransition

      public boolean reportRegionStateTransition(org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext context)
      Specified by:
      reportRegionStateTransition in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • registerService

      public boolean registerService(org.apache.hbase.thirdparty.com.google.protobuf.Service service)
      Specified by:
      registerService in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • execRegionServerService

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CoprocessorServiceResponse execRegionServerService(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:
      execRegionServerService in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • updateConfiguration

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationResponse updateConfiguration(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateConfigurationRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      updateConfiguration in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • clearRegionBlockCache

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheResponse clearRegionBlockCache(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      clearRegionBlockCache in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getHeapMemoryManager

      public org.apache.hadoop.hbase.regionserver.HeapMemoryManager getHeapMemoryManager()
      Specified by:
      getHeapMemoryManager in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getCompactionPressure

      public double getCompactionPressure()
      Specified by:
      getCompactionPressure in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getFlushThroughputController

      public org.apache.hadoop.hbase.regionserver.throttle.ThroughputController getFlushThroughputController()
      Specified by:
      getFlushThroughputController in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getFlushPressure

      public double getFlushPressure()
      Specified by:
      getFlushPressure in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getMetrics

      public org.apache.hadoop.hbase.regionserver.MetricsRegionServer getMetrics()
      Specified by:
      getMetrics in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • regionLock

      public org.apache.hadoop.hbase.client.locking.EntityLock regionLock(List<org.apache.hadoop.hbase.client.RegionInfo> regionInfos, String description, org.apache.hadoop.hbase.Abortable abort) throws IOException
      Specified by:
      regionLock in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
      Throws:
      IOException
    • prepareBulkLoad

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadResponse prepareBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.PrepareBulkLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      prepareBulkLoad in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • cleanupBulkLoad

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadResponse cleanupBulkLoad(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CleanupBulkLoadRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      cleanupBulkLoad in interface org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getSecureBulkLoadManager

      public org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager getSecureBulkLoadManager()
      Specified by:
      getSecureBulkLoadManager in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • unassign

      public void unassign(byte[] regionName) throws IOException
      Specified by:
      unassign in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
      Throws:
      IOException
    • getRegionServerSpaceQuotaManager

      public org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager getRegionServerSpaceQuotaManager()
      Specified by:
      getRegionServerSpaceQuotaManager in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • executeProcedures

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresResponse executeProcedures(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      executeProcedures in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • clearSlowLogsResponses

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponses clearSlowLogsResponses(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearSlowLogResponseRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      clearSlowLogsResponses in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.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.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • getSpaceQuotaSnapshots

      public org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsResponse getSpaceQuotaSnapshots(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.QuotaProtos.GetSpaceQuotaSnapshotsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      getSpaceQuotaSnapshots in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • createConnection

      public org.apache.hadoop.hbase.client.Connection createConnection(org.apache.hadoop.conf.Configuration conf) throws IOException
      Specified by:
      createConnection in interface org.apache.hadoop.hbase.Server
      Throws:
      IOException
    • reportRegionSizesForQuotas

      public boolean reportRegionSizesForQuotas(org.apache.hadoop.hbase.quotas.RegionSizeStore sizeStore)
      Specified by:
      reportRegionSizesForQuotas in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • reportFileArchivalForQuotas

      public boolean reportFileArchivalForQuotas(org.apache.hadoop.hbase.TableName tableName, Collection<Map.Entry<String,Long>> archivedFiles)
      Specified by:
      reportFileArchivalForQuotas in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • isClusterUp

      public boolean isClusterUp()
      Specified by:
      isClusterUp in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getReplicationSourceService

      public org.apache.hadoop.hbase.regionserver.ReplicationSourceService getReplicationSourceService()
      Specified by:
      getReplicationSourceService in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getTableDescriptors

      public org.apache.hadoop.hbase.TableDescriptors getTableDescriptors()
      Specified by:
      getTableDescriptors in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getBlockCache

      public Optional<org.apache.hadoop.hbase.io.hfile.BlockCache> getBlockCache()
      Specified by:
      getBlockCache in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getMobFileCache

      public Optional<org.apache.hadoop.hbase.mob.MobFileCache> getMobFileCache()
      Specified by:
      getMobFileCache in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getAccessChecker

      public org.apache.hadoop.hbase.security.access.AccessChecker getAccessChecker()
      Specified by:
      getAccessChecker in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getZKPermissionWatcher

      public org.apache.hadoop.hbase.security.access.ZKPermissionWatcher getZKPermissionWatcher()
      Specified by:
      getZKPermissionWatcher in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • getAsyncClusterConnection

      public org.apache.hadoop.hbase.client.AsyncClusterConnection getAsyncClusterConnection()
      Specified by:
      getAsyncClusterConnection in interface org.apache.hadoop.hbase.Server
    • getRegionReplicationBufferManager

      public org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager getRegionReplicationBufferManager()
      Specified by:
      getRegionReplicationBufferManager in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
    • replicateToReplica

      public org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryResponse replicateToReplica(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ReplicateWALEntryRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Specified by:
      replicateToReplica in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException