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 IOMetricsAccessExecution. getIOMetrics()IOMetricsArchivedExecution. getIOMetrics()IOMetricsExecution. getIOMetrics()IOMetricsTaskExecutionStateTransition. getIOMetrics()Methods in org.apache.flink.runtime.executiongraph with parameters of type IOMetrics Modifier and Type Method Description voidExecution. 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 IOMetricsExecutionVertexFinishedEvent. 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 IOMetricsTaskIOMetricGroup. 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 classMutableIOMetricsThis class is a mutable version of theIOMetricsclass 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 voidDefaultScheduler. onTaskFinished(Execution execution, IOMetrics ioMetrics)protected abstract voidSchedulerBase. 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 voidAdaptiveBatchScheduler. 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 IOMetricsTaskExecutionState. 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.
-