Class StandaloneDispatcher
- java.lang.Object
-
- org.apache.flink.runtime.rpc.RpcEndpoint
-
- org.apache.flink.runtime.rpc.FencedRpcEndpoint<DispatcherId>
-
- org.apache.flink.runtime.dispatcher.Dispatcher
-
- org.apache.flink.runtime.dispatcher.StandaloneDispatcher
-
- All Implemented Interfaces:
AutoCloseable
,DispatcherGateway
,org.apache.flink.runtime.rpc.FencedRpcGateway<DispatcherId>
,org.apache.flink.runtime.rpc.RpcGateway
,RestfulGateway
,org.apache.flink.util.AutoCloseableAsync
public class StandaloneDispatcher extends Dispatcher
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.runtime.dispatcher.Dispatcher
Dispatcher.ExecutionType
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.dispatcher.Dispatcher
CLIENT_ALIVENESS_CHECK_DURATION, DISPATCHER_NAME, shutDownFuture
-
-
Constructor Summary
Constructors Constructor Description StandaloneDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices)
-
Method Summary
-
Methods inherited from class org.apache.flink.runtime.dispatcher.Dispatcher
cancelJob, deliverCoordinationRequestToCoordinator, disposeSavepoint, getBlobServerPort, getShutDownFuture, getTriggeredCheckpointStatus, getTriggeredSavepointStatus, jobReachedTerminalState, listJobs, onFatalError, onRemovedExecutionPlan, onStart, onStop, reportJobClientHeartbeat, requestCheckpointStats, requestClusterOverview, requestExecutionGraphInfo, requestJobResourceRequirements, requestJobResult, requestJobStatus, requestMetricQueryServiceAddresses, requestMultipleJobDetails, requestTaskManagerMetricQueryServiceAddresses, requestThreadDump, runPostJobGloballyTerminated, shutDownCluster, shutDownCluster, stopWithSavepoint, stopWithSavepointAndGetLocation, submitFailedJob, submitJob, triggerCheckpoint, triggerCheckpoint, triggerCheckpointAndGetCheckpointID, triggerSavepoint, triggerSavepointAndGetLocation, updateJobResourceRequirements
-
Methods inherited from class org.apache.flink.runtime.rpc.RpcEndpoint
callAsync, closeAsync, getAddress, getEndpointId, getHostname, getMainThreadExecutor, getMainThreadExecutor, getRpcService, getSelfGateway, getTerminationFuture, internalCallOnStart, internalCallOnStop, isRunning, 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.runtime.webmonitor.RestfulGateway
requestJob
-
-
-
-
Constructor Detail
-
StandaloneDispatcher
public StandaloneDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices) throws Exception
- Throws:
Exception
-
-