Skip to content
Prev Previous commit
Next Next commit
Merge branch 'master' into SPARK-24063
  • Loading branch information
gaborgsomogyi committed Feb 22, 2019
commit 43e61ef9e0ae6331fcd4b30e146fad02ebea04af
Original file line number Diff line number Diff line change
Expand Up @@ -28,7 +28,7 @@ import org.apache.spark.rpc.RpcEndpointRef
import org.apache.spark.sql.LocalSparkSession
import org.apache.spark.sql.execution.streaming.continuous._
import org.apache.spark.sql.internal.SQLConf.CONTINUOUS_STREAMING_EPOCH_BACKLOG_QUEUE_SIZE
import org.apache.spark.sql.sources.v2.reader.streaming.{ContinuousReadSupport, PartitionOffset}
import org.apache.spark.sql.sources.v2.reader.streaming.{ContinuousStream, PartitionOffset}
import org.apache.spark.sql.sources.v2.writer.WriterCommitMessage
import org.apache.spark.sql.sources.v2.writer.streaming.StreamingWrite
import org.apache.spark.sql.test.TestSparkSession
Expand Down
You are viewing a condensed version of this merge commit. You can view the full changes here.