diff --git a/sql/core/src/main/scala/org/apache/spark/sql/DataFrameWriter.scala b/sql/core/src/main/scala/org/apache/spark/sql/DataFrameWriter.scala index 2148875ce2817..acdeda9ae32c2 100644 --- a/sql/core/src/main/scala/org/apache/spark/sql/DataFrameWriter.scala +++ b/sql/core/src/main/scala/org/apache/spark/sql/DataFrameWriter.scala @@ -252,9 +252,9 @@ final class DataFrameWriter[T] private[sql](ds: Dataset[T]) { f.fallBackFileFormat case _ => lookupCls } - // SPARK-26673: In Data Source V2 project, partitioning is still under development. - // Here we fallback to V1 if the write path if output partitioning is required. - // TODO: use V2 implementations when partitioning feature is supported. + // In Data Source V2 project, partitioning is still under development. + // Here we fallback to V1 if the write path if output partitioning is required. + // TODO(SPARK-26778): use V2 implementations when partitioning feature is supported. if (classOf[TableProvider].isAssignableFrom(cls) && partitioningColumns.isEmpty) { val provider = cls.getConstructor().newInstance().asInstanceOf[TableProvider] val sessionOptions = DataSourceV2Utils.extractSessionConfigs( diff --git a/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/FallbackOrcDataSourceV2.scala b/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/FallbackOrcDataSourceV2.scala index d22b3d5049c86..254c09001f7ec 100644 --- a/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/FallbackOrcDataSourceV2.scala +++ b/sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/FallbackOrcDataSourceV2.scala @@ -28,8 +28,8 @@ import org.apache.spark.sql.execution.datasources.v2.orc.OrcTable * Replace the ORC V2 data source of table in [[InsertIntoTable]] to V1 [[FileFormat]]. * E.g, with temporary view `t` using [[FileDataSourceV2]], inserting into view `t` fails * since there is no corresponding physical plan. - * SPARK-23817: This is a temporary hack for making current data source V2 work. It should be - * removed when Catalog of file data source v2 is finished. + * This is a temporary hack for making current data source V2 work. It should be + * removed when Catalog support of file data source v2 is finished. */ class FallbackOrcDataSourceV2(sparkSession: SparkSession) extends Rule[LogicalPlan] { override def apply(plan: LogicalPlan): LogicalPlan = plan resolveOperators {