Package org.apache.hadoop.hbase.ipc
Class FailingNettyRpcServer
java.lang.Object
org.apache.hadoop.hbase.ipc.RpcServer
org.apache.hadoop.hbase.ipc.NettyRpcServer
org.apache.hadoop.hbase.ipc.FailingNettyRpcServer
- All Implemented Interfaces:
org.apache.hadoop.hbase.conf.ConfigurationObserver
,org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Nested Class Summary
Modifier and TypeClassDescription(package private) static final class
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.ipc.RpcServer
org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface, org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup
-
Field Summary
Fields inherited from class org.apache.hadoop.hbase.ipc.NettyRpcServer
allChannels, CHANNEL_WRITABLE_FATAL_WATERMARK_KEY, CHANNEL_WRITABLE_HIGH_WATERMARK_KEY, CHANNEL_WRITABLE_LOW_WATERMARK_KEY, HBASE_NETTY_ALLOCATOR_KEY, HEAP_ALLOCATOR_TYPE, LOG, POOLED_ALLOCATOR_TYPE, UNPOOLED_ALLOCATOR_TYPE
Fields inherited from class org.apache.hadoop.hbase.ipc.RpcServer
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, serverPrincipal, services, started, tcpKeepAlive, tcpNoDelay, TRACE_LOG_MAX_LENGTH, userProvider, WARN_RESPONSE_SIZE, WARN_RESPONSE_TIME, WARN_SCAN_RESPONSE_SIZE, WARN_SCAN_RESPONSE_TIME, warnResponseSize, warnResponseTime, warnScanResponseSize, warnScanResponseTime
-
Constructor Summary
ConstructorDescriptionFailingNettyRpcServer
(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler) -
Method Summary
Modifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
createNettyServerRpcConnection
(org.apache.hbase.thirdparty.io.netty.channel.Channel channel) Methods inherited from class org.apache.hadoop.hbase.ipc.NettyRpcServer
call, call, getListenerAddress, getNumOpenConnections, getSslContext, getTotalAndMaxNettyOutboundBytes, getWriteBufferFatalThreshold, isWritabilityBackpressureEnabled, join, onConfigurationChange, setSocketSendBufSize, sslHandshakeCompleteHandler, start, stop
Methods inherited from class org.apache.hadoop.hbase.ipc.RpcServer
addCallSize, authorize, call, channelRead, createSecretManager, getByteBuffAllocator, getConf, getCurrentCall, getErrorHandler, getMetrics, getRemoteAddress, getRemoteIp, getRequestUser, getRequestUserName, getScheduler, getSecretManager, getService, getServiceAndInterface, getServiceInterface, getServices, getStatus, initReconfigurable, isInRpcCallContext, isStarted, logResponse, needAuthorization, refreshAuthManager, setCurrentCall, setErrorHandler, setNamedQueueRecorder, setRsRpcServices, setSecretManager, truncateTraceLog, unsetCurrentCall
-
Constructor Details
-
FailingNettyRpcServer
public FailingNettyRpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler) throws IOException - Throws:
IOException
-
-
Method Details
-
createNettyServerRpcConnection
protected org.apache.hadoop.hbase.ipc.NettyServerRpcConnection createNettyServerRpcConnection(org.apache.hbase.thirdparty.io.netty.channel.Channel channel) - Overrides:
createNettyServerRpcConnection
in classorg.apache.hadoop.hbase.ipc.NettyRpcServer
-