org.apache.spark.sql.hive

execution

package execution

Visibility
  1. Public
  2. All

Type Members

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

    :: DeveloperApi :: The Hive table scan operator.

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

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