Skip to content

Commit

Permalink
Changes for SPARK-1853
Browse files Browse the repository at this point in the history
  • Loading branch information
mubarak committed Aug 11, 2014
1 parent 5f3105a commit 1d90cc3
Show file tree
Hide file tree
Showing 4 changed files with 2 additions and 4 deletions.
1 change: 0 additions & 1 deletion conf/log4j.properties.template
Original file line number Diff line number Diff line change
Expand Up @@ -4,7 +4,6 @@ log4j.appender.console=org.apache.log4j.ConsoleAppender
log4j.appender.console.target=System.err
log4j.appender.console.layout=org.apache.log4j.PatternLayout
log4j.appender.console.layout.ConversionPattern=%d{yy/MM/dd HH:mm:ss} %p %c{1}: %m%n
log4j.logger.org.apache.spark.rdd.RDD=INFO

# Settings to quiet third party logs that are too verbose
log4j.logger.org.eclipse.jetty=WARN
Expand Down
2 changes: 1 addition & 1 deletion core/src/main/scala/org/apache/spark/rdd/RDD.scala
Original file line number Diff line number Diff line change
Expand Up @@ -125,7 +125,7 @@ abstract class RDD[T: ClassTag](
val id: Int = sc.newRddId()

/** A friendly name for this RDD */
@transient var name: String = sc.getLocalProperty("rddName")
@transient var name: String = null

/** Assign a name to this RDD */
def setName(_name: String): this.type = {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -35,7 +35,7 @@ class ForEachDStream[T: ClassTag] (
override def compute(validTime: Time): Option[RDD[Unit]] = None

override def generateJob(time: Time): Option[Job] = {
return parent.getOrCompute(time) match {
parent.getOrCompute(time) match {
case Some(rdd) =>
val jobFunc = () => {
foreachFunc(rdd, time)
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -22,7 +22,6 @@ import org.apache.spark.{SparkException, SparkEnv, Logging}
import org.apache.spark.streaming.{Checkpoint, Time, CheckpointWriter}
import org.apache.spark.streaming.util.{ManualClock, RecurringTimer, Clock}
import scala.util.{Failure, Success, Try}
import org.apache.spark.util.{CallSite, Utils}

/** Event classes for JobGenerator */
private[scheduler] sealed trait JobGeneratorEvent
Expand Down

0 comments on commit 1d90cc3

Please sign in to comment.