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 2020/02/13 10:08:49 UTC

[GitHub] [spark] xuanyuanking opened a new pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

xuanyuanking opened a new pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560
 
 
   ### What changes were proposed in this pull request?
   - Add missing `since` annotation.
   - Don't show classes under `org.apache.spark.sql.dynamicpruning` package in API docs.
   - Fix the scope of `xxxExactNumeric` to remove it from the API docs.
   
   ### Why are the changes needed?
   Avoid leaking APIs unintentionally in Spark 3.0.0.
   
   ### Does this PR introduce any user-facing change?
   No. All these changes are to avoid leaking APIs unintentionally in Spark 3.0.0.
   
   ### How was this patch tested?
   Manually generated the API docs and verified the above issues have been fixed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381890238
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/numerics.scala
 ##########
 @@ -22,7 +22,7 @@ import scala.math.Ordering
 
 import org.apache.spark.sql.types.Decimal.DecimalIsConflicted
 
-object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
+private[sql] object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
 
 Review comment:
   we can move it in followup

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381886953
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+    @throws[CatalogNotFoundException]
 
 Review comment:
   is the indentation corrected?

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381960179
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/numerics.scala
 ##########
 @@ -22,7 +22,7 @@ import scala.math.Ordering
 
 import org.apache.spark.sql.types.Decimal.DecimalIsConflicted
 
-object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
+private[sql] object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
 
 Review comment:
   Got it, the whole file needs to be moved to a private package.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588810581
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118710/
   Test FAILed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589461379
 
 
   **[Test build #118740 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118740/testReport)** for PR 27560 at commit [`14b121e`](https://github.com/apache/spark/commit/14b121e28ee9695ff1d8ac1c2731f3250e6590a8).

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588809818
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23461/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588999705
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] xuanyuanking commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589639233
 
 
   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.
 
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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589493341
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23500/
   Test PASSed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381890133
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/numerics.scala
 ##########
 @@ -22,7 +22,7 @@ import scala.math.Ordering
 
 import org.apache.spark.sql.types.Decimal.DecimalIsConflicted
 
-object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
+private[sql] object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
 
 Review comment:
   I'm OK with it. But we should also move this file to a private package.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589493341
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23500/
   Test PASSed.

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


[GitHub] [spark] Ngone51 commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
Ngone51 commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379304947
 
 

 ##########
 File path: sql/catalyst/src/main/java/org/apache/spark/sql/connector/ExternalCommandRunner.java
 ##########
 @@ -27,6 +27,8 @@
  * cores for Solr and so on.
  * <p>
  * This interface will be instantiated when end users call `SparkSession#executeCommand`.
+ *
+ * @since 3.0.0
 
 Review comment:
   Oh..no...thanks for adding this. BTW, how do you find it?

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588809818
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23461/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588810537
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379244642
 
 

 ##########
 File path: core/src/main/scala/org/apache/spark/rpc/RpcEndpointRef.scala
 ##########
 @@ -108,7 +108,7 @@ private[spark] abstract class RpcEndpointRef(conf: SparkConf)
 /**
  * An exception thrown if the RPC is aborted.
  */
