Class SparkListenerExecutorMetricsUpdate

Object
org.apache.spark.scheduler.SparkListenerExecutorMetricsUpdate
All Implemented Interfaces:
Serializable, SparkListenerEvent, scala.Equals, scala.Product, scala.Serializable

public class SparkListenerExecutorMetricsUpdate extends Object implements SparkListenerEvent, scala.Product, scala.Serializable
Periodic updates from executors. param: execId executor id param: accumUpdates sequence of (taskId, stageId, stageAttemptId, accumUpdates) param: executorUpdates executor level per-stage metrics updates

Since:
3.1.0
See Also:
  • Constructor Details

    • SparkListenerExecutorMetricsUpdate

      public SparkListenerExecutorMetricsUpdate(String execId, scala.collection.Seq<scala.Tuple4<Object,Object,Object,scala.collection.Seq<AccumulableInfo>>> accumUpdates, scala.collection.Map<scala.Tuple2<Object,Object>,org.apache.spark.executor.ExecutorMetrics> executorUpdates)
  • Method Details

    • apply

      public abstract static R apply(T1 v1, T2 v2, T3 v3)
    • toString

      public static String toString()
    • execId

      public String execId()
    • accumUpdates

      public scala.collection.Seq<scala.Tuple4<Object,Object,Object,scala.collection.Seq<AccumulableInfo>>> accumUpdates()
    • executorUpdates

      public scala.collection.Map<scala.Tuple2<Object,Object>,org.apache.spark.executor.ExecutorMetrics> executorUpdates()