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 SummaryNested classes/interfaces inherited from class org.apache.hadoop.hbase.ipc.ServerRpcConnectionServerRpcConnection.PreambleResponse
- 
Field SummaryFieldsModifier 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.ServerRpcConnectionaddr, authenticatedWithFallback, callCleanup, clientCertificateChain, codec, compressionCodec, connectionAttributes, connectionHeader, connectionHeaderRead, hostAddress, provider, remotePort, retryImmediatelySupported, rpcServer, saslProviders, saslServer, service, skipInitialSaslHandshake, ugi, user, useSasl
- 
Constructor SummaryConstructorsConstructorDescriptionSimpleServerRpcConnection(SimpleRpcServer rpcServer, SocketChannel channel, long lastContact) Deprecated.
- 
Method SummaryModifier 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.ServerRpcConnectioncallCleanupIfNeeded, disposeSasl, doRawSaslReply, finishSaslNegotiation, getErrorResponse, getHostAddress, getHostInetAddress, getOrCreateSaslServer, getRemotePort, getVersionInfo, isSimpleAuthentication, processOneRpc, processPreamble, processRequest, toString
- 
Field Details- 
channelDeprecated.
- 
dataDeprecated.
- 
dataLengthBufferDeprecated.
- 
preambleBufferDeprecated.
- 
rpcCountDeprecated.
- 
lastContactDeprecated.
- 
socketDeprecated.
- 
responderDeprecated.
- 
connectionPreambleReadDeprecated.
- 
saslContextEstablishedDeprecated.
- 
unwrappedDataDeprecated.
- 
unwrappedDataLengthBufferDeprecated.
- 
useWrapboolean useWrapDeprecated.
- 
responseQueueDeprecated.
- 
responseWriteLockDeprecated.
- 
lastSentTimelong lastSentTimeDeprecated.
 
- 
- 
Constructor Details- 
SimpleServerRpcConnectionpublic SimpleServerRpcConnection(SimpleRpcServer rpcServer, SocketChannel channel, long lastContact) Deprecated.
 
- 
- 
Method Details- 
setLastContactDeprecated.
- 
getLastContactDeprecated.
- 
isIdleboolean isIdle()Deprecated.
- 
decRpcCountDeprecated.
- 
incRpcCountDeprecated.
- 
readPreambleDeprecated.- Throws:
- IOException
 
- 
read4BytesDeprecated.- Throws:
- IOException
 
- 
processUnwrappedDataDeprecated.- Throws:
- IOException
- InterruptedException
 
- 
saslReadAndProcessDeprecated.- Throws:
- IOException
- InterruptedException
 
- 
readAndProcessDeprecated.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
 
- 
initByteBuffToReadIntoDeprecated.
- 
channelDataReadDeprecated.- Throws:
- IOException
 
- 
processDeprecated.Process the data buffer and clean the connection state for the next call.- Throws:
- IOException
- InterruptedException
 
- 
closeDeprecated.
- 
isConnectionOpenDeprecated.- Specified by:
- isConnectionOpenin class- ServerRpcConnection
 
- 
createCallpublic 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 class- ServerRpcConnection
 
- 
doRespondDeprecated.- Specified by:
- doRespondin class- ServerRpcConnection
- Throws:
- IOException
 
 
-