Uses of Interface
org.apache.flink.runtime.scheduler.VertexParallelismStore
-
-
Uses of VertexParallelismStore in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type VertexParallelismStore 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 ArchivedExecutionGraph
ArchivedExecutionGraph. createSparseArchivedExecutionGraphWithJobVertices(org.apache.flink.api.common.JobID jobId, String jobName, org.apache.flink.api.common.JobStatus jobStatus, JobType jobType, Throwable throwable, JobCheckpointingSettings checkpointingSettings, long initializationTimestamp, Iterable<JobVertex> jobVertices, VertexParallelismStore initialParallelismStore)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type VertexParallelismStore 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<org.apache.flink.core.execution.JobStatusHook> jobStatusHooks, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, TaskDeploymentDescriptorFactory taskDeploymentDescriptorFactory, List<org.apache.flink.core.execution.JobStatusChangedListener> jobStatusChangedListeners)
-
Uses of VertexParallelismStore in org.apache.flink.runtime.scheduler
Subinterfaces of VertexParallelismStore in org.apache.flink.runtime.scheduler Modifier and Type Interface Description interface
MutableVertexParallelismStore
Mutability extension to theVertexParallelismStore
.Classes in org.apache.flink.runtime.scheduler that implement VertexParallelismStore Modifier and Type Class Description class
DefaultVertexParallelismStore
Maintains the configured parallelisms for vertices, which should be defined by a scheduler.Methods in org.apache.flink.runtime.scheduler that return VertexParallelismStore Modifier and Type Method Description static VertexParallelismStore
SchedulerBase. computeVertexParallelismStore(Iterable<JobVertex> vertices)
Compute theVertexParallelismStore
for all given vertices, which will set defaults and ensure that the returned store contains valid parallelisms.static VertexParallelismStore
SchedulerBase. computeVertexParallelismStore(Iterable<JobVertex> vertices, Function<JobVertex,Integer> defaultMaxParallelismFunc)
static VertexParallelismStore
SchedulerBase. computeVertexParallelismStore(Iterable<JobVertex> vertices, Function<JobVertex,Integer> defaultMaxParallelismFunc, Function<Integer,Integer> normalizeParallelismFunc)
Compute theVertexParallelismStore
for all given vertices, which will set defaults and ensure that the returned store contains valid parallelisms, with a custom function for default max parallelism calculation and a custom function for normalizing vertex parallelism.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.Methods in org.apache.flink.runtime.scheduler that return types with arguments of type VertexParallelismStore Modifier and Type Method Description static Optional<VertexParallelismStore>
DefaultVertexParallelismStore. applyJobResourceRequirements(VertexParallelismStore oldVertexParallelismStore, JobResourceRequirements jobResourceRequirements)
Create a newVertexParallelismStore
that reflects givenJobResourceRequirements
.Methods in org.apache.flink.runtime.scheduler with parameters of type VertexParallelismStore Modifier and Type Method Description static Optional<VertexParallelismStore>
DefaultVertexParallelismStore. applyJobResourceRequirements(VertexParallelismStore oldVertexParallelismStore, JobResourceRequirements jobResourceRequirements)
Create a newVertexParallelismStore
that reflects givenJobResourceRequirements
.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.Constructors in org.apache.flink.runtime.scheduler with parameters of type VertexParallelismStore 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 VertexParallelismStore in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return VertexParallelismStore Modifier and Type Method Description VertexParallelismStore
JobGraphJobInformation. getVertexParallelismStore()
Constructors in org.apache.flink.runtime.scheduler.adaptive with parameters of type VertexParallelismStore Constructor Description JobGraphJobInformation(JobGraph jobGraph, VertexParallelismStore vertexParallelismStore)
-
Uses of VertexParallelismStore in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return VertexParallelismStore Modifier and Type Method Description static VertexParallelismStore
AdaptiveBatchScheduler. computeVertexParallelismStoreForDynamicGraph(Iterable<JobVertex> vertices, int defaultMaxParallelism)
Compute theVertexParallelismStore
for all given vertices in a dynamic graph, which will set defaults and ensure that the returned store contains valid parallelisms, with the configured default max parallelism.
-