You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by davies <gi...@git.apache.org> on 2016/04/13 01:15:49 UTC

[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

GitHub user davies opened a pull request:

    https://github.com/apache/spark/pull/12342

    [SPARK-14581] [SQL] push predicatese through more logical plans

    ## What changes were proposed in this pull request?
    
    Right now, filter push down only works with Project, Aggregate, Generate and Join, they can't be pushed through many other plans.
    
    This PR added support for Union, Intersect, Except and all unary plans.
    
    ## How was this patch tested?
    
    Added tests.
    


You can merge this pull request into a Git repository by running:

    $ git pull https://github.com/davies/spark filter_hint

Alternatively you can review and apply these changes as the patch at:

    https://github.com/apache/spark/pull/12342.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

    This closes #12342
    
----
commit d43919c8fec28c0b31d3318f5df9942dfbbc024c
Author: Davies Liu <da...@databricks.com>
Date:   2016-04-12T22:08:59Z

    improve filter push down

commit 2329623e2b899f1e782e4118f5b0ba89c023593d
Author: Davies Liu <da...@databricks.com>
Date:   2016-04-12T22:47:32Z

    push filter for Union and intersect

----


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209296124
  
    **[Test build #55697 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55697/consoleFull)** for PR 12342 at commit [`388dbc0`](https://github.com/apache/spark/commit/388dbc0b42e4e376283460e7055571f7a92e7afd).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59492551
  
    --- Diff: sql/catalyst/src/test/scala/org/apache/spark/sql/catalyst/optimizer/FilterPushdownSuite.scala ---
    @@ -681,4 +679,67 @@ class FilterPushdownSuite extends PlanTest {
     
         comparePlans(optimized, correctAnswer)
       }
    +
    +  test("broadcast hint") {
    +    val originalQuery = BroadcastHint(testRelation)
    +      .where('a === 2L && 'b + Rand(10).as("rnd") === 3)
    +
    +    val optimized = Optimize.execute(originalQuery.analyze)
    +
    +    val correctAnswer = BroadcastHint(testRelation.where('a === 2L))
    +      .where('b + Rand(10).as("rnd") === 3)
    +      .analyze
    +
    +    comparePlans(optimized, correctAnswer)
    +  }
    +
    +  test("union") {
    +    val testRelation2 = LocalRelation('d.int, 'e.int, 'f.int)
    +
    +    val originalQuery = Union(Seq(testRelation, testRelation2))
    +      .where('a === 2L && 'b + Rand(10).as("rnd") === 3)
    +
    +    val optimized = Optimize.execute(originalQuery.analyze)
    +
    +    val correctAnswer = Union(Seq(
    +      testRelation.where('a === 2L && 'b + Rand(10).as("rnd") === 3),
    --- End diff --
    
    the non-deterministic expression shouldn't be pushed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59470693
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -915,41 +913,7 @@ object PushPredicateThroughProject extends Rule[LogicalPlan] with PredicateHelpe
           })
     
           project.copy(child = Filter(replaceAlias(condition, aliasMap), grandChild))
    -  }
    -
    -}
    -
    -/**
    - * Push [[Filter]] operators through [[Generate]] operators. Parts of the predicate that reference
    - * attributes generated in [[Generate]] will remain above, and the rest should be pushed beneath.
    - */
    -object PushPredicateThroughGenerate extends Rule[LogicalPlan] with PredicateHelper {
    -
    -  def apply(plan: LogicalPlan): LogicalPlan = plan transform {
    -    case filter @ Filter(condition, g: Generate) =>
    --- End diff --
    
    This case is included in the UnaryNode case


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209233666
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209606448
  
    Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209623241
  
    Merging this into master, thanks!


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209162587
  
    **[Test build #55662 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55662/consoleFull)** for PR 12342 at commit [`2329623`](https://github.com/apache/spark/commit/2329623e2b899f1e782e4118f5b0ba89c023593d).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59487786
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    +      val output = u.output
    +      val newChildren = u.children.map { child =>
    +        val attrMap: Map[Expression, Expression] = output.zip(child.output).toMap
    +        val newCond = condition transform {
    +          case e if attrMap.contains(e) => attrMap(e)
    +        }
    +        Filter(newCond, child)
    +      }
    +      Union(newChildren)
    +
    +    case filter @ Filter(condition, i: Intersect) =>
    +      // Intersect could change the rows, so non-deterministic predicate can't be pushed down
    +      val (pushDown, stayUp) = splitConjunctivePredicates(condition).partition { cond =>
    +        cond.deterministic
    +      }
    +      if (pushDown.nonEmpty) {
    +        val pushDownCond = pushDown.reduceLeft(And)
    +        val output = i.output
    +        val newChildren = i.children.map { child =>
    +          val attrMap: Map[Expression, Expression] = output.zip(child.output).toMap
    +          val newCond = pushDownCond transform {
    +            case e if attrMap.contains(e) => attrMap(e)
    +          }
    +          Filter(newCond, child)
    +        }
    +        val newIntersect = i.withNewChildren(newChildren)
    +        if (stayUp.nonEmpty) {
    +          Filter(stayUp.reduceLeft(And), newIntersect)
    +        } else {
    +          newIntersect
    +        }
    +      } else {
    +        filter
    +      }
    +
    +    case filter @ Filter(condition, e @ Except(left, _)) =>
    +      pushDownPredicate(filter, e, e.left) { pushDown =>
    +        e.copy(left = Filter(pushDown, left))
    +      }
    +
    +    case filter @ Filter(condition, u: UnaryNode) if u.expressions.forall(_.deterministic) =>
    --- End diff --
    
    Sample and Sort could change the rows, just to be safe.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209164137
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/55663/
    Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209147366
  
    **[Test build #55663 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55663/consoleFull)** for PR 12342 at commit [`8fdf31b`](https://github.com/apache/spark/commit/8fdf31b086171e09fccde03454edf36ad30baa62).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209146531
  
    **[Test build #55662 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55662/consoleFull)** for PR 12342 at commit [`2329623`](https://github.com/apache/spark/commit/2329623e2b899f1e782e4118f5b0ba89c023593d).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209164021
  
    **[Test build #55663 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55663/consoleFull)** for PR 12342 at commit [`8fdf31b`](https://github.com/apache/spark/commit/8fdf31b086171e09fccde03454edf36ad30baa62).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209218940
  
    **[Test build #55685 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55685/consoleFull)** for PR 12342 at commit [`3c11e4c`](https://github.com/apache/spark/commit/3c11e4c2084475b2cb3c7542fd519f58b92dc178).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209162971
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209232569
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/55685/
    Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209232491
  
    **[Test build #55685 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55685/consoleFull)** for PR 12342 at commit [`3c11e4c`](https://github.com/apache/spark/commit/3c11e4c2084475b2cb3c7542fd519f58b92dc178).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209565845
  
    **[Test build #55731 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55731/consoleFull)** for PR 12342 at commit [`71a8317`](https://github.com/apache/spark/commit/71a83173cad945a087626c583496192f9fb482c3).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209233403
  
    **[Test build #55686 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55686/consoleFull)** for PR 12342 at commit [`099b668`](https://github.com/apache/spark/commit/099b66886a7a4650f6eea2cb2061cb7ebcfad3d3).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59488521
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    --- End diff --
    
    yea I agree, but this depends on the current implementation of `Union`, and it's weird to use the RDD partition stuff while working on SQL optimization rules...


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209296274
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209219838
  
    **[Test build #55686 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55686/consoleFull)** for PR 12342 at commit [`099b668`](https://github.com/apache/spark/commit/099b66886a7a4650f6eea2cb2061cb7ebcfad3d3).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59492783
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +940,68 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, child)
    +      if child.isInstanceOf[Union] || child.isInstanceOf[Intersect] =>
    +      // Union/Intersect could change the rows, so non-deterministic predicate can't be pushed down
    +      val (pushDown, stayUp) = splitConjunctivePredicates(condition).partition { cond =>
    +        cond.deterministic
    +      }
    +      if (pushDown.nonEmpty) {
    +        val pushDownCond = pushDown.reduceLeft(And)
    +        val output = child.output
    +        val newGrandChildren = child.children.map { grandchild =>
    +          val newCond = pushDownCond transform {
    +            case e if output.exists(_.semanticEquals(e)) =>
    --- End diff --
    
    this can be simplified to: `case a: Attributes => grandchild.output(output.indexWhere(_.semanticEquals(a)))`
    The filter condition can only reference to child output, so all attribute should be exist in `child.output`


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209217192
  
    @cloud-fan Most of the predicates are determistic, so I'd like to not push down non-determistic predicate aggresively in this PR.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209605702
  
    **[Test build #55731 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55731/consoleFull)** for PR 12342 at commit [`71a8317`](https://github.com/apache/spark/commit/71a83173cad945a087626c583496192f9fb482c3).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59486756
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    --- End diff --
    
    I think we can't push filter down if the condition is non-determinstic


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59486877
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    --- End diff --
    
    The rows in child of Union should be exactly the same as Union, I think we could push it down.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209606455
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/55731/
    Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209209559
  
    My general thoughts about filter push down: If the filter's condition is non-deterministic, we shouldn't push it down through some operators that will change the number or order of the input rows, e.g. set operations, others should be ok, e.g. the following optimization is allowed:
    ```
    // From:
    df.select('a, 'b).filter('c > rand(42))
    // To:
    df.filter('c > rand(42)).select('a, 'b)
    ```
    If the underlying operator contains non-deterministic expression, filter push down is not allowed. Currently only 4 operator may contain non-deterministic expression: Project, Filter, Aggregate, Window


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209164134
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59487855
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    --- End diff --
    
    Each state should be separate in partition, Union does not change the partition. Coalesce() could change that.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209249372
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/55688/
    Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies closed the pull request at:

    https://github.com/apache/spark/pull/12342


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59487580
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    --- End diff --
    
    "non-determinstic" means the condition has internal state and may change every time it processes an input row. Before push down, we have only one stateful condition that processes all output rows of `Union`. But if we push it down, then each child of `Union` will have a stateful condition, I think it's different than before.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59487680
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    +      val output = u.output
    +      val newChildren = u.children.map { child =>
    +        val attrMap: Map[Expression, Expression] = output.zip(child.output).toMap
    +        val newCond = condition transform {
    +          case e if attrMap.contains(e) => attrMap(e)
    +        }
    +        Filter(newCond, child)
    +      }
    +      Union(newChildren)
    +
    +    case filter @ Filter(condition, i: Intersect) =>
    +      // Intersect could change the rows, so non-deterministic predicate can't be pushed down
    +      val (pushDown, stayUp) = splitConjunctivePredicates(condition).partition { cond =>
    +        cond.deterministic
    +      }
    +      if (pushDown.nonEmpty) {
    +        val pushDownCond = pushDown.reduceLeft(And)
    +        val output = i.output
    +        val newChildren = i.children.map { child =>
    +          val attrMap: Map[Expression, Expression] = output.zip(child.output).toMap
    +          val newCond = pushDownCond transform {
    +            case e if attrMap.contains(e) => attrMap(e)
    +          }
    +          Filter(newCond, child)
    +        }
    +        val newIntersect = i.withNewChildren(newChildren)
    +        if (stayUp.nonEmpty) {
    +          Filter(stayUp.reduceLeft(And), newIntersect)
    +        } else {
    +          newIntersect
    +        }
    +      } else {
    +        filter
    +      }
    +
    +    case filter @ Filter(condition, e @ Except(left, _)) =>
    +      pushDownPredicate(filter, e, e.left) { pushDown =>
    +        e.copy(left = Filter(pushDown, left))
    +      }
    +
    +    case filter @ Filter(condition, u: UnaryNode) if u.expressions.forall(_.deterministic) =>
    --- End diff --
    
    For `UnaryNode`, I think we can also push down non-deterministic filter, as long as this operator doesn't re-order the input rows(do we have such an operator?)


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by davies <gi...@git.apache.org>.
Github user davies commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209146107
  
    cc @marmbrus @cloud-fan 


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209233668
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/55686/
    Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by rxin <gi...@git.apache.org>.
Github user rxin commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59471369
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -898,7 +896,7 @@ object PruneFilters extends Rule[LogicalPlan] with PredicateHelper {
      *
      * This heuristic is valid assuming the expression evaluation cost is minimal.
      */
    -object PushPredicateThroughProject extends Rule[LogicalPlan] with PredicateHelper {
    +object PushPredicate extends Rule[LogicalPlan] with PredicateHelper {
    --- End diff --
    
    name this PushDownPredicate?


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209248699
  
    **[Test build #55688 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55688/consoleFull)** for PR 12342 at commit [`21c8482`](https://github.com/apache/spark/commit/21c848267346e974b1845198083da070537f558e).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209228701
  
    **[Test build #55688 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55688/consoleFull)** for PR 12342 at commit [`21c8482`](https://github.com/apache/spark/commit/21c848267346e974b1845198083da070537f558e).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209162975
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/55662/
    Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by marmbrus <gi...@git.apache.org>.
Github user marmbrus commented on a diff in the pull request:

    https://github.com/apache/spark/pull/12342#discussion_r59490343
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/optimizer/Optimizer.scala ---
    @@ -975,6 +939,73 @@ object PushPredicateThroughAggregate extends Rule[LogicalPlan] with PredicateHel
           } else {
             filter
           }
    +
    +    case filter @ Filter(condition, u: Union) =>
    --- End diff --
    
    +1 we should probably avoid nondeterministic predicates.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209228199
  
    LGTM


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209265290
  
    **[Test build #55697 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/55697/consoleFull)** for PR 12342 at commit [`388dbc0`](https://github.com/apache/spark/commit/388dbc0b42e4e376283460e7055571f7a92e7afd).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209296276
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/55697/
    Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-14581] [SQL] push predicatese through m...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the pull request:

    https://github.com/apache/spark/pull/12342#issuecomment-209232566
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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