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

[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

GitHub user tedyu opened a pull request:

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

    [SPARK-12415] Do not use closure serializer to serialize task result

    As the name suggests, closure serializer is for closures. We should be able to use the generic serializer for task results. If we want to do this we need to register `org.apache.spark.scheduler.TaskResult` if we use Kryo.
    
    @andrewor14 
    Please review

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

    $ git pull https://github.com/tedyu/spark master

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

    https://github.com/apache/spark/pull/10368.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 #10368
    
----
commit 6809b164d6dd1dbfe4dd3fe13e0dadf60efa0537
Author: tedyu <yu...@gmail.com>
Date:   2015-12-18T01:11:33Z

    [SPARK-12415] Do not use closure serializer to serialize task result

----


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166028404
  
    **[Test build #48058 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48058/consoleFull)** for PR 10368 at commit [`422ac1c`](https://github.com/apache/spark/commit/422ac1cfd5369e9a00e3d52693bb868048e30ba2).
     * This patch **fails Scala style tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48508806
  
    --- Diff: core/src/main/scala/org/apache/spark/serializer/KryoSerializer.scala ---
    @@ -109,6 +111,9 @@ class KryoSerializer(conf: SparkConf)
         kryo.register(classOf[SerializableJobConf], new KryoJavaSerializer())
         kryo.register(classOf[HttpBroadcast[_]], new KryoJavaSerializer())
         kryo.register(classOf[PythonBroadcast], new KryoJavaSerializer())
    +    kryo.register(classOf[TaskMetrics], new KryoJavaSerializer())
    +    kryo.register(classOf[DirectTaskResult[_]], new KryoJavaSerializer())
    +    kryo.register(classOf[IndirectTaskResult[_]], new KryoJavaSerializer())
    --- End diff --
    
    Moreover, `_accumulatorUpdates` is much more complicated. Its value could be any type, e.g., `SQLMetricValue`. If someone adds a new `SQLMetricValue` type, it's hard for reviewers to recall it will be stored in `TaskMetrics`.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165923726
  
    **[Test build #48039 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48039/consoleFull)** for PR 10368 at commit [`62f4ccc`](https://github.com/apache/spark/commit/62f4ccc6825c6bda4a20e396e9929f8bb4072fff).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167028329
  
    **[Test build #48278 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48278/consoleFull)** for PR 10368 at commit [`ac0199a`](https://github.com/apache/spark/commit/ac0199a11cfc885fa8f062e73b8c439bf9f3cab3).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166046525
  
    **[Test build #2239 has finished](https://amplab.cs.berkeley.edu/jenkins/job/NewSparkPullRequestBuilder/2239/consoleFull)** for PR 10368 at commit [`facf246`](https://github.com/apache/spark/commit/facf2460e184900c66393edd3652607cb4e40b12).
     * This patch **fails executing the `dev/run-tests` script**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167047677
  
    **[Test build #48288 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48288/consoleFull)** for PR 10368 at commit [`a4173eb`](https://github.com/apache/spark/commit/a4173ebf248617fd16864df156516e6c038a09a1).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166358855
  
    **[Test build #48119 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48119/consoleFull)** for PR 10368 at commit [`bc7699c`](https://github.com/apache/spark/commit/bc7699cc2793aeaa74f6a51bd8518dc91f327999).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48507734
  
    --- Diff: core/src/main/scala/org/apache/spark/serializer/KryoSerializer.scala ---
    @@ -109,6 +111,9 @@ class KryoSerializer(conf: SparkConf)
         kryo.register(classOf[SerializableJobConf], new KryoJavaSerializer())
         kryo.register(classOf[HttpBroadcast[_]], new KryoJavaSerializer())
         kryo.register(classOf[PythonBroadcast], new KryoJavaSerializer())
    +    kryo.register(classOf[TaskMetrics], new KryoJavaSerializer())
    +    kryo.register(classOf[DirectTaskResult[_]], new KryoJavaSerializer())
    +    kryo.register(classOf[IndirectTaskResult[_]], new KryoJavaSerializer())
    --- End diff --
    
    bq. people may forget to register new classes if they just add an Option field to TaskMetrics in future
    
    Addition to TaskMetrics would be reviewed, right ?
    A comment can be added to TaskMetrics reminding them to register corresponding class.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48071188
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/TaskResultGetterSuite.scala ---
    @@ -81,6 +81,16 @@ class TaskResultGetterSuite extends SparkFunSuite with BeforeAndAfter with Local
       // as we can make it) so the tests don't take too long.
       def conf: SparkConf = new SparkConf().set("spark.akka.frameSize", "1")
     
    +  test("Kryo serializer for TaskResult") {
    +    val conf1 = new SparkConf(false)
    +    conf1.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer")
    +    conf1.set("spark.kryoserializer.buffer", "1m")
    +    conf1.set("spark.kryoserializer.buffer.max", "2m")
    +    sc = new SparkContext("local", "test", conf1)
    +    val result = sc.parallelize(Seq(1), 1).map(x => 2 * x).reduce((x, y) => x)
    +    assert(result === 2)
    --- End diff --
    
    It's a more specific test. In case we didn't set this one up correctly for some reason this may still pass even if kryo doesn't actually work.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166067939
  
    **[Test build #48070 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48070/consoleFull)** for PR 10368 at commit [`c9ad494`](https://github.com/apache/spark/commit/c9ad49427f040f24fa05878dd9fa77fd8d270135).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48389119
  
    --- Diff: core/src/main/scala/org/apache/spark/executor/TaskMetrics.scala ---
    @@ -215,6 +215,18 @@ class TaskMetrics extends Serializable {
         inputMetrics.foreach(_.updateBytesRead())
       }
     
    +  override def equals(other: Any): Boolean = other match {
    --- End diff --
    
    yeah, that would be preferable actually. In the future if we add more fields to `TaskMetrics` we might forget to add it to `equals`


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48458317
  
    --- Diff: core/src/test/scala/org/apache/spark/HeartbeatReceiverSuite.scala ---
    @@ -220,7 +222,7 @@ class HeartbeatReceiverSuite
         } else {
           assert(!response.reregisterBlockManager)
           // Additionally verify that the scheduler callback is called with the correct parameters
    -      verify(scheduler).executorHeartbeatReceived(
    +      verify(scheduler, VerificationModeFactory.atLeast(1)).executorHeartbeatReceived(
    --- End diff --
    
    @tedyu this still needs attention. Is the rest OK to commit @andrewor14 or are you interested in refining the tests?


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167033459
  
    **[Test build #48279 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48279/consoleFull)** for PR 10368 at commit [`5011926`](https://github.com/apache/spark/commit/501192630532e37223f9f9d9e5fb7a5c7b8936aa).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165865749
  
    Sorry, my comment was misleading. I'm wondering if you can write a simple test that uses `KryoSerializer `. Just to make sure we don't forget to register any class for `Kryo`.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48371257
  
    --- Diff: core/src/main/scala/org/apache/spark/serializer/KryoSerializer.scala ---
    @@ -109,6 +111,9 @@ class KryoSerializer(conf: SparkConf)
         kryo.register(classOf[SerializableJobConf], new KryoJavaSerializer())
         kryo.register(classOf[HttpBroadcast[_]], new KryoJavaSerializer())
         kryo.register(classOf[PythonBroadcast], new KryoJavaSerializer())
    +    kryo.register(classOf[TaskMetrics], new KryoJavaSerializer())
    +    kryo.register(classOf[DirectTaskResult[_]], new KryoJavaSerializer())
    +    kryo.register(classOf[IndirectTaskResult[_]], new KryoJavaSerializer())
    --- End diff --
    
    FYI, each of these calls is actually somewhat expensive. We create thousands of new Kryo serializer instances because we don't reuse them and so we end up calling `register` here many times. There is an outstanding issue [SPARK-12473](https://issues.apache.org/jira/browse/SPARK-12473) to resolve this, but until that is fixed this commit will likely cause minor performance regressions.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167046506
  
    ```
    [info] PostgresIntegrationSuite:
    [info] Exception encountered when attempting to run a suite with class name: org.apache.spark.sql.jdbc.PostgresIntegrationSuite *** ABORTED *** (9 seconds, 292 milliseconds)
    [info]   com.spotify.docker.client.DockerRequestException: Request error: POST unix://localhost:80/containers/bc67f5d74a6cfb298d238cbc53eb6540564c4e642ac630e6448da4dd0871fc37/start: 500
    [info]   at com.spotify.docker.client.DefaultDockerClient.propagate(DefaultDockerClient.java:1133)
    [info]   at com.spotify.docker.client.DefaultDockerClient.request(DefaultDockerClient.java:1104)
    [info]   at com.spotify.docker.client.DefaultDockerClient.startContainer(DefaultDockerClient.java:401)
    ```
    Don't think the above was related to this PR


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48079521
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/TaskResultGetterSuite.scala ---
    @@ -81,6 +81,16 @@ class TaskResultGetterSuite extends SparkFunSuite with BeforeAndAfter with Local
       // as we can make it) so the tests don't take too long.
       def conf: SparkConf = new SparkConf().set("spark.akka.frameSize", "1")
     
    +  test("Kryo serializer for TaskResult") {
    +    val conf1 = new SparkConf(false)
    +    conf1.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer")
    +    conf1.set("spark.kryoserializer.buffer", "1m")
    +    conf1.set("spark.kryoserializer.buffer.max", "2m")
    +    sc = new SparkContext("local", "test", conf1)
    +    val result = sc.parallelize(Seq(1), 1).map(x => 2 * x).reduce((x, y) => x)
    +    assert(result === 2)
    --- End diff --
    
    All I'm suggesting is a test that looks like the one added here:
    https://github.com/apache/spark/commit/de0278286cf6db8df53b0b68918ea114f2c77f1f
    
    In general tests should be as fine-grained as possible. Right now this just does an end-to-end test, which may be sufficient but is quite brittle. E.g. imagine if we change the name of the config or the serializer, then this won't actually test what we want.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167673871
  
    As @zsxwing pointed out, the existing unit tests are not sufficient because they didn't catch the fact that `ShuffleReadMetrics` et al must also be registered. This is because these fields are options. In the future, people are free to add more options fields and it will be hard for reviewers to maintain this additional requirement of registering it with Kryo.
    
    Given this the suggestion is to close this issue for now. Eventually when we get rid of closure serializer altogether (SPARK-12414) we can just replace this one with Java serializer, and add a huge comment why it can't be Kryo.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165936471
  
    **[Test build #48044 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48044/consoleFull)** for PR 10368 at commit [`6e7fb36`](https://github.com/apache/spark/commit/6e7fb36f7741ae31d5e61ded1897a6b6e622621b).


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

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


[GitHub] spark issue #10368: [SPARK-12415] Do not use closure serializer to serialize...

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

    https://github.com/apache/spark/pull/10368
  
    Java:org.apache.spark.SparkException: Task not serializable
    
    Any method used in relation to sorting will be wrongly reported “Task not serializable”
    
    EX:
    
    sims.top(K, new Comparator<Tuple2<Object, Double>>(){})
    
    sc.parallelize(Arrays.asList(_data)).zipWithIndex().sortByKey(new Comparator<Double>)


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165789107
  
    Given the naming, I'm inclined to think you're right. CC @kayousterhout and @davies who have happened to touch these lines last.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48370672
  
    --- Diff: core/src/main/scala/org/apache/spark/executor/TaskMetrics.scala ---
    @@ -215,6 +215,19 @@ class TaskMetrics extends Serializable {
         inputMetrics.foreach(_.updateBytesRead())
       }
     
    +  override def equals(other: Any): Boolean = other match {
    +    case that: TaskMetrics => {
    +      if (this.executorDeserializeTime != that.executorDeserializeTime) return false
    +      if (this.executorRunTime != that.executorRunTime) return false
    +      if (this.resultSize != that.resultSize) return false
    +      if (this.jvmGCTime != that.jvmGCTime) return false
    +      if (this.resultSerializationTime != that.resultSerializationTime) return false
    +      if (this.hostname == null && that.hostname != null) return false
    +      if (this.hostname != null) this.hostname.equals(that.hostname) else true
    +    }
    --- End diff --
    
    it would be better if this looked like:
    ```
    this.executorDeserializeTime == that.executorDeserializeTime &&
    this.executorRunTime == that.executorRunTime &&
    ...
    this.hostname == that.hostname
    ```
    no need to check `equals` here because we're in scala


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166032102
  
    **[Test build #48059 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48059/consoleFull)** for PR 10368 at commit [`b65aeb6`](https://github.com/apache/spark/commit/b65aeb67ea3a8a8bfabead4a7ba86a2dfeb83fa0).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48372644
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskResult.scala ---
    @@ -46,6 +46,26 @@ class DirectTaskResult[T](var valueBytes: ByteBuffer, var accumUpdates: Map[Long
     
       def this() = this(null.asInstanceOf[ByteBuffer], null, null)
     
    +  override def toString: String = valueBytes.toString + " " + accumUpdates + " " + metrics
    +
    +  override def equals(other: Any): Boolean = other match {
    +    case that: DirectTaskResult[_] => {
    +      if (!this.valueBytes.equals(that.valueBytes)) return false
    +
    +      val accumSize = if (accumUpdates != null) accumUpdates.size else 0
    +      val thatAccumSize = if (that.accumUpdates != null) that.accumUpdates.size else 0
    +      if (accumSize != thatAccumSize) return false
    +      if (accumSize > 0) {
    +        val b = this.accumUpdates.keys.forall { key =>
    +          this.accumUpdates.get(key) == that.accumUpdates.get(key)
    +        }
    +        if (!b) return false;
    +      }
    +      this.metrics.equals(that.metrics)
    +    }
    --- End diff --
    
    Also use `==` instead of `equals`.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165934542
  
    **[Test build #48043 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48043/consoleFull)** for PR 10368 at commit [`feedace`](https://github.com/apache/spark/commit/feedace9c293cdfcd5e94be1df7879d1aef7448d).
     * This patch **fails to build**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48070627
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/TaskResultGetterSuite.scala ---
    @@ -81,6 +81,16 @@ class TaskResultGetterSuite extends SparkFunSuite with BeforeAndAfter with Local
       // as we can make it) so the tests don't take too long.
       def conf: SparkConf = new SparkConf().set("spark.akka.frameSize", "1")
     
    +  test("Kryo serializer for TaskResult") {
    +    val conf1 = new SparkConf(false)
    +    conf1.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer")
    +    conf1.set("spark.kryoserializer.buffer", "1m")
    +    conf1.set("spark.kryoserializer.buffer.max", "2m")
    +    sc = new SparkContext("local", "test", conf1)
    +    val result = sc.parallelize(Seq(1), 1).map(x => 2 * x).reduce((x, y) => x)
    +    assert(result === 2)
    --- End diff --
    
    Isn't the above action covered by the new test ?


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167014071
  
    LGTM except some nits. Thanks a lot for fixing this @tedyu 


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165934018
  
    **[Test build #48043 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48043/consoleFull)** for PR 10368 at commit [`feedace`](https://github.com/apache/spark/commit/feedace9c293cdfcd5e94be1df7879d1aef7448d).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167046527
  
    Jenkins, test this please


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167802141
  
    I think the first two days' work aligns with SPARK-12414.
    
    Is it possible to keep that (without modification to KryoSerializer and the new test) ?


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166046523
  
    **[Test build #2239 has started](https://amplab.cs.berkeley.edu/jenkins/job/NewSparkPullRequestBuilder/2239/consoleFull)** for PR 10368 at commit [`facf246`](https://github.com/apache/spark/commit/facf2460e184900c66393edd3652607cb4e40b12).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48389541
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskResult.scala ---
    @@ -46,6 +46,8 @@ class DirectTaskResult[T](var valueBytes: ByteBuffer, var accumUpdates: Map[Long
     
       def this() = this(null.asInstanceOf[ByteBuffer], null, null)
     
    +  override def toString: String = valueBytes.toString + " " + accumUpdates + " " + metrics
    --- End diff --
    
    This would make String form of TaskResult more readable.
    Can this be kept ?


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48513944
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/TaskResultGetterSuite.scala ---
    @@ -81,6 +81,16 @@ class TaskResultGetterSuite extends SparkFunSuite with BeforeAndAfter with Local
       // as we can make it) so the tests don't take too long.
       def conf: SparkConf = new SparkConf().set("spark.akka.frameSize", "1")
     
    +  test("Kryo serializer for TaskResult") {
    +    val conf1 = new SparkConf(false)
    +    conf1.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer")
    --- End diff --
    
    I wasn't aware of SPARK-12414 previously.
    If Java serializer is to be used everywhere, is there some code in this PR that is useful for SPARK-12414 ?


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166060830
  
    Jenkins, test this please.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165632408
  
    **[Test build #47969 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/47969/consoleFull)** for PR 10368 at commit [`267cf40`](https://github.com/apache/spark/commit/267cf408a604889cce861d4492923ca88bd2629d).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166149468
  
    **[Test build #48087 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48087/consoleFull)** for PR 10368 at commit [`86dbca8`](https://github.com/apache/spark/commit/86dbca8e399e260f56c2a27ca1ab9748c83e2962).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167081572
  
    **[Test build #48304 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48304/consoleFull)** for PR 10368 at commit [`a4173eb`](https://github.com/apache/spark/commit/a4173ebf248617fd16864df156516e6c038a09a1).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166034107
  
    **[Test build #48063 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48063/consoleFull)** for PR 10368 at commit [`facf246`](https://github.com/apache/spark/commit/facf2460e184900c66393edd3652607cb4e40b12).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165871041
  
    See if the new test makes sense


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165987346
  
    Modified new test in KryoSerializerSuite.scala
    
    Looks like DirectTaskResult#equals should be defined to compare the fields.
    
    Let me know if the above should be done.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167014373
  
    **[Test build #48269 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48269/consoleFull)** for PR 10368 at commit [`4b5657b`](https://github.com/apache/spark/commit/4b5657b25658d8e06021a55c48d0277d8a569ba3).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167024446
  
    **[Test build #48275 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48275/consoleFull)** for PR 10368 at commit [`846b939`](https://github.com/apache/spark/commit/846b93900b5fcc0f35b30a42c0c6a48f61063014).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48385365
  
    --- Diff: core/src/main/scala/org/apache/spark/executor/TaskMetrics.scala ---
    @@ -215,6 +215,18 @@ class TaskMetrics extends Serializable {
         inputMetrics.foreach(_.updateBytesRead())
       }
     
    +  override def equals(other: Any): Boolean = other match {
    --- End diff --
    
    This is not a correct `equals`. There are other fields in `TaskMetrics`. To make `TaskMetrics.equals` work, there are also other classes need to be updated. Instead, could you just manually compare fields of DirectTaskResult in the tests rather than adding an incorrect `equals`? 


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166999771
  
    **[Test build #48257 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48257/consoleFull)** for PR 10368 at commit [`7cfde71`](https://github.com/apache/spark/commit/7cfde714ba2f7716ba2459f5165f44a254959237).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48389325
  
    --- Diff: core/src/test/scala/org/apache/spark/HeartbeatReceiverSuite.scala ---
    @@ -220,7 +222,7 @@ class HeartbeatReceiverSuite
         } else {
           assert(!response.reregisterBlockManager)
           // Additionally verify that the scheduler callback is called with the correct parameters
    -      verify(scheduler).executorHeartbeatReceived(
    +      verify(scheduler, VerificationModeFactory.atLeast(1)).executorHeartbeatReceived(
    --- End diff --
    
    nit: revert changes to `HeartbeatReceiverSuite`.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165644041
  
    Jenkins, test this please


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165946451
  
    **[Test build #48046 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48046/consoleFull)** for PR 10368 at commit [`25f0d3d`](https://github.com/apache/spark/commit/25f0d3d311b6730f844665e8e6bca2effcfb8737).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48507496
  
    --- Diff: core/src/main/scala/org/apache/spark/serializer/KryoSerializer.scala ---
    @@ -109,6 +111,9 @@ class KryoSerializer(conf: SparkConf)
         kryo.register(classOf[SerializableJobConf], new KryoJavaSerializer())
         kryo.register(classOf[HttpBroadcast[_]], new KryoJavaSerializer())
         kryo.register(classOf[PythonBroadcast], new KryoJavaSerializer())
    +    kryo.register(classOf[TaskMetrics], new KryoJavaSerializer())
    +    kryo.register(classOf[DirectTaskResult[_]], new KryoJavaSerializer())
    +    kryo.register(classOf[IndirectTaskResult[_]], new KryoJavaSerializer())
    --- End diff --
    
    I just found there are more classes need to register, such as `ShuffleReadMetrics`, `OutputMetrics` and `ShuffleWriteMetrics`. The problem is that most fields in `TaskMetrics` are `Option` so the new added unit tests cannot cover them.
    
    Not sure how many people uses `spark.kryo.registrationRequired`. But if they enable it, we will break their codes.
    
    In addition, even if we register all necessary classes now, people may forget to register new classes if they just add an `Option` field in future.
    
    I prefer to close this PR since I don't think this patch buys us much due to the tricky thing introduced.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48384718
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskResult.scala ---
    @@ -46,6 +46,23 @@ class DirectTaskResult[T](var valueBytes: ByteBuffer, var accumUpdates: Map[Long
     
       def this() = this(null.asInstanceOf[ByteBuffer], null, null)
     
    +  override def toString: String = valueBytes.toString + " " + accumUpdates + " " + metrics
    +
    +  override def equals(other: Any): Boolean = other match {
    +    case that: DirectTaskResult[_] => {
    +      val accumEquals =
    +        if (accumUpdates != null) {
    +          accumUpdates.keys.forall { k => accumUpdates.get(k) == that.accumUpdates.get(k) }
    +        } else {
    +          that.accumUpdates == null
    +        }
    +      valueBytes == that.valueBytes &&
    +      metrics == that.metrics &&
    +      accumEquals
    --- End diff --
    
    We can just use `accumUpdates == that.accumUpdates` here.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167025330
  
    **[Test build #48275 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48275/consoleFull)** for PR 10368 at commit [`846b939`](https://github.com/apache/spark/commit/846b93900b5fcc0f35b30a42c0c6a48f61063014).
     * This patch **fails to build**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165633033
  
    **[Test build #47969 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/47969/consoleFull)** for PR 10368 at commit [`267cf40`](https://github.com/apache/spark/commit/267cf408a604889cce861d4492923ca88bd2629d).
     * This patch **fails to build**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166033780
  
    Jenkins, test this please


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165855980
  
    Could you add a test for this issue? Such as, create a result that is not Serializable but supports `Kryo`.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167015292
  
    **[Test build #48269 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48269/consoleFull)** for PR 10368 at commit [`4b5657b`](https://github.com/apache/spark/commit/4b5657b25658d8e06021a55c48d0277d8a569ba3).
     * This patch **fails to build**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165948129
  
    **[Test build #48048 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48048/consoleFull)** for PR 10368 at commit [`c5e02d3`](https://github.com/apache/spark/commit/c5e02d396b5d33c6a704e8873988c3d31b03ff81).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48511217
  
    --- Diff: core/src/main/scala/org/apache/spark/serializer/KryoSerializer.scala ---
    @@ -109,6 +111,9 @@ class KryoSerializer(conf: SparkConf)
         kryo.register(classOf[SerializableJobConf], new KryoJavaSerializer())
         kryo.register(classOf[HttpBroadcast[_]], new KryoJavaSerializer())
         kryo.register(classOf[PythonBroadcast], new KryoJavaSerializer())
    +    kryo.register(classOf[TaskMetrics], new KryoJavaSerializer())
    +    kryo.register(classOf[DirectTaskResult[_]], new KryoJavaSerializer())
    +    kryo.register(classOf[IndirectTaskResult[_]], new KryoJavaSerializer())
    --- End diff --
    
    I see, that does seem like a real problem. Let's move this discussion to the main thread so more people can see.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166061058
  
    **[Test build #48068 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48068/consoleFull)** for PR 10368 at commit [`facf246`](https://github.com/apache/spark/commit/facf2460e184900c66393edd3652607cb4e40b12).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167859672
  
    Thanks for putting the effort into this @tedyu. It did move us forward in the sense that now we know we can't use Kryo for serializing task results. I'm going to close the issue.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48070203
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/TaskResultGetterSuite.scala ---
    @@ -81,6 +81,16 @@ class TaskResultGetterSuite extends SparkFunSuite with BeforeAndAfter with Local
       // as we can make it) so the tests don't take too long.
       def conf: SparkConf = new SparkConf().set("spark.akka.frameSize", "1")
     
    +  test("Kryo serializer for TaskResult") {
    +    val conf1 = new SparkConf(false)
    +    conf1.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer")
    +    conf1.set("spark.kryoserializer.buffer", "1m")
    +    conf1.set("spark.kryoserializer.buffer.max", "2m")
    +    sc = new SparkContext("local", "test", conf1)
    +    val result = sc.parallelize(Seq(1), 1).map(x => 2 * x).reduce((x, y) => x)
    +    assert(result === 2)
    --- End diff --
    
    can you explicitly create a `KryoSerializer` and use it to serialize both `TaskResult`s?


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167018650
  
    Here was why I implemented equals for Map (from #48257):
    {code}
    [info] - Bug: SPARK-12415 *** FAILED *** (3 milliseconds)
    [info]   java.nio.HeapByteBuffer[pos=0 lim=2 cap=2] null org.apache.spark.executor.TaskMetrics@60d6ae17 did not equal java.nio.HeapByteBuffer[pos=0 lim=2 cap=2] Map() org.apache.spark.executor.TaskMetrics@2122833f Deser java.nio.HeapByteBuffer[pos=0 lim=2 cap=2] null org.apache.spark.executor.TaskMetrics@60d6ae17 orig java.nio.HeapByteBuffer[pos=0 lim=2 cap=2] Map() org.apache.spark.executor.TaskMetrics@2122833f (KryoSerializerSuite.scala:163)
    {code}
    One Map was null and one Map was empty.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165670276
  
    **[Test build #47973 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/47973/consoleFull)** for PR 10368 at commit [`0a0a9de`](https://github.com/apache/spark/commit/0a0a9de9258cc994c5991b4d4957fa58dca34052).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48372722
  
    --- Diff: core/src/test/scala/org/apache/spark/serializer/KryoSerializerSuite.scala ---
    @@ -154,6 +155,19 @@ class KryoSerializerSuite extends SparkFunSuite with SharedSparkContext {
           mutable.HashMap(1 -> "one", 2 -> "two", 3 -> "three")))
       }
     
    +  test("Bug: SPARK-12415") {
    +    val ser = new KryoSerializer(conf.clone.set("spark.kryo.registrationRequired", "true"))
    +      .newInstance()
    +    def check[T: ClassTag](t: T) {
    +      val ret = ser.deserialize[T](ser.serialize(t))
    +      assert(ret.equals(t), "Deser " + ret + " orig " + t)
    --- End diff --
    
    Nit: Use `==` insead


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166055164
  
    **[Test build #48067 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48067/consoleFull)** for PR 10368 at commit [`facf246`](https://github.com/apache/spark/commit/facf2460e184900c66393edd3652607cb4e40b12).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48078649
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/TaskResultGetterSuite.scala ---
    @@ -81,6 +81,16 @@ class TaskResultGetterSuite extends SparkFunSuite with BeforeAndAfter with Local
       // as we can make it) so the tests don't take too long.
       def conf: SparkConf = new SparkConf().set("spark.akka.frameSize", "1")
     
    +  test("Kryo serializer for TaskResult") {
    +    val conf1 = new SparkConf(false)
    +    conf1.set("spark.serializer", "org.apache.spark.serializer.KryoSerializer")
    +    conf1.set("spark.kryoserializer.buffer", "1m")
    +    conf1.set("spark.kryoserializer.buffer.max", "2m")
    +    sc = new SparkContext("local", "test", conf1)
    +    val result = sc.parallelize(Seq(1), 1).map(x => 2 * x).reduce((x, y) => x)
    +    assert(result === 2)
    --- End diff --
    
    Please take a look at createTaskResult() in core/src/test/scala/org/apache/spark/scheduler/TaskSetManagerSuite.scala :
    ```
      def createTaskResult(id: Int): DirectTaskResult[Int] = {
        val valueSer = SparkEnv.get.serializer.newInstance()
        new DirectTaskResult[Int](valueSer.serialize(id), mutable.Map.empty, new TaskMetrics)
      }
    ```


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166387628
  
    @andrewor14 @zsxwing 
    Please take another look.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167086261
  
    ```
    sbt.ForkMain$ForkError: org.scalatest.exceptions.TestFailedDueToTimeoutException: The code passed to eventually never returned normally. Attempted 209 times over 10.019028894 seconds. Last failure message: strings.forall({
      ((elem: Any) => DirectKafkaStreamSuite.collectedData.contains(elem))
    }) was false.
    	at org.scalatest.concurrent.Eventually$class.tryTryAgain$1(Eventually.scala:420)
    	at org.scalatest.concurrent.Eventually$class.eventually(Eventually.scala:438)
    	at org.apache.spark.streaming.kafka.DirectKafkaStreamSuite.eventually(DirectKafkaStreamSuite.scala:44)
    	at org.scalatest.concurrent.Eventually$class.eventually(Eventually.scala:307)
    	at org.apache.spark.streaming.kafka.DirectKafkaStreamSuite.eventually(DirectKafkaStreamSuite.scala:44)
    	at org.apache.spark.streaming.kafka.DirectKafkaStreamSuite$$anonfun$5.org$apache$spark$streaming$kafka$DirectKafkaStreamSuite$$anonfun$$sendDataAndWaitForReceive$1(DirectKafkaStreamSuite.scala:249)
    	at org.apache.spark.streaming.kafka.DirectKafkaStreamSuite$$anonfun$5.apply$mcV$sp(DirectKafkaStreamSuite.scala:310)
    	at org.apache.spark.streaming.kafka.DirectKafkaStreamSuite$$anonfun$5.apply(DirectKafkaStreamSuite.scala:235)
    	at org.apache.spark.streaming.kafka.DirectKafkaStreamSuite$$anonfun$5.apply(DirectKafkaStreamSuite.scala:235)
    ```
    Not sure if the test failure in build #48288 was related.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165946496
  
    **[Test build #48046 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48046/consoleFull)** for PR 10368 at commit [`25f0d3d`](https://github.com/apache/spark/commit/25f0d3d311b6730f844665e8e6bca2effcfb8737).
     * This patch **fails Scala style tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166052576
  
    Jenkins, test this please


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167855990
  
    What first two days of work are you referring to? The problem is we just can't use Kryo for serializing task results because there might be unregistered classes. Because of this constraint we can't use `spark.serializer` here since the user can specify Kryo there.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167022099
  
    **[Test build #48273 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48273/consoleFull)** for PR 10368 at commit [`710dc44`](https://github.com/apache/spark/commit/710dc448e2b25fad734c624d834a47ff8990b840).
     * This patch **fails to build**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166034110
  
    **[Test build #48063 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48063/consoleFull)** for PR 10368 at commit [`facf246`](https://github.com/apache/spark/commit/facf2460e184900c66393edd3652607cb4e40b12).
     * This patch **fails executing the `dev/run-tests` script**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167019833
  
    **[Test build #48273 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48273/consoleFull)** for PR 10368 at commit [`710dc44`](https://github.com/apache/spark/commit/710dc448e2b25fad734c624d834a47ff8990b840).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165988274
  
    **[Test build #48053 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48053/consoleFull)** for PR 10368 at commit [`cdd07e2`](https://github.com/apache/spark/commit/cdd07e2f61ba8f1f58954fe1c689c8096ed07985).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165874180
  
    **[Test build #48015 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48015/consoleFull)** for PR 10368 at commit [`bbc7c0f`](https://github.com/apache/spark/commit/bbc7c0f1c9e320668393a13fe5652ae62544ad4c).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166028352
  
    **[Test build #48058 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48058/consoleFull)** for PR 10368 at commit [`422ac1c`](https://github.com/apache/spark/commit/422ac1cfd5369e9a00e3d52693bb868048e30ba2).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165648189
  
    **[Test build #47973 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/47973/consoleFull)** for PR 10368 at commit [`0a0a9de`](https://github.com/apache/spark/commit/0a0a9de9258cc994c5991b4d4957fa58dca34052).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165858582
  
    I took a look at ./core/src/test/scala/org/apache/spark/scheduler/TaskResultGetterSuite.scala but may need some hint how such result should be formed.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166060825
  
    HeartbeatReceiverSuite.'expire dead hosts' failed
    
    Doesn't seem to be related to the PR.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48371027
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskResult.scala ---
    @@ -46,6 +46,26 @@ class DirectTaskResult[T](var valueBytes: ByteBuffer, var accumUpdates: Map[Long
     
       def this() = this(null.asInstanceOf[ByteBuffer], null, null)
     
    +  override def toString: String = valueBytes.toString + " " + accumUpdates + " " + metrics
    +
    +  override def equals(other: Any): Boolean = other match {
    +    case that: DirectTaskResult[_] => {
    +      if (!this.valueBytes.equals(that.valueBytes)) return false
    +
    +      val accumSize = if (accumUpdates != null) accumUpdates.size else 0
    +      val thatAccumSize = if (that.accumUpdates != null) that.accumUpdates.size else 0
    +      if (accumSize != thatAccumSize) return false
    +      if (accumSize > 0) {
    +        val b = this.accumUpdates.keys.forall { key =>
    +          this.accumUpdates.get(key) == that.accumUpdates.get(key)
    +        }
    +        if (!b) return false;
    +      }
    +      this.metrics.equals(that.metrics)
    +    }
    --- End diff --
    
    similarly, this can be simplified
    ```
    val accumEquals =
      if (accumUpdates != null) {
        accumUpdates.keys.forall { k => accumUpdates.get(k) == that.accumUpdates.get(k) }
      } else {
        that.accumUpdates == null
      }
      valueBytes.equals(that.valueBytes) &&
      metrics.equals(that.metrics) &&
      accumEquals
    ```


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167030479
  
    **[Test build #48278 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48278/consoleFull)** for PR 10368 at commit [`ac0199a`](https://github.com/apache/spark/commit/ac0199a11cfc885fa8f062e73b8c439bf9f3cab3).
     * This patch **fails to build**.
     * This patch merges cleanly.
     * This patch adds no public classes.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167079477
  
    Jenkins, test this please


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48389780
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskResult.scala ---
    @@ -46,6 +46,8 @@ class DirectTaskResult[T](var valueBytes: ByteBuffer, var accumUpdates: Map[Long
     
       def this() = this(null.asInstanceOf[ByteBuffer], null, null)
     
    +  override def toString: String = valueBytes.toString + " " + accumUpdates + " " + metrics
    --- End diff --
    
    This representation isn't really useful. It doesn't even tell you the task ID. I would just revert this change since it's unrelated and doesn't add much value.


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48372093
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskResult.scala ---
    @@ -46,6 +46,26 @@ class DirectTaskResult[T](var valueBytes: ByteBuffer, var accumUpdates: Map[Long
     
       def this() = this(null.asInstanceOf[ByteBuffer], null, null)
     
    +  override def toString: String = valueBytes.toString + " " + accumUpdates + " " + metrics
    +
    +  override def equals(other: Any): Boolean = other match {
    +    case that: DirectTaskResult[_] => {
    +      if (!this.valueBytes.equals(that.valueBytes)) return false
    +
    +      val accumSize = if (accumUpdates != null) accumUpdates.size else 0
    +      val thatAccumSize = if (that.accumUpdates != null) that.accumUpdates.size else 0
    +      if (accumSize != thatAccumSize) return false
    +      if (accumSize > 0) {
    +        val b = this.accumUpdates.keys.forall { key =>
    --- End diff --
    
    Why compare two Maps manually? I think `Map` already implements `equals`. Right?


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

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


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#discussion_r48389313
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskResult.scala ---
    @@ -46,6 +46,8 @@ class DirectTaskResult[T](var valueBytes: ByteBuffer, var accumUpdates: Map[Long
     
       def this() = this(null.asInstanceOf[ByteBuffer], null, null)
     
    +  override def toString: String = valueBytes.toString + " " + accumUpdates + " " + metrics
    --- End diff --
    
    nit: remove this


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-165643949
  
    ```
    ERROR: Timeout after 15 minutes
    ERROR: Error fetching remote repo 'origin'
    hudson.plugins.git.GitException: Failed to fetch from https://github.com/apache/spark.git
    ```


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-167038607
  
    **[Test build #48283 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/48283/consoleFull)** for PR 10368 at commit [`a4173eb`](https://github.com/apache/spark/commit/a4173ebf248617fd16864df156516e6c038a09a1).


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

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


[GitHub] spark pull request: [SPARK-12415] Do not use closure serializer to...

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

    https://github.com/apache/spark/pull/10368#issuecomment-166972579
  
    The rest of it looks OK. @zsxwing can you take another pass?


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

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