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 c1dfda1 commit 8e77408
Showing 1 changed file with 3 additions and 3 deletions.
6 changes: 3 additions & 3 deletions core/src/main/scala/org/apache/spark/HeartbeatReceiver.scala
Original file line number Diff line number Diff line change
Expand Up @@ -49,16 +49,16 @@ private[spark] class HeartbeatReceiver(sc: SparkContext, scheduler: TaskSchedule

val executorLastSeen = new mutable.HashMap[String, Long]

val slaveTimeout = conf.getLong("spark.executor.heartbeat.timeoutMs", 120 * 1000)
val slaveTimeout = sc.conf.getLong("spark.executor.heartbeat.timeoutMs", 120 * 1000)

val checkTimeoutInterval = conf.getLong("spark.executor.heartbeat.timeoutIntervalMs", 60000)
val checkTimeoutInterval = sc.conf.getLong("spark.executor.heartbeat.timeoutIntervalMs", 60000)

var timeoutCheckingTask: Cancellable = null

override def preStart() {
import context.dispatcher
timeoutCheckingTask = context.system.scheduler.schedule(0.seconds,
checkTimeoutInterval.milliseconds, self, ExpireDeadHosts)
checkTimeoutInterval.milliseconds, self, ExpireDeadHosts)
super.preStart
}

Expand Down

0 comments on commit 8e77408

Please sign in to comment.