Packages

package columnar

Ordering
  1. Alphabetic
Visibility
  1. Public
  2. All

Type Members

  1. final class ColumnDictionary extends Dictionary
  2. class ColumnStatisticsSchema extends Serializable
  3. abstract class ColumnarIterator extends Iterator[InternalRow]

    An Iterator to walk through the InternalRows from a CachedBatch

  4. case class DefaultCachedBatch(numRows: Int, buffers: Array[Array[Byte]], stats: InternalRow) extends SimpleMetricsCachedBatch with Product with Serializable

    The default implementation of CachedBatch.

    The default implementation of CachedBatch.

    numRows

    The total number of rows in this batch

    buffers

    The buffers for serialized columns

    stats

    The stat of columns

  5. class DefaultCachedBatchSerializer extends SimpleMetricsCachedBatchSerializer

    The default implementation of CachedBatchSerializer.

  6. case class InMemoryRelation(output: Seq[Attribute], cacheBuilder: CachedRDDBuilder, outputOrdering: Seq[SortOrder]) extends LeafNode with MultiInstanceRelation with Product with Serializable
  7. case class InMemoryTableScanExec(attributes: Seq[Attribute], predicates: Seq[Expression], relation: InMemoryRelation) extends SparkPlan with LeafExecNode with Product with Serializable
  8. class MutableUnsafeRow extends InternalRow with BaseGenericInternalRow

    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.

  9. class PartitionStatistics extends Serializable

Value Members

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

    Generates bytecode for a ColumnarIterator for columnar cache.

  2. object InMemoryRelation extends Serializable

Ungrouped