org.apache.spark.sql

execution

package execution

The physical execution component of Spark SQL. Note that this is a private package. All classes in catalyst are considered an internal API to Spark SQL and are subject to change between minor releases.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. execution
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. case class AppendColumnsExec(func: (Any) ⇒ Any, deserializer: Expression, serializer: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryExecNode with Product with Serializable

    Applies the given function to each input row, appending the encoded result at the end of the row.

  2. case class AppendColumnsWithObjectExec(func: (Any) ⇒ Any, inputSerializer: Seq[NamedExpression], newColumnsSerializer: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with ObjectConsumerExec with Product with Serializable

    An optimized version of AppendColumnsExec, that can be executed on deserialized object directly.

  3. trait BaseLimitExec extends SparkPlan with UnaryExecNode with CodegenSupport

    Helper trait which defines methods that are shared by both LocalLimitExec and GlobalLimitExec.

  4. trait BinaryExecNode extends SparkPlan

  5. abstract class BufferedRowIterator extends AnyRef

  6. class CacheManager extends Logging

    Provides support in a SQLContext for caching query results and automatically using these cached results when subsequent queries are executed.

  7. case class CachedData(plan: LogicalPlan, cachedRepresentation: InMemoryRelation) extends Product with Serializable

    Holds a cached logical plan and its data

  8. case class CoGroupExec(func: (Any, Iterator[Any], Iterator[Any]) ⇒ TraversableOnce[Any], keyDeserializer: Expression, leftDeserializer: Expression, rightDeserializer: Expression, leftGroup: Seq[Attribute], rightGroup: Seq[Attribute], leftAttr: Seq[Attribute], rightAttr: Seq[Attribute], outputObjAttr: Attribute, left: SparkPlan, right: SparkPlan) extends SparkPlan with BinaryExecNode with ObjectProducerExec with Product with Serializable

    Co-groups the data from left and right children, and calls the function with each group and 2 iterators containing all elements in the group from left and right side.

  9. class CoGroupedIterator extends Iterator[(InternalRow, Iterator[InternalRow], Iterator[InternalRow])]

    Iterates over GroupedIterators and returns the cogrouped data, i.

  10. case class CoalesceExec(numPartitions: Int, child: SparkPlan) extends SparkPlan with UnaryExecNode with Product with Serializable

    Physical plan for returning a new RDD that has exactly numPartitions partitions.

  11. class CoalescedPartitioner extends Partitioner

    A Partitioner that might group together one or more partitions from the parent.

  12. trait CodegenSupport extends SparkPlan

    An interface for those physical operators that support codegen.

  13. case class CollapseCodegenStages(conf: SQLConf) extends Rule[SparkPlan] with Product with Serializable

    Find the chained plans that support codegen, collapse them together as WholeStageCodegen.

  14. case class CollectLimitExec(limit: Int, child: SparkPlan) extends SparkPlan with UnaryExecNode with Product with Serializable

    Take the first limit elements and collect them to a single partition.

  15. trait DataSourceScanExec extends SparkPlan with LeafExecNode with CodegenSupport

  16. case class DeserializeToObjectExec(deserializer: Expression, outputObjAttr: Attribute, child: SparkPlan) extends SparkPlan with UnaryExecNode with ObjectProducerExec with CodegenSupport with Product with Serializable

    Takes the input row from child and turns it into object using the given deserializer expression.

  17. abstract class ExecSubqueryExpression extends PlanExpression[SubqueryExec]

    The base class for subquery that is used in SparkPlan.

  18. case class ExpandExec(projections: Seq[Seq[Expression]], output: Seq[Attribute], child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

    Apply all of the GroupExpressions to every input row, hence we will get multiple output rows for an input row.

  19. case class ExternalRDD[T](outputObjAttr: Attribute, rdd: RDD[T])(session: SparkSession) extends LeafNode with ObjectProducer with MultiInstanceRelation with Product with Serializable

    Logical plan node for scanning data from an RDD.

  20. case class ExternalRDDScanExec[T](outputObjAttr: Attribute, rdd: RDD[T]) extends SparkPlan with LeafExecNode with ObjectProducerExec with Product with Serializable

    Physical plan node for scanning data from an RDD.

  21. trait FileRelation extends AnyRef

    An interface for relations that are backed by files.

  22. case class FileSourceScanExec(relation: HadoopFsRelation, output: Seq[Attribute], requiredSchema: StructType, partitionFilters: Seq[Expression], dataFilters: Seq[Expression], metastoreTableIdentifier: Option[TableIdentifier]) extends SparkPlan with DataSourceScanExec with ColumnarBatchScan with Product with Serializable

    Physical plan node for scanning data from HadoopFsRelations.

  23. case class FilterExec(condition: Expression, child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with PredicateHelper with Product with Serializable

    Physical plan for Filter.

  24. case class FlatMapGroupsInRExec(func: Array[Byte], packageNames: Array[Byte], broadcastVars: Array[Broadcast[AnyRef]], inputSchema: StructType, outputSchema: StructType, keyDeserializer: Expression, valueDeserializer: Expression, groupingAttributes: Seq[Attribute], dataAttributes: Seq[Attribute], outputObjAttr: Attribute, child: SparkPlan) extends SparkPlan with UnaryExecNode with ObjectProducerExec with Product with Serializable

    Groups the input rows together and calls the R function with each group and an iterator containing all elements in the group.

  25. case class GenerateExec(generator: Generator, join: Boolean, outer: Boolean, generatorOutput: Seq[Attribute], child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

    Applies a Generator to a stream of input rows, combining the output of each into a new stream of rows.

  26. case class GlobalLimitExec(limit: Int, child: SparkPlan) extends SparkPlan with BaseLimitExec with Product with Serializable

    Take the first limit elements of the child's single output partition.

  27. class GroupedIterator extends Iterator[(InternalRow, Iterator[InternalRow])]

    Iterates over a presorted set of rows, chunking it up by the grouping expression.

  28. case class InSubquery(child: Expression, plan: SubqueryExec, exprId: ExprId, result: Array[Any] = null, updated: Boolean = false) extends ExecSubqueryExpression with Product with Serializable

    A subquery that will check the value of child whether is in the result of a query or not.

  29. case class InputAdapter(child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

    InputAdapter is used to hide a SparkPlan from a subtree that support codegen.

  30. trait LeafExecNode extends SparkPlan

  31. case class LocalLimitExec(limit: Int, child: SparkPlan) extends SparkPlan with BaseLimitExec with Product with Serializable

    Take the first limit elements of each child partition, but do not collect or shuffle them.

  32. case class LocalTableScanExec(output: Seq[Attribute], rows: Seq[InternalRow]) extends SparkPlan with LeafExecNode with Product with Serializable

    Physical plan node for scanning data from a local collection.

  33. case class LogicalRDD(output: Seq[Attribute], rdd: RDD[InternalRow], outputPartitioning: Partitioning = ..., outputOrdering: Seq[SortOrder] = immutable.this.Nil)(session: SparkSession) extends LeafNode with MultiInstanceRelation with Product with Serializable

    Logical plan node for scanning data from an RDD of InternalRow.

  34. case class MapElementsExec(func: AnyRef, outputObjAttr: Attribute, child: SparkPlan) extends SparkPlan with ObjectConsumerExec with ObjectProducerExec with CodegenSupport with Product with Serializable

    Applies the given function to each input object.

  35. case class MapGroupsExec(func: (Any, Iterator[Any]) ⇒ TraversableOnce[Any], keyDeserializer: Expression, valueDeserializer: Expression, groupingAttributes: Seq[Attribute], dataAttributes: Seq[Attribute], outputObjAttr: Attribute, child: SparkPlan) extends SparkPlan with UnaryExecNode with ObjectProducerExec with Product with Serializable

    Groups the input rows together and calls the function with each group and an iterator containing all elements in the group.

  36. case class MapPartitionsExec(func: (Iterator[Any]) ⇒ Iterator[Any], outputObjAttr: Attribute, child: SparkPlan) extends SparkPlan with ObjectConsumerExec with ObjectProducerExec with Product with Serializable

    Applies the given function to input object iterator.

  37. trait ObjectConsumerExec extends SparkPlan with UnaryExecNode

    Physical version of ObjectConsumer.

  38. trait ObjectProducerExec extends SparkPlan

    Physical version of ObjectProducer.

  39. case class OptimizeMetadataOnlyQuery(catalog: SessionCatalog, conf: SQLConf) extends Rule[LogicalPlan] with Product with Serializable

    This rule optimizes the execution of queries that can be answered by looking only at partition-level metadata.

  40. case class OutputFakerExec(output: Seq[Attribute], child: SparkPlan) extends SparkPlan with Product with Serializable

    A plan node that does nothing but lie about the output of its child.

  41. case class PlanLater(plan: LogicalPlan) extends SparkPlan with LeafExecNode with Product with Serializable

  42. case class PlanSubqueries(sparkSession: SparkSession) extends Rule[SparkPlan] with Product with Serializable

    Plans scalar subqueries from that are present in the given SparkPlan.

  43. case class ProjectExec(projectList: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

    Physical plan for Project.

  44. class QueryExecution extends AnyRef

    The primary workflow for executing relational queries using Spark.

  45. class QueryExecutionException extends Exception

  46. case class RDDScanExec(output: Seq[Attribute], rdd: RDD[InternalRow], nodeName: String, outputPartitioning: Partitioning = ..., outputOrdering: Seq[SortOrder] = immutable.this.Nil) extends SparkPlan with LeafExecNode with Product with Serializable

    Physical plan node for scanning data from an RDD of InternalRow.

  47. case class RangeExec(range: Range) extends SparkPlan with LeafExecNode with CodegenSupport with Product with Serializable

    Physical plan for range (generating a range of 64 bit numbers).

  48. case class ReuseSubquery(conf: SQLConf) extends Rule[SparkPlan] with Product with Serializable

    Find out duplicated subqueries in the spark plan, then use the same subquery result for all the references.

  49. case class RowDataSourceScanExec(output: Seq[Attribute], rdd: RDD[InternalRow], relation: BaseRelation, outputPartitioning: Partitioning, metadata: Map[String, String], metastoreTableIdentifier: Option[TableIdentifier]) extends SparkPlan with DataSourceScanExec with Product with Serializable

    Physical plan node for scanning data from a relation.

  50. abstract class RowIterator extends AnyRef

    An internal iterator interface which presents a more restrictive API than scala.collection.Iterator.

  51. case class SampleExec(lowerBound: Double, upperBound: Double, withReplacement: Boolean, seed: Long, child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

    Physical plan for sampling the dataset.

  52. case class ScalarSubquery(plan: SubqueryExec, exprId: ExprId) extends ExecSubqueryExpression with Product with Serializable

    A subquery that will return only one row and one column.

  53. case class SerializeFromObjectExec(serializer: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with ObjectConsumerExec with CodegenSupport with Product with Serializable

    Takes the input object from child and turns in into unsafe row using the given serializer expression.

  54. class ShuffledRowRDD extends RDD[InternalRow]

    This is a specialized version of org.apache.spark.rdd.ShuffledRDD that is optimized for shuffling rows instead of Java key-value pairs.

  55. case class SortExec(sortOrder: Seq[SortOrder], global: Boolean, child: SparkPlan, testSpillFrequency: Int = 0) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

    Performs (external) sorting.

  56. class SparkOptimizer extends Optimizer

  57. abstract class SparkPlan extends QueryPlan[SparkPlan] with Logging with Serializable

    The base class for physical operators.

  58. class SparkPlanInfo extends AnyRef

    :: DeveloperApi :: Stores information about a SQL SparkPlan.

  59. class SparkPlanner extends SparkStrategies

  60. class SparkSqlAstBuilder extends AstBuilder

    Builder that converts an ANTLR ParseTree into a LogicalPlan/Expression/TableIdentifier.

  61. class SparkSqlParser extends AbstractSqlParser

    Concrete parser for Spark SQL statements.

  62. abstract class SparkStrategies extends QueryPlanner[SparkPlan]

  63. abstract class SparkStrategy extends GenericStrategy[SparkPlan]

    Converts a logical plan into zero or more SparkPlans.

  64. case class SubqueryExec(name: String, child: SparkPlan) extends SparkPlan with UnaryExecNode with Product with Serializable

    Physical plan for a subquery.

  65. case class TakeOrderedAndProjectExec(limit: Int, sortOrder: Seq[SortOrder], projectList: Seq[NamedExpression], child: SparkPlan) extends SparkPlan with UnaryExecNode with Product with Serializable

    Take the first limit elements as defined by the sortOrder, and do projection if needed.

  66. trait UnaryExecNode extends SparkPlan

  67. case class UnionExec(children: Seq[SparkPlan]) extends SparkPlan with Product with Serializable

    Physical plan for unioning two plans, without a distinct.

  68. final class UnsafeFixedWidthAggregationMap extends AnyRef

  69. final class UnsafeKVExternalSorter extends AnyRef

  70. class UnsafeRowSerializer extends Serializer with Serializable

    Serializer for serializing UnsafeRows during shuffle.

  71. case class WholeStageCodegenExec(child: SparkPlan) extends SparkPlan with UnaryExecNode with CodegenSupport with Product with Serializable

    WholeStageCodegen compile a subtree of plans that support codegen together into single Java function.

Value Members

  1. object ExternalRDD extends Serializable

  2. object GroupedIterator

  3. object MapGroupsExec extends Serializable

  4. object ObjectOperator

    Helper functions for physical operators that work with user defined objects.

  5. object RDDConversions

  6. object RowIterator

  7. object SQLExecution

  8. object SortPrefixUtils

  9. object SparkPlan extends Serializable

  10. object SubqueryExec extends Serializable

  11. object UnaryExecNode extends Serializable

  12. object WholeStageCodegenExec extends Serializable

  13. package aggregate

  14. package columnar

  15. package command

  16. package datasources

  17. package debug

    Contains methods for debugging query execution.

  18. package exchange

  19. package joins

    Physical execution operators for join operations.

  20. package metric

  21. package python

  22. package r

  23. package stat

  24. package streaming

  25. package ui

  26. package vectorized

  27. package window

Inherited from AnyRef

Inherited from Any

Ungrouped