@InterfaceAudience.Private public abstract class HBaseRpcServicesBase<S extends HBaseServerBase<?>> extends Object implements org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.BlockingInterface, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface, HBaseRPCErrorHandler, PriorityFunction, ConfigurationObserver
Modifier and Type | Field and Description |
---|---|
private AccessChecker |
accessChecker |
static String |
CLIENT_BOOTSTRAP_NODE_LIMIT |
static int |
DEFAULT_CLIENT_BOOTSTRAP_NODE_LIMIT |
private InetSocketAddress |
isa |
private static org.slf4j.Logger |
LOG |
protected PriorityFunction |
priority |
protected RpcServer |
rpcServer |
protected S |
server |
private ZKPermissionWatcher |
zkPermissionWatcher |
Modifier | Constructor and Description |
---|---|
protected |
HBaseRpcServicesBase(S server,
String processName) |
Modifier and Type | Method and Description |
---|---|
boolean |
checkOOME(Throwable e)
Check if an OOME and, if so, abort immediately to avoid creating more objects.
|
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) |
protected abstract PriorityFunction |
createPriority() |
protected abstract boolean |
defaultReservoirEnabled() |
AccessChecker |
getAccessChecker() |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetActiveMasterResponse |
getActiveMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetActiveMasterRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetBootstrapNodesResponse |
getBootstrapNodes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetBootstrapNodesRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetClusterIdResponse |
getClusterId(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetClusterIdRequest request) |
org.apache.hadoop.conf.Configuration |
getConfiguration() |
long |
getDeadline(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param)
Returns the deadline of the specified request.
|
protected abstract int |
getDefaultPort() |
protected abstract DNS.ServerType |
getDNSServerType() |
protected abstract String |
getHostname(org.apache.hadoop.conf.Configuration conf,
String defaultHostname) |
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.RegistryProtos.GetMastersResponse |
getMasters(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMastersRequest request) |
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMetaRegionLocationsResponse |
getMetaRegionLocations(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMetaRegionLocationsRequest request) |
protected abstract String |
getPortConfigName() |
int |
getPriority(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
User user)
Returns the 'priority type' of the specified request.
|
RpcScheduler |
getRpcScheduler() |
protected abstract Class<?> |
getRpcSchedulerFactoryClass(org.apache.hadoop.conf.Configuration conf) |
RpcServerInterface |
getRpcServer() |
S |
getServer() |
protected abstract List<RpcServer.BlockingServiceAndInterface> |
getServices() |
private List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> |
getSlowLogPayloads(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.SlowLogResponseRequest request,
NamedQueueRecorder namedQueueRecorder) |
InetSocketAddress |
getSocketAddress() |
ZKPermissionWatcher |
getZkPermissionWatcher() |
protected void |
internalStart(ZKWatcher zkWatcher) |
protected void |
internalStop() |
void |
onConfigurationChange(org.apache.hadoop.conf.Configuration conf)
This method would be called by the
ConfigurationManager object when the
Configuration object is reloaded from disk. |
protected void |
requirePermission(String request,
Permission.Action perm) |
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) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
clearCompactionQueues, clearRegionBlockCache, closeRegion, compactionSwitch, compactRegion, executeProcedures, flushRegion, getOnlineRegion, getRegionInfo, getRegionLoad, getServerInfo, getSpaceQuotaSnapshots, getStoreFile, openRegion, replay, replicateToReplica, replicateWALEntry, rollWALWriter, stopServer, updateFavoredNodes, warmupRegion
private static final org.slf4j.Logger LOG
public static final String CLIENT_BOOTSTRAP_NODE_LIMIT
public static final int DEFAULT_CLIENT_BOOTSTRAP_NODE_LIMIT
protected final S extends HBaseServerBase<?> server
private final InetSocketAddress isa
protected final PriorityFunction priority
private AccessChecker accessChecker
private ZKPermissionWatcher zkPermissionWatcher
protected HBaseRpcServicesBase(S server, String processName) throws IOException
IOException
protected abstract boolean defaultReservoirEnabled()
protected abstract DNS.ServerType getDNSServerType()
protected abstract String getHostname(org.apache.hadoop.conf.Configuration conf, String defaultHostname)
protected abstract String getPortConfigName()
protected abstract int getDefaultPort()
protected abstract PriorityFunction createPriority()
protected abstract Class<?> getRpcSchedulerFactoryClass(org.apache.hadoop.conf.Configuration conf)
protected abstract List<RpcServer.BlockingServiceAndInterface> getServices()
protected final void internalStart(ZKWatcher zkWatcher)
protected final void requirePermission(String request, Permission.Action perm) throws IOException
IOException
public AccessChecker getAccessChecker()
public ZKPermissionWatcher getZkPermissionWatcher()
protected final void internalStop()
public org.apache.hadoop.conf.Configuration getConfiguration()
public InetSocketAddress getSocketAddress()
public RpcServerInterface getRpcServer()
public RpcScheduler getRpcScheduler()
public int getPriority(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, User user)
PriorityFunction
getPriority
in interface PriorityFunction
public long getDeadline(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param)
PriorityFunction
getDeadline
in interface PriorityFunction
public boolean checkOOME(Throwable e)
checkOOME
in interface HBaseRPCErrorHandler
e
- the throwablepublic void onConfigurationChange(org.apache.hadoop.conf.Configuration conf)
ConfigurationObserver
ConfigurationManager
object when the
Configuration
object is reloaded from disk.onConfigurationChange
in interface ConfigurationObserver
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetClusterIdResponse getClusterId(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetClusterIdRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getClusterId
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetActiveMasterResponse getActiveMaster(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetActiveMasterRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getActiveMaster
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMastersResponse getMasters(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMastersRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getMasters
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMetaRegionLocationsResponse getMetaRegionLocations(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMetaRegionLocationsRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getMetaRegionLocations
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
public final org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetBootstrapNodesResponse getBootstrapNodes(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetBootstrapNodesRequest request) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
getBootstrapNodes
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
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
updateConfiguration
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
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
clearSlowLogsResponses
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
private List<org.apache.hadoop.hbase.shaded.protobuf.generated.TooSlowLog.SlowLogPayload> getSlowLogPayloads(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.SlowLogResponseRequest request, NamedQueueRecorder namedQueueRecorder)
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
getLogEntries
in interface org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.