org.apache.spark.sql.execution.ui

SQLHistoryListener

class SQLHistoryListener extends SQLListener

A SQLListener for rendering the SQL UI in the history server.

Linear Supertypes
SQLListener, Logging, SparkListener, SparkListenerInterface, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. SQLHistoryListener
  2. SQLListener
  3. Logging
  4. SparkListener
  5. SparkListenerInterface
  6. AnyRef
  7. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SQLHistoryListener(conf: SparkConf, sparkUI: SparkUI)

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  8. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  9. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  10. def executionIdToData: Map[Long, SQLExecutionUIData]

    Definition Classes
    SQLListener
  11. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  12. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  13. def getCompletedExecutions: Seq[SQLExecutionUIData]

    Definition Classes
    SQLListener
  14. def getExecution(executionId: Long): Option[SQLExecutionUIData]

    Definition Classes
    SQLListener
  15. def getExecutionMetrics(executionId: Long): Map[Long, String]

    Get all accumulator updates from all tasks which belong to this execution and merge them.

    Get all accumulator updates from all tasks which belong to this execution and merge them.

    Definition Classes
    SQLListener
  16. def getFailedExecutions: Seq[SQLExecutionUIData]

    Definition Classes
    SQLListener
  17. def getRunningExecutions: Seq[SQLExecutionUIData]

    Definition Classes
    SQLListener
  18. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  19. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Attributes
    protected
    Definition Classes
    Logging
  20. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  21. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  22. def jobIdToExecutionId: Map[Long, Long]

    Definition Classes
    SQLListener
  23. def log: Logger

    Attributes
    protected
    Definition Classes
    Logging
  24. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  25. def logDebug(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  26. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  27. def logError(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  28. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  29. def logInfo(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  30. def logName: String

    Attributes
    protected
    Definition Classes
    Logging
  31. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  32. def logTrace(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  33. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  34. def logWarning(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  35. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  36. final def notify(): Unit

    Definition Classes
    AnyRef
  37. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  38. def onApplicationEnd(applicationEnd: SparkListenerApplicationEnd): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  39. def onApplicationStart(applicationStart: SparkListenerApplicationStart): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  40. def onBlockManagerAdded(blockManagerAdded: SparkListenerBlockManagerAdded): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  41. def onBlockManagerRemoved(blockManagerRemoved: SparkListenerBlockManagerRemoved): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  42. def onBlockUpdated(blockUpdated: SparkListenerBlockUpdated): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  43. def onEnvironmentUpdate(environmentUpdate: SparkListenerEnvironmentUpdate): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  44. def onExecutorAdded(executorAdded: SparkListenerExecutorAdded): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  45. def onExecutorBlacklisted(executorBlacklisted: SparkListenerExecutorBlacklisted): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  46. def onExecutorMetricsUpdate(u: SparkListenerExecutorMetricsUpdate): Unit

    Definition Classes
    SQLHistoryListenerSQLListener → SparkListener → SparkListenerInterface
  47. def onExecutorRemoved(executorRemoved: SparkListenerExecutorRemoved): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  48. def onExecutorUnblacklisted(executorUnblacklisted: SparkListenerExecutorUnblacklisted): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  49. def onJobEnd(jobEnd: SparkListenerJobEnd): Unit

    Definition Classes
    SQLListener → SparkListener → SparkListenerInterface
  50. def onJobStart(jobStart: SparkListenerJobStart): Unit

    Definition Classes
    SQLListener → SparkListener → SparkListenerInterface
  51. def onNodeBlacklisted(nodeBlacklisted: SparkListenerNodeBlacklisted): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  52. def onNodeUnblacklisted(nodeUnblacklisted: SparkListenerNodeUnblacklisted): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  53. def onOtherEvent(event: SparkListenerEvent): Unit

    Definition Classes
    SQLHistoryListenerSQLListener → SparkListener → SparkListenerInterface
  54. def onStageCompleted(stageCompleted: SparkListenerStageCompleted): Unit

    Definition Classes
    SQLListener → SparkListener → SparkListenerInterface
  55. def onStageSubmitted(stageSubmitted: SparkListenerStageSubmitted): Unit

    Definition Classes
    SQLListener → SparkListener → SparkListenerInterface
  56. def onTaskEnd(taskEnd: SparkListenerTaskEnd): Unit

    Definition Classes
    SQLHistoryListenerSQLListener → SparkListener → SparkListenerInterface
  57. def onTaskGettingResult(taskGettingResult: SparkListenerTaskGettingResult): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  58. def onTaskStart(taskStart: SparkListenerTaskStart): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  59. def onUnpersistRDD(unpersistRDD: SparkListenerUnpersistRDD): Unit

    Definition Classes
    SparkListener → SparkListenerInterface
  60. def stageIdToStageMetrics: Map[Long, SQLStageMetrics]

    Definition Classes
    SQLListener
  61. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  62. def toString(): String

    Definition Classes
    AnyRef → Any
  63. def updateTaskAccumulatorValues(taskId: Long, stageId: Int, stageAttemptID: Int, _accumulatorUpdates: Seq[AccumulableInfo], finishTask: Boolean): Unit

    Update the accumulator values of a task with the latest metrics for this task.

    Update the accumulator values of a task with the latest metrics for this task. This is called every time we receive an executor heartbeat or when a task finishes.

    Attributes
    protected
    Definition Classes
    SQLListener
  64. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  65. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  66. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from SQLListener

Inherited from Logging

Inherited from SparkListener

Inherited from SparkListenerInterface

Inherited from AnyRef

Inherited from Any

Ungrouped