@InterfaceAudience.LimitedPrivate(value="Configuration") public class NettyRpcServer extends RpcServer
RpcServer.BlockingServiceAndInterface, RpcServer.CallCleanup
Modifier and Type | Field and Description |
---|---|
static org.slf4j.Logger |
LOG |
allowFallbackToSimpleAuth, AUDITLOG, AUTH_FAILED_FOR, AUTH_SUCCESSFUL_FOR, authManager, authTokenSecretMgr, 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, isSecurityEnabled, KEY_WORD_TRUNCATED, MAPPER, MAX_REQUEST_SIZE, maxQueueSizeInBytes, maxRequestSize, metrics, MIN_CLIENT_REQUEST_TIMEOUT, minClientRequestTimeout, minSizeForReservoirUse, MONITORED_RPC, NIO_BUFFER_LIMIT, REQUEST_TOO_BIG_EXCEPTION, reservoir, saslProps, scheduler, secretManager, server, services, 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 org.apache.hadoop.hbase.ipc.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, getCurrentCall, getErrorHandler, getMetrics, getRemoteAddress, getRemoteIp, getRequestUser, getRequestUserName, getScheduler, getSecretManager, getService, getServiceAndInterface, getServiceInterface, getStatus, initReconfigurable, isInRpcCallContext, isStarted, onConfigurationChange, refreshAuthManager, setErrorHandler, setRsRpcServices, setSecretManager
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
protected org.apache.hadoop.hbase.ipc.NettyRpcServerPreambleHandler createNettyRpcServerPreambleHandler()
public void start()
public void stop()
public void join() throws InterruptedException
InterruptedException
public InetSocketAddress getListenerAddress()
public void setSocketSendBufSize(int size)
public int getNumOpenConnections()
RpcServer
getNumOpenConnections
in class RpcServer
public 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
IOException
public 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
IOException
Copyright © 2007–2019 Cloudera. All rights reserved.