package columnar
- Alphabetic
- Public
- Protected
Type Members
- final class ColumnDictionary extends Dictionary
- class ColumnStatisticsSchema extends Serializable
- abstract class ColumnarIterator extends Iterator[InternalRow]
An Iterator to walk through the InternalRows from a CachedBatch
- 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
- class DefaultCachedBatchSerializer extends SimpleMetricsCachedBatchSerializer
The default implementation of CachedBatchSerializer.
- case class InMemoryRelation(output: Seq[Attribute], cacheBuilder: CachedRDDBuilder, outputOrdering: Seq[SortOrder]) extends LogicalPlan with LeafNode with MultiInstanceRelation with Product with Serializable
- case class InMemoryTableScanExec(attributes: Seq[Attribute], predicates: Seq[Expression], relation: InMemoryRelation) extends SparkPlan with LeafExecNode with Product with Serializable
- 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.
- class PartitionStatistics extends Serializable
Value Members
- object GenerateColumnAccessor extends CodeGenerator[Seq[DataType], ColumnarIterator] with Logging
Generates bytecode for a ColumnarIterator for columnar cache.
- object InMemoryRelation extends Serializable