Package org.apache.flink.runtime.scheduler
-
Interface Summary Interface Description ExecutionDeployer This deployer is responsible for deploying executions.ExecutionDeployer.Factory Factory to instantiate theExecutionDeployer
.ExecutionGraphFactory Factory for creating anExecutionGraph
.ExecutionOperations Operations on theExecution
.ExecutionSlotAllocator Component responsible for assigning slots to a collection ofExecution
.ExecutionSlotAllocatorFactory Interface forExecutionSlotAllocator
factories.GlobalFailureHandler An interface for handling global failures.InputsLocationsRetriever Component to retrieve the inputs locations of anExecutionVertex
.InternalFailuresListener This interface enables subscribing to failures that are detected from the JobMaster side (e.g., from within theExecutionGraph
).MutableVertexParallelismStore Mutability extension to theVertexParallelismStore
.OperatorCoordinatorHandler Handler for theOperatorCoordinators
.PreferredLocationsRetriever Component to retrieve the preferred locations of an execution vertex.SchedulerNG Interface for scheduling Flink jobs.SchedulerNGFactory Factory forSchedulerNG
.SchedulerOperations Component which is used bySchedulingStrategy
to commit scheduling decisions.SchedulingTopologyListener This listener will be notified whenever the scheduling topology is updated.StateLocationRetriever Component to retrieve the state location of an execution vertex.SyncPreferredLocationsRetriever Component to retrieve the preferred locations of an execution vertex.VertexParallelismInformation Manages the parallelism properties for a vertex in the execution graph, as well as how they can change during runtime.VertexParallelismStore Contains the max parallelism per vertex, along with metadata about how these maxes were calculated. -
Class Summary Class Description DefaultExecutionDeployer Default implementation ofExecutionDeployer
.DefaultExecutionDeployer.Factory Factory to instantiate theDefaultExecutionDeployer
.DefaultExecutionGraphFactory DefaultExecutionGraphFactory
implementation.DefaultExecutionOperations Default implementation ofExecutionOperations
.DefaultOperatorCoordinatorHandler Default handler for theOperatorCoordinators
.DefaultPreferredLocationsRetriever Default implementation ofPreferredLocationsRetriever
.DefaultScheduler The future default scheduler.DefaultSchedulerComponents Components to create aDefaultScheduler
.DefaultSchedulerFactory Factory forDefaultScheduler
.DefaultVertexParallelismInfo AVertexParallelismInformation
implementation that provides common validation.DefaultVertexParallelismStore Maintains the configured parallelisms for vertices, which should be defined by a scheduler.ExecutionGraphHandler Handler for theExecutionGraph
which offers some common operations.ExecutionGraphInfo ExecutionGraphInfo
serves as a composite class that provides differentExecutionGraph
-related information.ExecutionGraphToInputsLocationsRetrieverAdapter An implementation ofInputsLocationsRetriever
based on theExecutionGraph
.ExecutionSlotSharingGroup Represents execution vertices that will run the same shared slot.ExecutionVertexVersion This class helps to record version of an execution vertex.ExecutionVertexVersioner Records modifications ofExecutionVertices
, and allows for checking whether a vertex was modified.JobStatusStore Listens for and exposes the current job state and state timestamps.KvStateHandler Handler for common queryable state logic.SchedulerBase Base class which can be used to implementSchedulerNG
.SchedulerUtils Utils class for Flink's scheduler implementations.SharingPhysicalSlotRequestBulk Implementation ofPhysicalSlotRequestBulk
forSlotSharingExecutionSlotAllocator
.SimpleExecutionSlotAllocator A simple implementation ofExecutionSlotAllocator
.SimpleExecutionSlotAllocator.Factory Factory to instantiate aSimpleExecutionSlotAllocator
.SlotSharingExecutionSlotAllocatorFactory Factory forSlotSharingExecutionSlotAllocator
.SsgNetworkMemoryCalculationUtils Util to analyze inputs & outputs ofExecutionJobVertex
and calculate network memory requirement for slot sharing group (SSG).UpdateSchedulerNgOnInternalFailuresListener CallsSchedulerNG.updateTaskExecutionState(TaskExecutionStateTransition)
on task failure.VertexEndOfDataListener Records the end of data event of each task, and allows for checking whether all tasks of aJobGraph
have reached the end of data. -
Exception Summary Exception Description ClusterDatasetCorruptedException Indicates some task fail to consume cluster dataset.