Uses of Class
org.apache.flink.runtime.execution.ExecutionState
-
-
Uses of ExecutionState in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution that return ExecutionState Modifier and Type Method Description static ExecutionStateExecutionState. valueOf(String name)Returns the enum constant of this type with the specified name.static ExecutionState[]ExecutionState. values()Returns an array containing the constants of this enum type, in the order they are declared. -
Uses of ExecutionState in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return ExecutionState Modifier and Type Method Description static ExecutionStateExecutionJobVertex. getAggregateJobVertexState(int[] verticesPerState, int parallelism)A utility function that computes an "aggregated" state for the vertex.ExecutionStateAccessExecutionJobVertex. getAggregateState()Returns the aggregatedExecutionStatefor this job vertex.ExecutionStateArchivedExecutionJobVertex. getAggregateState()ExecutionStateExecutionJobVertex. getAggregateState()ExecutionStateAccessExecutionVertex. getExecutionState()Returns the currentExecutionStatefor this execution vertex.ExecutionStateArchivedExecutionVertex. getExecutionState()ExecutionStateExecutionVertex. getExecutionState()ExecutionStateTaskExecutionStateTransition. getExecutionState()ExecutionStateAccessExecution. getState()Returns the currentExecutionStatefor this execution.ExecutionStateArchivedExecution. getState()ExecutionStateExecution. getState()Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ExecutionState Modifier and Type Method Description CompletableFuture<ExecutionState>Execution. getTerminalStateFuture()Gets a future that completes once the task execution reaches a terminal state.Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionState Modifier and Type Method Description longAccessExecution. getStateEndTimestamp(ExecutionState state)Returns the end timestamp for the givenExecutionState.longArchivedExecution. getStateEndTimestamp(ExecutionState state)longExecution. getStateEndTimestamp(ExecutionState state)longAccessExecution. getStateTimestamp(ExecutionState state)Returns the timestamp for the givenExecutionState.longAccessExecutionVertex. getStateTimestamp(ExecutionState state)Returns the timestamp for the givenExecutionState.longArchivedExecution. getStateTimestamp(ExecutionState state)longArchivedExecutionVertex. getStateTimestamp(ExecutionState state)longExecution. getStateTimestamp(ExecutionState state)longExecutionVertex. getStateTimestamp(ExecutionState state)voidDefaultExecutionGraph. notifyExecutionChange(Execution execution, ExecutionState previousState, ExecutionState newExecutionState)voidInternalExecutionGraphAccessor. notifyExecutionChange(Execution execution, ExecutionState previousState, ExecutionState newExecutionState)voidExecutionStateUpdateListener. onStateUpdate(ExecutionAttemptID execution, ExecutionState previousState, ExecutionState newState)voidExecution. transitionState(ExecutionState targetState)Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionState Constructor Description ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators, IOMetrics ioMetrics, ExecutionAttemptID attemptId, ExecutionState state, ErrorInfo failureCause, TaskManagerLocation assignedResourceLocation, AllocationID assignedAllocationID, long[] stateTimestamps, long[] stateEndTimestamps)IllegalExecutionStateException(ExecutionState expected, ExecutionState actual)Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state.IllegalExecutionStateException(Execution execution, ExecutionState expected, ExecutionState actual)Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state. -
Uses of ExecutionState in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return ExecutionState Modifier and Type Method Description ExecutionStatePartitionProducerStateProvider.ResponseHandle. getConsumerExecutionState()Methods in org.apache.flink.runtime.io.network.partition that return types with arguments of type ExecutionState Modifier and Type Method Description org.apache.flink.types.Either<ExecutionState,Throwable>PartitionProducerStateProvider.ResponseHandle. getProducerExecutionState() -
Uses of ExecutionState in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type ExecutionState Modifier and Type Method Description CompletableFuture<ExecutionState>JobMaster. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)CompletableFuture<ExecutionState>JobMasterGateway. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID partitionId)Requests the current state of the partition. -
Uses of ExecutionState in org.apache.flink.runtime.operators.coordination
Constructors in org.apache.flink.runtime.operators.coordination with parameters of type ExecutionState Constructor Description TaskNotRunningException(String taskDescription, ExecutionState state) -
Uses of ExecutionState in org.apache.flink.runtime.rest.messages
Methods in org.apache.flink.runtime.rest.messages that return types with arguments of type ExecutionState Modifier and Type Method Description Map<ExecutionState,Long>SubtasksTimesInfo.SubtaskTimeInfo. getTimestamps()Constructors in org.apache.flink.runtime.rest.messages with parameters of type ExecutionState Constructor Description TaskManagersInfo(String endpoint, ExecutionState status, long startTime, long endTime, long duration, IOMetricsInfo metrics, Map<ExecutionState,Integer> statusCounts, String taskmanagerId, AggregatedTaskDetailsInfo aggregated)Constructor parameters in org.apache.flink.runtime.rest.messages with type arguments of type ExecutionState Constructor Description SubtaskTimeInfo(int subtask, String endpoint, long duration, Map<ExecutionState,Long> timestamps)TaskManagersInfo(String endpoint, ExecutionState status, long startTime, long endTime, long duration, IOMetricsInfo metrics, Map<ExecutionState,Integer> statusCounts, String taskmanagerId, AggregatedTaskDetailsInfo aggregated) -
Uses of ExecutionState in org.apache.flink.runtime.rest.messages.job
Methods in org.apache.flink.runtime.rest.messages.job that return ExecutionState Modifier and Type Method Description ExecutionStateJobDetailsInfo.JobVertexDetailsInfo. getExecutionState()ExecutionStateSubtaskExecutionAttemptDetailsInfo. getStatus()Methods in org.apache.flink.runtime.rest.messages.job that return types with arguments of type ExecutionState Modifier and Type Method Description static Map<ExecutionState,Long>StatusDurationUtils. getExecutionStateDuration(AccessExecution execution)Map<ExecutionState,Integer>JobDetailsInfo. getJobVerticesPerState()Map<ExecutionState,Long>SubtaskExecutionAttemptDetailsInfo. getStatusDuration()Map<ExecutionState,Integer>JobDetailsInfo.JobVertexDetailsInfo. getTasksPerState()Methods in org.apache.flink.runtime.rest.messages.job with parameters of type ExecutionState Modifier and Type Method Description longSubtaskExecutionAttemptDetailsInfo. getStatusDuration(ExecutionState state)Constructors in org.apache.flink.runtime.rest.messages.job with parameters of type ExecutionState Constructor Description JobVertexDetailsInfo(JobVertexID jobVertexID, SlotSharingGroupId slotSharingGroupId, String name, int maxParallelism, int parallelism, ExecutionState executionState, long startTime, long endTime, long duration, Map<ExecutionState,Integer> tasksPerState, IOMetricsInfo jobVertexMetrics)SubtaskExecutionAttemptDetailsInfo(int subtaskIndex, ExecutionState status, int attempt, String endpoint, long startTime, long endTime, long duration, IOMetricsInfo ioMetricsInfo, String taskmanagerId, Map<ExecutionState,Long> statusDuration, List<SubtaskExecutionAttemptDetailsInfo> otherConcurrentAttempts)Constructor parameters in org.apache.flink.runtime.rest.messages.job with type arguments of type ExecutionState Constructor Description JobVertexDetailsInfo(JobVertexID jobVertexID, SlotSharingGroupId slotSharingGroupId, String name, int maxParallelism, int parallelism, ExecutionState executionState, long startTime, long endTime, long duration, Map<ExecutionState,Integer> tasksPerState, IOMetricsInfo jobVertexMetrics)SubtaskExecutionAttemptDetailsInfo(int subtaskIndex, ExecutionState status, int attempt, String endpoint, long startTime, long endTime, long duration, IOMetricsInfo ioMetricsInfo, String taskmanagerId, Map<ExecutionState,Long> statusDuration, List<SubtaskExecutionAttemptDetailsInfo> otherConcurrentAttempts) -
Uses of ExecutionState in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return ExecutionState Modifier and Type Method Description ExecutionStateExecutionGraphHandler. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)ExecutionStateSchedulerBase. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId)ExecutionStateSchedulerNG. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId) -
Uses of ExecutionState in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return ExecutionState Modifier and Type Method Description ExecutionStateAdaptiveScheduler. requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID resultPartitionId) -
Uses of ExecutionState in org.apache.flink.runtime.scheduler.metrics
Methods in org.apache.flink.runtime.scheduler.metrics with parameters of type ExecutionState Modifier and Type Method Description voidDeploymentStateTimeMetrics. onStateUpdate(ExecutionAttemptID execution, ExecutionState previousState, ExecutionState newState) -
Uses of ExecutionState in org.apache.flink.runtime.scheduler.stopwithsavepoint
Method parameters in org.apache.flink.runtime.scheduler.stopwithsavepoint with type arguments of type ExecutionState Modifier and Type Method Description voidStopWithSavepointTerminationHandler. handleExecutionsTermination(Collection<ExecutionState> terminatedExecutionStates)Handles the termination of the job based on the passed terminatedExecutionStates. stop-with-savepoint expects theterminatedExecutionStatesto only containFINISHEDto succeed.voidStopWithSavepointTerminationHandlerImpl. handleExecutionsTermination(Collection<ExecutionState> terminatedExecutionStates) -
Uses of ExecutionState in org.apache.flink.runtime.scheduler.strategy
Methods in org.apache.flink.runtime.scheduler.strategy that return ExecutionState Modifier and Type Method Description ExecutionStateSchedulingExecutionVertex. getState()Gets the state of the execution vertex.Methods in org.apache.flink.runtime.scheduler.strategy with parameters of type ExecutionState Modifier and Type Method Description voidPipelinedRegionSchedulingStrategy. onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)voidSchedulingStrategy. onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)Called whenever anExecutionchanges its state.voidVertexwiseSchedulingStrategy. onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState) -
Uses of ExecutionState in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type ExecutionState Modifier and Type Method Description CompletableFuture<ExecutionState>PartitionProducerStateChecker. requestPartitionProducerState(org.apache.flink.api.common.JobID jobId, IntermediateDataSetID intermediateDataSetId, ResultPartitionID resultPartitionId)Requests the execution state of the execution producing a result partition. -
Uses of ExecutionState in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc that return types with arguments of type ExecutionState Modifier and Type Method Description CompletableFuture<ExecutionState>RpcPartitionStateChecker. requestPartitionProducerState(org.apache.flink.api.common.JobID jobId, IntermediateDataSetID resultId, ResultPartitionID partitionId) -
Uses of ExecutionState in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager that return ExecutionState Modifier and Type Method Description ExecutionStateTask. getExecutionState()Returns the current execution state of the task.ExecutionStateTaskExecutionState. getExecutionState()Returns the new execution state of the task.Methods in org.apache.flink.runtime.taskmanager that return types with arguments of type ExecutionState Modifier and Type Method Description CompletableFuture<ExecutionState>Task. getTerminationFuture()Constructors in org.apache.flink.runtime.taskmanager with parameters of type ExecutionState Constructor Description TaskExecutionState(ExecutionAttemptID executionId, ExecutionState executionState)Creates a new task execution state update, with no attached exception and no accumulators.TaskExecutionState(ExecutionAttemptID executionId, ExecutionState executionState, Throwable error)Creates a new task execution state update, with an attached exception but no accumulators.TaskExecutionState(ExecutionAttemptID executionId, ExecutionState executionState, Throwable error, AccumulatorSnapshot accumulators, IOMetrics ioMetrics)Creates a new task execution state update, with an attached exception.
-