Uses of Class
org.apache.hadoop.hbase.ipc.Call
Packages that use Call
-
Uses of Call in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as CallModifier and TypeFieldDescription(package private) final CallCallEvent.callprivate final CallPreambleCallHandler.preambleCallFields in org.apache.hadoop.hbase.ipc with type parameters of type CallModifier and TypeFieldDescriptionprivate final org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call>Call.callbackprivate final ConcurrentMap<Integer,Call> BlockingRpcConnection.callsBlockingRpcConnection.CallSender.callsToWriteBufferCallBeforeInitHandler.id2CallNettyRpcDuplexHandler.id2CallMethods in org.apache.hadoop.hbase.ipc that return CallModifier and TypeMethodDescriptionprivate CallAbstractRpcClient.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 CallRpcConnection.createSecurityPreambleCall(org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<Call> callback) Methods in org.apache.hadoop.hbase.ipc with parameters of type CallModifier and TypeMethodDescription(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeaderIPCUtil.buildRequestHeader(Call call, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.CellBlockMeta cellBlockMeta) protected voidBlockingRpcConnection.callTimeout(Call call) protected voidNettyRpcConnection.callTimeout(Call call) protected abstract voidRpcConnection.callTimeout(Call call) protected final StringRpcConnection.chooseServerPrincipal(Set<String> candidates, Call securityPreambleCall) private voidprivate <T extends InputStream & DataInput>
voidRpcConnection.finishCall(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ResponseHeader responseHeader, T in, Call call) private voidBlockingRpcConnection.getConnectionRegistry(InputStream inStream, OutputStream outStream, Call connectionRegistryCall) private voidNettyRpcConnection.getConnectionRegistry(org.apache.hbase.thirdparty.io.netty.channel.Channel ch, Call connectionRegistryCall) private voidAbstractRpcClient.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 voidNettyRpcConnection.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) voidprotected final voidRpcConnection.scheduleTimeoutTask(Call call) voidvoidBlockingRpcConnection.sendRequest(Call call, HBaseRpcController pcrc) voidNettyRpcConnection.sendRequest(Call call, HBaseRpcController hrc) abstract voidRpcConnection.sendRequest(Call call, HBaseRpcController hrc) private voidNettyRpcConnection.sendRequest0(Call call, HBaseRpcController hrc) (package private) static voidIPCUtil.setCancelled(Call call) static voidPreambleCallHandler.setup(org.apache.hbase.thirdparty.io.netty.channel.ChannelPipeline pipeline, int readTimeoutMs, NettyRpcConnection conn, byte[] preambleHeader, Call preambleCall) private voidBlockingRpcConnection.setupIOstreams(Call connectionRegistryCall) private voidBlockingRpcConnection.writeRequest(Call call) Initiates a call by sending the parameter to the remote server.private voidNettyRpcDuplexHandler.writeRequest(org.apache.hbase.thirdparty.io.netty.channel.ChannelHandlerContext ctx, Call call, org.apache.hbase.thirdparty.io.netty.channel.ChannelPromise promise) Method parameters in org.apache.hadoop.hbase.ipc with type arguments of type CallModifier and TypeMethodDescriptionprotected final CallRpcConnection.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) Constructors in org.apache.hadoop.hbase.ipc with parameters of type CallModifierConstructorDescription(package private)CallEvent(CallEvent.Type type, Call call) (package private)PreambleCallHandler(NettyRpcConnection conn, byte[] preambleHeader, Call preambleCall) Constructor parameters in org.apache.hadoop.hbase.ipc with type arguments of type CallModifierConstructorDescription(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)