You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@iceberg.apache.org by GitBox <gi...@apache.org> on 2021/12/05 17:04:55 UTC

[GitHub] [iceberg] ajantha-bhat opened a new pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

ajantha-bhat opened a new pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671


   This is a back sync of #3375 to spark-3.1 folder


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat edited a comment on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat edited a comment on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-986413732


   > The new name of the file is: spark/v3.1/spark/src/main/java/org/apache/spark/sql/catalyst/plans.logical/SetWriteDistributionAndOrdering.scala
   > It's odd to me that it would be catalyst/plans.logical/SetWriteDistributionAndOrdering.scala instead of with a slash in the file path name (instead using plans.logical for just part of the path).
   
   @kbendick: That shows only in the PR. but when merged, github / codebase can understand that it is a sub package.
   See final results here: https://github.com/apache/iceberg/tree/master/spark/v3.2/spark/src/main/java/org/apache/spark/sql/catalyst/plans/logical


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] RussellSpitzer commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
RussellSpitzer commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-990204587


   Merged! I'll go take a look at the 3.0 backport


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-987395629


   @kbendick : PR is ready. Could you please take a look at it again ?
   cc: @rdblue , @RussellSpitzer 


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] kbendick commented on a change in pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
kbendick commented on a change in pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#discussion_r762613269



