public interface BlockingRpcChannel
BlockingRpcChannel
is the blocking
equivalent to RpcChannel
.Modifier and Type | Method and Description |
---|---|
Message |
callBlockingMethod(Descriptors.MethodDescriptor method,
RpcController controller,
Message request,
Message responsePrototype)
Call the given method of the remote service and blocks until it returns.
|
Message callBlockingMethod(Descriptors.MethodDescriptor method, RpcController controller, Message request, Message responsePrototype) throws ServiceException
callBlockingMethod()
is the blocking equivalent to RpcChannel.callMethod(org.apache.flink.statefun.sdk.shaded.com.google.protobuf.Descriptors.MethodDescriptor, org.apache.flink.statefun.sdk.shaded.com.google.protobuf.RpcController, org.apache.flink.statefun.sdk.shaded.com.google.protobuf.Message, org.apache.flink.statefun.sdk.shaded.com.google.protobuf.Message, org.apache.flink.statefun.sdk.shaded.com.google.protobuf.RpcCallback<org.apache.flink.statefun.sdk.shaded.com.google.protobuf.Message>)
.ServiceException
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.