Skip to content

Commit bf6a173

Browse files
committed
addr comments
1 parent ae1d059 commit bf6a173

File tree

4 files changed

+5
-5
lines changed

4 files changed

+5
-5
lines changed

sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/v2/DescribeTableExec.scala

Lines changed: 0 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -31,9 +31,6 @@ case class DescribeTableExec(
3131
table: Table,
3232
isExtended: Boolean) extends V2CommandExec {
3333

34-
35-
override def producedAttributes: AttributeSet = outputSet
36-
3734
private val toRow = {
3835
RowEncoder(StructType.fromAttributes(output)).resolveAndBind().createSerializer()
3936
}

sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/v2/ShowTablePropertiesExec.scala

Lines changed: 0 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -30,8 +30,6 @@ case class ShowTablePropertiesExec(
3030
catalogTable: Table,
3131
propertyKey: Option[String]) extends V2CommandExec {
3232

33-
override def producedAttributes: AttributeSet = AttributeSet(output)
34-
3533
override protected def run(): Seq[InternalRow] = {
3634
import scala.collection.JavaConverters._
3735
val toRow = RowEncoder(schema).resolveAndBind().createSerializer()

sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/v2/V2CommandExec.scala

Lines changed: 4 additions & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -19,6 +19,7 @@ package org.apache.spark.sql.execution.datasources.v2
1919

2020
import org.apache.spark.rdd.RDD
2121
import org.apache.spark.sql.catalyst.InternalRow
22+
import org.apache.spark.sql.catalyst.expressions.AttributeSet
2223
import org.apache.spark.sql.execution.SparkPlan
2324

2425
/**
@@ -55,4 +56,7 @@ abstract class V2CommandExec extends SparkPlan {
5556
}
5657

5758
override def children: Seq[SparkPlan] = Nil
59+
60+
override def producedAttributes: AttributeSet = outputSet
61+
5862
}

sql/core/src/test/scala/org/apache/spark/sql/CharVarcharTestSuite.scala

Lines changed: 1 addition & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -612,6 +612,7 @@ class FileSourceCharVarcharTestSuite extends CharVarcharTestSuite with SharedSpa
612612
}
613613
}
614614

615+
// TODO: Move this test to super after SPARK-33875 implements DESCRIBE COLUMN for v2
615616
test("DESCRIBE COLUMN w/ char/varchar") {
616617
withTable("t") {
617618
sql(s"CREATE TABLE t(v VARCHAR(3), c CHAR(5)) USING $format")

0 commit comments

Comments
 (0)