Package

org.apache.spark.sql.execution

columnar

Permalink

package columnar

Visibility
  1. Public
  2. All

Type Members

  1. final class ByteArraysIteratorOnScan extends PRValuesIterator[Array[Array[Byte]]]

    Permalink
  2. final class CachedBatchCreator extends CompactExecRowToMutableRow

    Permalink
  3. final class CachedBatchIteratorOnRS extends ResultSetIterator[CachedBatch]

    Permalink
  4. class ColumnarRelationProvider extends SchemaRelationProvider with CreatableRelationProvider

    Permalink
  5. final class DefaultSource extends ColumnarRelationProvider

    Permalink
  6. trait ExternalStore extends Serializable

    Permalink
  7. class ExternalStorePartitionedRDD[T] extends RDD[CachedBatch]

    Permalink
  8. 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 DestroyRelation with IndexableRelation with internal.Logging with Serializable with Product

    Permalink

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

  9. class JDBCSourceAsStore extends ExternalStore

    Permalink
  10. final class OffHeapLobsIteratorOnScan extends PRValuesIterator[OffHeapCompactExecRowWithLobs]

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

    Permalink

Value Members

  1. object ConnectionType extends Enumeration

    Permalink
  2. object ExternalStoreUtils

    Permalink

    Utility methods used by external storage layers.

  3. object JDBCAppendableRelation extends internal.Logging with Serializable

    Permalink
  4. package encoding

    Permalink
  5. package impl

    Permalink

Ungrouped