Skip to content

Commit

Permalink
Moved ReceivedBlockInfo back into spark.streaming.scheduler package
Browse files Browse the repository at this point in the history
  • Loading branch information
tdas committed Oct 27, 2014
1 parent 95a4987 commit 18aec1e
Show file tree
Hide file tree
Showing 5 changed files with 6 additions and 6 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import org.apache.spark.rdd.{BlockRDD, RDD}
import org.apache.spark.storage.BlockId
import org.apache.spark.streaming._
import org.apache.spark.streaming.receiver.Receiver
import org.apache.spark.streaming.receiver.ReceivedBlockInfo
import org.apache.spark.streaming.scheduler.ReceivedBlockInfo

/**
* Abstract class for defining any [[org.apache.spark.streaming.dstream.InputDStream]]
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,6 @@ package org.apache.spark.streaming.scheduler

import org.apache.spark.annotation.DeveloperApi
import org.apache.spark.streaming.Time
import org.apache.spark.streaming.receiver.ReceivedBlockInfo

/**
* :: DeveloperApi ::
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,9 +17,9 @@

package org.apache.spark.streaming.scheduler

import scala.collection.mutable.{ArrayBuffer, HashSet}
import scala.collection.mutable.HashSet

import org.apache.spark.streaming.Time
import org.apache.spark.streaming.receiver.ReceivedBlockInfo

/** Class representing a set of Jobs
* belong to the same batch.
Expand Down
Original file line number Diff line number Diff line change
@@ -1,7 +1,8 @@
package org.apache.spark.streaming.receiver
package org.apache.spark.streaming.scheduler

import org.apache.spark.storage.StreamBlockId
import org.apache.spark.streaming.util.WriteAheadLogFileSegment
import org.apache.spark.annotation.DeveloperApi

/** Information about blocks received by the receiver */
private[streaming] case class ReceivedBlockInfo(
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import akka.actor._
import org.apache.spark.{SerializableWritable, Logging, SparkEnv, SparkException}
import org.apache.spark.SparkContext._
import org.apache.spark.streaming.{StreamingContext, Time}
import org.apache.spark.streaming.receiver.{ReceivedBlockInfo, Receiver, ReceiverSupervisorImpl, StopReceiver}
import org.apache.spark.streaming.receiver.{Receiver, ReceiverSupervisorImpl, StopReceiver}
import org.apache.spark.util.AkkaUtils

/**
Expand Down

0 comments on commit 18aec1e

Please sign in to comment.