Package org.apache.hadoop.hbase.ipc
Class NettyServerRpcConnection
java.lang.Object
org.apache.hadoop.hbase.ipc.ServerRpcConnection
org.apache.hadoop.hbase.ipc.NettyServerRpcConnection
- All Implemented Interfaces:
Closeable
,AutoCloseable
RpcConnection implementation for netty rpc server.
- Since:
- 2.0.0
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.ipc.ServerRpcConnection
ServerRpcConnection.PreambleResponse
-
Field Summary
Modifier and TypeFieldDescription(package private) final org.apache.hbase.thirdparty.io.netty.channel.Channel
Fields inherited from class org.apache.hadoop.hbase.ipc.ServerRpcConnection
addr, authenticatedWithFallback, callCleanup, clientCertificateChain, codec, compressionCodec, connectionAttributes, connectionHeader, connectionHeaderRead, hostAddress, provider, remotePort, retryImmediatelySupported, rpcServer, saslProviders, saslServer, service, skipInitialSaslHandshake, ugi, user, useSasl
-
Constructor Summary
ConstructorDescriptionNettyServerRpcConnection
(NettyRpcServer rpcServer, org.apache.hbase.thirdparty.io.netty.channel.Channel channel) -
Method Summary
Modifier and TypeMethodDescriptionvoid
close()
createCall
(int id, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, ExtendedCellScanner cellScanner, long size, InetAddress remoteAddress, int timeout, RpcServer.CallCleanup reqCleanup) protected void
doRespond
(RpcResponse resp) boolean
(package private) void
process
(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf buf) (package private) void
Methods inherited from class org.apache.hadoop.hbase.ipc.ServerRpcConnection
callCleanupIfNeeded, disposeSasl, doRawSaslReply, finishSaslNegotiation, getErrorResponse, getHostAddress, getHostInetAddress, getOrCreateSaslServer, getRemotePort, getVersionInfo, isSimpleAuthentication, processOneRpc, processPreamble, processRequest, toString
-
Field Details
-
channel
-
-
Constructor Details
-
NettyServerRpcConnection
NettyServerRpcConnection(NettyRpcServer rpcServer, org.apache.hbase.thirdparty.io.netty.channel.Channel channel)
-
-
Method Details
-
setupHandler
void setupHandler() -
process
void process(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf buf) throws IOException, InterruptedException - Throws:
IOException
InterruptedException
-
close
-
isConnectionOpen
- Specified by:
isConnectionOpen
in classServerRpcConnection
-
createCall
public NettyServerCall createCall(int id, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, ExtendedCellScanner cellScanner, long size, InetAddress remoteAddress, int timeout, RpcServer.CallCleanup reqCleanup) - Specified by:
createCall
in classServerRpcConnection
-
doRespond
- Specified by:
doRespond
in classServerRpcConnection
-