Skip to content

Commit

Permalink
update with master
Browse files Browse the repository at this point in the history
  • Loading branch information
lianhuiwang committed Feb 2, 2016
1 parent 35eef9a commit f749a5f
Show file tree
Hide file tree
Showing 3 changed files with 8 additions and 11 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -31,9 +31,8 @@ private[v1] class ExecutorListResource(ui: SparkUI) {
listener.synchronized {
// The follow codes should be protected by `listener` to make sure no executors will be
// removed before we query their status. See SPARK-12784.
val activeStorageStatusList = listener.activeStorageStatusList
val deadStorageStatusList = listener.deadStorageStatusList
(0 until activeStorageStatusList.size).map { statusId =>
val storageStatusList = listener.activeStorageStatusList
(0 until storageStatusList.size).map { statusId =>
ExecutorsPage.getExecInfo(listener, statusId, isActive = true)
}
}
Expand Down
10 changes: 5 additions & 5 deletions core/src/main/scala/org/apache/spark/ui/SparkUI.scala
Original file line number Diff line number Diff line change
Expand Up @@ -21,18 +21,18 @@ import java.util.{Date, ServiceLoader}

import scala.collection.JavaConverters._

import org.apache.spark.status.api.v1.{ApiRootResource, ApplicationAttemptInfo, ApplicationInfo,
UIRoot}
import org.apache.spark.util.Utils
import org.apache.spark.{Logging, SecurityManager, SparkConf, SparkContext}
import org.apache.spark.scheduler._
import org.apache.spark.status.api.v1.{ApiRootResource, ApplicationAttemptInfo, ApplicationInfo,
UIRoot}
import org.apache.spark.storage.StorageStatusListener
import org.apache.spark.ui.JettyUtils._
import org.apache.spark.ui.env.{EnvironmentListener, EnvironmentTab}
import org.apache.spark.ui.exec.{ExecutorsListener, ExecutorsTab}
import org.apache.spark.ui.jobs.{JobsTab, JobProgressListener, StagesTab}
import org.apache.spark.ui.storage.{StorageListener, StorageTab}
import org.apache.spark.ui.jobs.{JobProgressListener, JobsTab, StagesTab}
import org.apache.spark.ui.scope.RDDOperationGraphListener
import org.apache.spark.ui.storage.{StorageListener, StorageTab}
import org.apache.spark.util.Utils

/**
* Top level user interface for a Spark application.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -61,7 +61,6 @@ private[ui] class ExecutorsPage(
for (statusId <- 0 until listener.activeStorageStatusList.size)
yield ExecutorsPage.getExecInfo(listener, statusId, isActive = true)
}
val deadExecutorInfo = listener.deadStorageStatusList
val _deadExecutorInfo = {
for (statusId <- 0 until listener.deadStorageStatusList.size)
yield ExecutorsPage.getExecInfo(listener, statusId, isActive = false)
Expand Down Expand Up @@ -298,7 +297,7 @@ private[ui] class ExecutorsPage(
} else {
""
}
}>{failedTasks}</td>
}>{failedTasks}</td>
<td>{completedTasks}</td>
<td>{totalTasks}</td>
<td sorttable_customkey={totalDuration.toString} style={
Expand All @@ -315,7 +314,6 @@ private[ui] class ExecutorsPage(

tableData
}

}

private[spark] object ExecutorsPage {
Expand Down

0 comments on commit f749a5f

Please sign in to comment.