Package

org.apache.spark.sql.execution

columnar

Permalink

package columnar

Visibility
  1. Public
  2. All

Type Members

  1. case class CallbackColumnInsert(_schema: StructType) extends SparkPlan with LeafExecNode with CodegenSupportOnExecutor with Product with Serializable

    Permalink

    This class is an adapter over the iterator model as provided by generated code to closure callbacks model as required by StratifiedSampler.append

  2. case class ColumnBatch(numRows: Int, buffers: Array[ByteBuffer], statsData: Array[Byte], deltaIndexes: Array[Int]) extends Product with Serializable

    Permalink
  3. final class ColumnBatchCreator extends Logging

    Permalink
  4. final class ColumnBatchIterator extends PRValuesIterator[ByteBuffer]

    Permalink
  5. final class ColumnBatchIteratorOnRS extends ResultSetIterator[ByteBuffer]

    Permalink
  6. trait ColumnBatchRowsBuffer extends AnyRef

    Permalink
  7. case class ColumnDeleteExec(child: SparkPlan, columnTable: String, partitionColumns: Seq[String], partitionExpressions: Seq[Expression], numBuckets: Int, isPartitioned: Boolean, tableSchema: StructType, externalStore: ExternalStore, appendableRelation: JDBCAppendableRelation, keyColumns: Seq[Attribute], connProps: ConnectionProperties, onExecutor: Boolean) extends SparkPlan with ColumnExec with Product with Serializable

    Permalink

    Generated code plan for deletes into a column table.

    Generated code plan for deletes into a column table. This extends RowExec to generate the combined code for row buffer deletes.

  8. trait ColumnExec extends SparkPlan with RowExec

    Permalink

    Base class for bulk column table insert, update, put, delete operations.

  9. case class ColumnInsertExec(child: SparkPlan, partitionColumns: Seq[String], partitionExpressions: Seq[Expression], numBuckets: Int, isPartitioned: Boolean, relation: Option[DestroyRelation], batchParams: (Int, Int, String), columnTable: String, onExecutor: Boolean, tableSchema: StructType, externalStore: ExternalStore, useMemberVariables: Boolean) extends SparkPlan with TableExec with Product with Serializable

    Permalink

    Generated code plan for bulk insertion into a column table.

  10. case class ColumnPutIntoExec(insertPlan: SparkPlan, updatePlan: SparkPlan) extends SparkPlan with BinaryExecNode with Product with Serializable

    Permalink
  11. case class ColumnUpdateExec(child: SparkPlan, columnTable: String, partitionColumns: Seq[String], partitionExpressions: Seq[Expression], numBuckets: Int, isPartitioned: Boolean, tableSchema: StructType, externalStore: ExternalStore, appendableRelation: JDBCAppendableRelation, updateColumns: Seq[Attribute], updateExpressions: Seq[Expression], keyColumns: Seq[Attribute], connProps: ConnectionProperties, onExecutor: Boolean) extends SparkPlan with ColumnExec with Product with Serializable

    Permalink

    Generated code plan for updates into a column table.

    Generated code plan for updates into a column table. This extends RowExec to generate the combined code for row buffer updates.

  12. trait ConnectedExternalStore extends ExternalStore

    Permalink
  13. trait ExternalStore extends Serializable with Logging

    Permalink
  14. abstract case class JDBCAppendableRelation(table: String, provider: String, mode: SaveMode, schema: StructType, origOptions: Map[String, String], externalStore: ExternalStore, sqlContext: SQLContext) extends BaseRelation with PrunedUnsafeFilteredScan with InsertableRelation with PlanInsertableRelation with DestroyRelation with IndexableRelation with Logging with Serializable with Product

    Permalink

    A LogicalPlan implementation for an external column table whose contents are retrieved using a JDBC URL or DataSource.

  15. case class NumBatchRows(varName: String) extends LeafExpression with Product with Serializable

    Permalink
  16. abstract class ResultSetIterator[A] extends Iterator[A] with Logging

    Permalink

Value Members

  1. object ColumnBatchIterator

    Permalink
  2. object ColumnWriter

    Permalink
  3. object ConnectionType extends Enumeration

    Permalink
  4. object ExternalStoreUtils

    Permalink

    Utility methods used by external storage layers.

  5. package encoding

    Permalink
  6. package impl

    Permalink

Ungrouped