@InterfaceAudience.Private class NettyServerRpcConnection extends ServerRpcConnection
Modifier and Type | Field and Description |
---|---|
(package private) org.apache.hbase.thirdparty.io.netty.channel.Channel |
channel |
addr, authenticatedWithFallback, callCleanup, codec, compressionCodec, connectionHeader, connectionHeaderRead, cryptoAES, hostAddress, provider, remotePort, retryImmediatelySupported, rpcServer, saslContextEstablished, saslProviders, saslServer, service, skipInitialSaslHandshake, ugi, useCryptoAesWrap, user, useSasl, useWrap
Constructor and Description |
---|
NettyServerRpcConnection(NettyRpcServer rpcServer,
org.apache.hbase.thirdparty.io.netty.channel.Channel channel) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
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,
CellScanner cellScanner,
long size,
InetAddress remoteAddress,
int timeout,
RpcServer.CallCleanup reqCleanup) |
protected void |
doRespond(RpcResponse resp) |
boolean |
isConnectionOpen() |
(package private) void |
process(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf buf) |
(package private) void |
process(ByteBuff buf) |
(package private) void |
process(ByteBuffer buf) |
callCleanupIfNeeded, disposeSasl, doRawSaslReply, getErrorResponse, getHostAddress, getHostInetAddress, getRemotePort, getVersionInfo, isSimpleAuthentication, processOneRpc, processPreamble, processRequest, saslReadAndProcess, toString
final org.apache.hbase.thirdparty.io.netty.channel.Channel channel
NettyServerRpcConnection(NettyRpcServer rpcServer, org.apache.hbase.thirdparty.io.netty.channel.Channel channel)
void process(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf buf) throws IOException, InterruptedException
IOException
InterruptedException
void process(ByteBuffer buf) throws IOException, InterruptedException
IOException
InterruptedException
void process(ByteBuff buf) throws IOException, InterruptedException
IOException
InterruptedException
public void close()
public boolean isConnectionOpen()
isConnectionOpen
in class ServerRpcConnection
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, CellScanner cellScanner, long size, InetAddress remoteAddress, int timeout, RpcServer.CallCleanup reqCleanup)
createCall
in class ServerRpcConnection
protected void doRespond(RpcResponse resp)
doRespond
in class ServerRpcConnection
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.