Uses of Class
org.apache.hadoop.hbase.ipc.Call
-
Uses of Call in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescription(package private) final Call
CallEvent.call
private final Call
PreambleCallHandler.preambleCall
Modifier and TypeFieldDescriptionprivate final org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call>
Call.callback
private final ConcurrentMap<Integer,
Call> BlockingRpcConnection.calls
BlockingRpcConnection.CallSender.callsToWrite
BufferCallBeforeInitHandler.id2Call
NettyRpcDuplexHandler.id2Call
Modifier and TypeMethodDescriptionprivate 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) protected final Call
RpcConnection.createSecurityPreambleCall
(org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> callback) Modifier and TypeMethodDescription(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 void
BlockingRpcConnection.callTimeout
(Call call) protected void
NettyRpcConnection.callTimeout
(Call call) protected abstract void
RpcConnection.callTimeout
(Call call) protected final String
RpcConnection.chooseServerPrincipal
(Set<String> candidates, Call securityPreambleCall) private void
private <T extends InputStream & DataInput>
voidRpcConnection.finishCall
(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ResponseHeader responseHeader, T in, Call call) private void
BlockingRpcConnection.getConnectionRegistry
(InputStream inStream, OutputStream outStream, Call connectionRegistryCall) private void
NettyRpcConnection.getConnectionRegistry
(org.apache.hbase.thirdparty.io.netty.channel.Channel ch, Call connectionRegistryCall) 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) private void
NettyRpcConnection.onSecurityPreambleFinish
(org.apache.hbase.thirdparty.io.netty.channel.Channel ch, Set<String> serverPrincipals, Call securityPreambleCall) (package private) <T extends InputStream & DataInput>
voidRpcConnection.readResponse
(T in, Map<Integer, Call> id2Call, Call preambleCall, Consumer<org.apache.hadoop.ipc.RemoteException> fatalConnectionErrorConsumer) void
protected final void
RpcConnection.scheduleTimeoutTask
(Call call) void
void
BlockingRpcConnection.sendRequest
(Call call, HBaseRpcController pcrc) void
NettyRpcConnection.sendRequest
(Call call, HBaseRpcController hrc) abstract void
RpcConnection.sendRequest
(Call call, HBaseRpcController hrc) private void
NettyRpcConnection.sendRequest0
(Call call, HBaseRpcController hrc) (package private) static void
IPCUtil.setCancelled
(Call call) static void
PreambleCallHandler.setup
(org.apache.hbase.thirdparty.io.netty.channel.ChannelPipeline pipeline, int readTimeoutMs, NettyRpcConnection conn, byte[] preambleHeader, Call preambleCall) private void
BlockingRpcConnection.setupIOstreams
(Call connectionRegistryCall) 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) Modifier and TypeMethodDescriptionprotected final Call
RpcConnection.createSecurityPreambleCall
(org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> callback) (package private) <T extends InputStream & DataInput>
voidRpcConnection.readResponse
(T in, Map<Integer, Call> id2Call, Call preambleCall, Consumer<org.apache.hadoop.ipc.RemoteException> fatalConnectionErrorConsumer) ModifierConstructorDescription(package private)
CallEvent
(CallEvent.Type type, Call call) (package private)
PreambleCallHandler
(NettyRpcConnection conn, byte[] preambleHeader, Call preambleCall) ModifierConstructorDescription(package private)
Call
(int id, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hbase.thirdparty.com.google.protobuf.Message param, ExtendedCellScanner cells, org.apache.hbase.thirdparty.com.google.protobuf.Message responseDefaultType, int timeout, int priority, Map<String, byte[]> attributes, org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> callback, MetricsConnection.CallStats callStats)