[GitHub] [spark] brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a v1 fallback writer implementation for v2 data source codepaths

2019-08-20 Thread GitBox
brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a 
v1 fallback writer implementation for v2 data source codepaths
URL: https://github.com/apache/spark/pull/25348#discussion_r315910044
 
 

 ##
 File path: 
sql/core/src/test/scala/org/apache/spark/sql/sources/v2/V1WriteFallbackSuite.scala
 ##
 @@ -0,0 +1,166 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.sources.v2
+
+import java.util
+
+import scala.collection.JavaConverters._
+import scala.collection.mutable
+
+import org.scalatest.BeforeAndAfter
+
+import org.apache.spark.sql.{DataFrame, QueryTest, Row, SparkSession}
+import org.apache.spark.sql.catalog.v2.expressions.{FieldReference, 
IdentityTransform, Transform}
+import org.apache.spark.sql.sources.{DataSourceRegister, Filter, 
InsertableRelation}
+import org.apache.spark.sql.sources.v2.writer.{SupportsOverwrite, 
SupportsTruncate, V1WriteBuilder, WriteBuilder}
+import org.apache.spark.sql.test.SharedSQLContext
+import org.apache.spark.sql.types.{IntegerType, StringType, StructType}
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+
+class V1WriteFallbackSuite extends QueryTest with SharedSQLContext with 
BeforeAndAfter {
+
+  import testImplicits._
+
+  private val format = classOf[InMemoryV1Provider].getName
+
+  override def beforeAll(): Unit = {
+super.beforeAll()
+InMemoryV1Provider.clear()
+  }
+
+  override def afterEach(): Unit = {
+super.afterEach()
+InMemoryV1Provider.clear()
+  }
+
+  test("append fallback") {
 
 Review comment:
   Done


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


With regards,
Apache Git Services

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



[GitHub] [spark] brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a v1 fallback writer implementation for v2 data source codepaths

2019-08-20 Thread GitBox
brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a 
v1 fallback writer implementation for v2 data source codepaths
URL: https://github.com/apache/spark/pull/25348#discussion_r315909789
 
 

 ##
 File path: 
sql/core/src/main/scala/org/apache/spark/sql/sources/v2/writer/V1WriteBuilder.scala
 ##
 @@ -0,0 +1,53 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.sources.v2.writer
+
+import org.apache.spark.annotation.{Experimental, Unstable}
+import org.apache.spark.sql.sources.InsertableRelation
+import org.apache.spark.sql.sources.v2.writer.streaming.StreamingWrite
+
+/**
+ * A trait that should be implemented by V1 DataSources that would like to 
leverage the DataSource
+ * V2 write code paths. The InsertableRelation will be used only to Append 
data. Other
+ * instances of the [[WriteBuilder]] interface such as [[SupportsOverwrite]], 
[[SupportsTruncate]]
+ * should be extended as well to support additional operations other than data 
appends.
+ *
+ * This interface is designed to provide Spark DataSources time to migrate to 
DataSource V2 and
+ * will be removed in a future Spark release.
+ *
+ * @since 3.0.0
+ */
+@Experimental
+@Unstable
+trait V1WriteBuilder extends WriteBuilder {
+
+  /**
+   * Creates an InsertableRelation that allows appending a DataFrame to a
+   * a destination (using data source-specific parameters). The insert method 
will only be
+   * called with `overwrite=false`. The DataSource should implement the 
overwrite behavior as
+   * part of the [[SupportsOverwrite]], and [[SupportsTruncate]] interfaces.
+   *
+   * @since 3.0.0
+   */
+  def buildForV1Write(): InsertableRelation
+
+  // These methods cannot be implemented by a V1WriteBuilder.
+  override final def buildForBatch(): BatchWrite = super.buildForBatch()
 
 Review comment:
   not sure if this is required. Now WriteBuilder implementations need to 
   ```scala
   class ExampleBuilder extends WriteBuilder with V1WriteBuilder
   ```
   


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


With regards,
Apache Git Services

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



[GitHub] [spark] brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a v1 fallback writer implementation for v2 data source codepaths

2019-08-20 Thread GitBox
brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a 
v1 fallback writer implementation for v2 data source codepaths
URL: https://github.com/apache/spark/pull/25348#discussion_r315851494
 
 

 ##
 File path: 
sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/v2/V1FallbackWriters.scala
 ##
 @@ -0,0 +1,108 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.execution.datasources.v2
+
+import scala.collection.JavaConverters._
+
+import org.apache.spark.SparkException
+import org.apache.spark.rdd.RDD
+import org.apache.spark.sql.{Dataset, SaveMode}
+import org.apache.spark.sql.catalyst.InternalRow
+import org.apache.spark.sql.catalyst.expressions.Attribute
+import org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
+import org.apache.spark.sql.execution.SparkPlan
+import org.apache.spark.sql.sources.{AlwaysTrue, CreatableRelationProvider, 
Filter, InsertableRelation}
+import org.apache.spark.sql.sources.v2.Table
+import org.apache.spark.sql.sources.v2.writer._
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+
+/**
+ * Physical plan node for append into a v2 table using V1 write interfaces.
+ *
+ * Rows in the output data set are appended.
+ */
+case class AppendDataExecV1(
+writeBuilder: V1WriteBuilder,
+plan: LogicalPlan) extends V1FallbackWriters {
 
 Review comment:
   I think that'd be great to have when looking at explain plans


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


With regards,
Apache Git Services

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



[GitHub] [spark] brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a v1 fallback writer implementation for v2 data source codepaths

2019-08-15 Thread GitBox
brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a 
v1 fallback writer implementation for v2 data source codepaths
URL: https://github.com/apache/spark/pull/25348#discussion_r314377292
 
 

 ##
 File path: 
sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/v2/DataSourceV2Strategy.scala
 ##
 @@ -200,24 +202,37 @@ object DataSourceV2Strategy extends Strategy with 
PredicateHelper {
 catalog,
 ident,
 parts,
+query,
 planLater(query),
 props,
 writeOptions,
 orCreate = orCreate) :: Nil
   }
 
 case AppendData(r: DataSourceV2Relation, query, _) =>
-  AppendDataExec(r.table.asWritable, r.options, planLater(query)) :: Nil
 
 Review comment:
   I don't think most (98%) of Spark users already don't know what the physical 
nodes stand for, etc. I was thinking of using metrics as well. We just wanted 
to keep the nodes separate, because the semantics are a bit different for 
things like `OverwriteByExpression`, where the source's implementation of the 
Overwrite + Append (v2 behavior) may not be atomic, etc


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


With regards,
Apache Git Services

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



[GitHub] [spark] brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a v1 fallback writer implementation for v2 data source codepaths

2019-08-14 Thread GitBox
brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a 
v1 fallback writer implementation for v2 data source codepaths
URL: https://github.com/apache/spark/pull/25348#discussion_r313951437
 
 

 ##
 File path: 
sql/core/src/main/scala/org/apache/spark/sql/sources/v2/writer/V1WriteBuilder.scala
 ##
 @@ -0,0 +1,47 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.spark.sql.sources.v2.writer
+
+import org.apache.spark.annotation.{Experimental, Unstable}
+import org.apache.spark.sql.sources.InsertableRelation
+
+/**
+ * A trait that should be implemented by V1 DataSources that would like to 
leverage the DataSource
+ * V2 write code paths. The CreatableRelationProvider will be used only to 
Append data. Other
+ * instances of the [[WriteBuilder]] interface such as [[SupportsOverwrite]], 
[[SupportsTruncate]]
+ * should be extended as well to support additional operations other than data 
appends.
+ *
+ * This interface is designed to provide Spark DataSources time to migrate to 
DataSource V2 and
+ * will be removed in a future Spark release.
+ *
+ * @since 3.0.0
+ */
+@Experimental
+@Unstable
+trait V1WriteBuilder extends WriteBuilder {
 
 Review comment:
   Hmm, all of the other mixins and their functions return a `WriteBuilder` 
after their supported operation, whereas this ends the chain. I don't have too 
strong opinions on this. (I'm also considering, whether this should also 
finalize unsupported operations for the V2 writes, e.g. `final 
buildBatchWrite() => Unsupported`)


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


With regards,
Apache Git Services

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



[GitHub] [spark] brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a v1 fallback writer implementation for v2 data source codepaths

2019-08-14 Thread GitBox
brkyvz commented on a change in pull request #25348: [SPARK-28554][SQL] Adds a 
v1 fallback writer implementation for v2 data source codepaths
URL: https://github.com/apache/spark/pull/25348#discussion_r313949787
 
 

 ##
 File path: 
sql/core/src/main/scala/org/apache/spark/sql/execution/datasources/v2/DataSourceV2Strategy.scala
 ##
 @@ -200,24 +202,37 @@ object DataSourceV2Strategy extends Strategy with 
PredicateHelper {
 catalog,
 ident,
 parts,
+query,
 planLater(query),
 props,
 writeOptions,
 orCreate = orCreate) :: Nil
   }
 
 case AppendData(r: DataSourceV2Relation, query, _) =>
-  AppendDataExec(r.table.asWritable, r.options, planLater(query)) :: Nil
 
 Review comment:
   It's just cleaner to have a separation of which code path was used. (Shows 
up separately in the SQL tab, etc)


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


With regards,
Apache Git Services

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