replace AkkaSpec with StreamSpec for stream tests #21011

This commit is contained in:
Hawstein 2016-07-28 16:43:08 +08:00 committed by Johan Andrén
parent c520df3210
commit 39008dc58a
116 changed files with 188 additions and 294 deletions

View file

@ -3,12 +3,13 @@ package akka.stream
import akka.actor.{ ActorSystem, Props }
import akka.stream.impl.{ StreamSupervisor, ActorMaterializerImpl }
import akka.stream.scaladsl.{ Sink, Source }
import akka.testkit.{ AkkaSpec, TestActor, ImplicitSender }
import akka.stream.testkit.StreamSpec
import akka.testkit.{ TestActor, ImplicitSender }
import scala.concurrent.Await
import scala.concurrent.duration._
class ActorMaterializerSpec extends AkkaSpec with ImplicitSender {
class ActorMaterializerSpec extends StreamSpec with ImplicitSender {
"ActorMaterializer" must {

View file

@ -4,18 +4,15 @@
package akka.stream
import akka.stream.scaladsl._
import akka.testkit.AkkaSpec
import org.scalactic.ConversionCheckedTripleEquals
import akka.stream.testkit.StreamSpec
import akka.stream.Attributes._
import akka.stream.Fusing.FusedGraph
import scala.annotation.tailrec
import akka.stream.impl.StreamLayout.{ CopiedModule, Module }
import org.scalatest.concurrent.ScalaFutures
import scala.concurrent.duration._
import akka.stream.impl.fusing.GraphInterpreter
import akka.event.BusLogging
class FusingSpec extends AkkaSpec {
class FusingSpec extends StreamSpec {
final val Debug = false
implicit val materializer = ActorMaterializer()

View file

@ -10,7 +10,7 @@ import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.stream.impl.ReactiveStreamsCompliance
import akka.testkit.TestEvent.Mute
import akka.testkit.{ AkkaSpec, EventFilter, ImplicitSender, TestProbe }
import akka.testkit.{ EventFilter, ImplicitSender, TestProbe }
import scala.annotation.tailrec
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
@ -145,7 +145,7 @@ object ActorPublisherSpec {
}
class ActorPublisherSpec extends AkkaSpec(ActorPublisherSpec.config) with ImplicitSender {
class ActorPublisherSpec extends StreamSpec(ActorPublisherSpec.config) with ImplicitSender {
import akka.stream.actor.ActorPublisherSpec._

View file

@ -7,7 +7,7 @@ import akka.actor.{ Actor, ActorRef, Props }
import akka.routing.{ ActorRefRoutee, RoundRobinRoutingLogic, Router }
import akka.stream.ActorMaterializer
import akka.stream.scaladsl.{ Sink, Source }
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.testkit.ImplicitSender
import org.reactivestreams.Subscription
@ -103,7 +103,7 @@ object ActorSubscriberSpec {
}
}
class ActorSubscriberSpec extends AkkaSpec with ImplicitSender {
class ActorSubscriberSpec extends StreamSpec with ImplicitSender {
import ActorSubscriberMessage._
import ActorSubscriberSpec._

View file

@ -10,9 +10,8 @@ import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.TestProbe
import org.reactivestreams.{ Publisher, Subscriber }
import akka.testkit.AkkaSpec
class FlowTimedSpec extends AkkaSpec with ScriptedTest {
class FlowTimedSpec extends StreamSpec with ScriptedTest {
import scala.concurrent.duration._

View file

@ -3,10 +3,10 @@
*/
package akka.stream.impl
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.stream.ActorMaterializerSettings
class FixedBufferSpec extends AkkaSpec {
class FixedBufferSpec extends StreamSpec {
for (size List(1, 3, 4)) {

View file

@ -4,7 +4,7 @@
package akka.stream.impl
import akka.stream.stage.GraphStageLogic.{ EagerTerminateOutput, EagerTerminateInput }
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.stream._
import akka.stream.Fusing.aggressive
import akka.stream.scaladsl._
@ -14,7 +14,7 @@ import akka.stream.testkit.scaladsl.TestSink
import akka.stream.impl.fusing._
import scala.concurrent.duration.Duration
class GraphStageLogicSpec extends AkkaSpec with GraphInterpreterSpecKit {
class GraphStageLogicSpec extends StreamSpec with GraphInterpreterSpecKit {
implicit val materializer = ActorMaterializer()

View file

@ -5,12 +5,12 @@ package akka.stream.impl
import akka.stream._
import akka.stream.scaladsl._
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import org.reactivestreams.{ Publisher, Subscriber, Subscription }
import scala.concurrent.duration._
class StreamLayoutSpec extends AkkaSpec {
class StreamLayoutSpec extends StreamSpec {
import StreamLayout._
def testAtomic(inPortCount: Int, outPortCount: Int): Module = new AtomicModule {

View file

@ -8,13 +8,12 @@ import java.util.concurrent.TimeoutException
import akka.Done
import akka.stream.scaladsl._
import akka.stream.testkit.Utils._
import akka.stream.testkit.{ TestPublisher, TestSubscriber }
import akka.stream.testkit.{ StreamSpec, TestPublisher, TestSubscriber }
import akka.stream._
import scala.concurrent.duration._
import scala.concurrent.{ Await, Future }
import akka.testkit.AkkaSpec
class TimeoutsSpec extends AkkaSpec {
class TimeoutsSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()
"InitialTimeout" must {

View file

@ -10,15 +10,14 @@ import akka.stream.impl.ReactiveStreamsCompliance.SpecViolation
import akka.stream.scaladsl._
import akka.stream.stage.{ GraphStage, GraphStageLogic, InHandler, OutHandler }
import akka.stream.testkit.Utils._
import akka.stream.testkit.{ TestPublisher, TestSubscriber }
import akka.stream.testkit.{ StreamSpec, TestPublisher, TestSubscriber }
import akka.testkit.EventFilter
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
import org.reactivestreams.{ Publisher, Subscriber, Subscription }
class ActorGraphInterpreterSpec extends AkkaSpec {
class ActorGraphInterpreterSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()
"ActorGraphInterpreter" must {

View file

@ -1,10 +1,10 @@
package akka.stream.impl.fusing
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.Utils.TE
import akka.testkit.EventFilter
import akka.testkit.AkkaSpec
class GraphInterpreterFailureModesSpec extends AkkaSpec with GraphInterpreterSpecKit {
class GraphInterpreterFailureModesSpec extends StreamSpec with GraphInterpreterSpecKit {
"GraphInterpreter" must {

View file

@ -3,10 +3,10 @@
*/
package akka.stream.impl.fusing
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.Utils._
class GraphInterpreterPortsSpec extends AkkaSpec with GraphInterpreterSpecKit {
class GraphInterpreterPortsSpec extends StreamSpec with GraphInterpreterSpecKit {
"Port states" must {

View file

@ -4,13 +4,13 @@
package akka.stream.impl.fusing
import akka.NotUsed
import akka.stream.testkit.StreamSpec
import akka.stream.{ OverflowStrategy, Attributes }
import akka.stream.stage.AbstractStage.PushPullGraphStage
import akka.testkit.AkkaSpec
import akka.stream.scaladsl.{ Merge, Broadcast, Balance, Zip }
import GraphInterpreter._
class GraphInterpreterSpec extends AkkaSpec with GraphInterpreterSpecKit {
class GraphInterpreterSpec extends StreamSpec with GraphInterpreterSpecKit {
import GraphStages._
"GraphInterpreter" must {

View file

@ -8,11 +8,11 @@ import akka.stream._
import akka.stream.impl.fusing.GraphInterpreter.{ DownstreamBoundaryStageLogic, Failed, GraphAssembly, UpstreamBoundaryStageLogic }
import akka.stream.stage.AbstractStage.PushPullGraphStage
import akka.stream.stage.{ GraphStage, GraphStageLogic, InHandler, OutHandler, _ }
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.Utils.TE
import akka.stream.impl.fusing.GraphInterpreter.GraphAssembly
trait GraphInterpreterSpecKit extends AkkaSpec {
trait GraphInterpreterSpecKit extends StreamSpec {
val logger = Logging(system, "InterpreterSpecKit")

View file

@ -5,12 +5,12 @@ package akka.stream.impl.fusing
import akka.stream.impl.ConstantFun
import akka.stream.stage._
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.testkit.EventFilter
import akka.stream._
class InterpreterSpec extends AkkaSpec with GraphInterpreterSpecKit {
class InterpreterSpec extends StreamSpec with GraphInterpreterSpecKit {
import Supervision.stoppingDecider
/*

View file

@ -5,9 +5,9 @@ package akka.stream.impl.fusing
import akka.stream.impl.ConstantFun
import akka.stream.Supervision
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
class InterpreterStressSpec extends AkkaSpec with GraphInterpreterSpecKit {
class InterpreterStressSpec extends StreamSpec with GraphInterpreterSpecKit {
import Supervision.stoppingDecider
val chainLength = 1000 * 1000

View file

@ -3,15 +3,16 @@
*/
package akka.stream.impl.fusing
import akka.stream.testkit.StreamSpec
import scala.util.control.NoStackTrace
import akka.stream.Supervision
import akka.stream.stage.Context
import akka.stream.stage.PushPullStage
import akka.stream.stage.Stage
import akka.stream.stage.SyncDirective
import akka.testkit.AkkaSpec
class InterpreterSupervisionSpec extends AkkaSpec with GraphInterpreterSpecKit {
class InterpreterSupervisionSpec extends StreamSpec with GraphInterpreterSpecKit {
import Supervision.stoppingDecider
import Supervision.resumingDecider
import Supervision.restartingDecider

View file

@ -3,13 +3,13 @@
*/
package akka.stream.impl.fusing
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.util.ByteString
import akka.stream.stage._
import akka.stream.{ Attributes, Supervision }
import akka.stream.impl.fusing.GraphStages.SimpleLinearGraphStage
class IteratorInterpreterSpec extends AkkaSpec with GraphInterpreterSpecKit {
class IteratorInterpreterSpec extends StreamSpec with GraphInterpreterSpecKit {
import Supervision.stoppingDecider
"IteratorInterpreter" must {

View file

@ -5,15 +5,15 @@ package akka.stream.impl.fusing
import akka.actor.{ NoSerializationVerificationNeeded, ActorRef }
import akka.stream.scaladsl.{ Keep, Source }
import akka.stream.testkit.StreamSpec
import akka.stream.{ Attributes, Inlet, SinkShape, ActorMaterializer }
import akka.stream.stage.{ InHandler, AsyncCallback, GraphStageLogic, GraphStageWithMaterializedValue }
import akka.testkit.AkkaSpec
import akka.stream.testkit.Utils._
import scala.concurrent.{ Await, Promise, Future }
import scala.concurrent.duration._
class KeepGoingStageSpec extends AkkaSpec {
class KeepGoingStageSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()

View file

@ -6,12 +6,12 @@ package akka.stream.impl.fusing
import akka.stream.Attributes
import akka.stream.impl.fusing.GraphStages.SimpleLinearGraphStage
import akka.stream.stage._
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.Utils.TE
import scala.concurrent.duration._
class LifecycleInterpreterSpec extends AkkaSpec with GraphInterpreterSpecKit {
class LifecycleInterpreterSpec extends StreamSpec with GraphInterpreterSpecKit {
import akka.stream.Supervision._
"Interpreter" must {

View file

@ -18,9 +18,8 @@ import akka.util.{ ByteString, Timeout }
import scala.collection.mutable.ListBuffer
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class FileSinkSpec extends AkkaSpec(UnboundedMailboxConfig) {
class FileSinkSpec extends StreamSpec(UnboundedMailboxConfig) {
val settings = ActorMaterializerSettings(system).withDispatcher("akka.actor.default-dispatcher")
implicit val materializer = ActorMaterializer(settings)

View file

@ -24,13 +24,12 @@ import akka.util.ByteString
import akka.util.Timeout
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
object FileSourceSpec {
final case class Settings(chunkSize: Int, readAhead: Int)
}
class FileSourceSpec extends AkkaSpec(UnboundedMailboxConfig) {
class FileSourceSpec extends StreamSpec(UnboundedMailboxConfig) {
val settings = ActorMaterializerSettings(system).withDispatcher("akka.actor.default-dispatcher")
implicit val materializer = ActorMaterializer(settings)

View file

@ -14,16 +14,15 @@ import akka.stream.impl.{ ActorMaterializerImpl, StreamSupervisor }
import akka.stream.scaladsl.{ Keep, Source, StreamConverters }
import akka.stream.testkit.Utils._
import akka.stream.testkit.scaladsl.TestSource
import akka.stream.testkit.{ GraphStageMessages, TestSinkStage }
import akka.stream.testkit.{ StreamSpec, GraphStageMessages, TestSinkStage }
import akka.testkit.TestProbe
import akka.util.ByteString
import scala.concurrent.duration._
import java.util.concurrent.ThreadLocalRandom
import scala.concurrent.{ Await, Future }
import scala.util.control.NoStackTrace
import akka.testkit.AkkaSpec
class InputStreamSinkSpec extends AkkaSpec(UnboundedMailboxConfig) {
class InputStreamSinkSpec extends StreamSpec(UnboundedMailboxConfig) {
import system.dispatcher
val settings = ActorMaterializerSettings(system).withDispatcher("akka.actor.default-dispatcher")

View file

@ -3,7 +3,7 @@
*/
package akka.stream.io
import java.io.{ InputStream }
import java.io.InputStream
import java.util.concurrent.CountDownLatch
import akka.stream.scaladsl.{ Sink, StreamConverters }
@ -12,12 +12,10 @@ import akka.stream.testkit.Utils._
import akka.stream.testkit.scaladsl.TestSink
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.util.ByteString
import akka.testkit.AkkaSpec
import org.scalatest.concurrent.ScalaFutures
import scala.concurrent.Await
import scala.concurrent.duration._
class InputStreamSourceSpec extends AkkaSpec(UnboundedMailboxConfig) {
class InputStreamSourceSpec extends StreamSpec(UnboundedMailboxConfig) {
val settings = ActorMaterializerSettings(system).withDispatcher("akka.actor.default-dispatcher")
implicit val materializer = ActorMaterializer(settings)

View file

@ -9,13 +9,13 @@ import akka.stream.scaladsl.{ Source, StreamConverters }
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.testkit.{ AkkaSpec, TestProbe }
import akka.testkit.TestProbe
import akka.util.ByteString
import scala.concurrent.Await
import scala.concurrent.duration._
class OutputStreamSinkSpec extends AkkaSpec(UnboundedMailboxConfig) {
class OutputStreamSinkSpec extends StreamSpec(UnboundedMailboxConfig) {
val settings = ActorMaterializerSettings(system).withDispatcher("akka.actor.default-dispatcher")
implicit val materializer = ActorMaterializer(settings)

View file

@ -12,20 +12,18 @@ import akka.stream.Attributes.inputBuffer
import akka.stream.impl.StreamSupervisor.Children
import akka.stream.impl.io.OutputStreamSourceStage
import akka.stream.impl.{ ActorMaterializerImpl, StreamSupervisor }
import akka.stream.scaladsl.{ Source, Keep, StreamConverters, Sink }
import akka.stream.scaladsl.{ Keep, StreamConverters, Sink }
import akka.stream.testkit.Utils._
import akka.stream.testkit._
import akka.stream.testkit.scaladsl.TestSink
import akka.testkit.TestProbe
import akka.util.ByteString
import com.typesafe.config.ConfigFactory
import scala.concurrent.duration.Duration.Zero
import scala.concurrent.duration._
import scala.concurrent.{ Await, Future }
import scala.util.Random
import akka.testkit.AkkaSpec
class OutputStreamSourceSpec extends AkkaSpec(UnboundedMailboxConfig) {
class OutputStreamSourceSpec extends StreamSpec(UnboundedMailboxConfig) {
import system.dispatcher
val settings = ActorMaterializerSettings(system).withDispatcher("akka.actor.default-dispatcher")

View file

@ -19,9 +19,8 @@ import scala.concurrent.{ Promise, Await }
import scala.concurrent.duration._
import java.net.BindException
import akka.testkit.EventFilter
import akka.testkit.AkkaSpec
class TcpSpec extends AkkaSpec("akka.stream.materializer.subscription-timeout.timeout = 2s") with TcpHelper {
class TcpSpec extends StreamSpec("akka.stream.materializer.subscription-timeout.timeout = 2s") with TcpHelper {
"Outgoing TCP stream" must {

View file

@ -21,7 +21,7 @@ import akka.stream.scaladsl._
import akka.stream.stage._
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.{ AkkaSpec, EventFilter }
import akka.testkit.EventFilter
import akka.util.ByteString
import javax.net.ssl._
@ -83,7 +83,7 @@ object TlsSpec {
}
class TlsSpec extends AkkaSpec("akka.loglevel=INFO\nakka.actor.debug.receive=off") {
class TlsSpec extends StreamSpec("akka.loglevel=INFO\nakka.actor.debug.receive=off") {
import TlsSpec._
import system.dispatcher

View file

@ -9,10 +9,6 @@ import akka.stream.Attributes.inputBuffer
import akka.stream.testkit.Utils._
import akka.stream.testkit._
import akka.stream.testkit.scaladsl._
import org.scalatest.concurrent.ScalaFutures
import org.scalactic.ConversionCheckedTripleEquals
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
object ActorRefBackpressureSinkSpec {
val initMessage = "start"
@ -48,7 +44,7 @@ object ActorRefBackpressureSinkSpec {
}
class ActorRefBackpressureSinkSpec extends AkkaSpec {
class ActorRefBackpressureSinkSpec extends StreamSpec {
import ActorRefBackpressureSinkSpec._
implicit val mat = ActorMaterializer()

View file

@ -10,7 +10,6 @@ import akka.stream.testkit.scaladsl._
import akka.actor.Actor
import akka.actor.ActorRef
import akka.actor.Props
import akka.testkit.AkkaSpec
object ActorRefSinkSpec {
case class Fw(ref: ActorRef) extends Actor {
@ -20,7 +19,7 @@ object ActorRefSinkSpec {
}
}
class ActorRefSinkSpec extends AkkaSpec {
class ActorRefSinkSpec extends StreamSpec {
import ActorRefSinkSpec._
implicit val materializer = ActorMaterializer()

View file

@ -10,9 +10,8 @@ import akka.stream.testkit.scaladsl._
import akka.stream.testkit.Utils._
import akka.actor.PoisonPill
import akka.actor.Status
import akka.testkit.AkkaSpec
class ActorRefSourceSpec extends AkkaSpec {
class ActorRefSourceSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()
"A ActorRefSource" must {

View file

@ -14,9 +14,7 @@ import scala.concurrent.Future
import scala.concurrent.Promise
import akka.stream.impl.SinkModule
import akka.stream.impl.StreamLayout.Module
import org.scalatest.concurrent.ScalaFutures
import akka.stream.impl.SinkholeSubscriber
import akka.testkit.AkkaSpec
object AttributesSpec {
@ -38,7 +36,7 @@ object AttributesSpec {
}
class AttributesSpec extends AkkaSpec {
class AttributesSpec extends StreamSpec {
import AttributesSpec._
val settings = ActorMaterializerSettings(system)

View file

@ -4,16 +4,15 @@
package akka.stream.scaladsl
import akka.NotUsed
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.Utils._
import org.scalactic.ConversionCheckedTripleEquals
import akka.util.ByteString
import akka.stream._
import scala.concurrent.Await
import scala.concurrent.duration._
import scala.collection.immutable
import akka.testkit.AkkaSpec
class BidiFlowSpec extends AkkaSpec {
class BidiFlowSpec extends StreamSpec {
import Attributes._
import GraphDSL.Implicits._

View file

@ -6,12 +6,11 @@ package akka.stream.scaladsl
import akka.actor.ActorSystem
import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit.TestSubscriber
import akka.stream.testkit.{ StreamSpec, TestSubscriber }
import org.reactivestreams.Subscriber
import org.scalatest.Matchers
import akka.testkit.AkkaSpec
class FlowAppendSpec extends AkkaSpec with River {
class FlowAppendSpec extends StreamSpec with River {
val settings = ActorMaterializerSettings(system)
implicit val materializer = ActorMaterializer(settings)

View file

@ -8,9 +8,8 @@ import scala.concurrent.duration._
import java.util.concurrent.ThreadLocalRandom
import akka.stream.{ OverflowStrategy, ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit._
import akka.testkit.AkkaSpec
class FlowBatchSpec extends AkkaSpec {
class FlowBatchSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -6,9 +6,8 @@ package akka.stream.scaladsl
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit._
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class FlowBatchWeightedSpec extends AkkaSpec {
class FlowBatchWeightedSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -10,9 +10,8 @@ import akka.stream.{ BufferOverflowException, ActorMaterializer, ActorMaterializ
import akka.stream.testkit._
import akka.stream.testkit.scaladsl._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class FlowBufferSpec extends AkkaSpec {
class FlowBufferSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 1, maxSize = 1)

View file

@ -5,19 +5,15 @@ package akka.stream.scaladsl
import akka.stream.ActorAttributes._
import akka.stream.Supervision._
import akka.stream.impl.ConstantFun
import akka.stream.testkit.Utils.TE
import akka.stream.testkit.scaladsl.TestSink
import java.util.concurrent.ThreadLocalRandom.{ current random }
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.testkit.AkkaSpec
import akka.stream.testkit.{ TestSubscriber, ScriptedTest }
import akka.stream.testkit.{ StreamSpec, ScriptedTest }
import scala.util.control.NoStackTrace
class FlowCollectSpec extends AkkaSpec with ScriptedTest {
class FlowCollectSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
implicit val materializer = ActorMaterializer(settings)

View file

@ -4,6 +4,7 @@
package akka.stream.scaladsl
import akka.NotUsed
import akka.stream.testkit.StreamSpec
import org.reactivestreams.Publisher
import scala.collection.immutable.Seq
@ -11,9 +12,8 @@ import scala.concurrent.Future
import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.testkit.AkkaSpec
class FlowCompileSpec extends AkkaSpec {
class FlowCompileSpec extends StreamSpec {
val intSeq = Source(Seq(1, 2, 3))
val strSeq = Source(Seq("a", "b", "c"))

View file

@ -11,9 +11,8 @@ import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class FlowConcatAllSpec extends AkkaSpec {
class FlowConcatAllSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -13,9 +13,8 @@ import scala.concurrent.duration._
import java.util.concurrent.ThreadLocalRandom
import akka.stream._
import akka.stream.testkit._
import akka.testkit.AkkaSpec
class FlowConflateSpec extends AkkaSpec {
class FlowConflateSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -7,15 +7,14 @@ import akka.Done
import akka.stream.Attributes._
import akka.stream.testkit.Utils._
import akka.stream.testkit.scaladsl.TestSink
import akka.stream.testkit.{ TestPublisher, TestSubscriber }
import akka.stream.testkit.{ StreamSpec, TestPublisher, TestSubscriber }
import akka.stream.{ ActorMaterializer, Attributes, BufferOverflowException, DelayOverflowStrategy }
import scala.concurrent.{ Await, Future }
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import akka.testkit.AkkaSpec
class FlowDelaySpec extends AkkaSpec {
class FlowDelaySpec extends StreamSpec {
implicit val materializer = ActorMaterializer()

View file

@ -3,16 +3,13 @@
*/
package akka.stream.scaladsl
import org.scalactic.ConversionCheckedTripleEquals
import org.scalatest.concurrent.ScalaFutures
import akka.testkit.AkkaSpec
import akka.stream._
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.stream.testkit.scaladsl.TestSink
import akka.stream.testkit.Utils
import akka.stream.testkit.{ StreamSpec, Utils }
class FlowDetacherSpec extends AkkaSpec {
class FlowDetacherSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()

View file

@ -3,12 +3,12 @@
*/
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import akka.testkit.TestProbe
import akka.testkit.AkkaSpec
import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
class FlowDispatcherSpec extends AkkaSpec(s"my-dispatcher = $${akka.test.stream-dispatcher}") {
class FlowDispatcherSpec extends StreamSpec(s"my-dispatcher = $${akka.test.stream-dispatcher}") {
val defaultSettings = ActorMaterializerSettings(system)

View file

@ -7,9 +7,8 @@ import java.util.concurrent.ThreadLocalRandom.{ current ⇒ random }
import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.testkit.AkkaSpec
class FlowDropSpec extends AkkaSpec with ScriptedTest {
class FlowDropSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -10,10 +10,8 @@ import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.scaladsl.TestSink
import scala.util.control.NoStackTrace
import akka.testkit.AkkaSpec
class FlowDropWhileSpec extends AkkaSpec {
class FlowDropWhileSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)

View file

@ -6,9 +6,8 @@ package akka.stream.scaladsl
import scala.concurrent.duration._
import akka.stream.ActorMaterializer
import akka.stream.testkit._
import akka.testkit.AkkaSpec
class FlowDropWithinSpec extends AkkaSpec {
class FlowDropWithinSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()

View file

@ -10,9 +10,8 @@ import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit._
import akka.stream.testkit.scaladsl.TestSource
import akka.stream.testkit.scaladsl.TestSink
import akka.testkit.AkkaSpec
class FlowExpandSpec extends AkkaSpec {
class FlowExpandSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -12,11 +12,10 @@ import akka.stream.testkit.Utils._
import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.testkit.AkkaSpec
import scala.util.control.NoStackTrace
class FlowFilterSpec extends AkkaSpec with ScriptedTest {
class FlowFilterSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -4,18 +4,15 @@
package akka.stream.scaladsl
import akka.NotUsed
import akka.testkit.AkkaSpec
import akka.stream.{ ActorMaterializerSettings, ActorMaterializer }
import scala.concurrent._
import scala.concurrent.duration._
import org.scalatest.concurrent.ScalaFutures
import org.scalactic.ConversionCheckedTripleEquals
import akka.stream.testkit.TestPublisher
import akka.stream.testkit.{ StreamSpec, TestPublisher }
import org.scalatest.exceptions.TestFailedException
import akka.stream.testkit.scaladsl.TestSink
import akka.testkit.TestLatch
class FlowFlattenMergeSpec extends AkkaSpec {
class FlowFlattenMergeSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()
import system.dispatcher

View file

@ -4,16 +4,16 @@
package akka.stream.scaladsl
import akka.NotUsed
import akka.stream.testkit.StreamSpec
import scala.concurrent.Await
import scala.util.control.NoStackTrace
import akka.stream.ActorMaterializer
import akka.testkit.AkkaSpec
import akka.stream.testkit.Utils._
import scala.concurrent.duration._
class FlowFoldSpec extends AkkaSpec {
class FlowFoldSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()
"A Fold" must {

View file

@ -9,9 +9,8 @@ import akka.stream.testkit._
import akka.stream.testkit.Utils._
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class FlowForeachSpec extends AkkaSpec {
class FlowForeachSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()
import system.dispatcher

View file

@ -10,9 +10,8 @@ import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class FlowFromFutureSpec extends AkkaSpec {
class FlowFromFutureSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)

View file

@ -26,7 +26,6 @@ import org.scalactic.ConversionCheckedTripleEquals
import org.scalatest.concurrent.PatienceConfiguration.Timeout
import akka.stream.testkit.scaladsl.TestSource
import akka.stream.testkit.scaladsl.TestSink
import akka.testkit.AkkaSpec
import java.util.concurrent.ThreadLocalRandom
@ -38,7 +37,7 @@ object FlowGroupBySpec {
}
class FlowGroupBySpec extends AkkaSpec {
class FlowGroupBySpec extends StreamSpec {
import FlowGroupBySpec._
val settings = ActorMaterializerSettings(system)

View file

@ -7,10 +7,9 @@ import scala.collection.immutable
import java.util.concurrent.ThreadLocalRandom.{ current random }
import akka.stream.ActorMaterializerSettings
import akka.testkit.AkkaSpec
import akka.stream.testkit.ScriptedTest
import akka.stream.testkit.{ StreamSpec, ScriptedTest }
class FlowGroupedSpec extends AkkaSpec with ScriptedTest {
class FlowGroupedSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -9,11 +9,10 @@ import java.util.concurrent.ThreadLocalRandom.{ current ⇒ random }
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings, ThrottleMode }
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
import scala.concurrent.Await
class FlowGroupedWithinSpec extends AkkaSpec with ScriptedTest {
class FlowGroupedWithinSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)

View file

@ -1,12 +1,11 @@
package akka.stream.scaladsl
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit.{ TestSubscriber, TestPublisher, Utils }
import akka.stream.testkit.{ StreamSpec, TestSubscriber, TestPublisher, Utils }
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class FlowIdleInjectSpec extends AkkaSpec {
class FlowIdleInjectSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -2,12 +2,11 @@ package akka.stream.scaladsl
import java.util.concurrent.TimeoutException
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit.{ Utils, TestSubscriber }
import akka.stream.testkit.{ StreamSpec, Utils, TestSubscriber }
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class FlowInitialDelaySpec extends AkkaSpec {
class FlowInitialDelaySpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -6,11 +6,9 @@ package akka.stream.scaladsl
import akka.stream.testkit._
import akka.stream.testkit.scaladsl.{ TestSource, TestSink }
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import org.scalatest.concurrent.ScalaFutures
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class FlowIntersperseSpec extends AkkaSpec {
class FlowIntersperseSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -11,7 +11,6 @@ import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.EventFilter
import akka.testkit.AkkaSpec
class FlowIteratorSpec extends AbstractFlowIteratorSpec {
override def testName = "A Flow based on an iterator producing function"
@ -72,7 +71,7 @@ class FlowIterableSpec extends AbstractFlowIteratorSpec {
}
}
abstract class AbstractFlowIteratorSpec extends AkkaSpec {
abstract class AbstractFlowIteratorSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -7,14 +7,13 @@ import akka.stream.{ FlowShape, ActorMaterializer, ActorMaterializerSettings, Ov
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.stream.testkit.scaladsl._
import akka.testkit.AkkaSpec
import com.typesafe.config.ConfigFactory
import org.scalatest.concurrent.ScalaFutures
import org.scalatest.time._
import scala.collection.immutable
class FlowJoinSpec extends AkkaSpec(ConfigFactory.parseString("akka.loglevel=INFO")) {
class FlowJoinSpec extends StreamSpec(ConfigFactory.parseString("akka.loglevel=INFO")) {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -4,14 +4,14 @@
package akka.stream.scaladsl
import akka.Done
import akka.stream.{ ActorMaterializer, ClosedShape, KillSwitch, KillSwitches }
import akka.stream.testkit.StreamSpec
import akka.stream.{ ActorMaterializer, ClosedShape, KillSwitches }
import akka.stream.testkit.scaladsl.{ TestSink, TestSource }
import akka.stream.testkit.Utils.{ TE, assertAllStagesStopped }
import akka.testkit.{ AkkaSpec, EventFilter }
import scala.concurrent.duration._
class FlowKillSwitchSpec extends AkkaSpec {
class FlowKillSwitchSpec extends StreamSpec {
implicit val mat = ActorMaterializer()

View file

@ -3,12 +3,11 @@
*/
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import akka.stream.{ StreamLimitReachedException, ActorMaterializer, ActorMaterializerSettings }
import akka.testkit.AkkaSpec
import scala.concurrent.Await
import scala.concurrent.duration._
class FlowLimitSpec extends AkkaSpec {
class FlowLimitSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -8,16 +8,15 @@ import akka.event.{ DummyClassForStringSources, Logging }
import akka.stream.ActorAttributes._
import akka.stream.Attributes.LogLevels
import akka.stream.Supervision._
import akka.stream.testkit.ScriptedTest
import akka.stream.testkit.{ StreamSpec, ScriptedTest }
import akka.stream._
import akka.testkit.TestProbe
import akka.testkit.{ AkkaSpec, TestProbe }
import scala.concurrent.duration._
import scala.concurrent.Await
import scala.util.control.NoStackTrace
import akka.testkit.AkkaSpec
class FlowLogSpec extends AkkaSpec("akka.loglevel = DEBUG") with ScriptedTest {
class FlowLogSpec extends StreamSpec("akka.loglevel = DEBUG") with ScriptedTest {
implicit val mat: Materializer = ActorMaterializer()

View file

@ -3,14 +3,14 @@
*/
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.scaladsl.{ TestSource, TestSink }
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.testkit.AkkaSpec
import akka.stream.FlowMonitorState._
import scala.concurrent.duration._
class FlowMonitorSpec extends AkkaSpec {
class FlowMonitorSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)

View file

@ -12,9 +12,8 @@ import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.TestProbe
import akka.testkit.AkkaSpec
class FlowOnCompleteSpec extends AkkaSpec with ScriptedTest {
class FlowOnCompleteSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -4,15 +4,14 @@
package akka.stream.scaladsl
import scala.collection.immutable
import scala.concurrent.{ Await }
import scala.concurrent.Await
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import akka.stream._
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class FlowPrefixAndTailSpec extends AkkaSpec {
class FlowPrefixAndTailSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -3,14 +3,14 @@
*/
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.scaladsl.TestSink
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
import scala.util.control.NoStackTrace
class FlowRecoverSpec extends AkkaSpec {
class FlowRecoverSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system).withInputBuffer(initialSize = 1, maxSize = 1)

View file

@ -3,14 +3,14 @@
*/
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.scaladsl.TestSink
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
import scala.util.control.NoStackTrace
class FlowRecoverWithSpec extends AkkaSpec {
class FlowRecoverWithSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system).withInputBuffer(initialSize = 1, maxSize = 1)

View file

@ -3,15 +3,16 @@
*/
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import scala.concurrent.Await
import scala.util.control.NoStackTrace
import akka.stream.ActorMaterializer
import akka.testkit.AkkaSpec
import akka.stream.testkit.Utils._
import scala.concurrent.duration._
class FlowReduceSpec extends AkkaSpec {
class FlowReduceSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()
"A Reduce" must {

View file

@ -4,9 +4,9 @@
package akka.stream.scaladsl
import akka.NotUsed
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.scaladsl.TestSink
import akka.stream.{ ActorAttributes, ActorMaterializer, ActorMaterializerSettings, Supervision }
import akka.testkit.AkkaSpec
import akka.stream.testkit.Utils._
import scala.collection.immutable
@ -14,7 +14,7 @@ import scala.concurrent.Await
import scala.concurrent.duration._
import java.util.concurrent.ThreadLocalRandom.{ current random }
class FlowScanSpec extends AkkaSpec {
class FlowScanSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -6,7 +6,7 @@ package akka.stream.scaladsl
import akka.stream.Attributes._
import akka.stream.ActorAttributes._
import akka.stream.ActorMaterializer
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.actor.ActorRef
import akka.testkit.TestProbe
@ -18,7 +18,7 @@ object FlowSectionSpec {
"""
}
class FlowSectionSpec extends AkkaSpec(FlowSectionSpec.config) {
class FlowSectionSpec extends StreamSpec(FlowSectionSpec.config) {
implicit val materializer = ActorMaterializer()

View file

@ -7,12 +7,10 @@ import akka.stream.testkit.Utils._
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.stream.testkit._
import org.scalacheck.Gen
import org.scalatest.concurrent.ScalaFutures
import org.scalatest.prop.GeneratorDrivenPropertyChecks
import akka.pattern.pipe
import akka.testkit.AkkaSpec
class FlowSlidingSpec extends AkkaSpec with GeneratorDrivenPropertyChecks {
class FlowSlidingSpec extends StreamSpec with GeneratorDrivenPropertyChecks {
import system.dispatcher
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -23,7 +23,6 @@ import scala.concurrent.Await
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import akka.stream.impl.fusing.GraphInterpreterShell
import akka.testkit.AkkaSpec
object FlowSpec {
class Fruit
@ -32,7 +31,7 @@ object FlowSpec {
}
class FlowSpec extends AkkaSpec(ConfigFactory.parseString("akka.actor.debug.receive=off\nakka.loglevel=INFO")) {
class FlowSpec extends StreamSpec(ConfigFactory.parseString("akka.actor.debug.receive=off\nakka.loglevel=INFO")) {
import FlowSpec._
val settings = ActorMaterializerSettings(system)

View file

@ -6,9 +6,7 @@ package akka.stream.scaladsl
import akka.NotUsed
import akka.stream._
import akka.stream.Supervision.resumingDecider
import akka.testkit.AkkaSpec
import akka.stream.testkit.TestPublisher
import akka.stream.testkit.TestSubscriber
import akka.stream.testkit.{ StreamSpec, TestPublisher, TestSubscriber }
import akka.stream.testkit.Utils._
import org.reactivestreams.Publisher
import scala.concurrent.Await
@ -24,7 +22,7 @@ object FlowSplitAfterSpec {
}
class FlowSplitAfterSpec extends AkkaSpec {
class FlowSplitAfterSpec extends StreamSpec {
import FlowSplitAfterSpec._
val settings = ActorMaterializerSettings(system)

View file

@ -12,9 +12,8 @@ import akka.stream.testkit._
import org.reactivestreams.Publisher
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class FlowSplitWhenSpec extends AkkaSpec {
class FlowSplitWhenSpec extends StreamSpec {
import FlowSplitAfterSpec._
val settings = ActorMaterializerSettings(system)

View file

@ -17,9 +17,8 @@ import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import akka.stream.testkit.scaladsl.TestSink
import akka.stream.testkit.scaladsl.TestSource
import akka.testkit.AkkaSpec
class FlowStageSpec extends AkkaSpec(ConfigFactory.parseString("akka.actor.debug.receive=off\nakka.loglevel=INFO")) {
class FlowStageSpec extends StreamSpec(ConfigFactory.parseString("akka.actor.debug.receive=off\nakka.loglevel=INFO")) {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 2)

View file

@ -7,9 +7,8 @@ import akka.stream.testkit.scaladsl.TestSink
import akka.stream.{ ActorMaterializer, ActorAttributes, Supervision, ActorMaterializerSettings }
import akka.stream.testkit._
import scala.util.control.NoStackTrace
import akka.testkit.AkkaSpec
class FlowStatefulMapConcatSpec extends AkkaSpec with ScriptedTest {
class FlowStatefulMapConcatSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -13,9 +13,8 @@ import akka.stream.Supervision
import akka.stream.impl.ReactiveStreamsCompliance
import akka.stream.ActorAttributes
import akka.NotUsed
import akka.testkit.AkkaSpec
class FlowSupervisionSpec extends AkkaSpec {
class FlowSupervisionSpec extends StreamSpec {
import ActorAttributes.supervisionStrategy
implicit val materializer = ActorMaterializer()(system)

View file

@ -12,9 +12,8 @@ import akka.stream.actor.ActorSubscriberMessage.OnComplete
import akka.stream.actor.ActorSubscriberMessage.OnNext
import akka.stream.impl.RequestMore
import akka.stream.testkit._
import akka.testkit.AkkaSpec
class FlowTakeSpec extends AkkaSpec with ScriptedTest {
class FlowTakeSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -11,9 +11,8 @@ import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.scaladsl.TestSink
import scala.util.control.NoStackTrace
import akka.testkit.AkkaSpec
class FlowTakeWhileSpec extends AkkaSpec {
class FlowTakeWhileSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)

View file

@ -7,9 +7,8 @@ import scala.concurrent.duration._
import akka.stream.ActorMaterializer
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class FlowTakeWithinSpec extends AkkaSpec {
class FlowTakeWithinSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()

View file

@ -12,9 +12,8 @@ import scala.concurrent.Await
import scala.concurrent.duration._
import scala.util.Random
import scala.util.control.NoStackTrace
import akka.testkit.AkkaSpec
class FlowThrottleSpec extends AkkaSpec {
class FlowThrottleSpec extends StreamSpec {
implicit val materializer = ActorMaterializer(ActorMaterializerSettings(system).withInputBuffer(1, 1))
def genByteString(length: Int) =

View file

@ -6,16 +6,14 @@ package akka.stream.scaladsl
import akka.Done
import akka.pattern.pipe
import akka.stream._
import akka.testkit.AkkaSpec
import akka.stream.testkit.StreamSpec
import akka.stream.testkit.Utils._
import akka.stream.testkit.scaladsl.{ TestSink, TestSource }
import org.scalactic.ConversionCheckedTripleEquals
import org.scalatest.concurrent.ScalaFutures
import scala.util.control.NoStackTrace
import scala.concurrent.duration._
class FlowWatchTerminationSpec extends AkkaSpec {
class FlowWatchTerminationSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)

View file

@ -7,8 +7,7 @@ import java.nio.ByteOrder
import akka.stream.scaladsl.Framing.FramingException
import akka.stream.stage.{ Context, PushPullStage, SyncDirective, TerminationDirective }
import akka.stream.testkit.{ TestSubscriber, TestPublisher }
import akka.testkit.AkkaSpec
import akka.stream.testkit.{ StreamSpec, TestSubscriber, TestPublisher }
import akka.stream.{ ActorMaterializer, ActorMaterializerSettings }
import akka.util.{ ByteString, ByteStringBuilder }
@ -18,7 +17,7 @@ import scala.concurrent.duration._
import java.util.concurrent.ThreadLocalRandom
import scala.util.Random
class FramingSpec extends AkkaSpec {
class FramingSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
implicit val materializer = ActorMaterializer(settings)

View file

@ -8,7 +8,6 @@ import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream._
import org.reactivestreams.Subscriber
import akka.testkit.AkkaSpec
object GraphFlowSpec {
val source1 = Source(0 to 3)
@ -36,7 +35,7 @@ object GraphFlowSpec {
val stdResult = Set(1, 2, 3, 4, 5, 6, 7, 8, 9, 10)
}
class GraphFlowSpec extends AkkaSpec {
class GraphFlowSpec extends StreamSpec {
import GraphFlowSpec._

View file

@ -7,9 +7,8 @@ import akka.stream.{ SourceShape, ClosedShape, ActorMaterializer, ActorMateriali
import akka.stream.testkit._
import akka.stream.testkit.scaladsl._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class GraphBalanceSpec extends AkkaSpec {
class GraphBalanceSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -6,9 +6,8 @@ import scala.concurrent.duration._
import akka.stream._
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class GraphBroadcastSpec extends AkkaSpec {
class GraphBroadcastSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -6,14 +6,13 @@ package akka.stream.scaladsl
import akka.stream.{ ClosedShape, ActorMaterializer, OverflowStrategy }
import akka.stream.testkit._
import akka.stream.stage._
import akka.testkit.AkkaSpec
object GraphDSLCompileSpec {
class Fruit
class Apple extends Fruit
}
class GraphDSLCompileSpec extends AkkaSpec {
class GraphDSLCompileSpec extends StreamSpec {
import GraphDSLCompileSpec._
implicit val materializer = ActorMaterializer()

View file

@ -10,9 +10,8 @@ import akka.stream.testkit._
import scala.concurrent.Await
import scala.concurrent.Future
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class GraphMatValueSpec extends AkkaSpec {
class GraphMatValueSpec extends StreamSpec {
import GraphDSL.Implicits._

View file

@ -6,8 +6,6 @@ import scala.concurrent.{ Future, Await }
import scala.concurrent.duration._
import akka.stream._
import akka.stream.testkit._
import org.scalactic.ConversionCheckedTripleEquals
import akka.testkit.AkkaSpec
object GraphOpsIntegrationSpec {
import GraphDSL.Implicits._
@ -43,7 +41,7 @@ object GraphOpsIntegrationSpec {
}
class GraphOpsIntegrationSpec extends AkkaSpec {
class GraphOpsIntegrationSpec extends StreamSpec {
import akka.stream.scaladsl.GraphOpsIntegrationSpec._
import GraphDSL.Implicits._

View file

@ -1,12 +1,12 @@
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import akka.stream.{ ClosedShape, ActorMaterializer, ActorMaterializerSettings, FlowShape }
import akka.testkit.AkkaSpec
import scala.concurrent.{ Await }
import scala.concurrent.Await
import scala.concurrent.duration._
class GraphPartialSpec extends AkkaSpec {
class GraphPartialSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -9,9 +9,8 @@ import akka.stream.testkit.Utils._
import org.scalatest.concurrent.ScalaFutures
import scala.concurrent.Await
import scala.concurrent.duration._
import akka.testkit.AkkaSpec
class GraphPartitionSpec extends AkkaSpec {
class GraphPartitionSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -7,7 +7,6 @@ import akka.actor.ActorRef
import akka.stream.{ Attributes, ActorMaterializer }
import akka.stream.impl.fusing.GraphStages.SimpleLinearGraphStage
import akka.stream.stage.{ TimerGraphStageLogic, OutHandler, AsyncCallback, InHandler }
import akka.testkit.AkkaSpec
import akka.testkit.TestDuration
import scala.concurrent.Promise
@ -36,7 +35,7 @@ object GraphStageTimersSpec {
}
class GraphStageTimersSpec extends AkkaSpec {
class GraphStageTimersSpec extends StreamSpec {
import GraphStageTimersSpec._
implicit val materializer = ActorMaterializer()

View file

@ -7,9 +7,8 @@ import scala.concurrent.duration._
import akka.stream.{ ClosedShape, OverflowStrategy, ActorMaterializerSettings, ActorMaterializer }
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class GraphUnzipSpec extends AkkaSpec {
class GraphUnzipSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -11,9 +11,8 @@ import org.reactivestreams.Publisher
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import akka.testkit.EventFilter
import akka.testkit.AkkaSpec
class GraphUnzipWithSpec extends AkkaSpec {
class GraphUnzipWithSpec extends StreamSpec {
import GraphDSL.Implicits._

View file

@ -11,9 +11,8 @@ import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class HeadSinkSpec extends AkkaSpec with ScriptedTest {
class HeadSinkSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 2, maxSize = 16)

View file

@ -10,9 +10,8 @@ import akka.stream.ActorMaterializer
import akka.stream.ActorMaterializerSettings
import akka.stream.testkit._
import akka.stream.testkit.Utils._
import akka.testkit.AkkaSpec
class LastSinkSpec extends AkkaSpec with ScriptedTest {
class LastSinkSpec extends StreamSpec with ScriptedTest {
val settings = ActorMaterializerSettings(system)

View file

@ -8,16 +8,15 @@ import java.util.concurrent.TimeoutException
import akka.stream.ActorAttributes.supervisionStrategy
import akka.stream.Supervision._
import akka.stream._
import akka.stream.testkit.TestPublisher
import akka.stream.testkit.{ StreamSpec, TestPublisher }
import akka.stream.testkit.TestSubscriber.Probe
import akka.stream.testkit.Utils._
import akka.stream.testkit.scaladsl.TestSink
import akka.testkit.AkkaSpec
import scala.concurrent.{ Promise, Future, Await }
import scala.concurrent.duration._
class LazySinkSpec extends AkkaSpec {
class LazySinkSpec extends StreamSpec {
val settings = ActorMaterializerSettings(system)
.withInputBuffer(initialSize = 1, maxSize = 1)

View file

@ -3,15 +3,15 @@
*/
package akka.stream.scaladsl
import akka.stream.testkit.StreamSpec
import akka.stream.{ ClosedShape, ActorMaterializer }
import akka.testkit.AkkaSpec
import akka.stream.testkit.Utils._
import scala.concurrent.duration._
import scala.concurrent.Await
class PublisherSinkSpec extends AkkaSpec {
class PublisherSinkSpec extends StreamSpec {
implicit val materializer = ActorMaterializer()

Some files were not shown because too many files have changed in this diff Show more