Skip to content

Commit

Permalink
Fix test failed
Browse files Browse the repository at this point in the history
  • Loading branch information
shenh062326 committed Feb 5, 2015
1 parent bccd515 commit ce9257e
Showing 1 changed file with 2 additions and 2 deletions.
4 changes: 2 additions & 2 deletions core/src/main/scala/org/apache/spark/HeartbeatReceiver.scala
Original file line number Diff line number Diff line change
Expand Up @@ -58,7 +58,7 @@ private[spark] class HeartbeatReceiver(sc: SparkContext, scheduler: TaskSchedule
override def preStart() {
import context.dispatcher
timeoutCheckingTask = context.system.scheduler.schedule(0.seconds,
checkTimeoutInterval.milliseconds, self, ExpireDeadHosts)
checkTimeoutInterval.milliseconds, self, ExpireDeadHosts)
super.preStart
}

Expand All @@ -84,7 +84,7 @@ private[spark] class HeartbeatReceiver(sc: SparkContext, scheduler: TaskSchedule
for ((executorId, lastSeenMs) <- executorLastSeen) {
if (lastSeenMs < minSeenTime) {
logWarning("Removing Executor " + executorId + " with no recent heartbeats: "
+ (now - lastSeenMs) + " ms exceeds " + slaveTimeout + "ms")
+ (now - lastSeenMs) + " ms exceeds " + slaveTimeout + "ms")
scheduler.executorLost(executorId, SlaveLost())
sc.killExecutor(executorId)
executorLastSeen.remove(executorId)
Expand Down

0 comments on commit ce9257e

Please sign in to comment.