Package org.apache.flink.runtime.rpc
Interface RpcServer
-
- All Superinterfaces:
MainThreadExecutable
,RpcGateway
,StartStoppable
- All Known Implementing Classes:
FencedPekkoInvocationHandler
public interface RpcServer extends StartStoppable, MainThreadExecutable, RpcGateway
Interface for self gateways.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description CompletableFuture<Void>
getTerminationFuture()
Return a future which is completed when the rpc endpoint has been terminated.-
Methods inherited from interface org.apache.flink.runtime.rpc.MainThreadExecutable
callAsync, runAsync, scheduleRunAsync
-
Methods inherited from interface org.apache.flink.runtime.rpc.RpcGateway
getAddress, getHostname
-
Methods inherited from interface org.apache.flink.runtime.rpc.StartStoppable
start, stop
-
-
-
-
Method Detail
-
getTerminationFuture
CompletableFuture<Void> getTerminationFuture()
Return a future which is completed when the rpc endpoint has been terminated.- Returns:
- Future indicating when the rpc endpoint has been terminated
-
-