Uses of Class
org.apache.flink.runtime.executiongraph.IOMetrics
-
-
Uses of IOMetrics in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return IOMetrics Modifier and Type Method Description IOMetrics
AccessExecution. getIOMetrics()
IOMetrics
ArchivedExecution. getIOMetrics()
IOMetrics
Execution. getIOMetrics()
IOMetrics
TaskExecutionStateTransition. getIOMetrics()
Methods in org.apache.flink.runtime.executiongraph with parameters of type IOMetrics Modifier and Type Method Description void
Execution. recoverExecution(ExecutionAttemptID attemptId, TaskManagerLocation location, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> userAccumulators, IOMetrics metrics)
Recover the execution attempt status after JM failover.Constructors in org.apache.flink.runtime.executiongraph with parameters of type IOMetrics Constructor Description ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators, IOMetrics ioMetrics, ExecutionAttemptID attemptId, ExecutionState state, ErrorInfo failureCause, TaskManagerLocation assignedResourceLocation, AllocationID assignedAllocationID, long[] stateTimestamps, long[] stateEndTimestamps)
-
Uses of IOMetrics in org.apache.flink.runtime.jobmaster.event
Methods in org.apache.flink.runtime.jobmaster.event that return IOMetrics Modifier and Type Method Description IOMetrics
ExecutionVertexFinishedEvent. getIOMetrics()
Constructors in org.apache.flink.runtime.jobmaster.event with parameters of type IOMetrics Constructor Description ExecutionVertexFinishedEvent(ExecutionAttemptID executionAttemptId, TaskManagerLocation location, Map<OperatorID,CompletableFuture<byte[]>> operatorCoordinatorSnapshotFutures, CompletableFuture<ShuffleMasterSnapshot> shuffleMasterSnapshotFuture, IOMetrics ioMetrics, Map<String,org.apache.flink.api.common.accumulators.Accumulator<?,?>> userAccumulators)
-
Uses of IOMetrics in org.apache.flink.runtime.metrics.groups
Methods in org.apache.flink.runtime.metrics.groups that return IOMetrics Modifier and Type Method Description IOMetrics
TaskIOMetricGroup. createSnapshot()
-
Uses of IOMetrics in org.apache.flink.runtime.rest.handler.util
Subclasses of IOMetrics in org.apache.flink.runtime.rest.handler.util Modifier and Type Class Description class
MutableIOMetrics
This class is a mutable version of theIOMetrics
class that allows adding up IO-related metrics. -
Uses of IOMetrics in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type IOMetrics Modifier and Type Method Description protected void
DefaultScheduler. onTaskFinished(Execution execution, IOMetrics ioMetrics)
protected abstract void
SchedulerBase. onTaskFinished(Execution execution, IOMetrics ioMetrics)
-
Uses of IOMetrics in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type IOMetrics Modifier and Type Method Description protected void
AdaptiveBatchScheduler. onTaskFinished(Execution execution, IOMetrics ioMetrics)
-
Uses of IOMetrics in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager that return IOMetrics Modifier and Type Method Description IOMetrics
TaskExecutionState. getIOMetrics()
Constructors in org.apache.flink.runtime.taskmanager with parameters of type IOMetrics Constructor Description TaskExecutionState(ExecutionAttemptID executionId, ExecutionState executionState, Throwable error, AccumulatorSnapshot accumulators, IOMetrics ioMetrics)
Creates a new task execution state update, with an attached exception.
-