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/03/11 08:01:23 UTC

[GitHub] [spark] wangyum opened a new pull request #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

wangyum opened a new pull request #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874
 
 
   ### What changes were proposed in this pull request?
   
   This PR add support inferred morre constraints from equality constraints with cast, For e.g., 
   ```scala
   spark.sql("CREATE TABLE SPARK_31114_1(a BIGINT)")
   spark.sql("CREATE TABLE SPARK_31114_2(b DECIMAL(18, 0))")
   spark.sql("SELECT t1.* FROM SPARK_31114_1 t1 JOIN SPARK_31114_2 t2 ON t1.a = t2.b AND t1.a = 1L").explain
   ```
   Before this PR:
   ```
   == Physical Plan ==
   *(2) Project [a#0L]
   +- *(2) BroadcastHashJoin [cast(a#0L as decimal(20,0))], [cast(b#1 as decimal(20,0))], Inner, BuildRight
      :- *(2) Project [a#0L]
      :  +- *(2) Filter (isnotnull(a#0L) AND (a#0L = 1))
      :     +- *(2) ColumnarToRow
      :        +- FileScan parquet default.spark_31114_1[a#0L]
      +- BroadcastExchange HashedRelationBroadcastMode(List(cast(input[0, decimal(18,0), true] as decimal(20,0)))), [id=#50]
         +- *(1) Project [b#1]
            +- *(1) Filter isnotnull(b#1)
               +- *(1) ColumnarToRow
                  +- FileScan parquet default.spark_31114_2[b#1]
   ```
   After this PR:
   ```
   *(2) Project [a#218L]
   +- *(2) BroadcastHashJoin [cast(a#218L as decimal(20,0))], [cast(b#219 as decimal(20,0))], Inner, BuildRight
      :- *(2) Project [a#218L]
      :  +- *(2) Filter (isnotnull(a#218L) AND (a#218L = 1))
      :     +- *(2) ColumnarToRow
      :        +- FileScan parquet default.spark_31114_1[a#218L]
      +- BroadcastExchange HashedRelationBroadcastMode(List(cast(input[0, decimal(18,0), true] as decimal(20,0)))), [id=#119]
         +- *(1) Project [b#219]
            +- *(1) Filter ((cast(b#219 as bigint) = 1) AND isnotnull(b#219))
               +- *(1) ColumnarToRow
                  +- FileScan parquet default.spark_31114_2[b#219]
   
   ```
   
   
   ### Why are the changes needed?
   Improve query performance.
   
   
   ### Does this PR introduce any user-facing change?
   No.
   
   
   ### How was this patch tested?
   Unit test.
   

----------------------------------------------------------------
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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597560345
 
 
   **[Test build #119669 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/119669/testReport)** for PR 27874 at commit [`1e92854`](https://github.com/apache/spark/commit/1e9285496d260b39d3e3197268a8cbe3b8ae2deb).

----------------------------------------------------------------
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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597560877
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/24398/
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597608090
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/119669/
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597560872
 
 
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597497526
 
 
   **[Test build #119661 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/119661/testReport)** for PR 27874 at commit [`1e92854`](https://github.com/apache/spark/commit/1e9285496d260b39d3e3197268a8cbe3b8ae2deb).

----------------------------------------------------------------
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] wangyum commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
wangyum commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-599045928
 
 
   I closed it because this change cannot handle this case:
   ```scala
   spark.sql("create table T1(a string)")
   spark.sql("create table T2(b string)")
   spark.sql("create table T3(c bigint)")
   spark.sql("create table T4(d bigint)")
   
   spark.sql(
     """
       |SELECT t1.a, t2.b, t4.d
       |FROM T1 t1 JOIN T2 t2
       |       ON (t1.a = t2.b)
       |     JOIN T3 t3
       |       ON (t1.a = t3.c)
       |     JOIN T4 t4
       |       ON (t3.c = t4.d)
       |""".stripMargin).explain()
   ```

----------------------------------------------------------------
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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597520557
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/119661/
   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] wangyum commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
wangyum commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597558415
 
 
   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 commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597520407
 
 
   **[Test build #119661 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/119661/testReport)** for PR 27874 at commit [`1e92854`](https://github.com/apache/spark/commit/1e9285496d260b39d3e3197268a8cbe3b8ae2deb).
    * 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


[GitHub] [spark] AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597520557
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/119661/
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597560877
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/24398/
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597497877
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/24392/
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597520508
 
 
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597560345
 
 
   **[Test build #119669 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/119669/testReport)** for PR 27874 at commit [`1e92854`](https://github.com/apache/spark/commit/1e9285496d260b39d3e3197268a8cbe3b8ae2deb).

----------------------------------------------------------------
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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597497877
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/24392/
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597497526
 
 
   **[Test build #119661 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/119661/testReport)** for PR 27874 at commit [`1e92854`](https://github.com/apache/spark/commit/1e9285496d260b39d3e3197268a8cbe3b8ae2deb).

----------------------------------------------------------------
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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597560872
 
 
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597497869
 
 
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597608085
 
 
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597608085
 
 
   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] wangyum removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
wangyum removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597558415
 
 
   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 commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597607941
 
 
   **[Test build #119669 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/119669/testReport)** for PR 27874 at commit [`1e92854`](https://github.com/apache/spark/commit/1e9285496d260b39d3e3197268a8cbe3b8ae2deb).
    * 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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597608090
 
 
   Test FAILed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/119669/
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597497869
 
 
   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 #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597520407
 
 
   **[Test build #119661 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/119661/testReport)** for PR 27874 at commit [`1e92854`](https://github.com/apache/spark/commit/1e9285496d260b39d3e3197268a8cbe3b8ae2deb).
    * 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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874#issuecomment-597520508
 
 
   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] wangyum closed pull request #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast

Posted by GitBox <gi...@apache.org>.
wangyum closed pull request #27874: [WIP][SPARK-31114][SQL] Constraints inferred from equality constraints with cast
URL: https://github.com/apache/spark/pull/27874
 
 
   

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