Package org.apache.flink.runtime.rpc
Class FencedRpcEndpoint<F extends Serializable>
- java.lang.Object
-
- org.apache.flink.runtime.rpc.RpcEndpoint
-
- org.apache.flink.runtime.rpc.FencedRpcEndpoint<F>
-
- Type Parameters:
F
- type of the fencing token
- All Implemented Interfaces:
AutoCloseable
,RpcGateway
,AutoCloseableAsync
- Direct Known Subclasses:
Dispatcher
,JobMaster
,ResourceManager
public abstract class FencedRpcEndpoint<F extends Serializable> extends RpcEndpoint
Base class for fencedRpcEndpoint
. A fenced rpc endpoint expects all rpc messages being enriched with fencing tokens. Furthermore, the rpc endpoint has its own fencing token assigned. The rpc is then only executed if the attached fencing token equals the endpoint's own token.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.runtime.rpc.RpcEndpoint
RpcEndpoint.MainThreadExecutor
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.rpc.RpcEndpoint
log, rpcServer
-
-
Constructor Summary
Constructors Modifier Constructor Description protected
FencedRpcEndpoint(RpcService rpcService, F fencingToken)
protected
FencedRpcEndpoint(RpcService rpcService, String endpointId, F fencingToken)
protected
FencedRpcEndpoint(RpcService rpcService, String endpointId, F fencingToken, Map<String,String> loggingContext)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description F
getFencingToken()
-
Methods inherited from class org.apache.flink.runtime.rpc.RpcEndpoint
callAsync, closeAsync, getAddress, getEndpointId, getHostname, getMainThreadExecutor, getMainThreadExecutor, getRpcService, getSelfGateway, getTerminationFuture, internalCallOnStart, internalCallOnStop, isRunning, onStart, onStop, registerResource, runAsync, scheduleRunAsync, scheduleRunAsync, start, stop, unregisterResource, validateRunsInMainThread
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.util.AutoCloseableAsync
close
-
-
-
-
Constructor Detail
-
FencedRpcEndpoint
protected FencedRpcEndpoint(RpcService rpcService, String endpointId, F fencingToken, Map<String,String> loggingContext)
-
FencedRpcEndpoint
protected FencedRpcEndpoint(RpcService rpcService, String endpointId, F fencingToken)
-
FencedRpcEndpoint
protected FencedRpcEndpoint(RpcService rpcService, F fencingToken)
-
-
Method Detail
-
getFencingToken
public F getFencingToken()
-
-