You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@spark.apache.org by rx...@apache.org on 2014/09/28 07:18:19 UTC

git commit: Minor fix for the previous commit.

Repository: spark
Updated Branches:
  refs/heads/master 9966d1a8a -> 66e1c40c6


Minor fix for the previous commit.


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

Branch: refs/heads/master
Commit: 66e1c40c67f40dc4a5519812bc84877751933e7a
Parents: 9966d1a
Author: Reynold Xin <rx...@apache.org>
Authored: Sat Sep 27 22:18:02 2014 -0700
Committer: Reynold Xin <rx...@apache.org>
Committed: Sat Sep 27 22:18:02 2014 -0700

----------------------------------------------------------------------
 .../scheduler/cluster/CoarseGrainedSchedulerBackend.scala      | 6 +++---
 .../org/apache/spark/scheduler/cluster/ExecutorData.scala      | 5 ++---
 2 files changed, 5 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/spark/blob/66e1c40c/core/src/main/scala/org/apache/spark/scheduler/cluster/CoarseGrainedSchedulerBackend.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/spark/scheduler/cluster/CoarseGrainedSchedulerBackend.scala b/core/src/main/scala/org/apache/spark/scheduler/cluster/CoarseGrainedSchedulerBackend.scala
index 59e15ed..89089e7 100644
--- a/core/src/main/scala/org/apache/spark/scheduler/cluster/CoarseGrainedSchedulerBackend.scala
+++ b/core/src/main/scala/org/apache/spark/scheduler/cluster/CoarseGrainedSchedulerBackend.scala
@@ -142,9 +142,9 @@ class CoarseGrainedSchedulerBackend(scheduler: TaskSchedulerImpl, actorSystem: A
 
     // Make fake resource offers on all executors
     def makeOffers() {
-      launchTasks(scheduler.resourceOffers(
-        executorDataMap.map {case (id, executorData) =>
-          new WorkerOffer(id, executorData.executorHost, executorData.freeCores)}.toSeq))
+      launchTasks(scheduler.resourceOffers(executorDataMap.map { case (id, executorData) =>
+        new WorkerOffer(id, executorData.executorHost, executorData.freeCores)
+      }.toSeq))
     }
 
     // Make fake resource offers on just one executor

http://git-wip-us.apache.org/repos/asf/spark/blob/66e1c40c/core/src/main/scala/org/apache/spark/scheduler/cluster/ExecutorData.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/spark/scheduler/cluster/ExecutorData.scala b/core/src/main/scala/org/apache/spark/scheduler/cluster/ExecutorData.scala
index 74a9298..b71bd57 100644
--- a/core/src/main/scala/org/apache/spark/scheduler/cluster/ExecutorData.scala
+++ b/core/src/main/scala/org/apache/spark/scheduler/cluster/ExecutorData.scala
@@ -20,10 +20,9 @@ package org.apache.spark.scheduler.cluster
 import akka.actor.{Address, ActorRef}
 
 /**
- * Grouping of data that is accessed by a CourseGrainedScheduler. This class
- * is stored in a Map keyed by an executorID
+ * Grouping of data for an executor used by CoarseGrainedSchedulerBackend.
  *
- * @param executorActor The actorRef representing this executor
+ * @param executorActor The ActorRef representing this executor
  * @param executorAddress The network address of this executor
  * @param executorHost The hostname that this executor is running on
  * @param freeCores  The current number of cores available for work on the executor


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