Package

org.apache.spark.sql.execution

local

Permalink

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

    Permalink

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

    A HashJoinNode that builds the HashedRelation according to the value of buildSide. The actual work of this node is defined in HashJoinNode.

  2. abstract class BinaryLocalNode extends LocalNode

    Permalink
  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

    Permalink

    A HashJoinNode for broadcast join.

    A HashJoinNode for broadcast join. It takes a streamedNode and a broadcast HashedRelation. The actual work of this node is defined in HashJoinNode.

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

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

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

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

    Permalink
  8. trait HashJoinNode extends AnyRef

    Permalink

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

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

    Much of this code is similar to org.apache.spark.sql.execution.joins.HashJoin.

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

    Permalink
  10. abstract class LeafLocalNode extends LocalNode

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

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

    Permalink

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

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

    Before consuming the iterator, open function must be called. After consuming the iterator, close function must be called.

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

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

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

    Permalink

    Sample the dataset.

    Sample the dataset.

    conf

    the SQLConf

    lowerBound

    Lower-bound of the sampling probability (usually 0.0)

    upperBound

    Upper-bound of the sampling probability. The expected fraction sampled will be ub - lb.

    withReplacement

    Whether to sample with replacement.

    seed

    the random seed

    child

    the LocalNode

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

    Permalink

    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

    Permalink
  18. abstract class UnaryLocalNode extends LocalNode

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

    Permalink

Ungrouped