Package

org.apache.spark.sql.hive

execution

Permalink

package execution

Visibility
  1. Public
  2. All

Type Members

  1. case class CreateHiveTableAsSelectCommand(tableDesc: CatalogTable, query: LogicalPlan, ignoreIfExists: Boolean) extends LeafNode with RunnableCommand with Product with Serializable

    Permalink

    Create table and insert the query result into it.

    Create table and insert the query result into it.

    tableDesc

    the Table Describe, which may contains serde, storage handler etc.

    query

    the query whose result will be insert into the new relation

    ignoreIfExists

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

  2. case class HiveScriptIOSchema(inputRowFormat: Seq[(String, String)], outputRowFormat: Seq[(String, String)], inputSerdeClass: Option[String], outputSerdeClass: Option[String], inputSerdeProps: Seq[(String, String)], outputSerdeProps: Seq[(String, String)], recordReaderClass: Option[String], recordWriterClass: Option[String], schemaLess: Boolean) extends HiveInspectors with Product with Serializable

    Permalink

    The wrapper class of Hive input and output schema properties

  3. case class InsertIntoHiveTable(table: MetastoreRelation, partition: Map[String, Option[String]], child: SparkPlan, overwrite: Boolean, ifNotExists: Boolean) extends SparkPlan with UnaryExecNode with Product with Serializable

    Permalink
  4. case class ScriptTransformation(input: Seq[Expression], script: String, output: Seq[Attribute], child: SparkPlan, ioschema: HiveScriptIOSchema) extends SparkPlan with UnaryExecNode with Product with Serializable

    Permalink

    Transforms the input by forking and running the specified script.

    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.

Value Members

  1. object HiveScriptIOSchema extends Serializable

    Permalink

Ungrouped