Package | Description |
---|---|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
Modifier and Type | Field and Description |
---|---|
private Set<SimpleServerRpcConnection> |
SimpleRpcServer.ConnectionManager.connections |
private LinkedBlockingQueue<SimpleServerRpcConnection> |
SimpleRpcServer.Listener.Reader.pendingConnections |
private Set<SimpleServerRpcConnection> |
SimpleRpcServerResponder.writingCons |
Modifier and Type | Method and Description |
---|---|
(package private) SimpleServerRpcConnection |
SimpleServerCall.getConnection() |
protected SimpleServerRpcConnection |
SimpleRpcServer.getConnection(SocketChannel channel,
long time)
Subclasses of HBaseServer can override this to provide their own
Connection implementations.
|
(package private) SimpleServerRpcConnection |
SimpleRpcServer.ConnectionManager.register(SocketChannel channel) |
(package private) SimpleServerRpcConnection[] |
SimpleRpcServer.ConnectionManager.toArray() |
Modifier and Type | Method and Description |
---|---|
private boolean |
SimpleRpcServer.ConnectionManager.add(SimpleServerRpcConnection connection) |
void |
SimpleRpcServer.Listener.Reader.addConnection(SimpleServerRpcConnection conn)
Updating the readSelector while it's being used is not thread-safe,
so the connection must be queued.
|
(package private) boolean |
SimpleRpcServer.ConnectionManager.close(SimpleServerRpcConnection connection) |
protected void |
SimpleRpcServer.closeConnection(SimpleServerRpcConnection connection) |
(package private) void |
SimpleRpcServerResponder.doRespond(SimpleServerRpcConnection conn,
RpcResponse resp) |
private boolean |
SimpleRpcServerResponder.processAllResponses(SimpleServerRpcConnection connection)
Process all the responses for this connection
|
private boolean |
SimpleRpcServerResponder.processResponse(SimpleServerRpcConnection conn,
RpcResponse resp)
Process the response for this call.
|
void |
SimpleRpcServerResponder.registerForWrite(SimpleServerRpcConnection c)
Add a connection to the list that want to write,
|
private boolean |
SimpleRpcServer.ConnectionManager.remove(SimpleServerRpcConnection connection) |
Constructor and Description |
---|
SimpleServerCall(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,
CellScanner cellScanner,
SimpleServerRpcConnection connection,
long size,
InetAddress remoteAddress,
long receiveTime,
int timeout,
ByteBufferPool reservoir,
CellBlockBuilder cellBlockBuilder,
RpcServer.CallCleanup reqCleanup,
SimpleRpcServerResponder responder) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.