org.apache.spark.sql.hive

execution

package execution

Visibility
  1. Public
  2. All

Type Members

  1. case class AddFile(path: String) extends SparkPlan with LeafNode with Command with Product with Serializable

    :: DeveloperApi ::

    :: DeveloperApi ::

    Annotations
    @DeveloperApi()
  2. case class AddJar(path: String) extends SparkPlan with LeafNode with Command with Product with Serializable

    :: DeveloperApi ::

    :: DeveloperApi ::

    Annotations
    @DeveloperApi()
  3. case class AnalyzeTable(tableName: String) extends SparkPlan with LeafNode with Command with Product with Serializable

    :: DeveloperApi :: Analyzes the given table in the current database to generate statistics, which will be used in query optimizations.

    :: DeveloperApi :: Analyzes the given table in the current database to generate statistics, which will be used in query optimizations.

    Right now, it only supports Hive tables and it only updates the size of a Hive table in the Hive metastore.

    Annotations
    @DeveloperApi()
  4. case class CreateTableAsSelect(database: String, tableName: String, query: LogicalPlan, allowExisting: Boolean, desc: Option[CreateTableDesc]) extends SparkPlan with LeafNode with Command with Product with Serializable

    :: Experimental :: Create table and insert the query result into it.

    :: Experimental :: Create table and insert the query result into it.

    database

    the database name of the new relation

    tableName

    the table name of the new relation

    query

    the query whose result will be insert into the new relation

    allowExisting

    allow continue working if it's already exists, otherwise raise exception

    desc

    the CreateTableDesc, which may contains serde, storage handler etc.

    Annotations
    @Experimental()
  5. case class DescribeHiveTableCommand(table: MetastoreRelation, output: Seq[Attribute], isExtended: Boolean)(context: HiveContext) extends SparkPlan with LeafNode with Command with Product with Serializable

    Implementation for "describe [extended] table".

    Implementation for "describe [extended] table".

    :: DeveloperApi ::

    Annotations
    @DeveloperApi()
  6. case class DropTable(tableName: String, ifExists: Boolean) extends SparkPlan with LeafNode with Command with Product with Serializable

    :: DeveloperApi :: Drops a table from the metastore and removes it if it is cached.

    :: DeveloperApi :: Drops a table from the metastore and removes it if it is cached.

    Annotations
    @DeveloperApi()
  7. case class HiveTableScan(requestedAttributes: Seq[Attribute], relation: MetastoreRelation, partitionPruningPred: Option[Expression])(context: HiveContext) extends SparkPlan with LeafNode with Product with Serializable

    :: DeveloperApi :: The Hive table scan operator.

    :: DeveloperApi :: The Hive table scan operator. Column and partition pruning are both handled.

    requestedAttributes

    Attributes to be fetched from the Hive table.

    relation

    The Hive table be be scanned.

    partitionPruningPred

    An optional partition pruning predicate for partitioned table.

    Annotations
    @DeveloperApi()
  8. case class InsertIntoHiveTable(table: MetastoreRelation, partition: Map[String, Option[String]], child: SparkPlan, overwrite: Boolean)(sc: HiveContext) extends SparkPlan with UnaryNode with Command with HiveInspectors with Product with Serializable

    :: DeveloperApi ::

    :: DeveloperApi ::

    Annotations
    @DeveloperApi()
  9. case class NativeCommand(sql: String, output: Seq[Attribute])(context: HiveContext) extends SparkPlan with LeafNode with Command with Product with Serializable

    :: DeveloperApi ::

    :: DeveloperApi ::

    Annotations
    @DeveloperApi()
  10. case class ScriptTransformation(input: Seq[Expression], script: String, output: Seq[Attribute], child: SparkPlan)(sc: HiveContext) extends SparkPlan with UnaryNode with Product with Serializable

    :: DeveloperApi :: Transforms the input by forking and running the specified script.

    :: DeveloperApi :: Transforms the input by forking and running the specified script.

    input

    the set of expression that should be passed to the script.

    script

    the command that should be executed.

    output

    the attributes that are produced by the script.

    Annotations
    @DeveloperApi()

Ungrouped