class StageData extends AnyRef
- Source
- api.scala
- Alphabetic
- By Inheritance
- StageData
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- val accumulatorUpdates: Seq[AccumulableInfo]
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- val attemptId: Int
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- val completionTime: Option[Date]
- val description: Option[String]
- val details: String
- val diskBytesSpilled: Long
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- val executorCpuTime: Long
- val executorDeserializeCpuTime: Long
- val executorDeserializeTime: Long
- val executorMetricsDistributions: Option[ExecutorMetricsDistributions]
- val executorRunTime: Long
- val executorSummary: Option[Map[String, ExecutorStageSummary]]
- val failureReason: Option[String]
- val firstTaskLaunchedTime: Option[Date]
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- val inputBytes: Long
- val inputRecords: Long
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- val isShufflePushEnabled: Boolean
- val jvmGcTime: Long
- val killedTasksSummary: Map[String, Int]
- val memoryBytesSpilled: Long
- val name: String
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- val numActiveTasks: Int
- val numCompleteTasks: Int
- val numCompletedIndices: Int
- val numFailedTasks: Int
- val numKilledTasks: Int
- val numTasks: Int
- val outputBytes: Long
- val outputRecords: Long
- val peakExecutionMemory: Long
- val peakExecutorMetrics: Option[ExecutorMetrics]
- val rddIds: Seq[Int]
- val resourceProfileId: Int
- val resultSerializationTime: Long
- val resultSize: Long
- val schedulingPool: String
- val shuffleCorruptMergedBlockChunks: Long
- val shuffleFetchWaitTime: Long
- val shuffleLocalBlocksFetched: Long
- val shuffleLocalBytesRead: Long
- val shuffleMergedFetchFallbackCount: Long
- val shuffleMergedLocalBlocksFetched: Long
- val shuffleMergedLocalBytesRead: Long
- val shuffleMergedLocalChunksFetched: Long
- val shuffleMergedRemoteBlocksFetched: Long
- val shuffleMergedRemoteBytesRead: Long
- val shuffleMergedRemoteChunksFetched: Long
- val shuffleMergedRemoteReqsDuration: Long
- val shuffleMergersCount: Int
- val shuffleReadBytes: Long
- val shuffleReadRecords: Long
- val shuffleRemoteBlocksFetched: Long
- val shuffleRemoteBytesRead: Long
- val shuffleRemoteBytesReadToDisk: Long
- val shuffleRemoteReqsDuration: Long
- val shuffleWriteBytes: Long
- val shuffleWriteRecords: Long
- val shuffleWriteTime: Long
- val speculationSummary: Option[SpeculationStageSummary]
- val stageId: Int
- val status: StageStatus
- val submissionTime: Option[Date]
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- val taskMetricsDistributions: Option[TaskMetricDistributions]
- val tasks: Option[Map[Long, TaskData]]
- def toString(): String
- Definition Classes
- AnyRef → Any
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
Deprecated Value Members
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)