public class Heartbeat
extends Object
implements scala.Product, scala.Serializable
Constructor and Description |
---|
Heartbeat(String executorId,
scala.Tuple2<Object,org.apache.spark.executor.TaskMetrics>[] taskMetrics,
BlockManagerId blockManagerId) |
Modifier and Type | Method and Description |
---|---|
BlockManagerId |
blockManagerId() |
String |
executorId() |
scala.Tuple2<Object,org.apache.spark.executor.TaskMetrics>[] |
taskMetrics() |
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
public Heartbeat(String executorId, scala.Tuple2<Object,org.apache.spark.executor.TaskMetrics>[] taskMetrics, BlockManagerId blockManagerId)
public String executorId()
public scala.Tuple2<Object,org.apache.spark.executor.TaskMetrics>[] taskMetrics()
public BlockManagerId blockManagerId()