Class TestShortCircuitGet.MyRSRpcServices

java.lang.Object
org.apache.hadoop.hbase.regionserver.RSRpcServices
org.apache.hadoop.hbase.regionserver.TestShortCircuitGet.MyRSRpcServices
All Implemented Interfaces:
org.apache.hadoop.hbase.conf.ConfigurationObserver, org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler, org.apache.hadoop.hbase.ipc.PriorityFunction, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.BootstrapNodeProtos.BootstrapNodeService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.BlockingInterface
Enclosing class:
TestShortCircuitGet

private static class TestShortCircuitGet.MyRSRpcServices extends org.apache.hadoop.hbase.regionserver.RSRpcServices
  • Nested Class Summary

    Nested classes/interfaces inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices

    org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder, org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    private static AtomicReference<Throwable>
     

    Fields inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices

    clearCompactionQueues, CLIENT_BOOTSTRAP_NODE_LIMIT, DEFAULT_CLIENT_BOOTSTRAP_NODE_LIMIT, DEFAULT_REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA, isa, LOG, MASTER_RPC_SCHEDULER_FACTORY_CLASS, REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS, regionServer, REGIONSERVER_ADMIN_SERVICE_CONFIG, REGIONSERVER_BOOTSTRAP_NODES_SERVICE_CONFIG, REGIONSERVER_CLIENT_META_SERVICE_CONFIG, REGIONSERVER_CLIENT_SERVICE_CONFIG, requestCount, rpcFullScanRequestCount, rpcGetRequestCount, rpcMultiRequestCount, rpcMutateRequestCount, rpcScanRequestCount, rpcServer
  • Constructor Summary

    Constructors
    Constructor
    Description
    MyRSRpcServices(org.apache.hadoop.hbase.regionserver.HRegionServer rs)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    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.shaded.protobuf.generated.ClientProtos.MultiResponse
    multi(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest 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)
     

    Methods inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices

    addSize, bulkLoadHFile, checkOOME, checkOpen, cleanupBulkLoad, clearCompactionQueues, clearRegionBlockCache, clearSlowLogsResponses, closeRegion, compactionSwitch, compactRegion, createPriority, createRpcServer, execRegionServerService, execService, executeProcedures, exitIfOOME, flushRegion, getAccessChecker, getActiveMaster, getAllBootstrapNodes, getBootstrapNodes, getCachedFilesList, getClusterId, getConfiguration, getDeadline, getLargeLogResponses, getLogEntries, getMasters, getMetaRegionLocations, getOnlineRegion, getPriority, getPriority, getRegion, getRegionInfo, getRegionLoad, getRemoteClientIpAndPort, getRpcScheduler, getRpcSchedulerFactoryClass, getScanDetailsWithId, getScanDetailsWithRequest, getScanner, getScannersCount, getScannerVirtualTime, getServerInfo, getServices, getSlowLogResponses, getSocketAddress, getSpaceQuotaSnapshots, getStoreFile, getTimeLimit, getUserName, getZkPermissionWatcher, mutate, onConfigurationChange, openRegion, prepareBulkLoad, replay, replicateWALEntry, requirePermission, rollWALWriter, start, stop, stopServer, updateConfiguration, updateFavoredNodes, warmupRegion

    Methods inherited from class java.lang.Object

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

  • Constructor Details

  • Method Details

    • multi

      public org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiResponse multi(org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcc, 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
      Overrides:
      multi in class org.apache.hadoop.hbase.regionserver.RSRpcServices
      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
      Overrides:
      scan in class org.apache.hadoop.hbase.regionserver.RSRpcServices
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • 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
      Overrides:
      get in class org.apache.hadoop.hbase.regionserver.RSRpcServices
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException