static final class TestNettyIPC.TestFailingRpcServer.FailingConnection extends Object
| Modifier and Type | Field and Description | 
|---|---|
protected InetAddress | 
addr  | 
protected boolean | 
authenticatedWithFallback  | 
protected org.apache.hadoop.hbase.security.AuthMethod | 
authMethod  | 
protected org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup | 
callCleanup  | 
(package private) org.apache.hbase.thirdparty.io.netty.channel.Channel | 
channel  | 
protected org.apache.hadoop.hbase.codec.Codec | 
codec  | 
protected org.apache.hadoop.io.compress.CompressionCodec | 
compressionCodec  | 
protected org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ConnectionHeader | 
connectionHeader  | 
protected boolean | 
connectionHeaderRead  | 
protected org.apache.hadoop.hbase.io.crypto.aes.CryptoAES | 
cryptoAES  | 
protected String | 
hostAddress  | 
protected int | 
remotePort  | 
protected boolean | 
retryImmediatelySupported  | 
protected org.apache.hadoop.hbase.ipc.RpcServer | 
rpcServer  | 
protected boolean | 
saslContextEstablished  | 
protected org.apache.hadoop.hbase.security.HBaseSaslRpcServer | 
saslServer  | 
protected org.apache.hbase.thirdparty.com.google.protobuf.BlockingService | 
service  | 
protected boolean | 
skipInitialSaslHandshake  | 
protected org.apache.hadoop.security.UserGroupInformation | 
ugi  | 
protected boolean | 
useCryptoAesWrap  | 
protected org.apache.hadoop.hbase.security.User | 
user  | 
protected boolean | 
useSasl  | 
protected boolean | 
useWrap  | 
| Modifier | Constructor and Description | 
|---|---|
private  | 
FailingConnection(TestNettyIPC.TestFailingRpcServer rpcServer,
                 org.apache.hbase.thirdparty.io.netty.channel.Channel channel)  | 
| Modifier and Type | Method and Description | 
|---|---|
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.CellScanner arg5,
          long arg6,
          InetAddress arg7,
          int arg8,
          org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup arg9)  | 
protected void | 
disposeSasl()  | 
protected 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)  | 
protected org.apache.hadoop.hbase.ipc.RpcResponse | 
getErrorResponse(String arg0,
                Exception arg1)  | 
String | 
getHostAddress()  | 
InetAddress | 
getHostInetAddress()  | 
int | 
getRemotePort()  | 
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo | 
getVersionInfo()  | 
boolean | 
isConnectionOpen()  | 
(package private) void | 
process(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf arg0)  | 
(package private) void | 
process(org.apache.hadoop.hbase.nio.ByteBuff arg0)  | 
(package private) void | 
process(ByteBuffer arg0)  | 
void | 
processOneRpc(org.apache.hadoop.hbase.nio.ByteBuff arg0)  | 
protected boolean | 
processPreamble(ByteBuffer arg0)  | 
void | 
processRequest(org.apache.hadoop.hbase.nio.ByteBuff buf)  | 
void | 
saslReadAndProcess(org.apache.hadoop.hbase.nio.ByteBuff arg0)  | 
String | 
toString()  | 
final org.apache.hbase.thirdparty.io.netty.channel.Channel channel
protected final org.apache.hadoop.hbase.ipc.RpcServer rpcServer
protected boolean connectionHeaderRead
protected org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup callCleanup
protected String hostAddress
protected int remotePort
protected InetAddress addr
protected org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ConnectionHeader connectionHeader
protected org.apache.hadoop.hbase.codec.Codec codec
protected org.apache.hadoop.io.compress.CompressionCodec compressionCodec
protected org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service
protected org.apache.hadoop.hbase.security.AuthMethod authMethod
protected boolean saslContextEstablished
protected boolean skipInitialSaslHandshake
protected boolean useSasl
protected org.apache.hadoop.hbase.security.HBaseSaslRpcServer saslServer
protected org.apache.hadoop.hbase.io.crypto.aes.CryptoAES cryptoAES
protected boolean useWrap
protected boolean useCryptoAesWrap
protected boolean authenticatedWithFallback
protected boolean retryImmediatelySupported
protected org.apache.hadoop.hbase.security.User user
protected org.apache.hadoop.security.UserGroupInformation ugi
private FailingConnection(TestNettyIPC.TestFailingRpcServer rpcServer, org.apache.hbase.thirdparty.io.netty.channel.Channel channel)
public void processRequest(org.apache.hadoop.hbase.nio.ByteBuff buf) throws IOException, InterruptedException
IOExceptionInterruptedExceptionvoid process(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf arg0) throws IOException, InterruptedException
IOExceptionInterruptedExceptionvoid process(ByteBuffer arg0) throws IOException, InterruptedException
IOExceptionInterruptedExceptionvoid process(org.apache.hadoop.hbase.nio.ByteBuff arg0) throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void close()
public boolean isConnectionOpen()
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.CellScanner arg5, long arg6, InetAddress arg7, int arg8, org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup arg9)
protected void doRespond(org.apache.hadoop.hbase.ipc.RpcResponse arg0)
public String getHostAddress()
public InetAddress getHostInetAddress()
public int getRemotePort()
public org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo getVersionInfo()
protected final void disposeSasl()
protected final void doRawSaslReply(org.apache.hadoop.hbase.security.SaslStatus arg0, org.apache.hadoop.io.Writable arg1, String arg2, String arg3) throws IOException
IOExceptionpublic void saslReadAndProcess(org.apache.hadoop.hbase.nio.ByteBuff arg0) throws IOException, InterruptedException
IOExceptionInterruptedExceptionpublic void processOneRpc(org.apache.hadoop.hbase.nio.ByteBuff arg0) throws IOException, InterruptedException
IOExceptionInterruptedExceptionprotected final org.apache.hadoop.hbase.ipc.RpcResponse getErrorResponse(String arg0, Exception arg1) throws IOException
IOExceptionprotected final boolean processPreamble(ByteBuffer arg0) throws IOException
IOExceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.