You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by GitBox <gi...@apache.org> on 2019/02/16 09:10:23 UTC

[GitHub] cloud-fan commented on a change in pull request #23702: [SPARK-26785][SQL] data source v2 API refactor: streaming write

cloud-fan commented on a change in pull request #23702: [SPARK-26785][SQL] data source v2 API refactor: streaming write
URL: https://github.com/apache/spark/pull/23702#discussion_r257453861
 
 

 ##########
 File path: sql/core/src/main/scala/org/apache/spark/sql/execution/streaming/MicroBatchExecution.scala
 ##########
 @@ -513,13 +514,16 @@ class MicroBatchExecution(
 
     val triggerLogicalPlan = sink match {
       case _: Sink => newAttributePlan
-      case s: StreamingWriteSupportProvider =>
-        val writer = s.createStreamingWriteSupport(
-          s"$runId",
-          newAttributePlan.schema,
-          outputMode,
-          new DataSourceOptions(extraOptions.asJava))
-        WriteToDataSourceV2(new MicroBatchWrite(currentBatchId, writer), newAttributePlan)
+      case s: SupportsStreamingWrite =>
+        // TODO: we should translate OutputMode to concrete write actions like truncate, but
+        // the truncate action is being developed in SPARK-26666.
 
 Review comment:
   I'm not very familiar with streaming internals so I don't know what's the exact semantic of this UPDATE mode.
   
   I believe we can treat it as `SaveMode`: replace it with the new write operators(Append, Truncate, OverwriteByExpression, etc.) and make the semantic clear.
   
   Anyway this is just a TODO comment, we can have more discussion in the PR that address this TODO.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org