Package

org.apache.spark.sql.execution.columnar

impl

Permalink

package impl

Visibility
  1. Public
  2. All

Type Members

  1. abstract class BaseColumnFormatRelation extends JDBCAppendableRelation with PartitionedDataSourceScan with RowInsertableRelation with MutableRelation

    Permalink

    This class acts as a DataSource provider for column format tables provided Snappy.

    This class acts as a DataSource provider for column format tables provided Snappy. It uses GemFireXD as actual datastore to physically locate the tables. Column tables can be used for storing data in columnar compressed format. A example usage is given below.

    val data = Seq(Seq(1, 2, 3), Seq(7, 8, 9), Seq(9, 2, 3), Seq(4, 2, 3), Seq(5, 6, 7)) val rdd = sc.parallelize(data, data.length).map(s => new Data(s(0), s(1), s(2))) val dataDF = snc.createDataFrame(rdd) snc.createTable(tableName, "column", dataDF.schema, props) dataDF.write.insertInto(tableName)

    This provider scans underlying tables in parallel and is aware of the data partition. It does not introduces a shuffle if simple table query is fired. One can insert a single or multiple rows into this table as well as do a bulk insert by a Spark DataFrame. Bulk insert example is shown above.

  2. abstract class ClusteredColumnIterator extends CloseableIterator[RegionEntry]

    Permalink

    Base trait for iterators that are capable of reading and returning the entire set of columns of a column batch.

    Base trait for iterators that are capable of reading and returning the entire set of columns of a column batch. These can be local region iterators or those fetching entries from remote nodes.

  3. final class ColumnDelta extends ColumnFormatValue with Delta

    Permalink

    Encapsulates a delta for update to be applied to column table and also is stored in the region.

    Encapsulates a delta for update to be applied to column table and also is stored in the region. The key for a delta is a negative columnIndex evaluated as (ColumnFormatEntry.DELTA_STATROW_COL_INDEX - 1 + MAX_DEPTH * -columnIndex) where columnIndex is the 0-based index of the underlying table column.

    Note that this delta is for carrying the delta update and applying on existing delta, if any, while the actual value that is stored in the region is a ColumnFormatValue. This is to ensure clean working of the delta mechanism where store-layer code checks the type of object for Delta and makes assumptions about it (like it being a temporary value that should not go into region etc).

    For a description of column delta format see the class comments in org.apache.spark.sql.execution.columnar.encoding.ColumnDeltaEncoder.

  4. final class ColumnFormatEncoder extends RowEncoder

    Permalink

    A RowEncoder implementation for ColumnFormatValue and child classes.

  5. final class ColumnFormatIterator extends ClusteredColumnIterator with DiskRegionIterator

    Permalink

    A customized iterator for column store tables that projects out the required columns and returns those column batches first that have all their columns in the memory.

    A customized iterator for column store tables that projects out the required columns and returns those column batches first that have all their columns in the memory. Further this will make use of DiskBlockSortManager to allow for concurrent partition iterators to do cross-partition disk block sorting and fault-in for best disk read performance (SNAP-2012).

  6. final class ColumnFormatKey extends GfxdDataSerializable with ColumnBatchKey with RegionKey with Serializable

    Permalink

    Key object in the column store.

  7. class ColumnFormatRelation extends BaseColumnFormatRelation with ParentRelation with DependentRelation with BulkPutRelation

    Permalink
  8. class ColumnFormatValue extends SerializedDiskBuffer with GfxdSerializable with Sizeable

    Permalink

    Value object in the column store simply encapsulates binary data as a ByteBuffer.

    Value object in the column store simply encapsulates binary data as a ByteBuffer. This can be either a direct buffer or a heap buffer depending on the system off-heap configuration. The reason for a separate type is to easily store data off-heap without any major changes to engine otherwise as well as efficiently serialize/deserialize them directly to Oplog/socket.

    This class extends SerializedDiskBuffer to avoid a copy when reading/writing from Oplog. Consequently it writes the serialization header itself (typeID + classID + size) into stream as would be written by DataSerializer.writeObject. This helps it avoid additional byte writes when transferring data to the channels.

  9. final class ColumnPartitionResolver extends InternalPartitionResolver[ColumnFormatKey, ColumnFormatValue]

    Permalink

    Partition resolver for the column store.

  10. final class ColumnarStorePartitionedRDD extends RDDKryo[Any] with KryoSerializable

    Permalink
  11. final class DefaultSource extends SchemaRelationProvider with CreatableRelationProvider with DataSourceRegister

    Permalink
  12. class IndexColumnFormatRelation extends BaseColumnFormatRelation with DependentRelation

    Permalink

    Currently this is same as ColumnFormatRelation but has kept it as a separate class to allow adding of any index specific functionality in future.

  13. class JDBCSourceAsColumnarStore extends ExternalStore with KryoSerializable

    Permalink

    Column Store implementation for GemFireXD.

  14. final class RemoteEntriesIterator extends ClusteredColumnIterator

    Permalink

    A ClusteredColumnIterator that fetches entries from a remote bucket.

  15. final class SmartConnectorColumnRDD extends RDDKryo[Any] with KryoSerializable

    Permalink
  16. class SmartConnectorRowRDD extends RowFormatScanRDD

    Permalink
  17. class SnapshotConnectionListener extends TaskCompletionListener

    Permalink
  18. trait StoreCallback extends Serializable

    Permalink

Value Members

  1. object ColumnDelta

    Permalink
  2. object ColumnFormatEntry

    Permalink

    Utility methods for column format storage keys and values.

  3. object ColumnFormatRelation extends Logging with StoreCallback

    Permalink
  4. object StatsFilter extends Predicate[AnyRef] with Serializable

    Permalink
  5. object StoreCallbacksImpl extends StoreCallbacks with Logging with Serializable

    Permalink

Ungrouped