-class RpcAbortException(message: String) extends Exception(message)
+private[spark] class RpcAbortException(message: String) extends Exception(message)
 
 Review comment:
   shall we just make the `rpc` package private?

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585753826
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118353/
   Test PASSed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588810477
 
 
   **[Test build #118710 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118710/testReport)** for PR 27560 at commit [`a42f54c`](https://github.com/apache/spark/commit/a42f54c03f58061397f3817a6c5bf12e11ff6b96).
    * This patch **fails Scala style tests**.
    * This patch merges cleanly.
    * This patch adds no public classes.

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


[GitHub] [spark] SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588808088
 
 
   **[Test build #118710 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118710/testReport)** for PR 27560 at commit [`a42f54c`](https://github.com/apache/spark/commit/a42f54c03f58061397f3817a6c5bf12e11ff6b96).

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


[GitHub] [spark] SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589493045
 
 
   **[Test build #118749 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118749/testReport)** for PR 27560 at commit [`14b121e`](https://github.com/apache/spark/commit/14b121e28ee9695ff1d8ac1c2731f3250e6590a8).

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379408683
 
 

 ##########
 File path: project/SparkBuild.scala
 ##########
 @@ -834,6 +834,7 @@ object Unidoc {
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/util/collection")))
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/util/kvstore")))
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/sql/catalyst")))
+      .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/sql/dynamicpruning")))
 
 Review comment:
   Done in #27581.

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


[GitHub] [spark] xuanyuanking commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-586050561
 
 
   cc @cloud-fan 

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381865223
 
 

 ##########
 File path: sql/catalyst/src/main/java/org/apache/spark/sql/connector/catalog/Catalogs.java
 ##########
 @@ -48,6 +48,7 @@ private Catalogs() {
    * @return an initialized CatalogPlugin
    * @throws CatalogNotFoundException if the plugin class cannot be found
    * @throws SparkException if the plugin class cannot be instantiated
+   * @since 3.0.0
 
 Review comment:
   Thanks, rewrite done in 69ab608.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589539592
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588820766
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] xuanyuanking commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588603571
 
 
   Yes, will address comments today.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589490963
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118740/
   Test FAILed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381965830
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+  @throws[CatalogNotFoundException]
+  @throws[SparkException]
+  def load(name: String, conf: SQLConf): CatalogPlugin = {
+    var pluginClassName = ""
+    try {
+      pluginClassName = conf.getConfString("spark.sql.catalog." + name)
 
 Review comment:
   we can make it more scala-ish:
   ```
   val pluginClassName = try {
     ...
   } ...
   ```

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


[GitHub] [spark] xuanyuanking edited a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking edited a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-586050561
 
 
   cc @cloud-fan @gatorsmile 

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589461679
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23491/
   Test PASSed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381889311
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/DataType.scala
 ##########
 @@ -488,6 +488,8 @@ object DataType {
 
 /**
  * Jackson serializer for [[DataType]]. Internally this delegates to json4s based serialization.
+ *
+ * @since 3.0.0
  */
 class DataTypeJsonSerializer extends JsonSerializer[DataType] {
 
 Review comment:
   these 2 were added in https://github.com/apache/spark/pull/26127/files#diff-df78a74ef92d9b8fb4ac142ff9a62464R490
   
   I don't think we want to publish them. Can we move them to a private package? like `xxx.catalyst.utils`
   also cc @hvanhovell 

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585652819
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23110/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589490959
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r382358467
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+  @throws[CatalogNotFoundException]
+  @throws[SparkException]
+  def load(name: String, conf: SQLConf): CatalogPlugin = {
+    var pluginClassName = ""
+    try {
+      pluginClassName = conf.getConfString("spark.sql.catalog." + name)
 
 Review comment:
   Thanks, done in 14b121e.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381966033
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+  @throws[CatalogNotFoundException]
+  @throws[SparkException]
+  def load(name: String, conf: SQLConf): CatalogPlugin = {
+    var pluginClassName = ""
+    try {
+      pluginClassName = conf.getConfString("spark.sql.catalog." + name)
+    } catch {
+      case _: NoSuchElementException =>
+        throw new CatalogNotFoundException(
+          s"Catalog '$name' plugin class not found: spark.sql.catalog.$name is not defined")
+    }
+    val loader = Utils.getContextOrSparkClassLoader
+    try {
+      val pluginClass = loader.loadClass(pluginClassName)
+      if (!classOf[CatalogPlugin].isAssignableFrom(pluginClass)) throw new SparkException(
 
 Review comment:
   nit:
   ```
   if (...) {
     throw ...
   }
   ```

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588990816
 
 
   **[Test build #118718 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118718/testReport)** for PR 27560 at commit [`14dbf06`](https://github.com/apache/spark/commit/14dbf064d1674b894ddda75adb824cf7634c39db).

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


[GitHub] [spark] cloud-fan commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589562801
 
 
   thanks, merging to master/3.0!

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588991276
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589461674
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379243643
 
 

 ##########
 File path: sql/catalyst/src/main/java/org/apache/spark/sql/connector/catalog/Catalogs.java
 ##########
 @@ -48,6 +48,7 @@ private Catalogs() {
    * @return an initialized CatalogPlugin
    * @throws CatalogNotFoundException if the plugin class cannot be found
    * @throws SparkException if the plugin class cannot be instantiated
+   * @since 3.0.0
 
 Review comment:
   This is a private class (`@Private`)

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r382358516
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+  @throws[CatalogNotFoundException]
+  @throws[SparkException]
+  def load(name: String, conf: SQLConf): CatalogPlugin = {
+    var pluginClassName = ""
+    try {
+      pluginClassName = conf.getConfString("spark.sql.catalog." + name)
+    } catch {
+      case _: NoSuchElementException =>
+        throw new CatalogNotFoundException(
+          s"Catalog '$name' plugin class not found: spark.sql.catalog.$name is not defined")
+    }
+    val loader = Utils.getContextOrSparkClassLoader
+    try {
+      val pluginClass = loader.loadClass(pluginClassName)
+      if (!classOf[CatalogPlugin].isAssignableFrom(pluginClass)) throw new SparkException(
 
 Review comment:
   Thanks, done in 14b121e

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


[GitHub] [spark] hvanhovell commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
hvanhovell commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381891408
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/DataType.scala
 ##########
 @@ -488,6 +488,8 @@ object DataType {
 
 /**
  * Jackson serializer for [[DataType]]. Internally this delegates to json4s based serialization.
+ *
+ * @since 3.0.0
  */
 class DataTypeJsonSerializer extends JsonSerializer[DataType] {
 
 Review comment:
   Good catch. We should definitely move it into catalyst. I am not sure if we can change the visibility (jackson might not like that), but we should just try.

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


[GitHub] [spark] cloud-fan commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589492832
 
 
   retest this please

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


[GitHub] [spark] SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589461379
 
 
   **[Test build #118740 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118740/testReport)** for PR 27560 at commit [`14b121e`](https://github.com/apache/spark/commit/14b121e28ee9695ff1d8ac1c2731f3250e6590a8).

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588999705
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381930412
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/DataType.scala
 ##########
 @@ -488,6 +488,8 @@ object DataType {
 
 /**
  * Jackson serializer for [[DataType]]. Internally this delegates to json4s based serialization.
+ *
+ * @since 3.0.0
  */
 class DataTypeJsonSerializer extends JsonSerializer[DataType] {
 
 Review comment:
   classes in the catalyst package are treated as private classes and we don't really need to add the `private[sql]`

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381969188
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+  @throws[CatalogNotFoundException]
+  @throws[SparkException]
+  def load(name: String, conf: SQLConf): CatalogPlugin = {
+    var pluginClassName = ""
+    try {
+      pluginClassName = conf.getConfString("spark.sql.catalog." + name)
+    } catch {
+      case _: NoSuchElementException =>
+        throw new CatalogNotFoundException(
+          s"Catalog '$name' plugin class not found: spark.sql.catalog.$name is not defined")
+    }
+    val loader = Utils.getContextOrSparkClassLoader
+    try {
+      val pluginClass = loader.loadClass(pluginClassName)
+      if (!classOf[CatalogPlugin].isAssignableFrom(pluginClass)) throw new SparkException(
+        s"Plugin class for catalog '$name' does not implement CatalogPlugin: $pluginClassName")
+      val plugin = classOf[CatalogPlugin].cast(
 
 Review comment:
   nit: `pluginClass.getDeclaredConstructor().newInstance().asInstanceOf[CatalogPlugin]`

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588857074
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118711/
   Test FAILed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588857074
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118711/
   Test FAILed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588857033
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585752658
 
 
   **[Test build #118353 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118353/testReport)** for PR 27560 at commit [`c43d7ce`](https://github.com/apache/spark/commit/c43d7ceca06878830777f4b85b2c209e4783e0ba).
    * This patch passes all tests.
    * This patch merges cleanly.
    * This patch adds no public classes.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588999713
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118718/
   Test FAILed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585652807
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589490959
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381959787
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/DataType.scala
 ##########
 @@ -488,6 +488,8 @@ object DataType {
 
 /**
  * Jackson serializer for [[DataType]]. Internally this delegates to json4s based serialization.
+ *
+ * @since 3.0.0
  */
 class DataTypeJsonSerializer extends JsonSerializer[DataType] {
 
 Review comment:
   Thanks, move them to `org.apache.spark.sql.catalyst.util.DataTypeJsonUtils`.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588810581
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118710/
   Test FAILed.

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r382358552
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+  @throws[CatalogNotFoundException]
+  @throws[SparkException]
+  def load(name: String, conf: SQLConf): CatalogPlugin = {
+    var pluginClassName = ""
+    try {
+      pluginClassName = conf.getConfString("spark.sql.catalog." + name)
+    } catch {
+      case _: NoSuchElementException =>
+        throw new CatalogNotFoundException(
+          s"Catalog '$name' plugin class not found: spark.sql.catalog.$name is not defined")
+    }
+    val loader = Utils.getContextOrSparkClassLoader
+    try {
+      val pluginClass = loader.loadClass(pluginClassName)
+      if (!classOf[CatalogPlugin].isAssignableFrom(pluginClass)) throw new SparkException(
+        s"Plugin class for catalog '$name' does not implement CatalogPlugin: $pluginClassName")
+      val plugin = classOf[CatalogPlugin].cast(
 
 Review comment:
   Thanks, done in 14b121e

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588808088
 
 
   **[Test build #118710 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118710/testReport)** for PR 27560 at commit [`a42f54c`](https://github.com/apache/spark/commit/a42f54c03f58061397f3817a6c5bf12e11ff6b96).

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589539598
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118749/
   Test PASSed.

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


[GitHub] [spark] cloud-fan commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588207474
 
 
   any more updates?

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


[GitHub] [spark] SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588990816
 
 
   **[Test build #118718 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118718/testReport)** for PR 27560 at commit [`14dbf06`](https://github.com/apache/spark/commit/14dbf064d1674b894ddda75adb824cf7634c39db).

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588991285
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23469/
   Test PASSed.

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381960179
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/types/numerics.scala
 ##########
 @@ -22,7 +22,7 @@ import scala.math.Ordering
 
 import org.apache.spark.sql.types.Decimal.DecimalIsConflicted
 
-object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
+private[sql] object ByteExactNumeric extends ByteIsIntegral with Ordering.ByteOrdering {
 
 Review comment:
   Got it, others object in numerics.scala might also get moved together.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588809782
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585753813
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588829472
 
 
   **[Test build #118711 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118711/testReport)** for PR 27560 at commit [`71bad8e`](https://github.com/apache/spark/commit/71bad8e4051a4956e8908cc65d421c31059d6dbb).

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589490963
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118740/
   Test FAILed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589539592
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588991276
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585652819
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23110/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589461679
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23491/
   Test PASSed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589538924
 
 
   **[Test build #118749 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118749/testReport)** for PR 27560 at commit [`14b121e`](https://github.com/apache/spark/commit/14b121e28ee9695ff1d8ac1c2731f3250e6590a8).
    * This patch passes all tests.
    * This patch merges cleanly.
    * This patch adds no public classes.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585652123
 
 
   **[Test build #118353 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118353/testReport)** for PR 27560 at commit [`c43d7ce`](https://github.com/apache/spark/commit/c43d7ceca06878830777f4b85b2c209e4783e0ba).

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379244165
 
 

 ##########
 File path: project/SparkBuild.scala
 ##########
 @@ -834,6 +834,7 @@ object Unidoc {
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/util/collection")))
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/util/kvstore")))
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/sql/catalyst")))
+      .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/sql/dynamicpruning")))
 
 Review comment:
   shall we send a PR to move package first?

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


[GitHub] [spark] SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588829472
 
 
   **[Test build #118711 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118711/testReport)** for PR 27560 at commit [`71bad8e`](https://github.com/apache/spark/commit/71bad8e4051a4956e8908cc65d421c31059d6dbb).

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588809782
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379244083
 
 

 ##########
 File path: sql/catalyst/src/main/java/org/apache/spark/sql/connector/expressions/Transform.java
 ##########
 @@ -24,6 +24,8 @@
  * <p>
  * For example, the transform date(ts) is used to derive a date value from a timestamp column. The
  * transform name is "date" and its argument is a reference to the "ts" column.
+ *
+ * @since 3.0.0
  */
 @Experimental
 
 Review comment:
   I think all DS v2 classes are still evolving. Shall we use `@Evolving` consistently? e.g. https://github.com/apache/spark/pull/27560/files#diff-ab2a72871faeb3ad8bae1d7f951899deR29
   
   cc @brkyvz @rdblue 

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381959925
 
 

 ##########
 File path: sql/catalyst/src/main/scala/org/apache/spark/sql/connector/catalog/Catalogs.scala
 ##########
 @@ -0,0 +1,99 @@
+/*
+ * 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.connector.catalog
+
+import java.lang.reflect.InvocationTargetException
+import java.util
+import java.util.NoSuchElementException
+import java.util.regex.Pattern
+
+import org.apache.spark.SparkException
+import org.apache.spark.sql.internal.SQLConf
+import org.apache.spark.sql.util.CaseInsensitiveStringMap
+import org.apache.spark.util.Utils
+
+private[sql] object Catalogs {
+  /**
+   * Load and configure a catalog by name.
+   * <p>
+   * This loads, instantiates, and initializes the catalog plugin for each call; it does not cache
+   * or reuse instances.
+   *
+   * @param name a String catalog name
+   * @param conf a SQLConf
+   * @return an initialized CatalogPlugin
+   * @throws CatalogNotFoundException if the plugin class cannot be found
+   * @throws SparkException           if the plugin class cannot be instantiated
+   */
+    @throws[CatalogNotFoundException]
 
 Review comment:
   Thanks, fix in 14dbf06.

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381866343
 
 

 ##########
 File path: sql/catalyst/src/main/java/org/apache/spark/sql/connector/ExternalCommandRunner.java
 ##########
 @@ -27,6 +27,8 @@
  * cores for Solr and so on.
  * <p>
  * This interface will be instantiated when end users call `SparkSession#executeCommand`.
+ *
+ * @since 3.0.0
 
 Review comment:
   I compare the latest Scala API doc against the 2.4 version. :)

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r381865526
 
 

 ##########
 File path: core/src/main/scala/org/apache/spark/rpc/RpcEndpointRef.scala
 ##########
 @@ -108,7 +108,7 @@ private[spark] abstract class RpcEndpointRef(conf: SparkConf)
 /**
  * An exception thrown if the RPC is aborted.
  */
-class RpcAbortException(message: String) extends Exception(message)
+private[spark] class RpcAbortException(message: String) extends Exception(message)
 
 Review comment:
   Done in a42f54c.

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


[GitHub] [spark] cloud-fan closed pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan closed pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560
 
 
   

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589493045
 
 
   **[Test build #118749 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118749/testReport)** for PR 27560 at commit [`14b121e`](https://github.com/apache/spark/commit/14b121e28ee9695ff1d8ac1c2731f3250e6590a8).

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


[GitHub] [spark] cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
cloud-fan commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379300527
 
 

 ##########
 File path: sql/catalyst/src/main/java/org/apache/spark/sql/connector/catalog/Catalogs.java
 ##########
 @@ -48,6 +48,7 @@ private Catalogs() {
    * @return an initialized CatalogPlugin
    * @throws CatalogNotFoundException if the plugin class cannot be found
    * @throws SparkException if the plugin class cannot be instantiated
+   * @since 3.0.0
 
 Review comment:
   If it doesn't work, we can rewrite in with Scala and use `private[sql]`.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588820802
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23462/
   Test PASSed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588999682
 
 
   **[Test build #118718 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118718/testReport)** for PR 27560 at commit [`14dbf06`](https://github.com/apache/spark/commit/14dbf064d1674b894ddda75adb824cf7634c39db).
    * This patch **fails to generate documentation**.
    * This patch merges cleanly.
    * This patch adds the following public classes _(experimental)_:
     * `  class DataTypeJsonSerializer extends JsonSerializer[DataType] `
     * `  class DataTypeJsonDeserializer extends JsonDeserializer[DataType] `
     * `        throw new SparkException(\"Cannot instantiate abstract catalog plugin class 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.
 
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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589493332
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585753826
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118353/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588857033
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585652807
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
xuanyuanking commented on a change in pull request #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#discussion_r379255475
 
 

 ##########
 File path: project/SparkBuild.scala
 ##########
 @@ -834,6 +834,7 @@ object Unidoc {
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/util/collection")))
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/util/kvstore")))
       .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/sql/catalyst")))
+      .map(_.filterNot(_.getCanonicalPath.contains("org/apache/spark/sql/dynamicpruning")))
 
 Review comment:
   Sure, will do it today.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585753813
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589493332
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-585652123
 
 
   **[Test build #118353 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118353/testReport)** for PR 27560 at commit [`c43d7ce`](https://github.com/apache/spark/commit/c43d7ceca06878830777f4b85b2c209e4783e0ba).

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589539598
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118749/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588810537
 
 
   Merged build finished. Test FAILed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588820766
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588820802
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23462/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589461674
 
 
   Merged build finished. Test PASSed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588856746
 
 
   **[Test build #118711 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118711/testReport)** for PR 27560 at commit [`71bad8e`](https://github.com/apache/spark/commit/71bad8e4051a4956e8908cc65d421c31059d6dbb).
    * This patch **fails to generate documentation**.
    * This patch merges cleanly.
    * This patch adds no public classes.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588991285
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/23469/
   Test PASSed.

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


[GitHub] [spark] AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-588999713
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/118718/
   Test FAILed.

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


[GitHub] [spark] SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27560: [SPARK-30809][SQL] Review and fix issues in SQL API docs
URL: https://github.com/apache/spark/pull/27560#issuecomment-589490794
 
 
   **[Test build #118740 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/118740/testReport)** for PR 27560 at commit [`14b121e`](https://github.com/apache/spark/commit/14b121e28ee9695ff1d8ac1c2731f3250e6590a8).
    * This patch **fails Spark unit tests**.
    * This patch merges cleanly.
    * This patch adds no public classes.

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