Package org.apache.hadoop.hbase.ipc
Class FailingNettyRpcServer.FailingConnection
java.lang.Object
org.apache.hadoop.hbase.ipc.FailingNettyRpcServer.FailingConnection
- All Implemented Interfaces:
Closeable
,AutoCloseable
- Enclosing class:
- FailingNettyRpcServer
-
Nested Class Summary
Modifier and TypeClassDescriptionprotected static enum
org.apache.hadoop.hbase.ipc.ServerRpcConnection.PreambleResponse
-
Field Summary
Modifier and TypeFieldDescriptionprotected InetAddress
protected boolean
protected org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup
(package private) final org.apache.hbase.thirdparty.io.netty.channel.Channel
protected X509Certificate[]
protected org.apache.hadoop.hbase.codec.Codec
protected org.apache.hadoop.io.compress.CompressionCodec
protected org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ConnectionHeader
protected boolean
protected String
protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider
protected int
protected boolean
protected final org.apache.hadoop.hbase.ipc.RpcServer
protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
protected org.apache.hadoop.hbase.security.HBaseSaslRpcServer
protected org.apache.hbase.thirdparty.com.google.protobuf.BlockingService
protected boolean
protected org.apache.hadoop.security.UserGroupInformation
protected org.apache.hadoop.hbase.security.User
protected boolean
-
Constructor Summary
ModifierConstructorDescriptionprivate
FailingConnection
(FailingNettyRpcServer rpcServer, org.apache.hbase.thirdparty.io.netty.channel.Channel channel) -
Method Summary
Modifier and TypeMethodDescriptionprotected final void
void
close()
org.apache.hadoop.hbase.ipc.NettyServerCall
createCall
(int arg0, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService arg1, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor arg2, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader arg3, org.apache.hbase.thirdparty.com.google.protobuf.Message arg4, org.apache.hadoop.hbase.ExtendedCellScanner arg5, long arg6, InetAddress arg7, int arg8, org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup arg9) protected final void
protected final void
doRawSaslReply
(org.apache.hadoop.hbase.security.SaslStatus arg0, org.apache.hadoop.io.Writable arg1, String arg2, String arg3) protected void
doRespond
(org.apache.hadoop.hbase.ipc.RpcResponse arg0) (package private) void
protected final org.apache.hadoop.hbase.ipc.RpcResponse
getErrorResponse
(String arg0, Exception arg1) (package private) org.apache.hadoop.hbase.security.HBaseSaslRpcServer
int
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo
boolean
(package private) boolean
(package private) void
process
(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf arg0) void
processOneRpc
(org.apache.hadoop.hbase.nio.ByteBuff arg0) protected final org.apache.hadoop.hbase.ipc.ServerRpcConnection.PreambleResponse
processPreamble
(ByteBuffer arg0) void
processRequest
(org.apache.hadoop.hbase.nio.ByteBuff buf) (package private) void
toString()
-
Field Details
-
channel
final org.apache.hbase.thirdparty.io.netty.channel.Channel channel -
rpcServer
protected final org.apache.hadoop.hbase.ipc.RpcServer rpcServer -
connectionHeaderRead
protected boolean connectionHeaderRead -
callCleanup
protected org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup callCleanup -
hostAddress
-
remotePort
protected int remotePort -
addr
-
connectionHeader
protected org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ConnectionHeader connectionHeader -
connectionAttributes
-
codec
protected org.apache.hadoop.hbase.codec.Codec codec -
compressionCodec
protected org.apache.hadoop.io.compress.CompressionCodec compressionCodec -
service
protected org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service -
provider
protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider provider -
skipInitialSaslHandshake
protected boolean skipInitialSaslHandshake -
useSasl
protected boolean useSasl -
saslServer
protected org.apache.hadoop.hbase.security.HBaseSaslRpcServer saslServer -
authenticatedWithFallback
protected boolean authenticatedWithFallback -
retryImmediatelySupported
protected boolean retryImmediatelySupported -
user
protected org.apache.hadoop.hbase.security.User user -
ugi
protected org.apache.hadoop.security.UserGroupInformation ugi -
saslProviders
protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders saslProviders -
clientCertificateChain
-
-
Constructor Details
-
FailingConnection
private FailingConnection(FailingNettyRpcServer rpcServer, org.apache.hbase.thirdparty.io.netty.channel.Channel channel)
-
-
Method Details
-
processRequest
public void processRequest(org.apache.hadoop.hbase.nio.ByteBuff buf) throws IOException, InterruptedException - Throws:
IOException
InterruptedException
-
setupHandler
void setupHandler() -
process
void process(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf arg0) throws IOException, InterruptedException - Throws:
IOException
InterruptedException
-
close
public void close() -
isConnectionOpen
public boolean isConnectionOpen() -
createCall
public org.apache.hadoop.hbase.ipc.NettyServerCall createCall(int arg0, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService arg1, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor arg2, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader arg3, org.apache.hbase.thirdparty.com.google.protobuf.Message arg4, org.apache.hadoop.hbase.ExtendedCellScanner arg5, long arg6, InetAddress arg7, int arg8, org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup arg9) -
doRespond
protected void doRespond(org.apache.hadoop.hbase.ipc.RpcResponse arg0) -
toString
-
getHostAddress
-
getHostInetAddress
-
getRemotePort
public int getRemotePort() -
getVersionInfo
public org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo getVersionInfo() -
disposeSasl
protected final void disposeSasl() -
doRawSaslReply
protected final void doRawSaslReply(org.apache.hadoop.hbase.security.SaslStatus arg0, org.apache.hadoop.io.Writable arg1, String arg2, String arg3) throws IOException - Throws:
IOException
-
getOrCreateSaslServer
- Throws:
IOException
-
finishSaslNegotiation
- Throws:
IOException
-
processOneRpc
public void processOneRpc(org.apache.hadoop.hbase.nio.ByteBuff arg0) throws IOException, InterruptedException - Throws:
IOException
InterruptedException
-
getErrorResponse
protected final org.apache.hadoop.hbase.ipc.RpcResponse getErrorResponse(String arg0, Exception arg1) throws IOException - Throws:
IOException
-
callCleanupIfNeeded
protected final void callCleanupIfNeeded() -
processPreamble
protected final org.apache.hadoop.hbase.ipc.ServerRpcConnection.PreambleResponse processPreamble(ByteBuffer arg0) throws IOException - Throws:
IOException
-
isSimpleAuthentication
boolean isSimpleAuthentication()
-