File tree Expand file tree Collapse file tree 5 files changed +3
-5
lines changed
main/scala/org/apache/spark/streaming
test/scala/org/apache/spark/streaming Expand file tree Collapse file tree 5 files changed +3
-5
lines changed Original file line number Diff line number Diff line change 1515 * limitations under the License.
1616 */
1717
18- package org .apache .spark .streaming .ui
18+ package org .apache .spark .streaming .scheduler
1919
2020import org .apache .spark .streaming .Time
21- import org .apache .spark .streaming .scheduler .ReceivedBlockInfo
2221
2322/**
2423 * Class having information on completed batches.
Original file line number Diff line number Diff line change @@ -19,7 +19,6 @@ package org.apache.spark.streaming.scheduler
1919
2020import scala .collection .mutable .{ArrayBuffer , HashSet }
2121import org .apache .spark .streaming .Time
22- import org .apache .spark .streaming .ui .BatchInfo
2322
2423/** Class representing a set of Jobs
2524 * belong to the same batch.
Original file line number Diff line number Diff line change @@ -20,7 +20,6 @@ package org.apache.spark.streaming.scheduler
2020import scala .collection .mutable .Queue
2121
2222import org .apache .spark .util .Distribution
23- import org .apache .spark .streaming .ui .BatchInfo
2423
2524/** Base trait for events related to StreamingListener */
2625sealed trait StreamingListenerEvent
Original file line number Diff line number Diff line change @@ -22,6 +22,7 @@ import org.apache.spark.streaming.scheduler._
2222import scala .collection .mutable .{Queue , HashMap }
2323import org .apache .spark .streaming .scheduler .StreamingListenerReceiverStarted
2424import org .apache .spark .streaming .scheduler .StreamingListenerBatchStarted
25+ import org .apache .spark .streaming .scheduler .BatchInfo
2526import org .apache .spark .streaming .scheduler .StreamingListenerBatchSubmitted
2627import org .apache .spark .util .Distribution
2728import org .apache .spark .Logging
Original file line number Diff line number Diff line change @@ -25,7 +25,7 @@ import org.apache.spark.storage.StorageLevel
2525import org .apache .spark .streaming .dstream .DStream
2626import org .apache .spark .streaming .receiver .Receiver
2727import org .apache .spark .streaming .scheduler ._
28- import org .apache .spark .streaming .ui .{ BatchInfo , ReceiverInfo }
28+ import org .apache .spark .streaming .ui .ReceiverInfo
2929
3030import org .scalatest .matchers .ShouldMatchers
3131import org .scalatest .concurrent .Eventually ._
You can’t perform that action at this time.
0 commit comments