Package

org.apache.spark.sql.execution

ui

Permalink

package ui

Visibility
  1. Public
  2. All

Type Members

  1. class ExecutionPage extends WebUIPage with Logging

    Permalink
  2. class SQLHistoryListener extends SQLListener

    Permalink

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

  3. class SQLHistoryListenerFactory extends SparkHistoryListenerFactory

    Permalink
  4. class SQLListener extends SparkListener with Logging

    Permalink
  5. class SQLTab extends SparkUITab with Logging

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

    Permalink

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

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

    executionId

    The execution id for a query, so we can find the query plan.

    accumUpdates

    Map from accumulator id to the metric value (metrics are always 64-bit ints).

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

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

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

    Permalink

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

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

    Each graph is defined with a set of nodes and a set of edges. Each node represents a node in the SparkPlan tree, and each edge represents a parent-child relationship between two nodes.

Value Members

  1. object SQLTab

    Permalink
  2. object SparkPlanGraph extends Serializable

    Permalink

Ungrouped