You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by maropu <gi...@git.apache.org> on 2018/09/21 05:09:44 UTC

[GitHub] spark pull request #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite fai...

GitHub user maropu opened a pull request:

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

    [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures when the interpreter mode enabled

    ## What changes were proposed in this pull request?
    This pr fixed test failures in `SQLQueryTestSuite` when the interpreter mode enabled. This pr addressed the two cases below;
    -  The current `InterpretedMutableProjection` can't handle `UnsafeRow` in the internal buffer `mutableRow`. `AggregationIterator` uses `MutableProjection` in that manner and `GenerateMutableProjection` can handle `UnsafeRow` as buffer internally.
    - `Literal` returns different a typed value between codegen and interpreter modes in some cases, e.g., `Literal(1, LongType)` returns a long value for the codegen mode and returns an int value for the interpreter mode. So, `InterpretedUnsafeProjection` fails when running `SQLQueryTestSuite`.
    
    ## How was this patch tested?
    Existing tests.

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

    $ git pull https://github.com/maropu/spark InterpreterTest

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

    https://github.com/apache/spark/pull/22512.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 #22512
    
----
commit 39c5e92713b86f342e756591235f9cbe25126f90
Author: Takeshi Yamamuro <ya...@...>
Date:   2018-09-21T04:25:53Z

    Fix test failures with the interpreter mode enabled

----


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97962 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97962/testReport)** for PR 22512 at commit [`56698bb`](https://github.com/apache/spark/commit/56698bb3dc428474e032915185fab936b64d4984).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4460/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r227609747
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/InternalRow.scala ---
    @@ -143,4 +144,24 @@ object InternalRow {
         case u: UserDefinedType[_] => getAccessor(u.sqlType)
         case _ => (input, ordinal) => input.get(ordinal, dataType)
       }
    +
    +  /**
    +   * Returns a writer for an `InternalRow` with given data type.
    +   */
    +  def getWriter(ordinal: Int, dt: DataType): (InternalRow, Any) => Unit = dt match {
    +    case BooleanType => (input, v) => input.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType => (input, v) => input.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType => (input, v) => input.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType => (input, v) => input.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType => (input, v) => input.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType => (input, v) => input.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType => (input, v) => input.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      (input, v) => input.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: ObjectType | _: UserDefinedType[_] =>
    +      (input, v) => input.update(ordinal, v)
    +    case NullType => (input, v) => {}
    --- End diff --
    
    ok


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99601 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99601/testReport)** for PR 22512 at commit [`4cdc504`](https://github.com/apache/spark/commit/4cdc5040feb3da1e4cf9efcf434138d5873fae04).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97952 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97952/testReport)** for PR 22512 at commit [`a014145`](https://github.com/apache/spark/commit/a014145f94c3c771b42e7a2e73bd67d596ea802e).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

Posted by maropu <gi...@git.apache.org>.
Github user maropu commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    I'm looking into the failure reason... (passed in the local, but failed in the jenkins...)


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

Posted by maropu <gi...@git.apache.org>.
Github user maropu commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    ok, I'll add tests.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96923 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96923/testReport)** for PR 22512 at commit [`31c623f`](https://github.com/apache/spark/commit/31c623fbe2aa88f8533fd4d477a125f62cc8ab6e).


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227200656
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -49,10 +51,54 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
       def currentValue: InternalRow = mutableRow
     
       override def target(row: InternalRow): MutableProjection = {
    +    // If `mutableRow` is `UnsafeRow`, `MutableProjection` accepts fixed-length types only
    +    assert(!row.isInstanceOf[UnsafeRow] ||
    +      validExprs.forall { case (e, _) => UnsafeRow.isFixedLength(e.dataType) })
         mutableRow = row
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    --- End diff --
    
    we have `InternalRow.getAccessor`, shall we move this method there too?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r227226902
  
    --- Diff: sql/core/src/test/scala/org/apache/spark/sql/SQLQueryTestSuite.scala ---
    @@ -140,6 +141,14 @@ class SQLQueryTestSuite extends QueryTest with SharedSQLContext {
         val input = fileToString(new File(testCase.inputFile))
     
         val (comments, code) = input.split("\n").partition(_.startsWith("--"))
    +
    +    // Runs all the tests on both codegen-only and interpreter modes. Since explain results differ
    +    // when `WHOLESTAGE_CODEGEN_ENABLED` disabled, we don't run these tests now.
    +    val codegenConfigSets = Array(("false", "NO_CODEGEN"), ("true", "CODEGEN_ONLY")).map {
    +      case (wholeStageCodegenEnabled, codegenFactoryMode) =>
    +        Array( // SQLConf.WHOLESTAGE_CODEGEN_ENABLED.key -> wholeStageCodegenEnabled,
    --- End diff --
    
    ok


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5641/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3982/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3670/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #98058 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/98058/testReport)** for PR 22512 at commit [`5227e42`](https://github.com/apache/spark/commit/5227e422cda4d110c6b5a950ebdc49d6e25914f1).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r238172470
  
    --- Diff: sql/core/src/test/scala/org/apache/spark/sql/SQLQueryTestSuite.scala ---
    @@ -148,12 +156,21 @@ class SQLQueryTestSuite extends QueryTest with SharedSQLContext {
           })
           // When we are regenerating the golden files we don't need to run all the configs as they
           // all need to return the same result
    -      if (regenerateGoldenFiles && configs.nonEmpty) {
    +      if (regenerateGoldenFiles) {
             configs.take(1)
    --- End diff --
    
    what if `configs` is empty? `take(1)` will fail


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r238489997
  
    --- Diff: sql/core/src/test/scala/org/apache/spark/sql/SQLQueryTestSuite.scala ---
    @@ -148,12 +156,25 @@ class SQLQueryTestSuite extends QueryTest with SharedSQLContext {
           })
           // When we are regenerating the golden files we don't need to run all the configs as they
           // all need to return the same result
    -      if (regenerateGoldenFiles && configs.nonEmpty) {
    -        configs.take(1)
    +      if (regenerateGoldenFiles) {
    +        if (configs.nonEmpty) {
    +          configs.take(1)
    +        } else {
    +          Array.empty[Array[(String, String)]]
    --- End diff --
    
    ok


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite fai...

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

    https://github.com/apache/spark/pull/22512#discussion_r222530205
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/literals.scala ---
    @@ -238,7 +262,9 @@ object DecimalLiteral {
     /**
      * In order to do type checking, use Literal.create() instead of constructor
      */
    -case class Literal (value: Any, dataType: DataType) extends LeafExpression {
    +case class Literal(value: Any, dataType: DataType) extends LeafExpression {
    +
    +  Literal.validateLiteralValue(value, dataType)
    --- End diff --
    
    I'm not sure though, is it ok for `Literal` to have a different Scala-typed value for the corresponding `dataType`? , e.g., `new Literal(1 /* int value */, LongType)`? In the current master, there are some places to do so, e.g., 
    https://github.com/apache/spark/blob/927e527934a882fab89ca661c4eb31f84c45d830/sql/core/src/main/scala/org/apache/spark/sql/execution/command/AnalyzeColumnCommand.scala#L213
    https://github.com/apache/spark/blob/927e527934a882fab89ca661c4eb31f84c45d830/sql/catalyst/src/test/scala/org/apache/spark/sql/catalyst/analysis/TypeCoercionSuite.scala#L796
    
    In the codegen path, this is ok because we add a correct literal suffix in `Literal.doGenCode` (e.g., `1L` for `new Literal(1, LongType)`);
    https://github.com/apache/spark/blob/927e527934a882fab89ca661c4eb31f84c45d830/sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/literals.scala#L294
    
    But, in the non-codegen path (e.g., `spark.sql.codegen.factoryMode=NO_CODEGEN` and `ConstantFolding`), this case throws an exception ;
    ```
    
    scala> import org.apache.spark.sql.Column
    scala> import org.apache.spark.sql.catalyst.expressions.Literal
    scala> import org.apache.spark.sql.types._
    scala> val intOne: Int = 1
    scala> val lit = Literal.create(intOne, LongType)
    scala> spark.range(1).select(struct(new Column(lit))).collect
    18/10/04 11:35:56 ERROR Executor: Exception in task 3.0 in stage 0.0 (TID 3)
    java.lang.ClassCastException: java.lang.Integer cannot be cast to java.lang.Long
    	at scala.runtime.BoxesRunTime.unboxToLong(BoxesRunTime.java:105)
    	at org.apache.spark.sql.catalyst.expressions.BaseGenericInternalRow$class.getLong(rows.scala:42)
    	at org.apache.spark.sql.catalyst.expressions.GenericInternalRow.getLong(rows.scala:195)
    	at org.apache.spark.sql.catalyst.expressions.GeneratedClass$GeneratedIteratorForCodegenStage1.processNext(Unknown Source)
    	at org.apache.spark.sql.execution.BufferedRowIterator.hasNext(BufferedRowIterator.java:43)
    	at org.apache.spark.sql.execution.WholeStageCodegenExec$$anonfun$11$$anon$1.hasNext(WholeStageCodegenExec.scala:619)
        ...
    ```
    
    WDYT? cc: @gatorsmile @cloud-fan


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227238888
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -49,10 +51,54 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
       def currentValue: InternalRow = mutableRow
     
       override def target(row: InternalRow): MutableProjection = {
    +    // If `mutableRow` is `UnsafeRow`, `MutableProjection` accepts fixed-length types only
    +    assert(!row.isInstanceOf[UnsafeRow] ||
    +      validExprs.forall { case (e, _) => UnsafeRow.isFixedLength(e.dataType) })
         mutableRow = row
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    +    case BooleanType =>
    +      v => mutableRow.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType =>
    +      v => mutableRow.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType =>
    +      v => mutableRow.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType =>
    +      v => mutableRow.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType =>
    +      v => mutableRow.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType =>
    +      v => mutableRow.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType =>
    +      v => mutableRow.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      v => mutableRow.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: UserDefinedType[_] =>
    +      v => mutableRow.update(ordinal, v)
    +    case NullType =>
    +      v => {}
    --- End diff --
    
    the corresponding logic in the codegen version is simply call `row.update(null, i)`.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

Posted by maropu <gi...@git.apache.org>.
Github user maropu commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    retest this please


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

Posted by maropu <gi...@git.apache.org>.
Github user maropu commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    I made a new pr to address the Literal issue #22724


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

Posted by maropu <gi...@git.apache.org>.
Github user maropu commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    I thought we currently had less tests for interpreted projections, so I was checking if we had no bug caused by these projections. Then, I noticed these two issues when the interpreted mode enabled in `SQLQueryTestSuite`. I'm still digging if we have other bugs about interpreted projections, so I set `WIP`.
    
    Btw, we'd be better to split this pr into multiple ones, probably. But, I'd like to make all the related bugs clear first.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r238328405
  
    --- Diff: sql/core/src/test/scala/org/apache/spark/sql/SQLQueryTestSuite.scala ---
    @@ -148,12 +156,25 @@ class SQLQueryTestSuite extends QueryTest with SharedSQLContext {
           })
           // When we are regenerating the golden files we don't need to run all the configs as they
           // all need to return the same result
    -      if (regenerateGoldenFiles && configs.nonEmpty) {
    -        configs.take(1)
    +      if (regenerateGoldenFiles) {
    +        if (configs.nonEmpty) {
    +          configs.take(1)
    +        } else {
    +          Array.empty[Array[(String, String)]]
    --- End diff --
    
    nit: since configs don't matter when generating result, I think we can just return empty configs here. We can clean it up in a followup PR.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4432/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97390 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97390/testReport)** for PR 22512 at commit [`8e4f2b8`](https://github.com/apache/spark/commit/8e4f2b88221d1fc47ed16718d614193499408da5).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97960 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97960/testReport)** for PR 22512 at commit [`31d75ba`](https://github.com/apache/spark/commit/31d75baeccfd811aaec2d099e3e994cf59a676c8).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97901 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97901/testReport)** for PR 22512 at commit [`b8c5a17`](https://github.com/apache/spark/commit/b8c5a177b2ac72b35ad89d7076a063117568c768).


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite fai...

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/22512#discussion_r222532952
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -53,6 +55,47 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    +    case BooleanType =>
    +      v => mutableRow.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType =>
    +      v => mutableRow.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType =>
    +      v => mutableRow.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType =>
    +      v => mutableRow.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType =>
    +      v => mutableRow.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType =>
    +      v => mutableRow.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType =>
    +      v => mutableRow.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      v => mutableRow.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: UserDefinedType[_] =>
    +      v => mutableRow.update(ordinal, v)
    --- End diff --
    
    `UnsafeRow` doesn't support it, right?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97974 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97974/testReport)** for PR 22512 at commit [`d5ff351`](https://github.com/apache/spark/commit/d5ff3517fdf02a127c19b2be6b516a9cf0c80807).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96405 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96405/testReport)** for PR 22512 at commit [`39c5e92`](https://github.com/apache/spark/commit/39c5e92713b86f342e756591235f9cbe25126f90).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:
      * `      s\"but $`
      * `case class Literal(value: Any, dataType: DataType) extends LeafExpression `


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97989 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97989/testReport)** for PR 22512 at commit [`634dc23`](https://github.com/apache/spark/commit/634dc23220704762ea0c922f03ce948984862af2).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99217 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99217/testReport)** for PR 22512 at commit [`5227e42`](https://github.com/apache/spark/commit/5227e422cda4d110c6b5a950ebdc49d6e25914f1).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97998 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97998/testReport)** for PR 22512 at commit [`aec5a53`](https://github.com/apache/spark/commit/aec5a53090bc28592889feb055d64cf851ca9720).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97960 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97960/testReport)** for PR 22512 at commit [`31d75ba`](https://github.com/apache/spark/commit/31d75baeccfd811aaec2d099e3e994cf59a676c8).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97391 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97391/testReport)** for PR 22512 at commit [`2766bd1`](https://github.com/apache/spark/commit/2766bd19c0ac7e321eead159105055e24cd73ac3).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

Posted by kiszk <gi...@git.apache.org>.
Github user kiszk commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    retest this please


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3347/
    Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r238176184
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -64,7 +85,7 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
         i = 0
         while (i < validExprs.length) {
           val (_, ordinal) = validExprs(i)
    -      mutableRow(ordinal) = buffer(ordinal)
    +      fieldWriters(i)(buffer(ordinal))
    --- End diff --
    
    fixed in https://github.com/apache/spark/pull/22512/commits/95411c8b8b76503dff93756482642083a694b0b7


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96923 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96923/testReport)** for PR 22512 at commit [`31c623f`](https://github.com/apache/spark/commit/31c623fbe2aa88f8533fd4d477a125f62cc8ab6e).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97391 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97391/testReport)** for PR 22512 at commit [`2766bd1`](https://github.com/apache/spark/commit/2766bd19c0ac7e321eead159105055e24cd73ac3).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227433044
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/InternalRow.scala ---
    @@ -143,4 +144,24 @@ object InternalRow {
         case u: UserDefinedType[_] => getAccessor(u.sqlType)
         case _ => (input, ordinal) => input.get(ordinal, dataType)
       }
    +
    +  /**
    +   * Returns a writer for an `InternalRow` with given data type.
    +   */
    +  def getWriter(ordinal: Int, dt: DataType): (InternalRow, Any) => Unit = dt match {
    +    case BooleanType => (input, v) => input.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType => (input, v) => input.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType => (input, v) => input.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType => (input, v) => input.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType => (input, v) => input.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType => (input, v) => input.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType => (input, v) => input.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      (input, v) => input.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: ObjectType | _: UserDefinedType[_] =>
    --- End diff --
    
    we should recursive into UDT.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4402/
    Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227618778
  
    --- Diff: sql/catalyst/src/test/scala/org/apache/spark/sql/catalyst/expressions/MutableProjectionSuite.scala ---
    @@ -0,0 +1,66 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.sql.catalyst.expressions
    +
    +import org.apache.spark.SparkFunSuite
    +import org.apache.spark.sql.Row
    +import org.apache.spark.sql.catalyst.{CatalystTypeConverters, InternalRow}
    +import org.apache.spark.sql.types._
    +import org.apache.spark.unsafe.types.CalendarInterval
    +
    +class MutableProjectionSuite extends SparkFunSuite with ExpressionEvalHelper {
    +
    +  private def createMutableProjection(dataTypes: Array[DataType]): MutableProjection = {
    +    MutableProjection.create(dataTypes.zipWithIndex.map(x => BoundReference(x._2, x._1, true)))
    +  }
    +
    +  testBothCodegenAndInterpreted("fixed-length types") {
    +    val fixedLengthTypes = Array[DataType](
    +      BooleanType, ByteType, ShortType, IntegerType, LongType, FloatType, DoubleType,
    +      DateType, TimestampType)
    +    val proj = createMutableProjection(fixedLengthTypes)
    +    val inputRow = InternalRow.fromSeq(
    +      Seq(false, 3.toByte, 15.toShort, -83, 129L, 1.0f, 5.0, 100, 200L))
    +    assert(proj(inputRow) === inputRow)
    +
    +    // Use UnsafeRow as buffer
    +    val numBytes = UnsafeRow.calculateBitSetWidthInBytes(fixedLengthTypes.length)
    +    val unsafeBuffer = UnsafeRow.createFromByteArray(numBytes, fixedLengthTypes.length)
    +    val projUnsafeRow = proj.target(unsafeBuffer)(inputRow)
    +    assert(FromUnsafeProjection(fixedLengthTypes)(projUnsafeRow) === inputRow)
    +  }
    +
    +  testBothCodegenAndInterpreted("variable-length types") {
    +    val variableLengthTypes = Array(
    +      StringType, DecimalType.defaultConcreteType, CalendarIntervalType, BinaryType,
    +      ArrayType(StringType), MapType(IntegerType, StringType),
    +      StructType.fromDDL("a INT, b STRING"), ObjectType(classOf[java.lang.Integer]))
    +    val proj = createMutableProjection(variableLengthTypes)
    --- End diff --
    
    shall we also test that we should fail if the target row is unsafe row?


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227202171
  
    --- Diff: sql/core/src/test/scala/org/apache/spark/sql/SQLQueryTestSuite.scala ---
    @@ -140,6 +141,14 @@ class SQLQueryTestSuite extends QueryTest with SharedSQLContext {
         val input = fileToString(new File(testCase.inputFile))
     
         val (comments, code) = input.split("\n").partition(_.startsWith("--"))
    +
    +    // Runs all the tests on both codegen-only and interpreter modes. Since explain results differ
    +    // when `WHOLESTAGE_CODEGEN_ENABLED` disabled, we don't run these tests now.
    +    val codegenConfigSets = Array(("false", "NO_CODEGEN"), ("true", "CODEGEN_ONLY")).map {
    +      case (wholeStageCodegenEnabled, codegenFactoryMode) =>
    +        Array( // SQLConf.WHOLESTAGE_CODEGEN_ENABLED.key -> wholeStageCodegenEnabled,
    --- End diff --
    
    If `wholeStageCodegenEnabled` is not used, let's not complicate the code now.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4430/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99601 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99601/testReport)** for PR 22512 at commit [`4cdc504`](https://github.com/apache/spark/commit/4cdc5040feb3da1e4cf9efcf434138d5873fae04).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97974 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97974/testReport)** for PR 22512 at commit [`d5ff351`](https://github.com/apache/spark/commit/d5ff3517fdf02a127c19b2be6b516a9cf0c80807).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96922 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96922/testReport)** for PR 22512 at commit [`78795be`](https://github.com/apache/spark/commit/78795be1d877242279b52c990878e86ef338c243).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97962 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97962/testReport)** for PR 22512 at commit [`56698bb`](https://github.com/apache/spark/commit/56698bb3dc428474e032915185fab936b64d4984).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r227224030
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -49,10 +51,54 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
       def currentValue: InternalRow = mutableRow
     
       override def target(row: InternalRow): MutableProjection = {
    +    // If `mutableRow` is `UnsafeRow`, `MutableProjection` accepts fixed-length types only
    +    assert(!row.isInstanceOf[UnsafeRow] ||
    +      validExprs.forall { case (e, _) => UnsafeRow.isFixedLength(e.dataType) })
         mutableRow = row
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    +    case BooleanType =>
    +      v => mutableRow.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType =>
    +      v => mutableRow.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType =>
    +      v => mutableRow.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType =>
    +      v => mutableRow.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType =>
    +      v => mutableRow.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType =>
    +      v => mutableRow.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType =>
    +      v => mutableRow.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      v => mutableRow.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: UserDefinedType[_] =>
    +      v => mutableRow.update(ordinal, v)
    +    case NullType =>
    +      v => {}
    --- End diff --
    
    We need to take care of `e.nullable && e.dataType == NullType` here?


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227200458
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -49,10 +51,54 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
       def currentValue: InternalRow = mutableRow
     
       override def target(row: InternalRow): MutableProjection = {
    +    // If `mutableRow` is `UnsafeRow`, `MutableProjection` accepts fixed-length types only
    +    assert(!row.isInstanceOf[UnsafeRow] ||
    +      validExprs.forall { case (e, _) => UnsafeRow.isFixedLength(e.dataType) })
         mutableRow = row
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    +    case BooleanType =>
    +      v => mutableRow.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType =>
    +      v => mutableRow.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType =>
    +      v => mutableRow.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType =>
    +      v => mutableRow.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType =>
    +      v => mutableRow.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType =>
    +      v => mutableRow.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType =>
    +      v => mutableRow.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      v => mutableRow.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: UserDefinedType[_] =>
    +      v => mutableRow.update(ordinal, v)
    +    case NullType =>
    +      v => {}
    --- End diff --
    
    shall we call `mutableRow.setNullAt`?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3983/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97952 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97952/testReport)** for PR 22512 at commit [`a014145`](https://github.com/apache/spark/commit/a014145f94c3c771b42e7a2e73bd67d596ea802e).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96395 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96395/testReport)** for PR 22512 at commit [`39c5e92`](https://github.com/apache/spark/commit/39c5e92713b86f342e756591235f9cbe25126f90).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4441/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5647/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96430 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96430/testReport)** for PR 22512 at commit [`bff88ee`](https://github.com/apache/spark/commit/bff88ee81f57900cca38df8455c4a2eb78b4b758).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:
      * `      s\"but $`
      * `case class Literal(value: Any, dataType: DataType) extends LeafExpression `


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97390 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97390/testReport)** for PR 22512 at commit [`8e4f2b8`](https://github.com/apache/spark/commit/8e4f2b88221d1fc47ed16718d614193499408da5).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4391/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97961 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97961/testReport)** for PR 22512 at commit [`932d6f5`](https://github.com/apache/spark/commit/932d6f5e30bc9352582ac098c719b47af6bf41fb).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    @maropu are you still working on it?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r227224209
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -49,10 +51,54 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
       def currentValue: InternalRow = mutableRow
     
       override def target(row: InternalRow): MutableProjection = {
    +    // If `mutableRow` is `UnsafeRow`, `MutableProjection` accepts fixed-length types only
    +    assert(!row.isInstanceOf[UnsafeRow] ||
    +      validExprs.forall { case (e, _) => UnsafeRow.isFixedLength(e.dataType) })
         mutableRow = row
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    --- End diff --
    
    oh, yes! yea, I will.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

Posted by maropu <gi...@git.apache.org>.
Github user maropu commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    This is a simple query to reproduce;
    ```
    
    $ SPARK_TESTING=1 ./bin/spark-shell
    scala> sql("SET spark.sql.codegen.factoryMode=NO_CODEGEN")
    scala> sql("CREATE TABLE desc_col_table (key int COMMENT 'column_comment') USING PARQUET")
    scala> sql("""ANALYZE TABLE desc_col_table COMPUTE STATISTICS FOR COLUMNS key""")
    org.apache.spark.SparkException: Job aborted due to stage failure: Task 0 in stage 1.0 failed 1 times, most recent failure: Lost task 0.0 in stage 1.0 (TID 0, localhost, executor driver): java.lang.UnsupportedOperationException
    	at org.apache.spark.sql.catalyst.expressions.UnsafeRow.update(UnsafeRow.java:206)
    	at org.apache.spark.sql.catalyst.expressions.InterpretedMutableProjection.apply(InterpretedMutableProjection.scala:67)
    	at org.apache.spark.sql.catalyst.expressions.InterpretedMutableProjection.apply(InterpretedMutableProjection.scala:31)
    	at org.apache.spark.sql.execution.aggregate.TungstenAggregationIterator.createNewAggregationBuffer(TungstenAggregationIterator.scala:129)
    	at org.apache.spark.sql.execution.aggregate.TungstenAggregationIterator.<init>(TungstenAggregationIterator.scala:156)
    	at org.apache.spark.sql.execution.aggregate.HashAggregateExec$$anonfun$doExecute$1$$anonfun$4.apply(HashAggregateExec.scala:112)
    	at org.apache.spark.sql.execution.aggregate.HashAggregateExec$$anonfun$doExecute$1$$anonfun$4.apply(HashAggregateExec.scala:102)
    ```


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97989 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97989/testReport)** for PR 22512 at commit [`634dc23`](https://github.com/apache/spark/commit/634dc23220704762ea0c922f03ce948984862af2).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r238177033
  
    --- Diff: sql/core/src/test/scala/org/apache/spark/sql/SQLQueryTestSuite.scala ---
    @@ -148,12 +156,21 @@ class SQLQueryTestSuite extends QueryTest with SharedSQLContext {
           })
           // When we are regenerating the golden files we don't need to run all the configs as they
           // all need to return the same result
    -      if (regenerateGoldenFiles && configs.nonEmpty) {
    +      if (regenerateGoldenFiles) {
             configs.take(1)
    --- End diff --
    
    For better readability, fixed in https://github.com/apache/spark/pull/22512/commits/4cdc5040feb3da1e4cf9efcf434138d5873fae04


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97901 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97901/testReport)** for PR 22512 at commit [`b8c5a17`](https://github.com/apache/spark/commit/b8c5a177b2ac72b35ad89d7076a063117568c768).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99590 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99590/testReport)** for PR 22512 at commit [`3553d91`](https://github.com/apache/spark/commit/3553d9121f085fcbee480ce75084f9320d2b2fc8).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r227626505
  
    --- Diff: sql/catalyst/src/test/scala/org/apache/spark/sql/catalyst/expressions/MutableProjectionSuite.scala ---
    @@ -0,0 +1,66 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.sql.catalyst.expressions
    +
    +import org.apache.spark.SparkFunSuite
    +import org.apache.spark.sql.Row
    +import org.apache.spark.sql.catalyst.{CatalystTypeConverters, InternalRow}
    +import org.apache.spark.sql.types._
    +import org.apache.spark.unsafe.types.CalendarInterval
    +
    +class MutableProjectionSuite extends SparkFunSuite with ExpressionEvalHelper {
    +
    +  private def createMutableProjection(dataTypes: Array[DataType]): MutableProjection = {
    +    MutableProjection.create(dataTypes.zipWithIndex.map(x => BoundReference(x._2, x._1, true)))
    +  }
    +
    +  testBothCodegenAndInterpreted("fixed-length types") {
    +    val fixedLengthTypes = Array[DataType](
    +      BooleanType, ByteType, ShortType, IntegerType, LongType, FloatType, DoubleType,
    +      DateType, TimestampType)
    +    val proj = createMutableProjection(fixedLengthTypes)
    +    val inputRow = InternalRow.fromSeq(
    +      Seq(false, 3.toByte, 15.toShort, -83, 129L, 1.0f, 5.0, 100, 200L))
    +    assert(proj(inputRow) === inputRow)
    +
    +    // Use UnsafeRow as buffer
    +    val numBytes = UnsafeRow.calculateBitSetWidthInBytes(fixedLengthTypes.length)
    +    val unsafeBuffer = UnsafeRow.createFromByteArray(numBytes, fixedLengthTypes.length)
    +    val projUnsafeRow = proj.target(unsafeBuffer)(inputRow)
    +    assert(FromUnsafeProjection(fixedLengthTypes)(projUnsafeRow) === inputRow)
    +  }
    +
    +  testBothCodegenAndInterpreted("variable-length types") {
    +    val variableLengthTypes = Array(
    +      StringType, DecimalType.defaultConcreteType, CalendarIntervalType, BinaryType,
    +      ArrayType(StringType), MapType(IntegerType, StringType),
    +      StructType.fromDDL("a INT, b STRING"), ObjectType(classOf[java.lang.Integer]))
    +    val proj = createMutableProjection(variableLengthTypes)
    --- End diff --
    
    sure.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227618313
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/InternalRow.scala ---
    @@ -143,4 +144,25 @@ object InternalRow {
         case u: UserDefinedType[_] => getAccessor(u.sqlType)
         case _ => (input, ordinal) => input.get(ordinal, dataType)
       }
    +
    +  /**
    +   * Returns a writer for an `InternalRow` with given data type.
    +   */
    +  def getWriter(ordinal: Int, dt: DataType): (InternalRow, Any) => Unit = dt match {
    +    case BooleanType => (input, v) => input.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType => (input, v) => input.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType => (input, v) => input.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType => (input, v) => input.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType => (input, v) => input.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType => (input, v) => input.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType => (input, v) => input.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      (input, v) => input.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: ObjectType =>
    +      (input, v) => input.update(ordinal, v)
    +    case udt: UserDefinedType[_] => getWriter(ordinal, udt.sqlType)
    +    case NullType => (input, _) => input.setNullAt(ordinal)
    +    case _ => throw new SparkException(s"Unsupported data type $dt")
    --- End diff --
    
    one minor point: the codegen version just call `row.update` for un-caught types, which means it supports object type as well. Shall we follow?


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r238151565
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -64,7 +85,7 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
         i = 0
         while (i < validExprs.length) {
           val (_, ordinal) = validExprs(i)
    -      mutableRow(ordinal) = buffer(ordinal)
    +      fieldWriters(i)(buffer(ordinal))
    --- End diff --
    
    ah, sounds reasonable. I'll update later.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96430 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96430/testReport)** for PR 22512 at commit [`bff88ee`](https://github.com/apache/spark/commit/bff88ee81f57900cca38df8455c4a2eb78b4b758).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    thanks, merging to master!


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97923 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97923/testReport)** for PR 22512 at commit [`58e885a`](https://github.com/apache/spark/commit/58e885a36b791e3f4ce38d402bfeab357d89b7a4).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4392/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97961 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97961/testReport)** for PR 22512 at commit [`932d6f5`](https://github.com/apache/spark/commit/932d6f5e30bc9352582ac098c719b47af6bf41fb).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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/22512#discussion_r227432603
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/InternalRow.scala ---
    @@ -143,4 +144,24 @@ object InternalRow {
         case u: UserDefinedType[_] => getAccessor(u.sqlType)
         case _ => (input, ordinal) => input.get(ordinal, dataType)
       }
    +
    +  /**
    +   * Returns a writer for an `InternalRow` with given data type.
    +   */
    +  def getWriter(ordinal: Int, dt: DataType): (InternalRow, Any) => Unit = dt match {
    +    case BooleanType => (input, v) => input.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType => (input, v) => input.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType => (input, v) => input.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType => (input, v) => input.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType => (input, v) => input.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType => (input, v) => input.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType => (input, v) => input.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      (input, v) => input.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: ObjectType | _: UserDefinedType[_] =>
    +      (input, v) => input.update(ordinal, v)
    +    case NullType => (input, v) => {}
    --- End diff --
    
    In the codegen version `CodeGenerator.setColumn`, we don't match NullType and eventually call `row.update(null, i)`. Shall we follow and call `row.setNullAt` here?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    LGTM, we also need a unit test


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite fai...

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

    https://github.com/apache/spark/pull/22512#discussion_r222533632
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/literals.scala ---
    @@ -238,7 +262,9 @@ object DecimalLiteral {
     /**
      * In order to do type checking, use Literal.create() instead of constructor
      */
    -case class Literal (value: Any, dataType: DataType) extends LeafExpression {
    +case class Literal(value: Any, dataType: DataType) extends LeafExpression {
    +
    +  Literal.validateLiteralValue(value, dataType)
    --- End diff --
    
    yea, ok.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99217 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99217/testReport)** for PR 22512 at commit [`5227e42`](https://github.com/apache/spark/commit/5227e422cda4d110c6b5a950ebdc49d6e25914f1).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96395 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96395/testReport)** for PR 22512 at commit [`39c5e92`](https://github.com/apache/spark/commit/39c5e92713b86f342e756591235f9cbe25126f90).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:
      * `      s\"but $`
      * `case class Literal(value: Any, dataType: DataType) extends LeafExpression `


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97923 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97923/testReport)** for PR 22512 at commit [`58e885a`](https://github.com/apache/spark/commit/58e885a36b791e3f4ce38d402bfeab357d89b7a4).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:
      * `class MutableProjectionSuite extends SparkFunSuite with ExpressionEvalHelper `


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96922 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96922/testReport)** for PR 22512 at commit [`78795be`](https://github.com/apache/spark/commit/78795be1d877242279b52c990878e86ef338c243).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99583 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99583/testReport)** for PR 22512 at commit [`243fae3`](https://github.com/apache/spark/commit/243fae30f1be011a92bec31783dcd9dc92db7a38).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3332/
    Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r227609600
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/InternalRow.scala ---
    @@ -143,4 +144,24 @@ object InternalRow {
         case u: UserDefinedType[_] => getAccessor(u.sqlType)
         case _ => (input, ordinal) => input.get(ordinal, dataType)
       }
    +
    +  /**
    +   * Returns a writer for an `InternalRow` with given data type.
    +   */
    +  def getWriter(ordinal: Int, dt: DataType): (InternalRow, Any) => Unit = dt match {
    +    case BooleanType => (input, v) => input.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType => (input, v) => input.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType => (input, v) => input.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType => (input, v) => input.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType => (input, v) => input.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType => (input, v) => input.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType => (input, v) => input.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      (input, v) => input.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: ObjectType | _: UserDefinedType[_] =>
    --- End diff --
    
    ok


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite fai...

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

    https://github.com/apache/spark/pull/22512#discussion_r222534352
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/literals.scala ---
    @@ -162,6 +163,14 @@ object Literal {
         Literal(CatalystTypeConverters.convertToCatalyst(v), dataType)
    --- End diff --
    
    I think this API (`def create(v: Any, dataType: DataType): Literal`) might be a little obscure: `create(scalaValue, dataType)` vs `create(catalystValue, dataType)`. How about splitting this API into the two below?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5658/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4379/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5309/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

Posted by maropu <gi...@git.apache.org>.
Github user maropu commented on the issue:

    https://github.com/apache/spark/pull/22512
  
    Yea, I'll update in a few days.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4431/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4513/
    Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r227626456
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/InternalRow.scala ---
    @@ -143,4 +144,25 @@ object InternalRow {
         case u: UserDefinedType[_] => getAccessor(u.sqlType)
         case _ => (input, ordinal) => input.get(ordinal, dataType)
       }
    +
    +  /**
    +   * Returns a writer for an `InternalRow` with given data type.
    +   */
    +  def getWriter(ordinal: Int, dt: DataType): (InternalRow, Any) => Unit = dt match {
    +    case BooleanType => (input, v) => input.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType => (input, v) => input.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType => (input, v) => input.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType => (input, v) => input.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType => (input, v) => input.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType => (input, v) => input.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType => (input, v) => input.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      (input, v) => input.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: ObjectType =>
    +      (input, v) => input.update(ordinal, v)
    +    case udt: UserDefinedType[_] => getWriter(ordinal, udt.sqlType)
    +    case NullType => (input, _) => input.setNullAt(ordinal)
    +    case _ => throw new SparkException(s"Unsupported data type $dt")
    --- End diff --
    
    ok


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99583 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99583/testReport)** for PR 22512 at commit [`243fae3`](https://github.com/apache/spark/commit/243fae30f1be011a92bec31783dcd9dc92db7a38).


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite fai...

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

    https://github.com/apache/spark/pull/22512#discussion_r222533960
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -53,6 +55,47 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    +    case BooleanType =>
    +      v => mutableRow.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType =>
    +      v => mutableRow.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType =>
    +      v => mutableRow.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType =>
    +      v => mutableRow.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType =>
    +      v => mutableRow.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType =>
    +      v => mutableRow.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType =>
    +      v => mutableRow.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      v => mutableRow.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: UserDefinedType[_] =>
    +      v => mutableRow.update(ordinal, v)
    --- End diff --
    
    oh, yes. I'll recheck again.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r238146834
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -64,7 +85,7 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
         i = 0
         while (i < validExprs.length) {
           val (_, ordinal) = validExprs(i)
    -      mutableRow(ordinal) = buffer(ordinal)
    +      fieldWriters(i)(buffer(ordinal))
    --- End diff --
    
    Since `fieldWriters` is accessed via index, we should use `IndexedSeq` or `Array` explicitly?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5657/
    Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #99590 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99590/testReport)** for PR 22512 at commit [`3553d91`](https://github.com/apache/spark/commit/3553d9121f085fcbee480ce75084f9320d2b2fc8).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r225140616
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/InterpretedMutableProjection.scala ---
    @@ -53,6 +55,47 @@ class InterpretedMutableProjection(expressions: Seq[Expression]) extends Mutable
         this
       }
     
    +  private[this] val fieldWriters = validExprs.map { case (e, i) =>
    +    val writer = generateRowWriter(i, e.dataType)
    +    if (!e.nullable) {
    +      (v: Any) => writer(v)
    +    } else {
    +      (v: Any) => {
    +        if (v == null) {
    +          mutableRow.setNullAt(i)
    +        } else {
    +          writer(v)
    +        }
    +      }
    +    }
    +  }
    +
    +  private def generateRowWriter(ordinal: Int, dt: DataType): Any => Unit = dt match {
    +    case BooleanType =>
    +      v => mutableRow.setBoolean(ordinal, v.asInstanceOf[Boolean])
    +    case ByteType =>
    +      v => mutableRow.setByte(ordinal, v.asInstanceOf[Byte])
    +    case ShortType =>
    +      v => mutableRow.setShort(ordinal, v.asInstanceOf[Short])
    +    case IntegerType | DateType =>
    +      v => mutableRow.setInt(ordinal, v.asInstanceOf[Int])
    +    case LongType | TimestampType =>
    +      v => mutableRow.setLong(ordinal, v.asInstanceOf[Long])
    +    case FloatType =>
    +      v => mutableRow.setFloat(ordinal, v.asInstanceOf[Float])
    +    case DoubleType =>
    +      v => mutableRow.setDouble(ordinal, v.asInstanceOf[Double])
    +    case DecimalType.Fixed(precision, _) =>
    +      v => mutableRow.setDecimal(ordinal, v.asInstanceOf[Decimal], precision)
    +    case CalendarIntervalType | BinaryType | _: ArrayType | StringType | _: StructType |
    +         _: MapType | _: UserDefinedType[_] =>
    +      v => mutableRow.update(ordinal, v)
    --- End diff --
    
    This match should only accept the generic internal rows, so I added code to verify types for the `UnsafeRow` case;
    https://github.com/apache/spark/pull/22512/files#diff-3ed819282d4e4941571dd3b08fc03e37R55


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3981/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #98058 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/98058/testReport)** for PR 22512 at commit [`5227e42`](https://github.com/apache/spark/commit/5227e422cda4d110c6b5a950ebdc49d6e25914f1).


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL] InterpretedMutableProjection s...

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

    https://github.com/apache/spark/pull/22512#discussion_r238175630
  
    --- Diff: sql/core/src/test/scala/org/apache/spark/sql/SQLQueryTestSuite.scala ---
    @@ -148,12 +156,21 @@ class SQLQueryTestSuite extends QueryTest with SharedSQLContext {
           })
           // When we are regenerating the golden files we don't need to run all the configs as they
           // all need to return the same result
    -      if (regenerateGoldenFiles && configs.nonEmpty) {
    +      if (regenerateGoldenFiles) {
             configs.take(1)
    --- End diff --
    
    Actually, it returns an empty array?
    ```
    scala> Array.empty.take(1)
    res0: Array[Nothing] = Array()
    
    scala> Seq.empty.take(1)
    res1: Seq[Nothing] = List()
    ```


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97886 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97886/testReport)** for PR 22512 at commit [`79c435a`](https://github.com/apache/spark/commit/79c435aade61436b2e636cee215e73d3137c8133).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3324/
    Test PASSed.


---

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


[GitHub] spark pull request #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite fai...

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/22512#discussion_r222533085
  
    --- Diff: sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/literals.scala ---
    @@ -238,7 +262,9 @@ object DecimalLiteral {
     /**
      * In order to do type checking, use Literal.create() instead of constructor
      */
    -case class Literal (value: Any, dataType: DataType) extends LeafExpression {
    +case class Literal(value: Any, dataType: DataType) extends LeafExpression {
    +
    +  Literal.validateLiteralValue(value, dataType)
    --- End diff --
    
    I think we should not allow it. Can you send a separated PR for this change?


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97902 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97902/testReport)** for PR 22512 at commit [`45e65e5`](https://github.com/apache/spark/commit/45e65e5b3e61f702ebcb1203e95434051adbe437).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4424/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97886 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97886/testReport)** for PR 22512 at commit [`79c435a`](https://github.com/apache/spark/commit/79c435aade61436b2e636cee215e73d3137c8133).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

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


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/3671/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97998 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97998/testReport)** for PR 22512 at commit [`aec5a53`](https://github.com/apache/spark/commit/aec5a53090bc28592889feb055d64cf851ca9720).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #97902 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/97902/testReport)** for PR 22512 at commit [`45e65e5`](https://github.com/apache/spark/commit/45e65e5b3e61f702ebcb1203e95434051adbe437).


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL] InterpretedMutableProjection should h...

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

    https://github.com/apache/spark/pull/22512
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/4452/
    Test PASSed.


---

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


[GitHub] spark issue #22512: [SPARK-25498][SQL][WIP] Fix SQLQueryTestSuite failures w...

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

    https://github.com/apache/spark/pull/22512
  
    **[Test build #96405 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/96405/testReport)** for PR 22512 at commit [`39c5e92`](https://github.com/apache/spark/commit/39c5e92713b86f342e756591235f9cbe25126f90).


---

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