@InterfaceAudience.LimitedPrivate(value="Configuration") public class NettyRpcServer extends RpcServer
RpcServer.BlockingServiceAndInterface, RpcServer.CallCleanup| Modifier and Type | Field and Description |
|---|---|
private org.apache.hbase.thirdparty.io.netty.channel.group.ChannelGroup |
allChannels |
private InetSocketAddress |
bindAddress |
private CountDownLatch |
closed |
private static int |
EVENTLOOP_THREADCOUNT_DEFAULT |
static String |
HBASE_NETTY_EVENTLOOP_RPCSERVER_THREADCOUNT_KEY
Name of property to change netty rpc server eventloop thread count.
|
static org.slf4j.Logger |
LOG |
private org.apache.hbase.thirdparty.io.netty.channel.Channel |
serverChannel |
allowFallbackToSimpleAuth, AUDITLOG, AUTH_FAILED_FOR, AUTH_SUCCESSFUL_FOR, authManager, authTokenSecretMgr, bbAllocator, CALL_QUEUE_TOO_BIG_EXCEPTION, callQueueSizeInBytes, cellBlockBuilder, conf, CurCall, CURRENT_VERSION, DEFAULT_MAX_CALLQUEUE_LENGTH_PER_HANDLER, DEFAULT_MAX_CALLQUEUE_SIZE, DEFAULT_MAX_REQUEST_SIZE, DEFAULT_MIN_CLIENT_REQUEST_TIMEOUT, DEFAULT_TRACE_LOG_MAX_LENGTH, DEFAULT_WARN_RESPONSE_SIZE, DEFAULT_WARN_RESPONSE_TIME, errorHandler, FALLBACK_TO_INSECURE_CLIENT_AUTH, GSON, isSecurityEnabled, KEY_WORD_TRUNCATED, MAX_REQUEST_SIZE, maxQueueSizeInBytes, maxRequestSize, metrics, MIN_CLIENT_REQUEST_TIMEOUT, minClientRequestTimeout, MONITORED_RPC, NIO_BUFFER_LIMIT, REQUEST_TOO_BIG_EXCEPTION, running, saslProps, scheduler, secretManager, server, services, started, tcpKeepAlive, tcpNoDelay, TRACE_LOG_MAX_LENGTH, userProvider, WARN_RESPONSE_SIZE, WARN_RESPONSE_TIME, warnResponseSize, warnResponseTime| Constructor and Description |
|---|
NettyRpcServer(Server server,
String name,
List<RpcServer.BlockingServiceAndInterface> services,
InetSocketAddress bindAddress,
org.apache.hadoop.conf.Configuration conf,
RpcScheduler scheduler,
boolean reservoirEnabled) |
| Modifier and Type | Method and Description |
|---|---|
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status) |
Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> |
call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cellScanner,
long receiveTime,
MonitoredRPCHandler status,
long startTime,
int timeout) |
protected NettyRpcServerPreambleHandler |
createNettyRpcServerPreambleHandler() |
InetSocketAddress |
getListenerAddress() |
int |
getNumOpenConnections()
The number of open RPC conections
|
void |
join() |
void |
setSocketSendBufSize(int size) |
void |
start() |
void |
stop() |
addCallSize, authorize, call, channelRead, createSecretManager, getByteBuffAllocator, getConf, getCurrentCall, getErrorHandler, getMetrics, getRemoteAddress, getRemoteIp, getRequestUser, getRequestUserName, getScheduler, getSecretManager, getService, getServiceAndInterface, getServiceInterface, getStatus, initReconfigurable, isInRpcCallContext, isStarted, logResponse, onConfigurationChange, refreshAuthManager, setCurrentCall, setErrorHandler, setNamedQueueRecorder, setRsRpcServices, setSecretManager, truncateTraceLog, unsetCurrentCallpublic static final org.slf4j.Logger LOG
public static final String HBASE_NETTY_EVENTLOOP_RPCSERVER_THREADCOUNT_KEY
private static final int EVENTLOOP_THREADCOUNT_DEFAULT
private final InetSocketAddress bindAddress
private final CountDownLatch closed
private final org.apache.hbase.thirdparty.io.netty.channel.Channel serverChannel
private final org.apache.hbase.thirdparty.io.netty.channel.group.ChannelGroup allChannels
public NettyRpcServer(Server server, String name, List<RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, RpcScheduler scheduler, boolean reservoirEnabled) throws IOException
IOException@InterfaceAudience.Private protected NettyRpcServerPreambleHandler createNettyRpcServerPreambleHandler()
public void start()
public void stop()
public void join() throws InterruptedException
InterruptedExceptionpublic InetSocketAddress getListenerAddress()
public void setSocketSendBufSize(int size)
public int getNumOpenConnections()
RpcServergetNumOpenConnections in class RpcServerpublic Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, CellScanner cellScanner, long receiveTime, MonitoredRPCHandler status) throws IOException
IOExceptionpublic Pair<org.apache.hbase.thirdparty.com.google.protobuf.Message,CellScanner> call(org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, CellScanner cellScanner, long receiveTime, MonitoredRPCHandler status, long startTime, int timeout) throws IOException
IOExceptionCopyright © 2007–2021 The Apache Software Foundation. All rights reserved.