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. final class ColumnBatchCreator extends Logging

    Permalink
  3. class ColumnBatchIterator extends PRValuesIterator[ByteBuffer]

    Permalink
  4. trait ColumnBatchRowsBuffer extends AnyRef

    Permalink
  5. 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) 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.

  6. trait ColumnExec extends SparkPlan with RowExec

    Permalink

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

  7. 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.

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

    Permalink
  9. case class ColumnUpdateExec(child: SparkPlan, columnTable: String, partitionColumns: Seq[String], partitionExpressions: Seq[Expression], numBuckets: Int, isPartitioned: Boolean, tableSchema: StructType, externalStore: ExternalStore, columnRelation: BaseColumnFormatRelation, updateColumns: Seq[Attribute], updateExpressions: Seq[Expression], keyColumns: Seq[Attribute], connProps: ConnectionProperties) 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.

  10. trait ExternalStore extends Serializable with Logging

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

    Permalink

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

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

    Permalink
  13. case class StartsWithForStats(upper: Expression, lower: Expression, pattern: Expression) extends Expression with Product with Serializable

    Permalink

Value Members

  1. object ColumnBatchIterator

    Permalink
  2. object ColumnWriter

    Permalink
  3. object ConnectionType extends Enumeration

    Permalink
  4. object ExternalStoreUtils extends Logging

    Permalink

    Utility methods used by external storage layers.

  5. package impl

    Permalink

Ungrouped