org.apache.spark.sql.execution

local

package local

Visibility
  1. Public
  2. All

Type Members

  1. case class BinaryHashJoinNode(conf: SQLConf, leftKeys: Seq[Expression], rightKeys: Seq[Expression], buildSide: BuildSide, left: LocalNode, right: LocalNode) extends BinaryLocalNode with HashJoinNode with Product with Serializable

    A HashJoinNode that builds the HashedRelation according to the value of buildSide.

  2. abstract class BinaryLocalNode extends LocalNode

  3. case class BroadcastHashJoinNode(conf: SQLConf, streamedKeys: Seq[Expression], streamedNode: LocalNode, buildSide: BuildSide, buildOutput: Seq[Attribute], hashedRelation: Broadcast[HashedRelation]) extends UnaryLocalNode with HashJoinNode with Product with Serializable

    A HashJoinNode for broadcast join.

  4. case class ConvertToSafeNode(conf: SQLConf, child: LocalNode) extends UnaryLocalNode with Product with Serializable

  5. case class ConvertToUnsafeNode(conf: SQLConf, child: LocalNode) extends UnaryLocalNode with Product with Serializable

  6. case class ExpandNode(conf: SQLConf, projections: Seq[Seq[Expression]], output: Seq[Attribute], child: LocalNode) extends UnaryLocalNode with Product with Serializable

  7. case class FilterNode(conf: SQLConf, condition: Expression, child: LocalNode) extends UnaryLocalNode with Product with Serializable

  8. trait HashJoinNode extends AnyRef

    An abstract node for sharing common functionality among different implementations of inner hash equi-join, notably BinaryHashJoinNode and BroadcastHashJoinNode.

  9. case class IntersectNode(conf: SQLConf, left: LocalNode, right: LocalNode) extends BinaryLocalNode with Product with Serializable

  10. abstract class LeafLocalNode extends LocalNode

  11. case class LimitNode(conf: SQLConf, limit: Int, child: LocalNode) extends UnaryLocalNode with Product with Serializable

  12. abstract class LocalNode extends QueryPlan[LocalNode] with Logging

    A local physical operator, in the form of an iterator.

  13. case class NestedLoopJoinNode(conf: SQLConf, left: LocalNode, right: LocalNode, buildSide: BuildSide, joinType: JoinType, condition: Option[Expression]) extends BinaryLocalNode with Product with Serializable

  14. case class ProjectNode(conf: SQLConf, projectList: Seq[NamedExpression], child: LocalNode) extends UnaryLocalNode with Product with Serializable

  15. case class SampleNode(conf: SQLConf, lowerBound: Double, upperBound: Double, withReplacement: Boolean, seed: Long, child: LocalNode) extends UnaryLocalNode with Product with Serializable

    Sample the dataset.

  16. case class SeqScanNode(conf: SQLConf, output: Seq[Attribute], data: Seq[InternalRow]) extends LeafLocalNode with Product with Serializable

    An operator that scans some local data collection in the form of Scala Seq.

  17. case class TakeOrderedAndProjectNode(conf: SQLConf, limit: Int, sortOrder: Seq[SortOrder], projectList: Option[Seq[NamedExpression]], child: LocalNode) extends UnaryLocalNode with Product with Serializable

  18. abstract class UnaryLocalNode extends LocalNode

  19. case class UnionNode(conf: SQLConf, children: Seq[LocalNode]) extends LocalNode with Product with Serializable

Ungrouped