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 f749a5f commit 8f0be11
Show file tree
Hide file tree
Showing 4 changed files with 12 additions and 7 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -19,8 +19,8 @@ package org.apache.spark.storage

import scala.collection.mutable

import org.apache.spark.annotation.DeveloperApi
import org.apache.spark.SparkConf
import org.apache.spark.annotation.DeveloperApi
import org.apache.spark.scheduler._

/**
Expand Down
4 changes: 2 additions & 2 deletions core/src/main/scala/org/apache/spark/ui/SparkUI.scala
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import scala.collection.JavaConverters._
import org.apache.spark.{Logging, SecurityManager, SparkConf, SparkContext}
import org.apache.spark.scheduler._
import org.apache.spark.status.api.v1.{ApiRootResource, ApplicationAttemptInfo, ApplicationInfo,
UIRoot}
UIRoot}
import org.apache.spark.storage.StorageStatusListener
import org.apache.spark.ui.JettyUtils._
import org.apache.spark.ui.env.{EnvironmentListener, EnvironmentTab}
Expand Down Expand Up @@ -197,7 +197,7 @@ private[spark] object SparkUI {

val environmentListener = new EnvironmentListener
val storageStatusListener = new StorageStatusListener(conf)
val executorsListener = new ExecutorsListener(storageStatusListener)
val executorsListener = new ExecutorsListener(storageStatusListener, conf)
val storageListener = new StorageListener(storageStatusListener)
val operationGraphListener = new RDDOperationGraphListener(conf)

Expand Down
12 changes: 8 additions & 4 deletions core/src/main/scala/org/apache/spark/ui/exec/ExecutorsPage.scala
Original file line number Diff line number Diff line change
Expand Up @@ -59,11 +59,11 @@ private[ui] class ExecutorsPage(
// removed before we query their status. See SPARK-12784.
val _activeExecutorInfo = {
for (statusId <- 0 until listener.activeStorageStatusList.size)
yield ExecutorsPage.getExecInfo(listener, statusId, isActive = true)
yield ExecutorsPage.getExecInfo(listener, statusId, isActive = true)
}
val _deadExecutorInfo = {
for (statusId <- 0 until listener.deadStorageStatusList.size)
yield ExecutorsPage.getExecInfo(listener, statusId, isActive = false)
yield ExecutorsPage.getExecInfo(listener, statusId, isActive = false)
}
(_activeExecutorInfo, _deadExecutorInfo)
}
Expand Down Expand Up @@ -108,8 +108,12 @@ private[ui] class ExecutorsPage(
val content =
<div class="row">
<div class="span12">
<h4>DeadExecutors({deadExecutorInfo.size})</h4>
<h4>Totals for {activeExecutorInfo.size} Active Executors</h4>
<h4>Dead Executors({deadExecutorInfo.size})</h4>
</div>
</div>
<div class="row">
<div class="span12">
<h4>Active Executors({activeExecutorInfo.size})</h4>
{execSummary(activeExecutorInfo)}
</div>
</div>
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -18,6 +18,7 @@
package org.apache.spark.ui.storage

import org.scalatest.BeforeAndAfter

import org.apache.spark.{SparkConf, SparkFunSuite, Success}
import org.apache.spark.executor.TaskMetrics
import org.apache.spark.scheduler._
Expand Down

0 comments on commit 8f0be11

Please sign in to comment.