Uses of Class
org.apache.flink.runtime.executiongraph.ErrorInfo
-
Packages that use ErrorInfo Package Description org.apache.flink.runtime.executiongraph org.apache.flink.runtime.scheduler.exceptionhistory -
-
Uses of ErrorInfo in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return ErrorInfo Modifier and Type Method Description static ErrorInfo
ErrorInfo. createErrorInfoWithNullableCause(Throwable exception, long timestamp)
Instantiates anErrorInfo
to cover inconsistent behavior due to FLINK-21376.ErrorInfo
AccessExecutionGraph. getFailureInfo()
Returns the exception that caused the job to fail.ErrorInfo
ArchivedExecutionGraph. getFailureInfo()
ErrorInfo
DefaultExecutionGraph. getFailureInfo()
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ErrorInfo Modifier and Type Method Description Optional<ErrorInfo>
AccessExecution. getFailureInfo()
Returns the exception that caused the job to fail.Optional<ErrorInfo>
AccessExecutionVertex. getFailureInfo()
Returns the exception that caused the job to fail.Optional<ErrorInfo>
ArchivedExecution. getFailureInfo()
Optional<ErrorInfo>
ArchivedExecutionVertex. getFailureInfo()
Optional<ErrorInfo>
Execution. getFailureInfo()
Optional<ErrorInfo>
ExecutionVertex. getFailureInfo()
Constructors in org.apache.flink.runtime.executiongraph with parameters of type ErrorInfo Constructor Description ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators, IOMetrics ioMetrics, ExecutionAttemptID attemptId, ExecutionState state, ErrorInfo failureCause, TaskManagerLocation assignedResourceLocation, AllocationID assignedAllocationID, long[] stateTimestamps, long[] stateEndTimestamps)
ArchivedExecutionGraph(org.apache.flink.api.common.JobID jobID, String jobName, Map<JobVertexID,ArchivedExecutionJobVertex> tasks, List<ArchivedExecutionJobVertex> verticesInCreationOrder, long[] stateTimestamps, org.apache.flink.api.common.JobStatus state, JobType jobType, ErrorInfo failureCause, String jsonPlan, StringifiedAccumulatorResult[] archivedUserAccumulators, Map<String,org.apache.flink.util.SerializedValue<org.apache.flink.util.OptionalFailure<Object>>> serializedUserAccumulators, org.apache.flink.api.common.ArchivedExecutionConfig executionConfig, boolean isStoppable, CheckpointCoordinatorConfiguration jobCheckpointingConfiguration, CheckpointStatsSnapshot checkpointStatsSnapshot, String stateBackendName, String checkpointStorageName, org.apache.flink.util.TernaryBoolean stateChangelogEnabled, String changelogStorageName, String streamGraphJson, int pendingOperatorCount)
-
Uses of ErrorInfo in org.apache.flink.runtime.scheduler.exceptionhistory
Subclasses of ErrorInfo in org.apache.flink.runtime.scheduler.exceptionhistory Modifier and Type Class Description class
ExceptionHistoryEntry
ExceptionHistoryEntry
collects information about a single failure that triggered the scheduler's failure handling.class
RootExceptionHistoryEntry
RootExceptionHistoryEntry
extendingExceptionHistoryEntry
by providing a list ofExceptionHistoryEntry
instances to store concurrently caught failures.Methods in org.apache.flink.runtime.scheduler.exceptionhistory with parameters of type ErrorInfo Modifier and Type Method Description static RootExceptionHistoryEntry
RootExceptionHistoryEntry. fromGlobalFailure(ErrorInfo errorInfo)
Creates aRootExceptionHistoryEntry
based on the passedErrorInfo
.
-