Uses of Class
org.apache.flink.runtime.executiongraph.ExecutionJobVertex.Factory
-
Packages that use ExecutionJobVertex.Factory Package Description org.apache.flink.runtime.executiongraph org.apache.flink.runtime.scheduler -
-
Uses of ExecutionJobVertex.Factory in org.apache.flink.runtime.executiongraph
Subclasses of ExecutionJobVertex.Factory in org.apache.flink.runtime.executiongraph Modifier and Type Class Description static class
SpeculativeExecutionJobVertex.Factory
Factory to createSpeculativeExecutionJobVertex
.Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionJobVertex.Factory Modifier and Type Method Description static DefaultExecutionGraph
DefaultExecutionGraphBuilder. buildGraph(JobGraph jobGraph, Configuration jobManagerConfig, ScheduledExecutorService futureExecutor, Executor ioExecutor, ClassLoader classLoader, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, Duration rpcTimeout, BlobWriter blobWriter, org.slf4j.Logger log, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, CheckpointStatsTracker checkpointStatsTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, boolean nonFinishedHybridPartitionShouldBeUnknown, JobManagerJobMetricGroup jobManagerJobMetricGroup)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionJobVertex.Factory Constructor Description DefaultExecutionGraph(JobType jobType, JobInformation jobInformation, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, int executionHistorySizeLimit, ClassLoader userClassLoader, BlobWriter blobWriter, PartitionGroupReleaseStrategy.Factory partitionGroupReleaseStrategyFactory, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore initialAttemptCounts, VertexParallelismStore vertexParallelismStore, boolean isDynamic, ExecutionJobVertex.Factory executionJobVertexFactory, List<JobStatusHook> jobStatusHooks, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, TaskDeploymentDescriptorFactory taskDeploymentDescriptorFactory, List<JobStatusChangedListener> jobStatusChangedListeners)
-
Uses of ExecutionJobVertex.Factory in org.apache.flink.runtime.scheduler
Constructors in org.apache.flink.runtime.scheduler with parameters of type ExecutionJobVertex.Factory Constructor Description DefaultExecutionGraphFactory(Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, boolean nonFinishedHybridPartitionShouldBeUnknown)
-