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

[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

GitHub user xuanyuanking opened a pull request:

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

    [SPARK-25017][Core] Add test suite for BarrierCoordinator and ContextBarrierState

    ## What changes were proposed in this pull request?
    
    Currently `ContextBarrierState` and `BarrierCoordinator` are only covered by end-to-end test in `BarrierTaskContextSuite`, add BarrierCoordinatorSuite to test both classes.
    
    ## How was this patch tested?
    
    UT in BarrierCoordinatorSuite.


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

    $ git pull https://github.com/xuanyuanking/spark SPARK-25017

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

    https://github.com/apache/spark/pull/22165.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 #22165
    
----
commit 21bd1c37f4af6480adfc07130a15f70acdeda378
Author: liyuanjian <li...@...>
Date:   2018-08-21T05:24:07Z

    [SPARK-25017][Core] Add test suite for BarrierCoordinator and ContextBarrierState

----


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    cc @gatorsmile @cloud-fan 


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r215635071
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -65,7 +65,7 @@ private[spark] class BarrierCoordinator(
     
       // Record all active stage attempts that make barrier() call(s), and the corresponding internal
       // state.
    -  private val states = new ConcurrentHashMap[ContextBarrierId, ContextBarrierState]
    +  private[spark] val states = new ConcurrentHashMap[ContextBarrierId, ContextBarrierState]
    --- End diff --
    
    No problem, done in ecf12bd.


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r215326394
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/BarrierCoordinatorSuite.scala ---
    @@ -0,0 +1,153 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.scheduler
    +
    +import java.util.concurrent.TimeoutException
    +
    +import scala.concurrent.duration._
    +import scala.language.postfixOps
    +
    +import org.apache.spark._
    +import org.apache.spark.rpc.RpcTimeout
    +
    +class BarrierCoordinatorSuite extends SparkFunSuite with LocalSparkContext {
    +
    +  /**
    +   * Get the current barrierEpoch from barrierCoordinator.states by ContextBarrierId
    +   */
    +  def getCurrentBarrierEpoch(
    +      stageId: Int, stageAttemptId: Int, barrierCoordinator: BarrierCoordinator): Int = {
    +    val barrierId = ContextBarrierId(stageId, stageAttemptId)
    +    barrierCoordinator.states.get(barrierId).barrierEpoch
    +  }
    +
    +  test("normal test for single task") {
    +    sc = new SparkContext("local", "test")
    +    val barrierCoordinator = new BarrierCoordinator(5, sc.listenerBus, sc.env.rpcEnv)
    +    val rpcEndpointRef = sc.env.rpcEnv.setupEndpoint("barrierCoordinator", barrierCoordinator)
    +    val stageId = 0
    +    val stageAttemptNumber = 0
    +    rpcEndpointRef.askSync[Unit](
    +      message = RequestToSync(numTasks = 1, stageId, stageAttemptNumber, taskAttemptId = 0,
    +        barrierEpoch = 0),
    +      timeout = new RpcTimeout(5 seconds, "rpcTimeOut"))
    +    // sleep for waiting barrierEpoch value change
    +    Thread.sleep(500)
    --- End diff --
    
    Do not use explicit sleep. It basically means adding 0.5 seconds to total test time and flakyness. Use conditional wait, for example: https://github.com/apache/spark/commit/bfb74394a5513134ea1da9fcf4a1783b77dd64e4#diff-a90010f459c27926238d7a4ce5a0aca1R107


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    My pleasure, just find this during glance over jira in recent days. :)


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r220983212
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -141,7 +145,7 @@ private[spark] class BarrierCoordinator(
           logInfo(s"Current barrier epoch for $barrierId is $barrierEpoch.")
           if (epoch != barrierEpoch) {
             requester.sendFailure(new SparkException(s"The request to sync of $barrierId with " +
    -          s"barrier epoch $barrierEpoch has already finished. Maybe task $taskId is not " +
    +          s"barrier epoch $epoch has already finished. Maybe task $taskId is not " +
    --- End diff --
    
    During write the UT for ContextBarrierState, I think this is a little bug in log? @jiangxb1987 Please checking if I'm wrong.


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r215635587
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/BarrierCoordinatorSuite.scala ---
    @@ -0,0 +1,153 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.scheduler
    +
    +import java.util.concurrent.TimeoutException
    +
    +import scala.concurrent.duration._
    +import scala.language.postfixOps
    +
    +import org.apache.spark._
    +import org.apache.spark.rpc.RpcTimeout
    +
    +class BarrierCoordinatorSuite extends SparkFunSuite with LocalSparkContext {
    +
    +  /**
    +   * Get the current barrierEpoch from barrierCoordinator.states by ContextBarrierId
    +   */
    +  def getCurrentBarrierEpoch(
    +      stageId: Int, stageAttemptId: Int, barrierCoordinator: BarrierCoordinator): Int = {
    +    val barrierId = ContextBarrierId(stageId, stageAttemptId)
    +    barrierCoordinator.states.get(barrierId).barrierEpoch
    +  }
    +
    +  test("normal test for single task") {
    +    sc = new SparkContext("local", "test")
    +    val barrierCoordinator = new BarrierCoordinator(5, sc.listenerBus, sc.env.rpcEnv)
    +    val rpcEndpointRef = sc.env.rpcEnv.setupEndpoint("barrierCoordinator", barrierCoordinator)
    +    val stageId = 0
    +    val stageAttemptNumber = 0
    +    rpcEndpointRef.askSync[Unit](
    +      message = RequestToSync(numTasks = 1, stageId, stageAttemptNumber, taskAttemptId = 0,
    +        barrierEpoch = 0),
    +      timeout = new RpcTimeout(5 seconds, "rpcTimeOut"))
    +    // sleep for waiting barrierEpoch value change
    +    Thread.sleep(500)
    --- End diff --
    
    Thanks for guidance, done in ecf12bd. I'll also pay attention in the future work.


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r215324595
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -65,7 +65,7 @@ private[spark] class BarrierCoordinator(
     
       // Record all active stage attempts that make barrier() call(s), and the corresponding internal
       // state.
    -  private val states = new ConcurrentHashMap[ContextBarrierId, ContextBarrierState]
    +  private[spark] val states = new ConcurrentHashMap[ContextBarrierId, ContextBarrierState]
    --- End diff --
    
    Could you turn the `// ...` comment into ScalaDoc `/** ... */` and mention `Visible for unit testing.` in the doc?


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    @jiangxb1987 Great thanks for your comment!
    ```
    One general idea is that we don't need to rely on the RPC framework to test ContextBarrierState, just mock RpcCallContexts should be enough.
    ```
    Actually I also want to implement like this at first also as you asked in jira, but `ContextBarrierState` is the private inner class in `BarrierCoordinator`. Could I do the refactor of moving `ContextBarrierState` out of `BarrierCoordinator`? If that is permitted I think we can just mock RpcCallContext to reach this.
    ```
    We shall cover the following scenarios:
    ```
    Pretty cool for the list, the 5 in front scenarios are including in currently implement, I'll add the last checking work of `Make sure we clear all the internal data under each case.` after we reach an agreement. 


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    One general idea is that we don't need to rely on the RPC framework to test `ContextBarrierState`, just mock `RpcCallContext`s should be enough (haven't go into detail so correct me if I'm wrong).
    We shall cover the following scenarios:
    
    - `RequestToSync` that carries different `numTasks`;
    - `RequestToSync` that carries different `barrierEpoch`;
    - Collect enough `RequestToSync` messages before timeout;
    - Don't collect enough `RequestToSync` messages before timeout;
    - Handle `RequestToSync` from different stage attempts concurrently;
    - Make sure we clear all the internal data under each case.


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    ```
    Could I do the refactor of moving ContextBarrierState out of BarrierCoordinator?
    ```
    gental ping @jiangxb1987, I still follow up this. :)


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    I'll make one pass of this later today :) Thanks for taking this task!


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    gental ping @jiangxb1987 @kiszk 


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r220590215
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -187,6 +191,12 @@ private[spark] class BarrierCoordinator(
           requesters.clear()
           cancelTimerTask()
         }
    +
    +    // Check for clearing internal data, visible for test only.
    +    private[spark] def cleanCheck(): Boolean = requesters.isEmpty && timerTask == null
    --- End diff --
    
    nit: `cleanCheck()` -> `isInternalStateClear()`


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

    https://github.com/apache/spark/pull/22165
  
    gental ping @jiangxb1987 


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    cc @jiangxb1987 @mengxr 


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r218328998
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -84,20 +88,20 @@ private[spark] class BarrierCoordinator(
     
       /**
        * Provide the current state of a barrier() call. A state is created when a new stage attempt
    -   * sends out a barrier() call, and recycled on stage completed.
    +   * sends out a barrier() call, and recycled on stage completed. Visible for testing.
        *
        * @param barrierId Identifier of the barrier stage that make a barrier() call.
        * @param numTasks Number of tasks of the barrier stage, all barrier() calls from the stage shall
        *                 collect `numTasks` requests to succeed.
        */
    -  private class ContextBarrierState(
    +  private[spark] class ContextBarrierState(
           val barrierId: ContextBarrierId,
           val numTasks: Int) {
     
         // There may be multiple barrier() calls from a barrier stage attempt, `barrierEpoch` is used
         // to identify each barrier() call. It shall get increased when a barrier() call succeeds, or
         // reset when a barrier() call fails due to timeout.
    -    private var barrierEpoch: Int = 0
    +    private[spark] var barrierEpoch: Int = 0
    --- End diff --
    
    Make sense, done in ec8466a。


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    Actually my original thinking was like this:
    ```
          val state = new ContextBarrierState(barrierId, numTasks)
          val requester = mockRequester()
          val request = forgeRequest(numTasks, stageId, stageAttemptId, taskAttemptId, barrierEpoch)
          state.handleRequest(requester, request)
          // Verify states
          ...
          // Verify cleanup
          ...
    ```
    So you don't have to launch a SparkContext for the test. Could you please check whether this is feasible?


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    I think it should be fine to make `ContextBarrierState` private[spark] to test it, WDYT @mengxr ?


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    UT fixed by #22452.
    retest this please.


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    **[Test build #95007 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/95007/testReport)** for PR 22165 at commit [`21bd1c3`](https://github.com/apache/spark/commit/21bd1c37f4af6480adfc07130a15f70acdeda378).


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for ContextBar...

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

    https://github.com/apache/spark/pull/22165#discussion_r224955955
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/ContextBarrierStateSuite.scala ---
    @@ -0,0 +1,175 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.scheduler
    +
    +import scala.concurrent.duration._
    +import scala.language.postfixOps
    +
    +import org.mockito.ArgumentMatcher
    +import org.mockito.Matchers._
    +import org.mockito.Mockito._
    +import org.scalatest.concurrent.Eventually
    +
    +import org.apache.spark._
    +import org.apache.spark.rpc.{RpcAddress, RpcCallContext, RpcEnv}
    +
    +class ContextBarrierStateSuite extends SparkFunSuite with LocalSparkContext with Eventually {
    +
    +  private def mockRpcCallContext() = {
    +    val rpcAddress = mock(classOf[RpcAddress])
    +    val rpcCallContext = mock(classOf[RpcCallContext])
    +    when(rpcCallContext.senderAddress).thenReturn(rpcAddress)
    +    rpcCallContext
    +  }
    +
    +  test("normal test for single task") {
    +    val barrierCoordinator = new BarrierCoordinator(
    --- End diff --
    
    ```
    So you don't have to launch a SparkContext for the test. Could you please check whether this is feasible?
    ```
    Thanks for Xingbo's guidance and sorry for misunderstand at first. That's feasible. But maybe this is the last thing not clear cause we still need a real BarrierCoordinator. Because a mock one will cause the `timer` NPE. Thanks @jiangxb1987 
    https://github.com/apache/spark/blob/2eaf0587883ac3c65e77d01ffbb39f64c6152f87/core/src/main/scala/org/apache/spark/BarrierCoordinator.scala#L152


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r220986263
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -187,6 +191,12 @@ private[spark] class BarrierCoordinator(
           requesters.clear()
           cancelTimerTask()
         }
    +
    +    // Check for clearing internal data, visible for test only.
    +    private[spark] def cleanCheck(): Boolean = requesters.isEmpty && timerTask == null
    --- End diff --
    
    Thanks, done in fd4d150.


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r220984340
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -187,6 +191,12 @@ private[spark] class BarrierCoordinator(
           requesters.clear()
           cancelTimerTask()
         }
    +
    +    // Check for clearing internal data, visible for test only.
    +    private[spark] def cleanCheck(): Boolean = requesters.isEmpty && timerTask == null
    +
    +    // Get currently barrier epoch, visible for test only.
    +    private[spark] def getBarrierEpoch(): Int = barrierEpoch
    --- End diff --
    
    https://github.com/apache/spark/pull/22165#discussion_r218093991 As the comment here, need revert back?


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r218093991
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -84,20 +88,20 @@ private[spark] class BarrierCoordinator(
     
       /**
        * Provide the current state of a barrier() call. A state is created when a new stage attempt
    -   * sends out a barrier() call, and recycled on stage completed.
    +   * sends out a barrier() call, and recycled on stage completed. Visible for testing.
        *
        * @param barrierId Identifier of the barrier stage that make a barrier() call.
        * @param numTasks Number of tasks of the barrier stage, all barrier() calls from the stage shall
        *                 collect `numTasks` requests to succeed.
        */
    -  private class ContextBarrierState(
    +  private[spark] class ContextBarrierState(
           val barrierId: ContextBarrierId,
           val numTasks: Int) {
     
         // There may be multiple barrier() calls from a barrier stage attempt, `barrierEpoch` is used
         // to identify each barrier() call. It shall get increased when a barrier() call succeeds, or
         // reset when a barrier() call fails due to timeout.
    -    private var barrierEpoch: Int = 0
    +    private[spark] var barrierEpoch: Int = 0
    --- End diff --
    
    nit: Is it better to add a getter method? This is because to make `var` visible may cause unexpected update of the variable.


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r215326727
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/BarrierCoordinatorSuite.scala ---
    @@ -0,0 +1,153 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.scheduler
    +
    +import java.util.concurrent.TimeoutException
    +
    +import scala.concurrent.duration._
    +import scala.language.postfixOps
    +
    +import org.apache.spark._
    +import org.apache.spark.rpc.RpcTimeout
    +
    +class BarrierCoordinatorSuite extends SparkFunSuite with LocalSparkContext {
    +
    +  /**
    +   * Get the current barrierEpoch from barrierCoordinator.states by ContextBarrierId
    +   */
    +  def getCurrentBarrierEpoch(
    +      stageId: Int, stageAttemptId: Int, barrierCoordinator: BarrierCoordinator): Int = {
    +    val barrierId = ContextBarrierId(stageId, stageAttemptId)
    +    barrierCoordinator.states.get(barrierId).barrierEpoch
    +  }
    +
    +  test("normal test for single task") {
    +    sc = new SparkContext("local", "test")
    +    val barrierCoordinator = new BarrierCoordinator(5, sc.listenerBus, sc.env.rpcEnv)
    +    val rpcEndpointRef = sc.env.rpcEnv.setupEndpoint("barrierCoordinator", barrierCoordinator)
    +    val stageId = 0
    +    val stageAttemptNumber = 0
    +    rpcEndpointRef.askSync[Unit](
    +      message = RequestToSync(numTasks = 1, stageId, stageAttemptNumber, taskAttemptId = 0,
    +        barrierEpoch = 0),
    +      timeout = new RpcTimeout(5 seconds, "rpcTimeOut"))
    +    // sleep for waiting barrierEpoch value change
    +    Thread.sleep(500)
    +    assert(getCurrentBarrierEpoch(stageId, stageAttemptNumber, barrierCoordinator) == 1)
    +  }
    +
    +  test("normal test for multi tasks") {
    +    sc = new SparkContext("local", "test")
    +    val barrierCoordinator = new BarrierCoordinator(5, sc.listenerBus, sc.env.rpcEnv)
    +    val rpcEndpointRef = sc.env.rpcEnv.setupEndpoint("barrierCoordinator", barrierCoordinator)
    +    val numTasks = 3
    +    val stageId = 0
    +    val stageAttemptNumber = 0
    +    val rpcTimeOut = new RpcTimeout(5 seconds, "rpcTimeOut")
    +    // sync request from 3 tasks
    +    (0 until numTasks).foreach { taskId =>
    +      new Thread(s"task-$taskId-thread") {
    +        setDaemon(true)
    +        override def run(): Unit = {
    +          rpcEndpointRef.askSync[Unit](
    +            message = RequestToSync(numTasks, stageId, stageAttemptNumber, taskAttemptId = taskId,
    +              barrierEpoch = 0),
    +            timeout = rpcTimeOut)
    +        }
    +      }.start()
    +    }
    +    // sleep for waiting barrierEpoch value change
    +    Thread.sleep(500)
    --- End diff --
    
    ditto


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    I didn't make a full pass over the tests. @jiangxb1987 let me know if you need me to take a pass. 


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r220984492
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/BarrierCoordinatorSuite.scala ---
    @@ -0,0 +1,166 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.scheduler
    +
    +import java.util.concurrent.TimeoutException
    +
    +import scala.concurrent.duration._
    +import scala.language.postfixOps
    +
    +import org.scalatest.concurrent.Eventually
    +
    +import org.apache.spark._
    +import org.apache.spark.rpc.RpcTimeout
    +
    +class BarrierCoordinatorSuite extends SparkFunSuite with LocalSparkContext with Eventually {
    +
    +  /**
    +   * Get the current ContextBarrierState from barrierCoordinator.states by ContextBarrierId.
    +   */
    +  private def getBarrierState(
    +      stageId: Int,
    +      stageAttemptId: Int,
    +      barrierCoordinator: BarrierCoordinator) = {
    +    val barrierId = ContextBarrierId(stageId, stageAttemptId)
    +    barrierCoordinator.states.get(barrierId)
    +  }
    +
    +  test("normal test for single task") {
    +    sc = new SparkContext("local", "test")
    +    val barrierCoordinator = new BarrierCoordinator(5, sc.listenerBus, sc.env.rpcEnv)
    +    val rpcEndpointRef = sc.env.rpcEnv.setupEndpoint("barrierCoordinator", barrierCoordinator)
    +    val stageId = 0
    +    val stageAttemptNumber = 0
    +    rpcEndpointRef.askSync[Unit](
    --- End diff --
    
    Sorry for missing this, done in 8cd78a9.


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    gental ping @jiangxb1987


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    @xuanyuanking thanks for helping the test coverage!


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    **[Test build #94994 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/94994/testReport)** for PR 22165 at commit [`21bd1c3`](https://github.com/apache/spark/commit/21bd1c37f4af6480adfc07130a15f70acdeda378).


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r220589416
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -187,6 +191,12 @@ private[spark] class BarrierCoordinator(
           requesters.clear()
           cancelTimerTask()
         }
    +
    +    // Check for clearing internal data, visible for test only.
    +    private[spark] def cleanCheck(): Boolean = requesters.isEmpty && timerTask == null
    +
    +    // Get currently barrier epoch, visible for test only.
    +    private[spark] def getBarrierEpoch(): Int = barrierEpoch
    --- End diff --
    
    Why not just make `barrierEpoch` visible for testing?


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r220591706
  
    --- Diff: core/src/test/scala/org/apache/spark/scheduler/BarrierCoordinatorSuite.scala ---
    @@ -0,0 +1,166 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.scheduler
    +
    +import java.util.concurrent.TimeoutException
    +
    +import scala.concurrent.duration._
    +import scala.language.postfixOps
    +
    +import org.scalatest.concurrent.Eventually
    +
    +import org.apache.spark._
    +import org.apache.spark.rpc.RpcTimeout
    +
    +class BarrierCoordinatorSuite extends SparkFunSuite with LocalSparkContext with Eventually {
    +
    +  /**
    +   * Get the current ContextBarrierState from barrierCoordinator.states by ContextBarrierId.
    +   */
    +  private def getBarrierState(
    +      stageId: Int,
    +      stageAttemptId: Int,
    +      barrierCoordinator: BarrierCoordinator) = {
    +    val barrierId = ContextBarrierId(stageId, stageAttemptId)
    +    barrierCoordinator.states.get(barrierId)
    +  }
    +
    +  test("normal test for single task") {
    +    sc = new SparkContext("local", "test")
    +    val barrierCoordinator = new BarrierCoordinator(5, sc.listenerBus, sc.env.rpcEnv)
    +    val rpcEndpointRef = sc.env.rpcEnv.setupEndpoint("barrierCoordinator", barrierCoordinator)
    +    val stageId = 0
    +    val stageAttemptNumber = 0
    +    rpcEndpointRef.askSync[Unit](
    --- End diff --
    
    We are still relying on the RPC framework, can we get rid of this?


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark pull request #22165: [SPARK-25017][Core] Add test suite for BarrierCoo...

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

    https://github.com/apache/spark/pull/22165#discussion_r215636283
  
    --- Diff: core/src/main/scala/org/apache/spark/BarrierCoordinator.scala ---
    @@ -187,6 +191,9 @@ private[spark] class BarrierCoordinator(
           requesters.clear()
           cancelTimerTask()
         }
    +
    +    // Check for clearing internal data, visible for test only.
    +    private[spark] def cleanCheck(): Boolean = requesters.isEmpty && timerTask == null
    --- End diff --
    
    Add internal data clean check in Xingbo's comments: https://github.com/apache/spark/pull/22165#issuecomment-415086679.


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

    https://github.com/apache/spark/pull/22165
  
    cc @jiangxb1987 


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for ContextBarrierSta...

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

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


---

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


[GitHub] spark issue #22165: [SPARK-25017][Core] Add test suite for BarrierCoordinato...

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

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


---

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