Skip to content

Commit

Permalink
[SPARK-1853] Show Streaming application code context (file, line numb…
Browse files Browse the repository at this point in the history
…er) in Spark Stages UI
  • Loading branch information
mubarak committed Jul 18, 2014
1 parent d466d75 commit 9d38d3c
Show file tree
Hide file tree
Showing 3 changed files with 1 addition and 5 deletions.
3 changes: 0 additions & 3 deletions core/src/main/scala/org/apache/spark/SparkContext.scala
Original file line number Diff line number Diff line change
Expand Up @@ -1296,9 +1296,6 @@ object SparkContext extends Logging {

private[spark] val SPARK_UNKNOWN_USER = "<unknown>"

private[spark] val SPARK_JOB_CALL_SITE_SHORT = "spark.job.callSiteShort"
private[spark] val SPARK_JOB_CALL_SITE_LONG = "spark.job.callSiteLong"

implicit object DoubleAccumulatorParam extends AccumulatorParam[Double] {
def addInPlace(t1: Double, t2: Double): Double = t1 + t2
def zero(initialValue: Double) = 0.0
Expand Down
2 changes: 1 addition & 1 deletion core/src/main/scala/org/apache/spark/util/Utils.scala
Original file line number Diff line number Diff line change
Expand Up @@ -852,7 +852,7 @@ private[spark] object Utils extends Logging {
callStack += el.toString
}
}
val callStackDepth = System.getProperty("spark.callstack.depth", "10").toInt
val callStackDepth = System.getProperty("spark.callstack.depth", "20").toInt
CallSite(
short = "%s at %s:%s".format(lastSparkMethod, firstUserFile, firstUserLine),
long = callStack.take(callStackDepth).mkString("\n"))
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -322,7 +322,6 @@ abstract class DStream[T: ClassTag] (
private[streaming] def generateJob(time: Time): Option[Job] = {
getOrCompute(time) match {
case Some(rdd) => {
//ssc.sc.setJobGroup("g","d")
val jobFunc = () => {
val emptyFunc = { (iterator: Iterator[T]) => {} }
context.sparkContext.runJob(rdd, emptyFunc)
Expand Down

0 comments on commit 9d38d3c

Please sign in to comment.