Skip to content

Commit

Permalink
SPARK-7729: build failure correction.
Browse files Browse the repository at this point in the history
  • Loading branch information
archit.thakur committed Nov 20, 2015
1 parent 2cf4f71 commit e1577dc
Show file tree
Hide file tree
Showing 2 changed files with 6 additions and 2 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -55,7 +55,8 @@ private[ui] class ExecutorsPage(
private val listener = parent.listener

def render(request: HttpServletRequest): Seq[Node] = {
val storageStatusList = listener.storageStatusList ++ listener.removedExecutorStorageStatusList
val storageStatusList =
listener.storageStatusList ++ listener.removedExecutorStorageStatusList
val maxMem = storageStatusList.map(_.maxMem).sum
val memUsed = storageStatusList.map(_.memUsed).sum
val diskUsed = storageStatusList.map(_.diskUsed).sum
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ package org.apache.spark.ui.exec

import scala.collection.mutable.HashMap

import org.apache.spark.{Resubmitted, ExceptionFailure, SparkContext}
import org.apache.spark.{ExceptionFailure, Resubmitted, SparkContext}
import org.apache.spark.annotation.DeveloperApi
import org.apache.spark.scheduler._
import org.apache.spark.storage.{StorageStatus, StorageStatusListener}
Expand Down Expand Up @@ -58,6 +58,9 @@ class ExecutorsListener(storageStatusListener: StorageStatusListener) extends Sp
val executorIdToData = HashMap[String, ExecutorUIData]()

def storageStatusList: Seq[StorageStatus] = storageStatusListener.storageStatusList

def removedExecutorStorageStatusList: Seq[StorageStatus] =
storageStatusListener.removedExecutorStorageStatusList

override def onExecutorAdded(executorAdded: SparkListenerExecutorAdded): Unit = synchronized {
val eid = executorAdded.executorId
Expand Down

0 comments on commit e1577dc

Please sign in to comment.