@InterfaceAudience.LimitedPrivate(value="Configuration") public class NettyRpcServer extends RpcServer
RpcServer.BlockingServiceAndInterface, RpcServer.CallCleanup| Modifier and Type | Field and Description |
|---|---|
(package private) org.apache.hbase.thirdparty.io.netty.channel.group.ChannelGroup |
allChannels |
private InetSocketAddress |
bindAddress |
private org.apache.hbase.thirdparty.io.netty.buffer.ByteBufAllocator |
channelAllocator |
private CountDownLatch |
closed |
static String |
HBASE_NETTY_ALLOCATOR_KEY
Name of property to change the byte buf allocator for the netty channels.
|
(package private) static String |
HEAP_ALLOCATOR_TYPE |
static org.slf4j.Logger |
LOG |
(package private) static String |
POOLED_ALLOCATOR_TYPE |
private org.apache.hbase.thirdparty.io.netty.channel.Channel |
serverChannel |
(package private) static String |
UNPOOLED_ALLOCATOR_TYPE |
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, 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() |
private org.apache.hbase.thirdparty.io.netty.buffer.ByteBufAllocator |
getChannelAllocator(org.apache.hadoop.conf.Configuration conf) |
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, needAuthorization, onConfigurationChange, refreshAuthManager, setCurrentCall, setErrorHandler, setNamedQueueRecorder, setRsRpcServices, setSecretManager, truncateTraceLog, unsetCurrentCallpublic static final org.slf4j.Logger LOG
public static final String HBASE_NETTY_ALLOCATOR_KEY
"pooled" and "unpooled" may prefer direct memory depending on netty configuration, which is controlled by platform specific code and documented system properties.
"heap" will prefer heap arena allocations.
static final String POOLED_ALLOCATOR_TYPE
static final String UNPOOLED_ALLOCATOR_TYPE
static final String HEAP_ALLOCATOR_TYPE
private final InetSocketAddress bindAddress
private final CountDownLatch closed
private final org.apache.hbase.thirdparty.io.netty.channel.Channel serverChannel
final org.apache.hbase.thirdparty.io.netty.channel.group.ChannelGroup allChannels
private final org.apache.hbase.thirdparty.io.netty.buffer.ByteBufAllocator channelAllocator
public NettyRpcServer(Server server, String name, List<RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, RpcScheduler scheduler, boolean reservoirEnabled) throws IOException
IOExceptionprivate org.apache.hbase.thirdparty.io.netty.buffer.ByteBufAllocator getChannelAllocator(org.apache.hadoop.conf.Configuration conf) 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–2020 The Apache Software Foundation. All rights reserved.