public class SparkListenerExecutorMetricsUpdate extends Object implements SparkListenerEvent, scala.Product, scala.Serializable
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
scala.collection.Seq<scala.Tuple4<Object,Object,Object,scala.collection.Seq<AccumulableInfo>>> |
accumUpdates() |
abstract static R |
apply(T1 v1,
T2 v2,
T3 v3) |
String |
execId() |
scala.collection.Map<scala.Tuple2<Object,Object>,org.apache.spark.executor.ExecutorMetrics> |
executorUpdates() |
static String |
toString() |
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
logEvent
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)
public abstract static R apply(T1 v1, T2 v2, T3 v3)
public static String toString()
public String execId()
public scala.collection.Seq<scala.Tuple4<Object,Object,Object,scala.collection.Seq<AccumulableInfo>>> accumUpdates()
public scala.collection.Map<scala.Tuple2<Object,Object>,org.apache.spark.executor.ExecutorMetrics> executorUpdates()