org.apache.spark.sql.execution

ui

package ui

Visibility
  1. Public
  2. All

Type Members

  1. class ExecutionPage extends WebUIPage with Logging

  2. class SQLHistoryListener extends SQLListener

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

  3. class SQLHistoryListenerFactory extends SparkHistoryListenerFactory

  4. class SQLListener extends SparkListener with Logging

  5. class SQLTab extends SparkUITab with Logging

  6. case class SparkListenerDriverAccumUpdates(executionId: Long, accumUpdates: Seq[(Long, Long)]) extends SparkListenerEvent with Product with Serializable

    A message used to update SQL metric value for driver-side updates (which doesn't get reflected automatically).

  7. case class SparkListenerSQLExecutionEnd(executionId: Long, time: Long) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  8. case class SparkListenerSQLExecutionStart(executionId: Long, description: String, details: String, physicalPlanDescription: String, sparkPlanInfo: SparkPlanInfo, time: Long) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  9. case class SparkPlanGraph(nodes: Seq[SparkPlanGraphNode], edges: Seq[SparkPlanGraphEdge]) extends Product with Serializable

    A graph used for storing information of an executionPlan of DataFrame.

Value Members

  1. object SQLTab

  2. object SparkPlanGraph extends Serializable

Ungrouped