Uses of Class
org.apache.flink.runtime.jobgraph.JobGraph
-
-
Uses of JobGraph in org.apache.flink.runtime.entrypoint.component
Methods in org.apache.flink.runtime.entrypoint.component that return JobGraph Modifier and Type Method Description JobGraphFileJobGraphRetriever. retrieveJobGraph(org.apache.flink.configuration.Configuration configuration)JobGraphJobGraphRetriever. retrieveJobGraph(org.apache.flink.configuration.Configuration configuration)Retrieve theJobGraph. -
Uses of JobGraph in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type JobGraph Modifier and Type Method Description static DefaultExecutionGraphDefaultExecutionGraphBuilder. buildGraph(JobGraph jobGraph, org.apache.flink.configuration.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, ExecutionPlanSchedulingContext executionPlanSchedulingContext)static booleanDefaultExecutionGraphBuilder. isCheckpointingEnabled(JobGraph jobGraph) -
Uses of JobGraph in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return JobGraph Modifier and Type Method Description JobGraphJobGraphBuilder. build() -
Uses of JobGraph in org.apache.flink.runtime.jobgraph.jsonplan
Methods in org.apache.flink.runtime.jobgraph.jsonplan with parameters of type JobGraph Modifier and Type Method Description static JobPlanInfo.PlanJsonPlanGenerator. generatePlan(JobGraph jg) -
Uses of JobGraph in org.apache.flink.runtime.jobgraph.topology
Methods in org.apache.flink.runtime.jobgraph.topology with parameters of type JobGraph Modifier and Type Method Description static DefaultLogicalTopologyDefaultLogicalTopology. fromJobGraph(JobGraph jobGraph) -
Uses of JobGraph in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster with parameters of type JobGraph Modifier and Type Method Description org.apache.flink.api.common.JobExecutionResultMiniCluster. executeJobBlocking(JobGraph job)This method runs a job in blocking mode.voidMiniCluster. runDetached(JobGraph job)This method executes a job in detached mode. -
Uses of JobGraph in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return JobGraph Modifier and Type Method Description protected JobGraphSchedulerBase. getJobGraph()Methods in org.apache.flink.runtime.scheduler with parameters of type JobGraph Modifier and Type Method Description static VertexParallelismStoreSchedulerBase. computeVertexParallelismStore(JobGraph jobGraph)Compute theVertexParallelismStorefor all vertices of a given job graph, which will set defaults and ensure that the returned store contains valid parallelisms.ExecutionGraphDefaultExecutionGraphFactory. createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, ExecutionPlanSchedulingContext executionPlanSchedulingContext, org.slf4j.Logger log)ExecutionGraphExecutionGraphFactory. createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, ExecutionPlanSchedulingContext executionPlanSchedulingContext, org.slf4j.Logger log)Create and restoreExecutionGraphfrom the givenJobGraphand services.static CheckpointIDCounterSchedulerUtils. createCheckpointIDCounterIfCheckpointingIsEnabled(JobGraph jobGraph, CheckpointRecoveryFactory checkpointRecoveryFactory)static CheckpointStatsTrackerSchedulerUtils. createCheckpointStatsTrackerIfCheckpointingIsEnabled(JobGraph jobGraph, Supplier<CheckpointStatsTracker> checkpointStatsTrackerFactory)static CompletedCheckpointStoreSchedulerUtils. createCompletedCheckpointStoreIfCheckpointingIsEnabled(JobGraph jobGraph, org.apache.flink.configuration.Configuration configuration, CheckpointRecoveryFactory checkpointRecoveryFactory, Executor ioExecutor, org.slf4j.Logger log)Constructors in org.apache.flink.runtime.scheduler with parameters of type JobGraph Constructor Description DefaultScheduler(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, Consumer<org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor> startUpAction, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, ClassLoader userCodeLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, SchedulingStrategyFactory schedulingStrategyFactory, FailoverStrategy.Factory failoverStrategyFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, ExecutionSlotAllocatorFactory executionSlotAllocatorFactory, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory, ShuffleMaster<?> shuffleMaster, Duration rpcTimeout, VertexParallelismStore vertexParallelismStore, ExecutionDeployer.Factory executionDeployerFactory, ExecutionPlanSchedulingContext executionPlanSchedulingContext)SchedulerBase(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionVertexVersioner executionVertexVersioner, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, ExecutionGraphFactory executionGraphFactory, VertexParallelismStore vertexParallelismStore, ExecutionPlanSchedulingContext executionPlanSchedulingContext) -
Uses of JobGraph in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return JobGraph Modifier and Type Method Description JobGraphJobGraphJobInformation. copyJobGraph()Returns a copy of a jobGraph that can be mutated.Constructors in org.apache.flink.runtime.scheduler.adaptive with parameters of type JobGraph Constructor Description AdaptiveScheduler(AdaptiveScheduler.Settings settings, JobGraph jobGraph, JobResourceRequirements jobResourceRequirements, org.apache.flink.configuration.Configuration configuration, DeclarativeSlotPool declarativeSlotPool, SlotAllocator slotAllocator, Executor ioExecutor, ClassLoader userCodeClassLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, RestartBackoffTimeStrategy restartBackoffTimeStrategy, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory)JobGraphJobInformation(JobGraph jobGraph, VertexParallelismStore vertexParallelismStore) -
Uses of JobGraph in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return JobGraph Modifier and Type Method Description JobGraphAdaptiveExecutionHandler. getJobGraph()Returns theJobGraphrepresenting the batch job.JobGraphDefaultAdaptiveExecutionHandler. getJobGraph()JobGraphNonAdaptiveExecutionHandler. getJobGraph()Constructors in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type JobGraph Constructor Description NonAdaptiveExecutionHandler(JobGraph jobGraph) -
Uses of JobGraph in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return JobGraph Modifier and Type Method Description static JobGraphStreamingJobGraphGenerator. createAndInitializeJobGraph(StreamGraph streamGraph, org.apache.flink.api.common.JobID jobId)static JobGraphStreamingJobGraphGenerator. createJobGraph(ClassLoader userClassLoader, StreamGraph streamGraph, org.apache.flink.api.common.JobID jobID)static JobGraphStreamingJobGraphGenerator. createJobGraph(StreamGraph streamGraph)JobGraphAdaptiveGraphGenerator. getJobGraph()Retrieves the JobGraph representation of the current state of the Flink job.JobGraphAdaptiveGraphManager. getJobGraph()JobGraphStreamGraph. getJobGraph()Gets the assembledJobGraphwith a randomJobID.JobGraphStreamGraph. getJobGraph(ClassLoader userClassLoader)JobGraphStreamGraph. getJobGraph(ClassLoader userClassLoader, org.apache.flink.api.common.JobID jobID)Gets the assembledJobGraphwith a specifiedJobID. -
Uses of JobGraph in org.apache.flink.streaming.api.graph.util
Methods in org.apache.flink.streaming.api.graph.util that return JobGraph Modifier and Type Method Description JobGraphJobVertexBuildContext. getJobGraph()Constructors in org.apache.flink.streaming.api.graph.util with parameters of type JobGraph Constructor Description JobVertexBuildContext(JobGraph jobGraph, StreamGraph streamGraph, AtomicBoolean hasHybridResultPartition, Map<Integer,byte[]> hashes, List<Map<Integer,byte[]>> legacyHashes, SlotSharingGroup defaultSlotSharingGroup)
-