Skip to content

Commit

Permalink
[SPARK-13138][SQL] Add "logical" package prefix for ddl.scala
Browse files Browse the repository at this point in the history
  • Loading branch information
rxin committed Feb 2, 2016
1 parent 0df3cfb commit 6feb205
Showing 1 changed file with 7 additions and 6 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,8 @@ package org.apache.spark.sql.execution.datasources
import org.apache.spark.sql.{DataFrame, Row, SaveMode, SQLContext}
import org.apache.spark.sql.catalyst.TableIdentifier
import org.apache.spark.sql.catalyst.expressions.{Attribute, AttributeReference}
import org.apache.spark.sql.catalyst.plans.logical._
import org.apache.spark.sql.catalyst.plans.logical
import org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
import org.apache.spark.sql.execution.RunnableCommand
import org.apache.spark.sql.types._

Expand All @@ -32,7 +33,7 @@ import org.apache.spark.sql.types._
*/
case class DescribeCommand(
table: LogicalPlan,
isExtended: Boolean) extends LogicalPlan with Command {
isExtended: Boolean) extends LogicalPlan with logical.Command {

override def children: Seq[LogicalPlan] = Seq.empty

Expand All @@ -59,16 +60,16 @@ case class CreateTableUsing(
temporary: Boolean,
options: Map[String, String],
allowExisting: Boolean,
managedIfNoPath: Boolean) extends LogicalPlan with Command {
managedIfNoPath: Boolean) extends LogicalPlan with logical.Command {

override def output: Seq[Attribute] = Seq.empty
override def children: Seq[LogicalPlan] = Seq.empty
}

/**
* A node used to support CTAS statements and saveAsTable for the data source API.
* This node is a [[UnaryNode]] instead of a [[Command]] because we want the analyzer
* can analyze the logical plan that will be used to populate the table.
* This node is a [[logical.UnaryNode]] instead of a [[logical.Command]] because we want the
* analyzer can analyze the logical plan that will be used to populate the table.
* So, [[PreWriteCheck]] can detect cases that are not allowed.
*/
case class CreateTableUsingAsSelect(
Expand All @@ -79,7 +80,7 @@ case class CreateTableUsingAsSelect(
bucketSpec: Option[BucketSpec],
mode: SaveMode,
options: Map[String, String],
child: LogicalPlan) extends UnaryNode {
child: LogicalPlan) extends logical.UnaryNode {
override def output: Seq[Attribute] = Seq.empty[Attribute]
}

Expand Down

0 comments on commit 6feb205

Please sign in to comment.