You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@spark.apache.org by an...@apache.org on 2015/06/04 01:04:22 UTC

spark git commit: [HOTFIX] [TYPO] Fix typo in #6546

Repository: spark
Updated Branches:
  refs/heads/master d8662cd90 -> bfbdab12d


[HOTFIX] [TYPO] Fix typo in #6546


Project: http://git-wip-us.apache.org/repos/asf/spark/repo
Commit: http://git-wip-us.apache.org/repos/asf/spark/commit/bfbdab12
Tree: http://git-wip-us.apache.org/repos/asf/spark/tree/bfbdab12
Diff: http://git-wip-us.apache.org/repos/asf/spark/diff/bfbdab12

Branch: refs/heads/master
Commit: bfbdab12dd37587e5518dcbb76507b752759cace
Parents: d8662cd
Author: Andrew Or <an...@databricks.com>
Authored: Wed Jun 3 16:04:02 2015 -0700
Committer: Andrew Or <an...@databricks.com>
Committed: Wed Jun 3 16:04:02 2015 -0700

----------------------------------------------------------------------
 .../scala/org/apache/spark/ExternalShuffleServiceSuite.scala     | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/spark/blob/bfbdab12/core/src/test/scala/org/apache/spark/ExternalShuffleServiceSuite.scala
----------------------------------------------------------------------
diff --git a/core/src/test/scala/org/apache/spark/ExternalShuffleServiceSuite.scala b/core/src/test/scala/org/apache/spark/ExternalShuffleServiceSuite.scala
index 5b127a0..1400122 100644
--- a/core/src/test/scala/org/apache/spark/ExternalShuffleServiceSuite.scala
+++ b/core/src/test/scala/org/apache/spark/ExternalShuffleServiceSuite.scala
@@ -56,11 +56,11 @@ class ExternalShuffleServiceSuite extends ShuffleSuite with BeforeAndAfterAll {
     sc.env.blockManager.shuffleClient.getClass should equal(classOf[ExternalShuffleClient])
 
     // In a slow machine, one slave may register hundreds of milliseconds ahead of the other one.
-    // If we don't wait for all salves, it's possible that only one executor runs all jobs. Then
+    // If we don't wait for all slaves, it's possible that only one executor runs all jobs. Then
     // all shuffle blocks will be in this executor, ShuffleBlockFetcherIterator will directly fetch
     // local blocks from the local BlockManager and won't send requests to ExternalShuffleService.
     // In this case, we won't receive FetchFailed. And it will make this test fail.
-    // Therefore, we should wait until all salves are up
+    // Therefore, we should wait until all slaves are up
     sc.jobProgressListener.waitUntilExecutorsUp(2, 10000)
 
     val rdd = sc.parallelize(0 until 1000, 10).map(i => (i, 1)).reduceByKey(_ + _)


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