File tree Expand file tree Collapse file tree 2 files changed +5
-5
lines changed
sql/core/src/main/scala/org/apache/spark/sql Expand file tree Collapse file tree 2 files changed +5
-5
lines changed Original file line number Diff line number Diff line change @@ -252,9 +252,9 @@ final class DataFrameWriter[T] private[sql](ds: Dataset[T]) {
252
252
f.fallBackFileFormat
253
253
case _ => lookupCls
254
254
}
255
- // SPARK-26673: In Data Source V2 project, partitioning is still under development.
256
- // Here we fallback to V1 if the write path if output partitioning is required.
257
- // TODO: use V2 implementations when partitioning feature is supported.
255
+ // In Data Source V2 project, partitioning is still under development.
256
+ // Here we fallback to V1 if the write path if output partitioning is required.
257
+ // TODO(SPARK-26778) : use V2 implementations when partitioning feature is supported.
258
258
if (classOf [TableProvider ].isAssignableFrom(cls) && partitioningColumns.isEmpty) {
259
259
val provider = cls.getConstructor().newInstance().asInstanceOf [TableProvider ]
260
260
val sessionOptions = DataSourceV2Utils .extractSessionConfigs(
Original file line number Diff line number Diff line change @@ -28,8 +28,8 @@ import org.apache.spark.sql.execution.datasources.v2.orc.OrcTable
28
28
* Replace the ORC V2 data source of table in [[InsertIntoTable ]] to V1 [[FileFormat ]].
29
29
* E.g, with temporary view `t` using [[FileDataSourceV2 ]], inserting into view `t` fails
30
30
* since there is no corresponding physical plan.
31
- * SPARK-23817: This is a temporary hack for making current data source V2 work. It should be
32
- * removed when Catalog of file data source v2 is finished.
31
+ * This is a temporary hack for making current data source V2 work. It should be
32
+ * removed when Catalog support of file data source v2 is finished.
33
33
*/
34
34
class FallbackOrcDataSourceV2 (sparkSession : SparkSession ) extends Rule [LogicalPlan ] {
35
35
override def apply (plan : LogicalPlan ): LogicalPlan = plan resolveOperators {
You can’t perform that action at this time.
0 commit comments