Package org.apache.hadoop.hbase.ipc
Class SimpleServerRpcConnection
java.lang.Object
org.apache.hadoop.hbase.ipc.ServerRpcConnection
org.apache.hadoop.hbase.ipc.SimpleServerRpcConnection
- All Implemented Interfaces:
Closeable
,AutoCloseable
Deprecated.
Reads calls from a connection and queues them for handling.
-
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 SocketChannel
Deprecated.private boolean
Deprecated.private ByteBuff
Deprecated.private ByteBuffer
Deprecated.private long
Deprecated.(package private) long
Deprecated.private ByteBuffer
Deprecated.(package private) final SimpleRpcServerResponder
Deprecated.(package private) final ConcurrentLinkedDeque<RpcResponse>
Deprecated.(package private) final Lock
Deprecated.private final LongAdder
Deprecated.private boolean
Deprecated.private final Socket
Deprecated.private ByteBuffer
Deprecated.private ByteBuffer
Deprecated.(package private) boolean
Deprecated.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
ConstructorDescriptionSimpleServerRpcConnection
(SimpleRpcServer rpcServer, SocketChannel channel, long lastContact) Deprecated. -
Method Summary
Modifier and TypeMethodDescriptionprotected int
channelDataRead
(ReadableByteChannel channel, ByteBuff buf) Deprecated.void
close()
Deprecated.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) Deprecated.protected void
Deprecated.protected void
doRespond
(RpcResponse resp) Deprecated.long
Deprecated.protected void
Deprecated.private void
initByteBuffToReadInto
(int length) Deprecated.boolean
Deprecated.(package private) boolean
isIdle()
Deprecated.private void
process()
Deprecated.Process the data buffer and clean the connection state for the next call.private void
processUnwrappedData
(byte[] inBuf) Deprecated.private int
Deprecated.int
Deprecated.Read off the wire.private int
Deprecated.private void
saslReadAndProcess
(ByteBuff saslToken) Deprecated.void
setLastContact
(long lastContact) Deprecated.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
Deprecated. -
data
Deprecated. -
dataLengthBuffer
Deprecated. -
preambleBuffer
Deprecated. -
rpcCount
Deprecated. -
lastContact
Deprecated. -
socket
Deprecated. -
responder
Deprecated. -
connectionPreambleRead
Deprecated. -
saslContextEstablished
Deprecated. -
unwrappedData
Deprecated. -
unwrappedDataLengthBuffer
Deprecated. -
useWrap
boolean useWrapDeprecated. -
responseQueue
Deprecated. -
responseWriteLock
Deprecated. -
lastSentTime
long lastSentTimeDeprecated.
-
-
Constructor Details
-
SimpleServerRpcConnection
public SimpleServerRpcConnection(SimpleRpcServer rpcServer, SocketChannel channel, long lastContact) Deprecated.
-
-
Method Details
-
setLastContact
Deprecated. -
getLastContact
Deprecated. -
isIdle
boolean isIdle()Deprecated. -
decRpcCount
Deprecated. -
incRpcCount
Deprecated. -
readPreamble
Deprecated.- Throws:
IOException
-
read4Bytes
Deprecated.- Throws:
IOException
-
processUnwrappedData
Deprecated.- Throws:
IOException
InterruptedException
-
saslReadAndProcess
Deprecated.- Throws:
IOException
InterruptedException
-
readAndProcess
Deprecated.Read off the wire. If there is not enough data to read, update the connection state with what we have and returns.- Returns:
- Returns -1 if failure (and caller will close connection), else zero or more.
- Throws:
IOException
InterruptedException
-
initByteBuffToReadInto
Deprecated. -
channelDataRead
Deprecated.- Throws:
IOException
-
process
Deprecated.Process the data buffer and clean the connection state for the next call.- Throws:
IOException
InterruptedException
-
close
Deprecated. -
isConnectionOpen
Deprecated.- Specified by:
isConnectionOpen
in classServerRpcConnection
-
createCall
public SimpleServerCall 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) Deprecated.- Specified by:
createCall
in classServerRpcConnection
-
doRespond
Deprecated.- Specified by:
doRespond
in classServerRpcConnection
- Throws:
IOException
-