Package

org.apache.spark.sql

store

Permalink

package store

Visibility
  1. Public
  2. All

Type Members

  1. class ColumnPartitioner extends Partitioner

    Permalink
  2. trait GeneratedStatement extends AnyRef

    Permalink
  3. trait SerializeComplexType extends AnyRef

    Permalink
  4. final class StoreHashFunction extends AnyRef

    Permalink

    A partitioner that helps store to collocate data with Spark's partitions.

    A partitioner that helps store to collocate data with Spark's partitions. Each store layer hash computation invokes this to get their bucket information.

  5. class StoreInitRDD extends RDD[(InternalDistributedMember, BlockManagerId)]

    Permalink

    This RDD registers a store for each table being created.

Value Members

  1. object CodeGeneration extends internal.Logging

    Permalink

    Utilities to generate code for exchanging data from Spark layer (Row, InternalRow) to store (Statement, ExecRow).

    Utilities to generate code for exchanging data from Spark layer (Row, InternalRow) to store (Statement, ExecRow).

    This is both more efficient and allows better code reuse with the code generation facilities of Spark (esp for complex types like ArrayType).

  2. object MembershipAccumulator extends AccumulatorParam[Map[InternalDistributedMember, BlockManagerId]]

    Permalink
  3. object StoreUtils extends internal.Logging

    Permalink

Ungrouped