Uses of Package
org.apache.flink.runtime.executiongraph
-
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.accumulators Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.checkpoint Class Description Execution A single execution of a vertex.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionJobVertex ExecutionVertex The ExecutionVertex is a parallel subtask of the execution.JobStatusListener Interface for observers that monitor the status of a job. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.deployment Class Description Execution A single execution of a vertex.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.IndexRange This class represents the range of index.IntermediateResultPartition JobInformation Container class for job information which is stored in theExecutionGraph
.TaskInformation Container class for operator/task specific information which are stored at theExecutionJobVertex
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.execution Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.executiongraph Class Description AccessExecution Common interface for the runtimeExecution
andArchivedExecution
.AccessExecutionGraph Common interface for the runtimeDefaultExecutionGraph
andArchivedExecutionGraph
.AccessExecutionJobVertex Common interface for the runtimeExecutionJobVertex
andArchivedExecutionJobVertex
.AccessExecutionVertex Common interface for the runtimeExecutionVertex
andArchivedExecutionVertex
.ArchivedExecution ArchivedExecution
is a readonly representation ofExecution
.ArchivedExecutionGraph An archived execution graph represents a serializable form of anExecutionGraph
.ArchivedExecutionJobVertex ArchivedExecutionVertex ArchivedExecutionVertex
is a readonly representation ofExecutionVertex
.DefaultExecutionGraph Default implementation of theExecutionGraph
.EdgeManager Class that manages all the connections between tasks.ErrorInfo Simple container to hold an exception and the corresponding timestamp.Execution A single execution of a vertex.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionDeploymentListener A listener that is called when the deployment of an execution has been started/completed.ExecutionGraph The execution graph is the central data structure that coordinates the distributed execution of a data flow.ExecutionGraphID A class for statistically unique execution graph IDs.ExecutionHistory This class hosts the historical executions of anExecutionVertex
in aLinkedHashMap
with a size bound.ExecutionJobVertex ExecutionJobVertex.Factory Factory to createExecutionJobVertex
.ExecutionStateUpdateListener A listener that is called when an execution switched to a new state.ExecutionVertex The ExecutionVertex is a parallel subtask of the execution.ExecutionVertexInputInfo This class describe the inputs(partitions and subpartitions that belong to the same intermediate result) information of an execution vertex.IndexRange This class represents the range of index.IntermediateResult IntermediateResultInfo IntermediateResultPartition InternalExecutionGraphAccessor This interface encapsulates all methods needed by ExecutionJobVertex / ExecutionVertices / Execution from the DefaultExecutionGraph.IOMetrics An instance of this class represents a snapshot of the io-related metrics of a single task.JobInformation Container class for job information which is stored in theExecutionGraph
.JobStatusListener Interface for observers that monitor the status of a job.JobStatusProvider Interface for querying the state of a job and the timestamps of state transitions.JobVertexInputInfo This class describe how a job vertex consume an input(intermediate result).MarkPartitionFinishedStrategy This strategy is used to decide whether partition needs to be marked as finished.MutableVertexAttemptNumberStore Mutability extension to theVertexAttemptNumberStore
.NoOpExecutionDeploymentListener No-op implementation ofExecutionDeploymentListener
.ResultPartitionBytes This class represents a snapshot of the result partition bytes metrics.SubtaskAttemptNumberStore Contains the attempt number per subtask.TaskExecutionStateTransition WrapsTaskExecutionState
, along with actions to take if it is FAILED state.TaskInformation Container class for operator/task specific information which are stored at theExecutionJobVertex
.VertexAttemptNumberStore Contains the attempt numbers per vertex. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.executiongraph.failover Class Description Execution A single execution of a vertex. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.executiongraph.metrics Class Description JobStatusProvider Interface for querying the state of a job and the timestamps of state transitions. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.filecache Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.io.network Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.PartitionInfo Contains information where to find a partition. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.io.network.metrics Class Description ResultPartitionBytes This class represents a snapshot of the result partition bytes metrics. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.io.network.partition Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.IndexRange This class represents the range of index. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.io.network.partition.consumer Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.jobmanager.slots Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.PartitionInfo Contains information where to find a partition. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.jobmaster Class Description AccessExecutionGraph Common interface for the runtimeDefaultExecutionGraph
andArchivedExecutionGraph
.ArchivedExecutionGraph An archived execution graph represents a serializable form of anExecutionGraph
.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionDeploymentListener A listener that is called when the deployment of an execution has been started/completed.JobStatusListener Interface for observers that monitor the status of a job.PartitionInfo Contains information where to find a partition. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.jobmaster.event Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.IOMetrics An instance of this class represents a snapshot of the io-related metrics of a single task.JobVertexInputInfo This class describe how a job vertex consume an input(intermediate result). -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.jobmaster.factories Class Description ArchivedExecutionGraph An archived execution graph represents a serializable form of anExecutionGraph
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.messages Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.messages.checkpoint Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.messages.webmonitor Class Description AccessExecutionGraph Common interface for the runtimeDefaultExecutionGraph
andArchivedExecutionGraph
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.metrics.groups Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.IOMetrics An instance of this class represents a snapshot of the io-related metrics of a single task. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.metrics.scope Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.minicluster Class Description AccessExecutionGraph Common interface for the runtimeDefaultExecutionGraph
andArchivedExecutionGraph
.ArchivedExecutionGraph An archived execution graph represents a serializable form of anExecutionGraph
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.operators.coordination Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionJobVertex TaskInformation Container class for operator/task specific information which are stored at theExecutionJobVertex
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.query Class Description ExecutionJobVertex -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.rest.handler.job Class Description AccessExecution Common interface for the runtimeExecution
andArchivedExecution
.AccessExecutionGraph Common interface for the runtimeDefaultExecutionGraph
andArchivedExecutionGraph
.AccessExecutionJobVertex Common interface for the runtimeExecutionJobVertex
andArchivedExecutionJobVertex
.AccessExecutionVertex Common interface for the runtimeExecutionVertex
andArchivedExecutionVertex
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.rest.handler.job.checkpoints Class Description AccessExecutionGraph Common interface for the runtimeDefaultExecutionGraph
andArchivedExecutionGraph
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.rest.handler.job.metrics Class Description AccessExecutionJobVertex Common interface for the runtimeExecutionJobVertex
andArchivedExecutionJobVertex
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.rest.handler.util Class Description AccessExecution Common interface for the runtimeExecution
andArchivedExecution
.IOMetrics An instance of this class represents a snapshot of the io-related metrics of a single task. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.rest.messages.job Class Description AccessExecution Common interface for the runtimeExecution
andArchivedExecution
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler Class Description ArchivedExecutionGraph An archived execution graph represents a serializable form of anExecutionGraph
.Execution A single execution of a vertex.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionGraph The execution graph is the central data structure that coordinates the distributed execution of a data flow.ExecutionJobVertex ExecutionJobVertex.Factory Factory to createExecutionJobVertex
.ExecutionStateUpdateListener A listener that is called when an execution switched to a new state.ExecutionVertex The ExecutionVertex is a parallel subtask of the execution.IOMetrics An instance of this class represents a snapshot of the io-related metrics of a single task.JobStatusListener Interface for observers that monitor the status of a job.JobStatusProvider Interface for querying the state of a job and the timestamps of state transitions.MarkPartitionFinishedStrategy This strategy is used to decide whether partition needs to be marked as finished.TaskExecutionStateTransition WrapsTaskExecutionState
, along with actions to take if it is FAILED state.VertexAttemptNumberStore Contains the attempt numbers per vertex. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.adapter Class Description DefaultExecutionGraph Default implementation of theExecutionGraph
.EdgeManager Class that manages all the connections between tasks.ExecutionJobVertex -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.adaptive Class Description ArchivedExecutionGraph An archived execution graph represents a serializable form of anExecutionGraph
.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionGraph The execution graph is the central data structure that coordinates the distributed execution of a data flow.JobStatusListener Interface for observers that monitor the status of a job.TaskExecutionStateTransition WrapsTaskExecutionState
, along with actions to take if it is FAILED state. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.adaptive.allocator Class Description ExecutionGraph The execution graph is the central data structure that coordinates the distributed execution of a data flow. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.adaptivebatch Class Description Execution A single execution of a vertex.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionGraph The execution graph is the central data structure that coordinates the distributed execution of a data flow.ExecutionJobVertex ExecutionVertex The ExecutionVertex is a parallel subtask of the execution.IndexRange This class represents the range of index.IntermediateResultInfo IOMetrics An instance of this class represents a snapshot of the io-related metrics of a single task.JobStatusListener Interface for observers that monitor the status of a job.JobVertexInputInfo This class describe how a job vertex consume an input(intermediate result).MarkPartitionFinishedStrategy This strategy is used to decide whether partition needs to be marked as finished.ParallelismAndInputInfos The parallelism andJobVertexInputInfo
s of a job vertex .ResultPartitionBytes This class represents a snapshot of the result partition bytes metrics. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.adaptivebatch.util Class Description IndexRange This class represents the range of index.JobVertexInputInfo This class describe how a job vertex consume an input(intermediate result). -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.exceptionhistory Class Description AccessExecution Common interface for the runtimeExecution
andArchivedExecution
.ErrorInfo Simple container to hold an exception and the corresponding timestamp.Execution A single execution of a vertex. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.metrics Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionStateUpdateListener A listener that is called when an execution switched to a new state.JobStatusListener Interface for observers that monitor the status of a job. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.scheduler.slowtaskdetector Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.ExecutionGraph The execution graph is the central data structure that coordinates the distributed execution of a data flow. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.shuffle Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.IntermediateResultPartition PartitionInfo Contains information where to find a partition.ResultPartitionBytes This class represents a snapshot of the result partition bytes metrics. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.state Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.taskexecutor Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.JobInformation Container class for job information which is stored in theExecutionGraph
.PartitionInfo Contains information where to find a partition.TaskInformation Container class for operator/task specific information which are stored at theExecutionJobVertex
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.taskexecutor.rpc Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.taskexecutor.slot Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.taskmanager Class Description ExecutionAttemptID Unique identifier for the attempt to execute a tasks.IOMetrics An instance of this class represents a snapshot of the io-related metrics of a single task.JobInformation Container class for job information which is stored in theExecutionGraph
.TaskInformation Container class for operator/task specific information which are stored at theExecutionJobVertex
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.webmonitor Class Description ArchivedExecutionGraph An archived execution graph represents a serializable form of anExecutionGraph
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.webmonitor.history Class Description AccessExecutionGraph Common interface for the runtimeDefaultExecutionGraph
andArchivedExecutionGraph
. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.webmonitor.stats Class Description AccessExecutionJobVertex Common interface for the runtimeExecutionJobVertex
andArchivedExecutionJobVertex
.ExecutionAttemptID Unique identifier for the attempt to execute a tasks. -
Classes in org.apache.flink.runtime.executiongraph used by org.apache.flink.runtime.webmonitor.threadinfo Class Description AccessExecutionJobVertex Common interface for the runtimeExecutionJobVertex
andArchivedExecutionJobVertex
.ExecutionAttemptID Unique identifier for the attempt to execute a tasks.