##########
File path: spark/v3.1/spark/src/main/java/org/apache/spark/sql/execution.datasources/SparkExpressionConverter.scala
##########
@@ -0,0 +1,33 @@
+/*
+ * 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
+
+import org.apache.iceberg.spark.SparkFilters
+import org.apache.spark.sql.catalyst.expressions.Expression
+
+object SparkExpressionConverter {
+
+  def convertToIcebergExpression(sparkExpression: Expression): org.apache.iceberg.expressions.Expression = {
+    // Currently, it is a double conversion as we are converting Spark expression to Spark filter
+    // and then converting Spark filter to Iceberg expression.
+    // But these two conversions already exist and well tested. So, we are going with this approach.
+    SparkFilters.convert(DataSourceStrategy.translateFilter(sparkExpression, supportNestedPredicatePushdown = true).get)
+  }
+}

Review comment:
       I noticed that this Scala file was placed in the `java` codepath (e.g. it's in `src/main/java` and not `src/main/scala`).
   
   Is there a reason for this?
   
   Seems like something that might need to be updated in the original PR as well if it's not intentional.




-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] kbendick commented on a change in pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
kbendick commented on a change in pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#discussion_r762613269



##########
File path: spark/v3.1/spark/src/main/java/org/apache/spark/sql/execution.datasources/SparkExpressionConverter.scala
##########
@@ -0,0 +1,33 @@
+/*
+ * 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
+
+import org.apache.iceberg.spark.SparkFilters
+import org.apache.spark.sql.catalyst.expressions.Expression
+
+object SparkExpressionConverter {
+
+  def convertToIcebergExpression(sparkExpression: Expression): org.apache.iceberg.expressions.Expression = {
+    // Currently, it is a double conversion as we are converting Spark expression to Spark filter
+    // and then converting Spark filter to Iceberg expression.
+    // But these two conversions already exist and well tested. So, we are going with this approach.
+    SparkFilters.convert(DataSourceStrategy.translateFilter(sparkExpression, supportNestedPredicatePushdown = true).get)
+  }
+}

Review comment:
       I noticed that this Scala file was placed in the `java` codepath (e.g. it's in `src/main/java` and not `src/main/scala`).
   
   Is there a reason for this? Seems like something that might need to be updated in the original PR as well.




-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on a change in pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on a change in pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#discussion_r762669532



##########
File path: spark/v3.1/spark/src/main/java/org/apache/spark/sql/execution.datasources/SparkExpressionConverter.scala
##########
@@ -0,0 +1,33 @@
+/*
+ * 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
+
+import org.apache.iceberg.spark.SparkFilters
+import org.apache.spark.sql.catalyst.expressions.Expression
+
+object SparkExpressionConverter {
+
+  def convertToIcebergExpression(sparkExpression: Expression): org.apache.iceberg.expressions.Expression = {
+    // Currently, it is a double conversion as we are converting Spark expression to Spark filter
+    // and then converting Spark filter to Iceberg expression.
+    // But these two conversions already exist and well tested. So, we are going with this approach.
+    SparkFilters.convert(DataSourceStrategy.translateFilter(sparkExpression, supportNestedPredicatePushdown = true).get)
+  }
+}

Review comment:
       good catch @kbendick , I think I didn't notice it while creating a package. I will first fix in the spark-3.2 and then update these PR. Thanks




-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on a change in pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on a change in pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#discussion_r762685711



##########
File path: spark/v3.1/spark/src/main/java/org/apache/spark/sql/execution.datasources/SparkExpressionConverter.scala
##########
@@ -0,0 +1,33 @@
+/*
+ * 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
+
+import org.apache.iceberg.spark.SparkFilters
+import org.apache.spark.sql.catalyst.expressions.Expression
+
+object SparkExpressionConverter {
+
+  def convertToIcebergExpression(sparkExpression: Expression): org.apache.iceberg.expressions.Expression = {
+    // Currently, it is a double conversion as we are converting Spark expression to Spark filter
+    // and then converting Spark filter to Iceberg expression.
+    // But these two conversions already exist and well tested. So, we are going with this approach.
+    SparkFilters.convert(DataSourceStrategy.translateFilter(sparkExpression, supportNestedPredicatePushdown = true).get)
+  }
+}

Review comment:
       I checked `add_files` procedure, it doesn't involve functionality or code. So, probably you might have seen it in my spark-3.2 merged PR.




-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-986434110


   CI failed because of [this](https://github.com/apache/iceberg/issues/1144) problem
   I will update my testcase


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-989498915


   @jackye1995 : could you please add 0.13.0 milestone for this PR ?


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] RussellSpitzer merged pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
RussellSpitzer merged pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671


   


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] kbendick commented on a change in pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
kbendick commented on a change in pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#discussion_r762670477



##########
File path: spark/v3.1/spark/src/main/java/org/apache/spark/sql/execution.datasources/SparkExpressionConverter.scala
##########
@@ -0,0 +1,33 @@
+/*
+ * 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
+
+import org.apache.iceberg.spark.SparkFilters
+import org.apache.spark.sql.catalyst.expressions.Expression
+
+object SparkExpressionConverter {
+
+  def convertToIcebergExpression(sparkExpression: Expression): org.apache.iceberg.expressions.Expression = {
+    // Currently, it is a double conversion as we are converting Spark expression to Spark filter
+    // and then converting Spark filter to Iceberg expression.
+    // But these two conversions already exist and well tested. So, we are going with this approach.
+    SparkFilters.convert(DataSourceStrategy.translateFilter(sparkExpression, supportNestedPredicatePushdown = true).get)
+  }
+}

Review comment:
       No worries. I feel like we already have this class (though maybe I saw it when you previously merged it). I believe I saw it being used in the `add_files` procedure code.
   
   If we already do, then just use that one and just remove the extra file.
   
   Thanks for taking care of this. 🙂




-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on a change in pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on a change in pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#discussion_r762685711



##########
File path: spark/v3.1/spark/src/main/java/org/apache/spark/sql/execution.datasources/SparkExpressionConverter.scala
##########
@@ -0,0 +1,33 @@
+/*
+ * 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
+
+import org.apache.iceberg.spark.SparkFilters
+import org.apache.spark.sql.catalyst.expressions.Expression
+
+object SparkExpressionConverter {
+
+  def convertToIcebergExpression(sparkExpression: Expression): org.apache.iceberg.expressions.Expression = {
+    // Currently, it is a double conversion as we are converting Spark expression to Spark filter
+    // and then converting Spark filter to Iceberg expression.
+    // But these two conversions already exist and well tested. So, we are going with this approach.
+    SparkFilters.convert(DataSourceStrategy.translateFilter(sparkExpression, supportNestedPredicatePushdown = true).get)
+  }
+}

Review comment:
       I checked `add_files` procedure, it doesn't involve this functionality or code. So, probably you might have seen it in my spark-3.2 merged PR.




-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-986413732


   > The new name of the file is: spark/v3.1/spark/src/main/java/org/apache/spark/sql/catalyst/plans.logical/SetWriteDistributionAndOrdering.scala
   > It's odd to me that it would be catalyst/plans.logical/SetWriteDistributionAndOrdering.scala instead of with a slash in the file path name (instead using plans.logical for just part of the path).
   
   That shows only in the PR. but when merged, github / codebase can understand that it is a sub package.
   See final results here: https://github.com/apache/iceberg/tree/master/spark/v3.2/spark/src/main/java/org/apache/spark/sql/catalyst/plans/logical


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] ajantha-bhat commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
ajantha-bhat commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-987404066


   > The new name of the file is: spark/v3.1/spark/src/main/java/org/apache/spark/sql/catalyst/plans.logical/SetWriteDistributionAndOrdering.scala
   
   > It's odd to me that it would be catalyst/plans.logical/SetWriteDistributionAndOrdering.scala instead of with a slash in the file path name (instead using plans.logical for just part of the path).
   
   I have created a sub packages, instead single package. So, the path is using '/' now instead of '.'


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] jackye1995 commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
jackye1995 commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-989592089


   thanks for reminding, I am planning to review tomorrow morning


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org


[GitHub] [iceberg] RussellSpitzer commented on pull request #3671: Spark-3.1: support CALL procedure for rewrite_data_files

Posted by GitBox <gi...@apache.org>.
RussellSpitzer commented on pull request #3671:
URL: https://github.com/apache/iceberg/pull/3671#issuecomment-990133555


   @ajantha-bhat Are there any specific changes here from 3.2 that I should look out for?


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@iceberg.apache.org
For additional commands, e-mail: issues-help@iceberg.apache.org