Package

org.apache.spark.sql.execution

columnar

Permalink

package columnar

Visibility
  1. Public
  2. All

Type Members

  1. abstract class ColumnarIterator extends Iterator[InternalRow]

    Permalink

    An Iterator to walk through the InternalRows from a CachedBatch

  2. case class InMemoryRelation(output: Seq[Attribute], useCompression: Boolean, batchSize: Int, storageLevel: StorageLevel, child: SparkPlan, tableName: Option[String])(_cachedColumnBuffers: RDD[CachedBatch] = null, batchStats: LongAccumulator = ...) extends LeafNode with MultiInstanceRelation with Product with Serializable

    Permalink
  3. case class InMemoryTableScanExec(attributes: Seq[Attribute], predicates: Seq[Expression], relation: InMemoryRelation) extends SparkPlan with LeafExecNode with Product with Serializable

    Permalink
  4. class MutableUnsafeRow extends GenericMutableRow

    Permalink

    An helper class to update the fields of UnsafeRow, used by ColumnAccessor

    An helper class to update the fields of UnsafeRow, used by ColumnAccessor

    WARNING: These setter MUST be called in increasing order of ordinals.

Value Members

  1. object GenerateColumnAccessor extends CodeGenerator[Seq[DataType], ColumnarIterator] with Logging

    Permalink

    Generates bytecode for a ColumnarIterator for columnar cache.

  2. object InMemoryRelation extends Serializable

    Permalink

Ungrouped