Package org.apache.hadoop.hbase.client
Class TestAsyncClientPauseForRpcThrottling.ThrottlingRSRpcServicesForTest
java.lang.Object
org.apache.hadoop.hbase.regionserver.RSRpcServices
org.apache.hadoop.hbase.client.TestAsyncClientPauseForRpcThrottling.ThrottlingRSRpcServicesForTest
- 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:
- TestAsyncClientPauseForRpcThrottling
public static final class TestAsyncClientPauseForRpcThrottling.ThrottlingRSRpcServicesForTest
extends org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Field Summary
Fields inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices
CLIENT_BOOTSTRAP_NODE_LIMIT, DEFAULT_CLIENT_BOOTSTRAP_NODE_LIMIT, 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
-
Constructor Summary
ConstructorDescriptionThrottlingRSRpcServicesForTest
(org.apache.hadoop.hbase.regionserver.HRegionServer rs) -
Method Summary
Modifier and TypeMethodDescriptionorg.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) private void
private void
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
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, getRpcScheduler, getRpcSchedulerFactoryClass, getScanDetailsWithId, getScanDetailsWithRequest, getScannersCount, getServerInfo, getServices, getSlowLogResponses, getSocketAddress, getSpaceQuotaSnapshots, getStoreFile, getZkPermissionWatcher, mutate, onConfigurationChange, openRegion, prepareBulkLoad, replay, replicateWALEntry, requirePermission, rollWALWriter, stopServer, updateConfiguration, updateFavoredNodes, warmupRegion
-
Constructor Details
-
ThrottlingRSRpcServicesForTest
public ThrottlingRSRpcServicesForTest(org.apache.hadoop.hbase.regionserver.HRegionServer rs) throws IOException - Throws:
IOException
-
-
Method Details
-
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 interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
- Overrides:
get
in classorg.apache.hadoop.hbase.regionserver.RSRpcServices
- 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 rpcc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException - Specified by:
multi
in interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
- Overrides:
multi
in classorg.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 interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
- Overrides:
scan
in classorg.apache.hadoop.hbase.regionserver.RSRpcServices
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
maybeForceRetry
private void maybeForceRetry() throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-
maybeThrottle
private void maybeThrottle() throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-