final class TestBlockingIPC.TestFailingRpcServer.FailingConnection extends Object
Modifier and Type | Field and Description |
---|---|
protected InetAddress |
addr |
protected boolean |
authenticatedWithFallback |
protected org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup |
callCleanup |
(package private) SocketChannel |
channel
Deprecated.
|
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 |
(package private) long |
lastSentTime
Deprecated.
|
protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider |
provider |
protected int |
remotePort |
(package private) org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder |
responder
Deprecated.
|
(package private) ConcurrentLinkedDeque<org.apache.hadoop.hbase.ipc.RpcResponse> |
responseQueue
Deprecated.
|
(package private) Lock |
responseWriteLock
Deprecated.
|
protected boolean |
retryImmediatelySupported |
protected org.apache.hadoop.hbase.ipc.RpcServer |
rpcServer |
protected boolean |
saslContextEstablished |
protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders |
saslProviders |
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(TestBlockingIPC.TestFailingRpcServer rpcServer,
SocketChannel channel,
long lastContact) |
Modifier and Type | Method and Description |
---|---|
protected void |
callCleanupIfNeeded() |
protected int |
channelDataRead(ReadableByteChannel arg0,
org.apache.hadoop.hbase.nio.ByteBuff arg1)
Deprecated.
|
void |
close()
Deprecated.
|
org.apache.hadoop.hbase.ipc.SimpleServerCall |
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)
Deprecated.
|
protected void |
decRpcCount()
Deprecated.
|
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)
Deprecated.
|
protected org.apache.hadoop.hbase.ipc.RpcResponse |
getErrorResponse(String arg0,
Exception arg1) |
String |
getHostAddress() |
InetAddress |
getHostInetAddress() |
long |
getLastContact()
Deprecated.
|
int |
getRemotePort() |
org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo |
getVersionInfo() |
protected void |
incRpcCount()
Deprecated.
|
boolean |
isConnectionOpen()
Deprecated.
|
(package private) boolean |
isIdle()
Deprecated.
|
(package private) boolean |
isSimpleAuthentication() |
void |
processOneRpc(org.apache.hadoop.hbase.nio.ByteBuff arg0) |
protected boolean |
processPreamble(ByteBuffer arg0) |
void |
processRequest(org.apache.hadoop.hbase.nio.ByteBuff buf) |
int |
readAndProcess()
Deprecated.
|
void |
saslReadAndProcess(org.apache.hadoop.hbase.nio.ByteBuff arg0) |
void |
setLastContact(long arg0)
Deprecated.
|
String |
toString() |
final SocketChannel channel
final org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder responder
final ConcurrentLinkedDeque<org.apache.hadoop.hbase.ipc.RpcResponse> responseQueue
final Lock responseWriteLock
long lastSentTime
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.provider.SaslServerAuthenticationProvider provider
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
protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders saslProviders
private FailingConnection(TestBlockingIPC.TestFailingRpcServer rpcServer, SocketChannel channel, long lastContact)
public void processRequest(org.apache.hadoop.hbase.nio.ByteBuff buf) throws IOException, InterruptedException
IOException
InterruptedException
public void setLastContact(long arg0)
public long getLastContact()
boolean isIdle()
protected void decRpcCount()
protected void incRpcCount()
public int readAndProcess() throws IOException, InterruptedException
IOException
InterruptedException
protected int channelDataRead(ReadableByteChannel arg0, org.apache.hadoop.hbase.nio.ByteBuff arg1) throws IOException
IOException
public void close()
public boolean isConnectionOpen()
public org.apache.hadoop.hbase.ipc.SimpleServerCall 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) throws IOException
IOException
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
IOException
public void saslReadAndProcess(org.apache.hadoop.hbase.nio.ByteBuff arg0) throws IOException, InterruptedException
IOException
InterruptedException
public void processOneRpc(org.apache.hadoop.hbase.nio.ByteBuff arg0) throws IOException, InterruptedException
IOException
InterruptedException
protected final org.apache.hadoop.hbase.ipc.RpcResponse getErrorResponse(String arg0, Exception arg1) throws IOException
IOException
protected final void callCleanupIfNeeded()
protected final boolean processPreamble(ByteBuffer arg0) throws IOException
IOException
boolean isSimpleAuthentication()
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.