You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by liancheng <gi...@git.apache.org> on 2015/12/18 12:53:07 UTC

[GitHub] spark pull request: [SPARK-12218] Fixes ORC conjunction predicate ...

GitHub user liancheng opened a pull request:

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

    [SPARK-12218] Fixes ORC conjunction predicate push down

    This PR is a follow-up of PR #10362.
    
    Two major changes:
    
    1.  The fix introduced in #10362 is OK for Parquet, but may disable ORC PPD in many cases
    
        The fix introduced in #10362 stops converting an `AND` predicate if any branch is inconvertible.  On the other hand, `OrcFilters` combines all filters into a single big conjunction first and then tries to convert it into ORC `SearchArgument`.  This means, if any filter is inconvertible, no filters can be pushed down.  This PR fixes this issue by finding out all convertible filters first before doing the actual conversion.
    
        The reason behind the current implementation is mostly due to the limitation of ORC `SearchArgument` builder, which is documented in this PR in detail.
    
    1.  Copied the `AND` predicate fix for ORC from #10362 to avoid merge conflict.

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

    $ git pull https://github.com/liancheng/spark spark-12218.fix-orc-conjunction-ppd

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

    https://github.com/apache/spark/pull/10377.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 #10377
    
----
commit 11486080f755ef39097d6cbbe851264b2d539ef1
Author: Cheng Lian <li...@databricks.com>
Date:   2015-12-18T11:32:46Z

    Fixes ORC conjunction predicate push 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165937566
  
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165780597
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/48001/
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165764622
  
    **[Test build #48001 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48001/consoleFull)** for PR 10377 at commit [`1148608`](https://github.com/apache/spark/commit/11486080f755ef39097d6cbbe851264b2d539ef1).


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48374926
  
    --- Diff: sql/hive/src/test/scala/org/apache/spark/sql/hive/orc/OrcSourceSuite.scala ---
    @@ -174,4 +175,33 @@ class OrcSourceSuite extends OrcSuite {
              |)
            """.stripMargin)
       }
    +
    +  test("SPARK-12218 Converting conjunctions into ORC SearchArguments") {
    +    // The `LessThan` should be converted while the `StringContains` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        StringContains("b", "prefix")
    +      )).get.toString
    +    }
    +
    +    // The `LessThan` should be converted while the whole inner `And` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        Not(And(
    +          GreaterThan("a", 1),
    +          StringContains("b", "prefix")
    +        ))
    +      )).get.toString
    --- End diff --
    
    Actually, can we have a similar test for parquet? Right now, we only have a query test that will not trigger this anymore.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165937445
  
    **[Test build #48042 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48042/consoleFull)** for PR 10377 at commit [`e5913d2`](https://github.com/apache/spark/commit/e5913d25244597c0be2458d0a23d2e2f3f2f3a78).
     * 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165791655
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/48005/
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165791651
  
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48374725
  
    --- Diff: sql/hive/src/main/scala/org/apache/spark/sql/hive/orc/OrcFilters.scala ---
    @@ -50,37 +82,18 @@ private[orc] object OrcFilters extends Logging {
           case _ => false
         }
     
    -    // lian: I probably missed something here, and had to end up with a pretty weird double-checking
    -    // pattern when converting `And`/`Or`/`Not` filters.
    -    //
    -    // The annoying part is that, `SearchArgument` builder methods like `startAnd()` `startOr()`,
    -    // and `startNot()` mutate internal state of the builder instance.  This forces us to translate
    -    // all convertible filters with a single builder instance. However, before actually converting a
    -    // filter, we've no idea whether it can be recognized by ORC or not. Thus, when an inconvertible
    -    // filter is found, we may already end up with a builder whose internal state is inconsistent.
    -    //
    -    // For example, to convert an `And` filter with builder `b`, we call `b.startAnd()` first, and
    -    // then try to convert its children.  Say we convert `left` child successfully, but find that
    -    // `right` child is inconvertible.  Alas, `b.startAnd()` call can't be rolled back, and `b` is
    -    // inconsistent now.
    -    //
    -    // The workaround employed here is that, for `And`/`Or`/`Not`, we first try to convert their
    -    // children with brand new builders, and only do the actual conversion with the right builder
    -    // instance when the children are proven to be convertible.
    -    //
    -    // P.S.: Hive seems to use `SearchArgument` together with `ExprNodeGenericFuncDesc` only.
    -    // Usage of builder methods mentioned above can only be found in test code, where all tested
    -    // filters are known to be convertible.
    -
         expression match {
           case And(left, right) =>
    -        // At here, it is not safe to just convert one side if we do not understand the
    -        // other side. Here is an example used to explain the reason.
    -        // Let's say we have NOT(a = 2 AND b in ('1')) and we do not understand how to
    -        // convert b in ('1'). If we only convert a = 2, we will end up with a filter
    -        // NOT(a = 2), which will generate wrong results.
    -        // Pushing one side of AND down is only safe to do at the top level.
    -        // You can see ParquetRelation's initializeLocalJobFunc method as an example.
    +        // Conventionally, it's safe to push down only one branch of an `And` predicate even if the
    +        // other branch is inconvertible.  However, it's not safe to do so here.  Because the `And`
    +        // predicate maybe nested within a `Not` predicate.  Take the following predicate as an
    --- End diff --
    
    Should we just remove the sentence starting with `Conventionally`? If we do not know the parent predicate of `AND`, we cannot make decision if it is ok to push.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48374780
  
    --- Diff: sql/hive/src/test/scala/org/apache/spark/sql/hive/orc/OrcHadoopFsRelationSuite.scala ---
    @@ -23,6 +23,7 @@ import org.apache.spark.deploy.SparkHadoopUtil
     import org.apache.spark.sql.{Row, SQLConf}
     import org.apache.spark.sql.sources.HadoopFsRelationTest
     import org.apache.spark.sql.types._
    +import org.apache.spark.sql.{Row, SQLConf}
    --- End diff --
    
    Remove this?


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165819666
  
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167031314
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/48270/
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48390319
  
    --- Diff: sql/hive/src/main/scala/org/apache/spark/sql/hive/orc/OrcFilters.scala ---
    @@ -26,15 +26,47 @@ import org.apache.spark.Logging
     import org.apache.spark.sql.sources._
     
     /**
    - * It may be optimized by push down partial filters. But we are conservative here.
    - * Because if some filters fail to be parsed, the tree may be corrupted,
    - * and cannot be used anymore.
    + * Helper object for building ORC `SearchArgument`s, which are used for ORC predicate push-down.
    + *
    + * Due to limitation of ORC `SearchArgument` builder, we had to end up with a pretty weird double-
    + * checking pattern when converting `And`/`Or`/`Not` filters.
    + *
    + * An ORC `SearchArgument` must be built in one pass using a single builder.  For example, you can't
    + * build `a = 1` and `b = 2` first, and then combine them into `a = 1 AND b = 2`.  This is quite
    + * different from the cases in Spark SQL or Parquet, where complex filters can be easily built using
    + * existing simpler ones.
    + *
    + * The annoying part is that, `SearchArgument` builder methods like `startAnd()`, `startOr()`, and
    + * `startNot()` mutate internal state of the builder instance.  This forces us to translate all
    + * convertible filters with a single builder instance. However, before actually converting a filter,
    + * we've no idea whether it can be recognized by ORC or not. Thus, when an inconvertible filter is
    + * found, we may already end up with a builder whose internal state is inconsistent.
    + *
    + * For example, to convert an `And` filter with builder `b`, we call `b.startAnd()` first, and then
    + * try to convert its children.  Say we convert `left` child successfully, but find that `right`
    + * child is inconvertible.  Alas, `b.startAnd()` call can't be rolled back, and `b` is inconsistent
    + * now.
    + *
    + * The workaround employed here is that, for `And`/`Or`/`Not`, we first try to convert their
    --- End diff --
    
    `buildSearchArgument` is recursive, so nested `And`/`Or`/`Not` within top level filters are also covered.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48390321
  
    --- Diff: sql/hive/src/main/scala/org/apache/spark/sql/hive/orc/OrcFilters.scala ---
    @@ -50,37 +82,18 @@ private[orc] object OrcFilters extends Logging {
           case _ => false
         }
     
    -    // lian: I probably missed something here, and had to end up with a pretty weird double-checking
    -    // pattern when converting `And`/`Or`/`Not` filters.
    -    //
    -    // The annoying part is that, `SearchArgument` builder methods like `startAnd()` `startOr()`,
    -    // and `startNot()` mutate internal state of the builder instance.  This forces us to translate
    -    // all convertible filters with a single builder instance. However, before actually converting a
    -    // filter, we've no idea whether it can be recognized by ORC or not. Thus, when an inconvertible
    -    // filter is found, we may already end up with a builder whose internal state is inconsistent.
    -    //
    -    // For example, to convert an `And` filter with builder `b`, we call `b.startAnd()` first, and
    -    // then try to convert its children.  Say we convert `left` child successfully, but find that
    -    // `right` child is inconvertible.  Alas, `b.startAnd()` call can't be rolled back, and `b` is
    -    // inconsistent now.
    -    //
    -    // The workaround employed here is that, for `And`/`Or`/`Not`, we first try to convert their
    -    // children with brand new builders, and only do the actual conversion with the right builder
    -    // instance when the children are proven to be convertible.
    -    //
    -    // P.S.: Hive seems to use `SearchArgument` together with `ExprNodeGenericFuncDesc` only.
    -    // Usage of builder methods mentioned above can only be found in test code, where all tested
    -    // filters are known to be convertible.
    -
         expression match {
           case And(left, right) =>
    -        // At here, it is not safe to just convert one side if we do not understand the
    -        // other side. Here is an example used to explain the reason.
    -        // Let's say we have NOT(a = 2 AND b in ('1')) and we do not understand how to
    -        // convert b in ('1'). If we only convert a = 2, we will end up with a filter
    -        // NOT(a = 2), which will generate wrong results.
    -        // Pushing one side of AND down is only safe to do at the top level.
    -        // You can see ParquetRelation's initializeLocalJobFunc method as an example.
    +        // Conventionally, it's safe to push down only one branch of an `And` predicate even if the
    +        // other branch is inconvertible.  However, it's not safe to do so here.  Because the `And`
    +        // predicate maybe nested within a `Not` predicate.  Take the following predicate as an
    --- End diff --
    
    OK, I'll just use the comment you used in Parquet then.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167321196
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/48344/
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167018079
  
    **[Test build #48270 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48270/consoleFull)** for PR 10377 at commit [`f877ffa`](https://github.com/apache/spark/commit/f877ffafbaee0fb53ce85f5d6785423ccbc8bd2b).


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165773766
  
    **[Test build #48005 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48005/consoleFull)** for PR 10377 at commit [`88ad9a3`](https://github.com/apache/spark/commit/88ad9a3cc0538262e815b5ba78d9b8ea3b087378).


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165819478
  
    **[Test build #48006 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48006/consoleFull)** for PR 10377 at commit [`fe1ab88`](https://github.com/apache/spark/commit/fe1ab88666dc399783bc031d3e106fc41a2b0837).
     * 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48390324
  
    --- Diff: sql/hive/src/test/scala/org/apache/spark/sql/hive/orc/OrcHadoopFsRelationSuite.scala ---
    @@ -23,6 +23,7 @@ import org.apache.spark.deploy.SparkHadoopUtil
     import org.apache.spark.sql.{Row, SQLConf}
     import org.apache.spark.sql.sources.HadoopFsRelationTest
     import org.apache.spark.sql.types._
    +import org.apache.spark.sql.{Row, SQLConf}
    --- End diff --
    
    Thanks, done.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165937568
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/48042/
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48390328
  
    --- Diff: sql/hive/src/test/scala/org/apache/spark/sql/hive/orc/OrcSourceSuite.scala ---
    @@ -174,4 +175,33 @@ class OrcSourceSuite extends OrcSuite {
              |)
            """.stripMargin)
       }
    +
    +  test("SPARK-12218 Converting conjunctions into ORC SearchArguments") {
    +    // The `LessThan` should be converted while the `StringContains` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        StringContains("b", "prefix")
    --- End diff --
    
    No, ORC `SearchArgument` doesn't support string operations.


---
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-12218] Fixes ORC conjunction predicate ...

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

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


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167031310
  
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165791503
  
    **[Test build #48005 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48005/consoleFull)** for PR 10377 at commit [`88ad9a3`](https://github.com/apache/spark/commit/88ad9a3cc0538262e815b5ba78d9b8ea3b087378).
     * 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165780594
  
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48446551
  
    --- Diff: sql/hive/src/test/scala/org/apache/spark/sql/hive/orc/OrcSourceSuite.scala ---
    @@ -174,4 +175,33 @@ class OrcSourceSuite extends OrcSuite {
              |)
            """.stripMargin)
       }
    +
    +  test("SPARK-12218 Converting conjunctions into ORC SearchArguments") {
    +    // The `LessThan` should be converted while the `StringContains` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        StringContains("b", "prefix")
    +      )).get.toString
    +    }
    +
    +    // The `LessThan` should be converted while the whole inner `And` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        Not(And(
    +          GreaterThan("a", 1),
    +          StringContains("b", "prefix")
    +        ))
    +      )).get.toString
    --- End diff --
    
    Actually added the Parquet test 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165780487
  
    **[Test build #48001 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48001/consoleFull)** for PR 10377 at commit [`1148608`](https://github.com/apache/spark/commit/11486080f755ef39097d6cbbe851264b2d539ef1).
     * 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48374840
  
    --- Diff: sql/hive/src/test/scala/org/apache/spark/sql/hive/orc/OrcSourceSuite.scala ---
    @@ -174,4 +175,33 @@ class OrcSourceSuite extends OrcSuite {
              |)
            """.stripMargin)
       }
    +
    +  test("SPARK-12218 Converting conjunctions into ORC SearchArguments") {
    +    // The `LessThan` should be converted while the `StringContains` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        StringContains("b", "prefix")
    --- End diff --
    
    `StringContains` is not supported?


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165792084
  
    **[Test build #48006 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48006/consoleFull)** for PR 10377 at commit [`fe1ab88`](https://github.com/apache/spark/commit/fe1ab88666dc399783bc031d3e106fc41a2b0837).


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48374502
  
    --- Diff: sql/hive/src/main/scala/org/apache/spark/sql/hive/orc/OrcFilters.scala ---
    @@ -26,15 +26,47 @@ import org.apache.spark.Logging
     import org.apache.spark.sql.sources._
     
     /**
    - * It may be optimized by push down partial filters. But we are conservative here.
    - * Because if some filters fail to be parsed, the tree may be corrupted,
    - * and cannot be used anymore.
    + * Helper object for building ORC `SearchArgument`s, which are used for ORC predicate push-down.
    + *
    + * Due to limitation of ORC `SearchArgument` builder, we had to end up with a pretty weird double-
    + * checking pattern when converting `And`/`Or`/`Not` filters.
    + *
    + * An ORC `SearchArgument` must be built in one pass using a single builder.  For example, you can't
    + * build `a = 1` and `b = 2` first, and then combine them into `a = 1 AND b = 2`.  This is quite
    + * different from the cases in Spark SQL or Parquet, where complex filters can be easily built using
    + * existing simpler ones.
    + *
    + * The annoying part is that, `SearchArgument` builder methods like `startAnd()`, `startOr()`, and
    + * `startNot()` mutate internal state of the builder instance.  This forces us to translate all
    + * convertible filters with a single builder instance. However, before actually converting a filter,
    + * we've no idea whether it can be recognized by ORC or not. Thus, when an inconvertible filter is
    + * found, we may already end up with a builder whose internal state is inconsistent.
    + *
    + * For example, to convert an `And` filter with builder `b`, we call `b.startAnd()` first, and then
    + * try to convert its children.  Say we convert `left` child successfully, but find that `right`
    + * child is inconvertible.  Alas, `b.startAnd()` call can't be rolled back, and `b` is inconsistent
    + * now.
    + *
    + * The workaround employed here is that, for `And`/`Or`/`Not`, we first try to convert their
    --- End diff --
    
    Do we need to mention `for And Or Not`? `createFilter` is dealing with the top level filters (they will be connected by `AND`), right? I think it is important to emphasize that `createFilter` is for top level filters.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167320980
  
    **[Test build #48344 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48344/consoleFull)** for PR 10377 at commit [`6c59503`](https://github.com/apache/spark/commit/6c59503f84dd1fa227f1d6dd9102fbb3de21bf0c).
     * 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165870814
  
    sorry.. My commit introduced a conflict...


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167030998
  
    **[Test build #48270 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48270/consoleFull)** for PR 10377 at commit [`f877ffa`](https://github.com/apache/spark/commit/f877ffafbaee0fb53ce85f5d6785423ccbc8bd2b).
     * 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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165929066
  
    @yhuai Nvm, rebased.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167735494
  
    Thanks for the review!


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165819669
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/48006/
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167321193
  
    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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#discussion_r48390348
  
    --- Diff: sql/hive/src/test/scala/org/apache/spark/sql/hive/orc/OrcSourceSuite.scala ---
    @@ -174,4 +175,33 @@ class OrcSourceSuite extends OrcSuite {
              |)
            """.stripMargin)
       }
    +
    +  test("SPARK-12218 Converting conjunctions into ORC SearchArguments") {
    +    // The `LessThan` should be converted while the `StringContains` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        StringContains("b", "prefix")
    +      )).get.toString
    +    }
    +
    +    // The `LessThan` should be converted while the whole inner `And` shouldn't
    +    assertResult(
    +      """leaf-0 = (LESS_THAN a 10)
    +        |expr = leaf-0
    +      """.stripMargin.trim
    +    ) {
    +      OrcFilters.createFilter(Array(
    +        LessThan("a", 10),
    +        Not(And(
    +          GreaterThan("a", 1),
    +          StringContains("b", "prefix")
    +        ))
    +      )).get.toString
    --- End diff --
    
    OK, will open a follow up PR for this.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-167601702
  
    LGTM. Merging to master.


---
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-12218] Fixes ORC conjunction predicate ...

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

    https://github.com/apache/spark/pull/10377#issuecomment-165929767
  
    **[Test build #48042 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48042/consoleFull)** for PR 10377 at commit [`e5913d2`](https://github.com/apache/spark/commit/e5913d25244597c0be2458d0a23d2e2f3f2f3a78).


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