org.apache.spark.sql.execution

datasources

package datasources

Visibility
  1. Public
  2. All

Type Members

  1. class CaseInsensitiveMap extends Map[String, String] with Serializable

    Builds a map in which keys are case insensitive

  2. case class CreateTableUsing(tableIdent: TableIdentifier, userSpecifiedSchema: Option[StructType], provider: String, temporary: Boolean, options: Map[String, String], allowExisting: Boolean, managedIfNoPath: Boolean) extends LogicalPlan with Command with Product with Serializable

    Used to represent the operation of create table using a data source.

  3. case class CreateTableUsingAsSelect(tableIdent: TableIdentifier, provider: String, temporary: Boolean, partitionColumns: Array[String], mode: SaveMode, options: Map[String, String], child: LogicalPlan) extends catalyst.plans.logical.UnaryNode with Product with Serializable

    A node used to support CTAS statements and saveAsTable for the data source API.

  4. case class CreateTempTableUsing(tableIdent: TableIdentifier, userSpecifiedSchema: Option[StructType], provider: String, options: Map[String, String]) extends LogicalPlan with RunnableCommand with Product with Serializable

  5. case class CreateTempTableUsingAsSelect(tableIdent: TableIdentifier, provider: String, partitionColumns: Array[String], mode: SaveMode, options: Map[String, String], query: LogicalPlan) extends LogicalPlan with RunnableCommand with Product with Serializable

  6. class DDLException extends RuntimeException

    The exception thrown from the DDL parser.

  7. class DDLParser extends AbstractSparkSQLParser with DataTypeParser with Logging

    A parser for foreign DDL commands.

  8. case class DescribeCommand(table: LogicalPlan, isExtended: Boolean) extends LogicalPlan with Command with Product with Serializable

    Returned for the "DESCRIBE [EXTENDED] [dbName.

  9. case class LogicalRelation(relation: BaseRelation, expectedOutputAttributes: Option[Seq[Attribute]] = scala.None) extends catalyst.plans.logical.LeafNode with MultiInstanceRelation with Product with Serializable

    Used to link a BaseRelation in to a logical query plan.

  10. case class RefreshTable(tableIdent: TableIdentifier) extends LogicalPlan with RunnableCommand with Product with Serializable

  11. case class ResolvedDataSource(provider: Class[_], relation: BaseRelation) extends Product with Serializable

Value Members

  1. object ResolvedDataSource extends Logging with Serializable

  2. package jdbc

  3. package json

  4. package parquet

  5. package text

Ungrouped