Package

org.apache.spark.sql.execution

row

Permalink

package row

Visibility
  1. Public
  2. All

Type Members

  1. final class CompactExecRowIteratorOnRS extends ResultSetIterator[AbstractCompactExecRow]

    Permalink
  2. final class CompactExecRowIteratorOnScan extends PRValuesIterator[AbstractCompactExecRow]

    Permalink
  3. final class DefaultSource extends MutableRelationProvider with DataSourceRegister

    Permalink
  4. abstract class PRValuesIterator[T] extends Iterator[T]

    Permalink
  5. final class ResultSetDecoder extends ColumnDecoder

    Permalink

    An adapter for a ResultSet to pose as ColumnEncoding so that the same generated code can be used for both row buffer and column data access.

  6. class ResultSetNullHolder extends ResultWasNull

    Permalink
  7. final class ResultSetTraversal extends ResultSetIterator[Void]

    Permalink

    This does not return any valid results from result set rather caller is expected to explicitly invoke ResultSet.next()/get*.

    This does not return any valid results from result set rather caller is expected to explicitly invoke ResultSet.next()/get*. This is primarily intended to be used for cleanup.

  8. case class RowDeleteExec(child: SparkPlan, resolvedName: String, partitionColumns: Seq[String], partitionExpressions: Seq[Expression], numBuckets: Int, isPartitioned: Boolean, tableSchema: StructType, relation: Option[DestroyRelation], keyColumns: Seq[Attribute], connProps: ConnectionProperties, onExecutor: Boolean) extends SparkPlan with RowExec with Product with Serializable

    Permalink

    Generated code plan for deletes in a row table.

  9. trait RowExec extends SparkPlan with TableExec

    Permalink

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

  10. class RowFormatRelation extends JDBCMutableRelation with PartitionedDataSourceScan with RowPutRelation with ParentRelation with DependentRelation

    Permalink

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

  11. class RowFormatScanRDD extends RDDKryo[Any] with KryoSerializable

    Permalink

    A scanner RDD which is very specific to Snappy store row tables.

    A scanner RDD which is very specific to Snappy store row tables. This scans row tables in parallel unlike Spark's inbuilt JDBCRDD.

  12. case class RowInsertExec(child: SparkPlan, putInto: Boolean, partitionColumns: Seq[String], partitionExpressions: Seq[Expression], numBuckets: Int, isPartitioned: Boolean, tableSchema: StructType, relation: Option[DestroyRelation], onExecutor: Boolean, resolvedName: String, connProps: ConnectionProperties) extends SparkPlan with RowExec with Product with Serializable

    Permalink

    Generated code plan for bulk inserts/puts into a row table.

  13. case class RowUpdateExec(child: SparkPlan, resolvedName: String, partitionColumns: Seq[String], partitionExpressions: Seq[Expression], numBuckets: Int, isPartitioned: Boolean, tableSchema: StructType, relation: Option[DestroyRelation], updateColumns: Seq[Attribute], updateExpressions: Seq[Expression], keyColumns: Seq[Attribute], connProps: ConnectionProperties, onExecutor: Boolean) extends SparkPlan with RowExec with Product with Serializable

    Permalink

    Generated code plan for updates in a row table.

  14. final class UnsafeRowDecoder extends ColumnDecoder

    Permalink
  15. final class UnsafeRowHolder extends AnyRef

    Permalink

Ungrouped