Uses of Class
org.apache.flink.runtime.jobgraph.JobGraph
-
-
Uses of JobGraph in org.apache.flink.runtime.client
Methods in org.apache.flink.runtime.client with parameters of type JobGraph Modifier and Type Method Description static void
ClientUtils. extractAndUploadJobGraphFiles(JobGraph jobGraph, org.apache.flink.util.function.SupplierWithException<BlobClient,IOException> clientSupplier)
Extracts all files required for the execution from the givenJobGraph
and uploads them using theBlobClient
from the givenSupplier
.static void
ClientUtils. uploadJobGraphFiles(JobGraph jobGraph, Collection<org.apache.flink.core.fs.Path> userJars, Collection<org.apache.flink.api.java.tuple.Tuple2<String,org.apache.flink.core.fs.Path>> userArtifacts, org.apache.flink.util.function.SupplierWithException<BlobClient,IOException> clientSupplier)
Uploads the given jars and artifacts required for the execution of the givenJobGraph
using theBlobClient
from the givenSupplier
. -
Uses of JobGraph in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher with parameters of type JobGraph Modifier and Type Method Description JobManagerRunner
JobManagerRunnerFactory. createJobManagerRunner(JobGraph jobGraph, org.apache.flink.configuration.Configuration configuration, org.apache.flink.runtime.rpc.RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, JobManagerSharedServices jobManagerServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
JobManagerRunner
JobMasterServiceLeadershipRunnerFactory. createJobManagerRunner(JobGraph jobGraph, org.apache.flink.configuration.Configuration configuration, org.apache.flink.runtime.rpc.RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, JobManagerSharedServices jobManagerServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
CompletableFuture<Acknowledge>
Dispatcher. submitJob(JobGraph jobGraph, Duration timeout)
CompletableFuture<Acknowledge>
DispatcherGateway. submitJob(JobGraph jobGraph, Duration timeout)
Submit a job to the dispatcher.CompletableFuture<Acknowledge>
MiniDispatcher. submitJob(JobGraph jobGraph, Duration timeout)
Method parameters in org.apache.flink.runtime.dispatcher with type arguments of type JobGraph Modifier and Type Method Description Dispatcher
DispatcherFactory. createDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<JobGraph> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents)
Create aDispatcher
.MiniDispatcher
JobDispatcherFactory. createDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<JobGraph> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents)
StandaloneDispatcher
SessionDispatcherFactory. createDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<JobGraph> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents partialDispatcherServicesWithJobPersistenceComponents)
Constructors in org.apache.flink.runtime.dispatcher with parameters of type JobGraph Constructor Description MiniDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, DispatcherServices dispatcherServices, JobGraph jobGraph, JobResult recoveredDirtyJob, DispatcherBootstrapFactory dispatcherBootstrapFactory, JobManagerRunnerRegistry jobManagerRunnerRegistry, ResourceCleanerFactory resourceCleanerFactory, ClusterEntrypoint.ExecutionMode executionMode)
MiniDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, DispatcherServices dispatcherServices, JobGraph jobGraph, JobResult recoveredDirtyJob, DispatcherBootstrapFactory dispatcherBootstrapFactory, ClusterEntrypoint.ExecutionMode executionMode)
Constructor parameters in org.apache.flink.runtime.dispatcher with type arguments of type JobGraph Constructor Description Dispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<JobGraph> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices)
Dispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<JobGraph> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices, JobManagerRunnerRegistry jobManagerRunnerRegistry, ResourceCleanerFactory resourceCleanerFactory)
StandaloneDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<JobGraph> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices)
-
Uses of JobGraph in org.apache.flink.runtime.dispatcher.runner
Method parameters in org.apache.flink.runtime.dispatcher.runner with type arguments of type JobGraph Modifier and Type Method Description AbstractDispatcherLeaderProcess.DispatcherGatewayService
AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory. create(DispatcherId dispatcherId, Collection<JobGraph> recoveredJobs, Collection<JobResult> recoveredDirtyJobResults, JobGraphWriter jobGraphWriter, JobResultStore jobResultStore)
-
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 JobGraph
FileJobGraphRetriever. retrieveJobGraph(org.apache.flink.configuration.Configuration configuration)
JobGraph
JobGraphRetriever. 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 DefaultExecutionGraph
DefaultExecutionGraphBuilder. 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)
static boolean
DefaultExecutionGraphBuilder. 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 JobGraph
JobGraphBuilder. build()
Methods in org.apache.flink.runtime.jobgraph with parameters of type JobGraph Modifier and Type Method Description static Optional<JobResourceRequirements>
JobResourceRequirements. readFromJobGraph(JobGraph jobGraph)
Readresource requirements
from the configuration of a givenJobGraph
.static void
JobResourceRequirements. writeToJobGraph(JobGraph jobGraph, JobResourceRequirements jobResourceRequirements)
Writeresource requirements
into the configuration of a givenJobGraph
. -
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 String
JsonPlanGenerator. 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 DefaultLogicalTopology
DefaultLogicalTopology. fromJobGraph(JobGraph jobGraph)
-
Uses of JobGraph in org.apache.flink.runtime.jobmanager
Methods in org.apache.flink.runtime.jobmanager that return JobGraph Modifier and Type Method Description JobGraph
DefaultJobGraphStore. recoverJobGraph(org.apache.flink.api.common.JobID jobId)
JobGraph
JobGraphStore. recoverJobGraph(org.apache.flink.api.common.JobID jobId)
JobGraph
StandaloneJobGraphStore. recoverJobGraph(org.apache.flink.api.common.JobID jobId)
Methods in org.apache.flink.runtime.jobmanager with parameters of type JobGraph Modifier and Type Method Description void
DefaultJobGraphStore. putJobGraph(JobGraph jobGraph)
void
JobGraphWriter. putJobGraph(JobGraph jobGraph)
Adds theJobGraph
instance.void
StandaloneJobGraphStore. putJobGraph(JobGraph jobGraph)
void
ThrowingJobGraphWriter. putJobGraph(JobGraph jobGraph)
Constructor parameters in org.apache.flink.runtime.jobmanager with type arguments of type JobGraph Constructor Description DefaultJobGraphStore(StateHandleStore<JobGraph,R> stateHandleStore, JobGraphStoreWatcher jobGraphStoreWatcher, JobGraphStoreUtil jobGraphStoreUtil)
-
Uses of JobGraph in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type JobGraph Modifier and Type Method Description SchedulerNG
DefaultSlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)
SchedulerNG
SlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)
Creates aSchedulerNG
.Constructors in org.apache.flink.runtime.jobmaster with parameters of type JobGraph Constructor Description JobMaster(org.apache.flink.runtime.rpc.RpcService rpcService, JobMasterId jobMasterId, JobMasterConfiguration jobMasterConfiguration, ResourceID resourceId, JobGraph jobGraph, HighAvailabilityServices highAvailabilityService, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobMetricGroupFactory, OnCompletionActions jobCompletionActions, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClassLoader userCodeLoader, ShuffleMaster<?> shuffleMaster, PartitionTrackerFactory partitionTrackerFactory, ExecutionDeploymentTracker executionDeploymentTracker, ExecutionDeploymentReconciler.Factory executionDeploymentReconcilerFactory, BlocklistHandler.Factory blocklistHandlerFactory, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
-
Uses of JobGraph in org.apache.flink.runtime.jobmaster.factories
Methods in org.apache.flink.runtime.jobmaster.factories with parameters of type JobGraph Modifier and Type Method Description JobManagerJobMetricGroup
DefaultJobManagerJobMetricGroupFactory. create(JobGraph jobGraph)
JobManagerJobMetricGroup
JobManagerJobMetricGroupFactory. create(JobGraph jobGraph)
Create a newJobManagerJobMetricGroup
.JobManagerJobMetricGroup
UnregisteredJobManagerJobMetricGroupFactory. create(JobGraph jobGraph)
Constructors in org.apache.flink.runtime.jobmaster.factories with parameters of type JobGraph Constructor Description DefaultJobMasterServiceFactory(Executor executor, org.apache.flink.runtime.rpc.RpcService rpcService, JobMasterConfiguration jobMasterConfiguration, JobGraph jobGraph, HighAvailabilityServices haServices, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClassLoader userCodeClassloader, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
-
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.JobExecutionResult
MiniCluster. executeJobBlocking(JobGraph job)
This method runs a job in blocking mode.void
MiniCluster. runDetached(JobGraph job)
This method executes a job in detached mode.CompletableFuture<org.apache.flink.api.common.JobSubmissionResult>
MiniCluster. submitJob(JobGraph jobGraph)
-
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 JobGraph
SchedulerBase. getJobGraph()
Methods in org.apache.flink.runtime.scheduler with parameters of type JobGraph Modifier and Type Method Description static VertexParallelismStore
SchedulerBase. computeVertexParallelismStore(JobGraph jobGraph)
Compute theVertexParallelismStore
for all vertices of a given job graph, which will set defaults and ensure that the returned store contains valid parallelisms.ExecutionGraph
DefaultExecutionGraphFactory. createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, org.slf4j.Logger log)
ExecutionGraph
ExecutionGraphFactory. createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, org.slf4j.Logger log)
Create and restoreExecutionGraph
from the givenJobGraph
and services.static CheckpointIDCounter
SchedulerUtils. createCheckpointIDCounterIfCheckpointingIsEnabled(JobGraph jobGraph, CheckpointRecoveryFactory checkpointRecoveryFactory)
static CheckpointStatsTracker
SchedulerUtils. createCheckpointStatsTrackerIfCheckpointingIsEnabled(JobGraph jobGraph, Supplier<CheckpointStatsTracker> checkpointStatsTrackerFactory)
static CompletedCheckpointStore
SchedulerUtils. createCompletedCheckpointStoreIfCheckpointingIsEnabled(JobGraph jobGraph, org.apache.flink.configuration.Configuration configuration, CheckpointRecoveryFactory checkpointRecoveryFactory, Executor ioExecutor, org.slf4j.Logger log)
SchedulerNG
DefaultSchedulerFactory. createInstance(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)
SchedulerNG
SchedulerNGFactory. createInstance(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)
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)
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)
-
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 JobGraph
JobGraphJobInformation. copyJobGraph()
Returns a copy of a jobGraph that can be mutated.Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type JobGraph Modifier and Type Method Description SchedulerNG
AdaptiveSchedulerFactory. createInstance(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)
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 with parameters of type JobGraph Modifier and Type Method Description SchedulerNG
AdaptiveBatchSchedulerFactory. createInstance(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, 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, BlocklistOperations blocklistOperations)
static AdaptiveBatchScheduler
AdaptiveBatchSchedulerFactory. createScheduler(org.slf4j.Logger log, JobGraph jobGraph, org.apache.flink.api.common.ExecutionConfig executionConfig, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations, ExecutionOperations executionOperations, ExecutionSlotAllocatorFactory allocatorFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, BatchJobRecoveryHandler jobRecoveryHandler)
Constructors in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type JobGraph Constructor Description AdaptiveBatchScheduler(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, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, int defaultMaxParallelism, BlocklistOperations blocklistOperations, org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint hybridPartitionDataConsumeConstraint, Map<JobVertexID,ForwardGroup> forwardGroupsByJobVertexId, BatchJobRecoveryHandler jobRecoveryHandler)
-
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 JobGraph
StreamingJobGraphGenerator. createJobGraph(ClassLoader userClassLoader, StreamGraph streamGraph, org.apache.flink.api.common.JobID jobID)
static JobGraph
StreamingJobGraphGenerator. createJobGraph(StreamGraph streamGraph)
JobGraph
StreamGraph. getJobGraph()
Gets the assembledJobGraph
with a randomJobID
.JobGraph
StreamGraph. getJobGraph(ClassLoader userClassLoader, org.apache.flink.api.common.JobID jobID)
Gets the assembledJobGraph
with a specifiedJobID
.
-