Skip to content

Commit fa4af88

Browse files
committed
remove duplicated import
1 parent 6ae3caa commit fa4af88

File tree

1 file changed

+1
-2
lines changed
  • streaming/src/main/scala/org/apache/spark/streaming/dstream

1 file changed

+1
-2
lines changed

streaming/src/main/scala/org/apache/spark/streaming/dstream/DStream.scala

Lines changed: 1 addition & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -17,6 +17,7 @@
1717

1818
package org.apache.spark.streaming.dstream
1919

20+
2021
import java.io.{IOException, ObjectInputStream, ObjectOutputStream}
2122

2223
import scala.deprecated
@@ -30,7 +31,6 @@ import org.apache.spark.streaming._
3031
import org.apache.spark.streaming.StreamingContext._
3132
import org.apache.spark.streaming.scheduler.Job
3233
import org.apache.spark.util.MetadataCleaner
33-
import org.apache.spark.streaming.Duration
3434

3535
/**
3636
* A Discretized Stream (DStream), the basic abstraction in Spark Streaming, is a continuous
@@ -557,7 +557,6 @@ abstract class DStream[T: ClassTag] (
557557
// because the DStream is reachable from the outer object here, and because
558558
// DStreams can't be serialized with closures, we can't proactively check
559559
// it for serializability and so we pass the optional false to SparkContext.clean
560-
561560
val cleanedF = context.sparkContext.clean(transformFunc, false)
562561
val realTransformFunc = (rdds: Seq[RDD[_]], time: Time) => {
563562
assert(rdds.length == 1)

0 commit comments

Comments
 (0)