Class TestRegionReplicaReplicationError.ErrorReplayRSRpcServices
java.lang.Object
org.apache.hadoop.hbase.HBaseRpcServicesBase<org.apache.hadoop.hbase.regionserver.HRegionServer>
org.apache.hadoop.hbase.regionserver.RSRpcServices
org.apache.hadoop.hbase.regionserver.TestRegionReplicaReplicationError.ErrorReplayRSRpcServices
- 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:
- TestRegionReplicaReplicationError
public static final class TestRegionReplicaReplicationError.ErrorReplayRSRpcServices
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.RegionScannerContext, org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannerHolder, org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack
-
Field Summary
Modifier and TypeFieldDescriptionprivate final ConcurrentHashMap<org.apache.hadoop.hbase.regionserver.HRegion,
AtomicInteger> Fields inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices
clearCompactionQueues, DEFAULT_REGION_SERVER_RPC_MINIMUM_SCAN_TIME_LIMIT_DELTA, REGION_SERVER_RPC_SCHEDULER_FACTORY_CLASS, REGIONSERVER_ADMIN_SERVICE_CONFIG, REGIONSERVER_BOOTSTRAP_NODES_SERVICE_CONFIG, REGIONSERVER_CLIENT_META_SERVICE_CONFIG, REGIONSERVER_CLIENT_SERVICE_CONFIG, requestCount, rpcFullScanRequestCount, rpcGetRequestCount, rpcMultiRequestCount, rpcMutateRequestCount, rpcScanRequestCount
Fields inherited from class org.apache.hadoop.hbase.HBaseRpcServicesBase
CLIENT_BOOTSTRAP_NODE_LIMIT, DEFAULT_CLIENT_BOOTSTRAP_NODE_LIMIT, priority, rpcServer, server
-
Constructor Summary
ConstructorDescriptionErrorReplayRSRpcServices
(org.apache.hadoop.hbase.regionserver.HRegionServer rs) -
Method Summary
Modifier and TypeMethodDescriptionorg.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) Methods inherited from class org.apache.hadoop.hbase.regionserver.RSRpcServices
addSize, bulkLoadHFile, checkOpen, checkQuotaAndGetRegionScannerContext, cleanupBulkLoad, clearCompactionQueues, clearRegionBlockCache, closeRegion, compactionSwitch, compactRegion, createPriority, createRpcServer, defaultReservoirEnabled, execRegionServerService, execService, executeProcedures, flushRegion, get, getAllBootstrapNodes, getCachedFilesList, getDefaultPort, getDNSServerType, getHostname, getOnlineRegion, getPortConfigName, getPriority, getRegion, getRegionInfo, getRegionLoad, getRemoteClientIpAndPort, getRpcSchedulerFactoryClass, getRpcSchedulerFactoryClass, getScanDetailsWithId, getScanDetailsWithRequest, getScanner, getScannersCount, getScannerVirtualTime, getServerInfo, getServices, getSpaceQuotaSnapshots, getStoreFile, getTimeLimit, getUserName, multi, mutate, onConfigurationChange, openRegion, prepareBulkLoad, replay, replicateWALEntry, rollWALWriter, scan, start, stop, stopServer, updateFavoredNodes, warmupRegion
Methods inherited from class org.apache.hadoop.hbase.HBaseRpcServicesBase
checkOOME, clearSlowLogsResponses, getAccessChecker, getActiveMaster, getBootstrapNodes, getClusterId, getConfiguration, getDeadline, getLogEntries, getMasters, getMetaRegionLocations, getPriority, getRpcScheduler, getRpcServer, getServer, getSocketAddress, getZkPermissionWatcher, internalStart, internalStop, requirePermission, updateConfiguration
-
Field Details
-
regionToCounter
private final ConcurrentHashMap<org.apache.hadoop.hbase.regionserver.HRegion,AtomicInteger> regionToCounter
-
-
Constructor Details
-
ErrorReplayRSRpcServices
public ErrorReplayRSRpcServices(org.apache.hadoop.hbase.regionserver.HRegionServer rs) throws IOException - Throws:
IOException
-
-
Method Details
-
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 interfaceorg.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
- Overrides:
replicateToReplica
in classorg.apache.hadoop.hbase.regionserver.RSRpcServices
- Throws:
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
-