Skip to content

Commit

Permalink
Removing whitespace modifications
Browse files Browse the repository at this point in the history
  • Loading branch information
mccheah committed Jan 22, 2015
1 parent 6b543ba commit 66a71cd
Show file tree
Hide file tree
Showing 3 changed files with 4 additions and 5 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -113,6 +113,7 @@ class DAGScheduler(
// This is only safe because DAGScheduler runs in a single thread.
private val closureSerializer = SparkEnv.get.closureSerializer.newInstance()


/** If enabled, we may run certain actions like take() and first() locally. */
private val localExecutionEnabled = sc.getConf.getBoolean("spark.localExecution.enabled", false)

Expand Down Expand Up @@ -1374,7 +1375,6 @@ private[scheduler] class DAGSchedulerEventProcessLoop(dagScheduler: DAGScheduler

case ResubmitFailedStages =>
dagScheduler.resubmitFailedStages()

}

override def onError(e: Throwable): Unit = {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -77,4 +77,3 @@ private[scheduler]
case class TaskSetFailed(taskSet: TaskSet, reason: String) extends DAGSchedulerEvent

private[scheduler] case object ResubmitFailedStages extends DAGSchedulerEvent

Original file line number Diff line number Diff line change
Expand Up @@ -32,9 +32,9 @@ import org.apache.spark.executor.{TaskMetrics}
import org.apache.spark.rdd.FakeOutputCommitter

/**
* Unit tests for the output commit coordination functionality. Overrides the SchedulerImpl
* to just run the tasks directly and send completion or error messages back to the
* DAG scheduler.
* Unit tests for the output commit coordination functionality. Overrides the
* SchedulerImpl to just run the tasks directly and send completion or error
* messages back to the DAG scheduler.
*/
class OutputCommitCoordinatorSuite
extends FunSuiteLike
Expand Down

0 comments on commit 66a71cd

Please sign in to comment.