org.apache.spark.sql.hive

execution

package execution

Visibility
  1. Public
  2. All

Type Members

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

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

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

  4. case class HiveTableScan(attributes: Seq[Attribute], relation: MetastoreRelation, partitionPruningPred: Option[Expression])(context: HiveContext) extends SparkPlan with LeafNode with Product with Serializable

    :: DeveloperApi :: The Hive table scan operator.

  5. case class InsertIntoHiveTable(table: MetastoreRelation, partition: Map[String, Option[String]], child: SparkPlan, overwrite: Boolean)(sc: HiveContext) extends SparkPlan with UnaryNode with Product with Serializable

    :: DeveloperApi ::

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

    :: DeveloperApi ::

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

Ungrouped