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
FieldsModifier and TypeFieldDescription(package private) final SocketChannelDeprecated.private booleanDeprecated.private ByteBuffDeprecated.private ByteBufferDeprecated.private longDeprecated.(package private) longDeprecated.private ByteBufferDeprecated.(package private) final SimpleRpcServerResponderDeprecated.(package private) final ConcurrentLinkedDeque<RpcResponse>Deprecated.(package private) final LockDeprecated.private final LongAdderDeprecated.private booleanDeprecated.private final SocketDeprecated.private ByteBufferDeprecated.private ByteBufferDeprecated.(package private) booleanDeprecated.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
ConstructorsConstructorDescriptionSimpleServerRpcConnection(SimpleRpcServer rpcServer, SocketChannel channel, long lastContact) Deprecated. -
Method Summary
Modifier and TypeMethodDescriptionprotected intchannelDataRead(ReadableByteChannel channel, ByteBuff buf) Deprecated.voidclose()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 voidDeprecated.protected voiddoRespond(RpcResponse resp) Deprecated.longDeprecated.protected voidDeprecated.private voidinitByteBuffToReadInto(int length) Deprecated.booleanDeprecated.(package private) booleanisIdle()Deprecated.private voidprocess()Deprecated.Process the data buffer and clean the connection state for the next call.private voidprocessUnwrappedData(byte[] inBuf) Deprecated.private intDeprecated.intDeprecated.Read off the wire.private intDeprecated.private voidsaslReadAndProcess(ByteBuff saslToken) Deprecated.voidsetLastContact(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:
IOExceptionInterruptedException
-
saslReadAndProcess
Deprecated.- Throws:
IOExceptionInterruptedException
-
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:
IOExceptionInterruptedException
-
initByteBuffToReadInto
Deprecated. -
channelDataRead
Deprecated.- Throws:
IOException
-
process
Deprecated.Process the data buffer and clean the connection state for the next call.- Throws:
IOExceptionInterruptedException
-
close
Deprecated. -
isConnectionOpen
Deprecated.- Specified by:
isConnectionOpenin 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:
createCallin classServerRpcConnection
-
doRespond
Deprecated.- Specified by:
doRespondin classServerRpcConnection- Throws:
IOException
-