Skip to content

Commit

Permalink
Rename JobProgressPage to AllStagesPage:
Browse files Browse the repository at this point in the history
This will avoid confusion once we have a page that lists all jobs.
  • Loading branch information
JoshRosen committed Oct 29, 2014
1 parent e7fd804 commit 2568a6c
Show file tree
Hide file tree
Showing 8 changed files with 12 additions and 12 deletions.
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 @@ -23,7 +23,7 @@ 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.{JobProgressListener, JobProgressTab}
import org.apache.spark.ui.jobs.{JobProgressListener, StagesTab}
import org.apache.spark.ui.storage.{StorageListener, StorageTab}

/**
Expand All @@ -45,7 +45,7 @@ private[spark] class SparkUI private (

/** Initialize all components of the server. */
def initialize() {
val jobProgressTab = new JobProgressTab(this)
val jobProgressTab = new StagesTab(this)
attachTab(jobProgressTab)
attachTab(new StorageTab(this))
attachTab(new EnvironmentTab(this))
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ import org.apache.spark.scheduler.Schedulable
import org.apache.spark.ui.{WebUIPage, UIUtils}

/** Page showing list of all ongoing and recently finished stages and pools */
private[ui] class JobProgressPage(parent: JobProgressTab) extends WebUIPage("") {
private[ui] class AllStagesPage(parent: StagesTab) extends WebUIPage("") {
private val sc = parent.sc
private val listener = parent.listener
private def isFairScheduler = parent.isFairScheduler
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ import org.apache.spark.ui.jobs.UIData.StageUIData
import org.apache.spark.util.Utils

/** Stage summary grouped by executors. */
private[ui] class ExecutorTable(stageId: Int, stageAttemptId: Int, parent: JobProgressTab) {
private[ui] class ExecutorTable(stageId: Int, stageAttemptId: Int, parent: StagesTab) {
private val listener = parent.listener

def toNodeSeq: Seq[Node] = {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ import org.apache.spark.scheduler.{Schedulable, StageInfo}
import org.apache.spark.ui.{WebUIPage, UIUtils}

/** Page showing specific pool details */
private[ui] class PoolPage(parent: JobProgressTab) extends WebUIPage("pool") {
private[ui] class PoolPage(parent: StagesTab) extends WebUIPage("pool") {
private val sc = parent.sc
private val listener = parent.listener

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import org.apache.spark.scheduler.{Schedulable, StageInfo}
import org.apache.spark.ui.UIUtils

/** Table showing list of pools */
private[ui] class PoolTable(pools: Seq[Schedulable], parent: JobProgressTab) {
private[ui] class PoolTable(pools: Seq[Schedulable], parent: StagesTab) {
private val listener = parent.listener

def toNodeSeq: Seq[Node] = {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -28,7 +28,7 @@ import org.apache.spark.util.{Utils, Distribution}
import org.apache.spark.scheduler.AccumulableInfo

/** Page showing statistics and task list for a given stage */
private[ui] class StagePage(parent: JobProgressTab) extends WebUIPage("stage") {
private[ui] class StagePage(parent: StagesTab) extends WebUIPage("stage") {
private val listener = parent.listener

def render(request: HttpServletRequest): Seq[Node] = {
Expand Down
4 changes: 2 additions & 2 deletions core/src/main/scala/org/apache/spark/ui/jobs/StageTable.scala
Original file line number Diff line number Diff line change
Expand Up @@ -29,7 +29,7 @@ import org.apache.spark.util.Utils
/** Page showing list of all ongoing and recently finished stages */
private[ui] class StageTableBase(
stages: Seq[StageInfo],
parent: JobProgressTab,
parent: StagesTab,
killEnabled: Boolean = false) {

private val listener = parent.listener
Expand Down Expand Up @@ -187,7 +187,7 @@ private[ui] class StageTableBase(

private[ui] class FailedStageTable(
stages: Seq[StageInfo],
parent: JobProgressTab,
parent: StagesTab,
killEnabled: Boolean = false)
extends StageTableBase(stages, parent, killEnabled) {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,14 +23,14 @@ import org.apache.spark.SparkConf
import org.apache.spark.scheduler.SchedulingMode
import org.apache.spark.ui.{SparkUI, SparkUITab}

/** Web UI showing progress status of all jobs in the given SparkContext. */
private[ui] class JobProgressTab(parent: SparkUI) extends SparkUITab(parent, "stages") {
/** Web UI showing progress status of all stages in the given SparkContext. */
private[ui] class StagesTab(parent: SparkUI) extends SparkUITab(parent, "stages") {
val sc = parent.sc
val conf = sc.map(_.conf).getOrElse(new SparkConf)
val killEnabled = sc.map(_.conf.getBoolean("spark.ui.killEnabled", true)).getOrElse(false)
val listener = parent.jobProgressListener

attachPage(new JobProgressPage(this))
attachPage(new AllStagesPage(this))
attachPage(new StagePage(this))
attachPage(new PoolPage(this))

Expand Down

0 comments on commit 2568a6c

Please sign in to comment.