Package | Description |
---|---|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
Modifier and Type | Field and Description |
---|---|
(package private) Call |
CallEvent.call |
Modifier and Type | Field and Description |
---|---|
private org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> |
Call.callback |
private ConcurrentMap<Integer,Call> |
BlockingRpcConnection.calls |
private Queue<Call> |
BlockingRpcConnection.CallSender.callsToWrite |
private Map<Integer,Call> |
NettyRpcDuplexHandler.id2Call |
private Map<Integer,Call> |
BufferCallBeforeInitHandler.id2Call |
Modifier and Type | Method and Description |
---|---|
private Call |
AbstractRpcClient.callMethod(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
HBaseRpcController hrc,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
org.apache.hbase.thirdparty.com.google.protobuf.Message returnType,
User ticket,
Address addr,
org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<org.apache.hbase.thirdparty.com.google.protobuf.Message> callback) |
Modifier and Type | Method and Description |
---|---|
(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader |
IPCUtil.buildRequestHeader(Call call,
org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.CellBlockMeta cellBlockMeta) |
protected abstract void |
RpcConnection.callTimeout(Call call) |
protected void |
BlockingRpcConnection.callTimeout(Call call) |
protected void |
NettyRpcConnection.callTimeout(Call call) |
private void |
AbstractRpcClient.onCallFinished(Call call,
HBaseRpcController hrc,
Address addr,
org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<org.apache.hbase.thirdparty.com.google.protobuf.Message> callback) |
void |
BlockingRpcConnection.CallSender.remove(Call call) |
protected void |
RpcConnection.scheduleTimeoutTask(Call call) |
void |
BlockingRpcConnection.CallSender.sendCall(Call call) |
abstract void |
RpcConnection.sendRequest(Call call,
HBaseRpcController hrc) |
void |
BlockingRpcConnection.sendRequest(Call call,
HBaseRpcController pcrc) |
void |
NettyRpcConnection.sendRequest(Call call,
HBaseRpcController hrc) |
private void |
NettyRpcConnection.sendRequest0(Call call,
HBaseRpcController hrc) |
(package private) static void |
IPCUtil.setCancelled(Call call) |
private void |
BlockingRpcConnection.writeRequest(Call call)
Initiates a call by sending the parameter to the remote server.
|
private void |
NettyRpcDuplexHandler.writeRequest(org.apache.hbase.thirdparty.io.netty.channel.ChannelHandlerContext ctx,
Call call,
org.apache.hbase.thirdparty.io.netty.channel.ChannelPromise promise) |
Constructor and Description |
---|
CallEvent(CallEvent.Type type,
Call call) |
Constructor and Description |
---|
Call(int id,
org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md,
org.apache.hbase.thirdparty.com.google.protobuf.Message param,
CellScanner cells,
org.apache.hbase.thirdparty.com.google.protobuf.Message responseDefaultType,
int timeout,
int priority,
org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> callback,
MetricsConnection.CallStats callStats) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.