Skip to content

Commit 0c1fe29

Browse files
author
Marcelo Vanzin
committed
Fix CheckpointSuite.
1 parent 40f23a4 commit 0c1fe29

File tree

1 file changed

+3
-1
lines changed

1 file changed

+3
-1
lines changed

streaming/src/test/scala/org/apache/spark/streaming/CheckpointSuite.scala

Lines changed: 3 additions & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -35,6 +35,7 @@ import org.scalatest.concurrent.Eventually._
3535
import org.scalatest.time.SpanSugar._
3636

3737
import org.apache.spark.{SparkConf, SparkContext, SparkFunSuite, TestUtils}
38+
import org.apache.spark.internal.config._
3839
import org.apache.spark.rdd.RDD
3940
import org.apache.spark.streaming.dstream._
4041
import org.apache.spark.streaming.scheduler._
@@ -406,7 +407,8 @@ class CheckpointSuite extends TestSuiteBase with DStreamCheckpointTester
406407
// explicitly.
407408
ssc = new StreamingContext(null, newCp, null)
408409
val restoredConf1 = ssc.conf
409-
assert(restoredConf1.get("spark.driver.host") === "localhost")
410+
val defaultConf = new SparkConf()
411+
assert(restoredConf1.get("spark.driver.host") === defaultConf.get(DRIVER_HOST_ADDRESS))
410412
assert(restoredConf1.get("spark.driver.port") !== "9999")
411413
}
412414

0 commit comments

Comments
 (0)