(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,
InetSocketAddress 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) |
(package private) static void |
IPCUtil.setCancelled(Call call) |
private void |
BlockingRpcConnection.tracedWriteRequest(Call call) |
private void |
NettyRpcConnection.write(org.apache.hbase.thirdparty.io.netty.channel.Channel ch,
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) |