Skip to content

Commit

Permalink
fix some typos
Browse files Browse the repository at this point in the history
  • Loading branch information
squito committed Aug 22, 2016
1 parent f012780 commit fc45f5b
Show file tree
Hide file tree
Showing 3 changed files with 5 additions and 4 deletions.
2 changes: 1 addition & 1 deletion core/src/main/scala/org/apache/spark/SparkConf.scala
Expand Up @@ -633,7 +633,7 @@ private[spark] object SparkConf extends Logging {
"are no longer accepted. To specify the equivalent now, one may use '64k'."),
DeprecatedConfig("spark.rpc", "2.0", "Not used any more."),
DeprecatedConfig("spark.scheduler.executorTaskBlacklistTime", "2.1.0",
"Please use the new blacklisting options, spark.scheduler.blacklist.*")
"Please use the new blacklisting options, spark.blacklist.*")
)

Map(configs.map { cfg => (cfg.key -> cfg) } : _*)
Expand Down
Expand Up @@ -292,7 +292,7 @@ class DistributedSuite extends SparkFunSuite with Matchers with LocalSparkContex
import DistributedSuite.{markNodeIfIdentity, failOnMarkedIdentity}
DistributedSuite.amMaster = true
val conf = new SparkConf().setAppName("test").setMaster(clusterUrl)
.set("spark.scheduler.blacklist.enabled", "false")
.set(BLACKLIST_ENABLED, false)
sc = new SparkContext(conf)
for (i <- 1 to 3) {
val data = sc.parallelize(Seq(true, true), 2)
Expand Down
Expand Up @@ -31,6 +31,7 @@ import org.scalatest.Assertions.AssertionsHelper

import org.apache.spark._
import org.apache.spark.TaskState._
import org.apache.spark.internal.config.BLACKLIST_ENABLED
import org.apache.spark.internal.Logging
import org.apache.spark.rdd.RDD
import org.apache.spark.util.{CallSite, ThreadUtils, Utils}
Expand Down Expand Up @@ -642,7 +643,7 @@ class BasicSchedulerIntegrationSuite extends SchedulerIntegrationSuite[SingleCor
val jobFuture = submit(new MockRDD(sc, 10, Nil), (0 until 10).toArray)
val duration = Duration(1, SECONDS)
awaitJobTermination(jobFuture, duration)
failure.getMessage.contains("test task failure")
assert(failure.getMessage.contains("test task failure"))
}
assertDataStructuresEmpty(noFailure = false)
}
Expand All @@ -651,6 +652,6 @@ class BasicSchedulerIntegrationSuite extends SchedulerIntegrationSuite[SingleCor
def testNoBlacklist(name: String)(body: => Unit): Unit = {
// in these simple tests, we only have one executor, so it doens't make sense to turn on the
// blacklist. Just an artifact of this simple test-framework still kinda acting like local-mode
testScheduler(name, extraConfs = Seq("spark.scheduler.blacklist.enabled" -> "false"))(body)
testScheduler(name, extraConfs = Seq(BLACKLIST_ENABLED.key -> "false"))(body)
}
}

0 comments on commit fc45f5b

Please sign in to comment.