Skip to content

Commit 2b65086

Browse files
committed
code clean
1 parent e6bef7d commit 2b65086

File tree

1 file changed

+1
-18
lines changed
  • sql/core/src/main/scala/org/apache/spark/sql/execution/command

1 file changed

+1
-18
lines changed

sql/core/src/main/scala/org/apache/spark/sql/execution/command/tables.scala

Lines changed: 1 addition & 18 deletions
Original file line numberDiff line numberDiff line change
@@ -33,28 +33,11 @@ import org.apache.spark.sql.catalyst.catalog.{BucketSpec, CatalogTable, CatalogT
3333
import org.apache.spark.sql.catalyst.catalog.CatalogTableType._
3434
import org.apache.spark.sql.catalyst.catalog.CatalogTypes.TablePartitionSpec
3535
import org.apache.spark.sql.catalyst.expressions.{Attribute, AttributeReference}
36-
import org.apache.spark.sql.catalyst.plans.logical.{Command, LogicalPlan, UnaryNode}
3736
import org.apache.spark.sql.catalyst.util.quoteIdentifier
38-
import org.apache.spark.sql.execution.datasources.{PartitioningUtils}
37+
import org.apache.spark.sql.execution.datasources.PartitioningUtils
3938
import org.apache.spark.sql.types._
4039
import org.apache.spark.util.Utils
4140

42-
case class CreateHiveTableAsSelectLogicalPlan(
43-
tableDesc: CatalogTable,
44-
child: LogicalPlan,
45-
allowExisting: Boolean) extends UnaryNode with Command {
46-
47-
override def output: Seq[Attribute] = Seq.empty[Attribute]
48-
49-
override lazy val resolved: Boolean =
50-
tableDesc.identifier.database.isDefined &&
51-
tableDesc.schema.nonEmpty &&
52-
tableDesc.storage.serde.isDefined &&
53-
tableDesc.storage.inputFormat.isDefined &&
54-
tableDesc.storage.outputFormat.isDefined &&
55-
childrenResolved
56-
}
57-
5841
/**
5942
* A command to create a table with the same definition of the given existing table.
6043
*

0 commit comments

Comments
 (0)