package columnar
- Alphabetic
- Public
- All
Type Members
- case class CachedRDDBuilder(useCompression: Boolean, batchSize: Int, storageLevel: StorageLevel, cachedPlan: SparkPlan, tableName: Option[String]) extends Product with Serializable
- final class ColumnDictionary extends Dictionary
-
abstract
class
ColumnarIterator extends Iterator[InternalRow]
An Iterator to walk through the InternalRows from a CachedBatch
- case class InMemoryRelation(output: Seq[Attribute], cacheBuilder: CachedRDDBuilder, outputOrdering: Seq[SortOrder]) extends 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.
Value Members
-
object
GenerateColumnAccessor extends CodeGenerator[Seq[DataType], ColumnarIterator] with Logging
Generates bytecode for a ColumnarIterator for columnar cache.
- object InMemoryRelation extends Serializable