chore: Sort imports on stream,stream-tests,stream-testkit

This commit is contained in:
He-Pin 2024-01-16 14:04:31 +08:00 committed by He-Pin(kerr)
parent 28b7f4ccdf
commit c44c0b7cbd
128 changed files with 327 additions and 290 deletions

View file

@ -13,12 +13,11 @@
package org.apache.pekko.stream.impl.fusing
import scala.annotation.nowarn
import scala.collection.{ Map => SMap }
import scala.concurrent.ExecutionContextExecutor
import scala.concurrent.duration.FiniteDuration
import scala.annotation.nowarn
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.actor.Cancellable

View file

@ -16,13 +16,13 @@ package org.apache.pekko.stream.testkit
import scala.collection.immutable
import scala.util.control.NoStackTrace
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.stream.scaladsl._
import pekko.stream.testkit.scaladsl.StreamTestKit._
import pekko.testkit.PekkoSpec
import org.reactivestreams.Publisher
abstract class BaseTwoStreamsSetup extends PekkoSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
pekko.stream.materializer.max-input-buffer-size = 2

View file

@ -14,7 +14,6 @@
package org.apache.pekko.stream.testkit
import scala.annotation.nowarn
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.NotUsed
@ -25,6 +24,8 @@ import pekko.stream.ActorMaterializerSettings
import pekko.stream.Materializer
import pekko.stream.scaladsl._
import org.reactivestreams.Publisher
class ChainSetup[In, Out, M](
stream: Flow[In, In, NotUsed] => Flow[In, Out, M],
val settings: ActorMaterializerSettings,

View file

@ -15,13 +15,10 @@ package org.apache.pekko.stream.testkit
import java.util.concurrent.ThreadLocalRandom
import scala.annotation.nowarn
import scala.annotation.tailrec
import scala.concurrent.duration._
import scala.annotation.nowarn
import org.reactivestreams.Publisher
import org.scalatest.matchers.should.Matchers
import org.apache.pekko
import pekko.NotUsed
import pekko.actor.ActorSystem
@ -34,6 +31,10 @@ import pekko.stream.scaladsl.Source
import pekko.stream.testkit.TestPublisher._
import pekko.stream.testkit.TestSubscriber._
import org.reactivestreams.Publisher
import org.scalatest.matchers.should.Matchers
trait ScriptedTest extends Matchers {
class ScriptException(msg: String) extends RuntimeException(msg)

View file

@ -16,18 +16,19 @@ package org.apache.pekko.stream.testkit
import scala.concurrent.Future
import scala.concurrent.duration._
import com.typesafe.config.{ Config, ConfigFactory }
import org.scalatest.Failed
import org.apache.pekko
import pekko.actor.{ ActorRef, ActorSystem }
import pekko.stream.Materializer
import pekko.stream.impl.PhasedFusingActorMaterializer
import pekko.stream.impl.StreamSupervisor
import pekko.stream.snapshot.{ MaterializerState, StreamSnapshotImpl }
import pekko.stream.testkit.scaladsl.StreamTestKit.{ assertNoChildren, stopAllChildren }
import pekko.testkit.{ PekkoSpec, TestProbe }
import pekko.testkit.TestKitUtils
import pekko.stream.impl.PhasedFusingActorMaterializer
import pekko.stream.testkit.scaladsl.StreamTestKit.{ assertNoChildren, stopAllChildren }
import pekko.stream.Materializer
import org.scalatest.Failed
import com.typesafe.config.{ Config, ConfigFactory }
abstract class StreamSpec(_system: ActorSystem) extends PekkoSpec(_system) {
def this(config: Config) =

View file

@ -13,8 +13,6 @@
package org.apache.pekko.stream.testkit
import com.typesafe.config.Config
import org.apache.pekko
import pekko.actor.Actor
import pekko.actor.ActorRef
@ -26,6 +24,8 @@ import pekko.dispatch.ProducesMessageQueue
import pekko.dispatch.UnboundedMailbox
import pekko.stream.impl.MaterializerGuardian
import com.typesafe.config.Config
/**
* INTERNAL API
* This mailbox is only used in tests to verify that stream actors are using

View file

@ -13,7 +13,10 @@
package org.apache.pekko.stream.testkit
import java.util
import scala.concurrent.duration._
import org.apache.pekko
import pekko.stream.scaladsl.Source
import pekko.stream.testkit.scaladsl.TestSink
@ -21,8 +24,6 @@ import pekko.testkit._
import pekko.testkit.TestEvent.Mute
import pekko.testkit.TestEvent.UnMute
import java.util
class StreamTestKitSpec extends PekkoSpec {
val ex = new Exception("Boom!")

View file

@ -13,8 +13,6 @@
package org.apache.pekko.stream.testkit
import org.reactivestreams.Subscription
import org.apache.pekko
import pekko.stream.scaladsl.Sink
import pekko.stream.scaladsl.Source
@ -23,6 +21,8 @@ import pekko.stream.testkit.TestSubscriber._
import pekko.stream.testkit.scaladsl.StreamTestKit._
import pekko.testkit.PekkoSpec
import org.reactivestreams.Subscription
class TestPublisherSubscriberSpec extends PekkoSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
pekko.stream.materializer.max-input-buffer-size = 2

View file

@ -13,12 +13,12 @@
package org.apache.pekko.stream.testkit
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.stream._
import pekko.stream.scaladsl._
import org.reactivestreams.Publisher
abstract class TwoStreamsSetup extends BaseTwoStreamsSetup {
abstract class Fixture {

View file

@ -15,12 +15,12 @@ package org.apache.pekko.stream.testkit
import scala.util.control.NoStackTrace
import com.typesafe.config.ConfigFactory
import org.apache.pekko
import pekko.actor.ActorRef
import pekko.actor.ActorRefWithCell
import com.typesafe.config.ConfigFactory
object Utils {
/** Sets the default-mailbox to the usual [[pekko.dispatch.UnboundedMailbox]] instead of [[StreamTestDefaultMailbox]]. */

View file

@ -19,8 +19,6 @@ import scala.concurrent.Future
import scala.concurrent.duration._
import scala.util.{ Failure, Try }
import com.typesafe.config.ConfigFactory
import org.apache.pekko
import pekko.Done
import pekko.actor.{ Actor, ActorSystem, PoisonPill, Props }
@ -35,6 +33,8 @@ import pekko.stream.testkit.{ StreamSpec, TestPublisher }
import pekko.testkit.{ ImplicitSender, TestProbe }
import pekko.testkit.TestKit
import com.typesafe.config.ConfigFactory
object IndirectMaterializerCreation extends ExtensionId[IndirectMaterializerCreation] with ExtensionIdProvider {
def createExtension(system: ExtendedActorSystem): IndirectMaterializerCreation =
new IndirectMaterializerCreation(system)

View file

@ -16,9 +16,10 @@ package org.apache.pekko.stream
import java.lang.reflect.Method
import java.lang.reflect.Modifier
import org.apache.pekko
import scala.annotation.nowarn
import org.apache.pekko
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpec

View file

@ -14,6 +14,7 @@
package org.apache.pekko.stream
import org.apache.pekko
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpec

View file

@ -15,14 +15,14 @@ package org.apache.pekko.stream
import scala.concurrent.Future
import org.scalatest.concurrent.ScalaFutures
import org.apache.pekko
import pekko.stream.scaladsl.Keep
import pekko.stream.scaladsl.Sink
import pekko.stream.scaladsl.Source
import pekko.stream.testkit.StreamSpec
import org.scalatest.concurrent.ScalaFutures
class SystemMaterializerSpec extends StreamSpec with ScalaFutures {
def compileOnly(): Unit = {

View file

@ -15,8 +15,6 @@ package org.apache.pekko.stream.impl
import scala.concurrent.duration.Duration
import org.scalatest.concurrent.ScalaFutures
import org.apache.pekko
import pekko.NotUsed
import pekko.stream._
@ -27,6 +25,8 @@ import pekko.stream.stage.GraphStageLogic.{ EagerTerminateInput, EagerTerminateO
import pekko.stream.testkit.StreamSpec
import pekko.stream.testkit.scaladsl.TestSink
import org.scalatest.concurrent.ScalaFutures
class GraphStageLogicSpec extends StreamSpec with GraphInterpreterSpecKit with ScalaFutures {
object emit1234 extends GraphStage[FlowShape[Int, Int]] {

View file

@ -15,11 +15,11 @@ package org.apache.pekko.stream.impl
import scala.util.Random
import org.apache.pekko.stream.impl.ResizableMultiReaderRingBuffer._
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpec
import org.apache.pekko.stream.impl.ResizableMultiReaderRingBuffer._
class ResizableMultiReaderRingBufferSpec extends AnyWordSpec with Matchers {
"A ResizableMultiReaderRingBuffer" should {

View file

@ -19,9 +19,6 @@ import scala.concurrent.Await
import scala.concurrent.Future
import scala.concurrent.duration._
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
import org.apache.pekko
import pekko.Done
import pekko.stream._
@ -31,6 +28,9 @@ import pekko.stream.testkit.TestPublisher
import pekko.stream.testkit.TestSubscriber
import pekko.stream.testkit.Utils._
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
class TimeoutsSpec extends StreamSpec {
"InitialTimeout" must {

View file

@ -19,10 +19,6 @@ import scala.concurrent.Await
import scala.concurrent.Promise
import scala.concurrent.duration._
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
import org.apache.pekko
import pekko.Done
import pekko.stream._
@ -40,6 +36,10 @@ import pekko.stream.testkit.Utils._
import pekko.testkit.EventFilter
import pekko.testkit.TestLatch
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
class ActorGraphInterpreterSpec extends StreamSpec {
"ActorGraphInterpreter" must {

View file

@ -15,13 +15,13 @@ package org.apache.pekko.stream.impl.io
import javax.net.ssl.{ SSLContext, SSLEngine, SSLParameters }
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
import org.apache.pekko
import pekko.stream.TLSClientAuth
import pekko.stream.TLSProtocol.NegotiateNewSession
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
class TLSUtilsSpec extends AnyWordSpecLike with Matchers {
"TlsUtils.applySessionParameters" must {

View file

@ -26,8 +26,6 @@ import scala.concurrent.Future
import scala.concurrent.duration._
import scala.util.Random
import com.typesafe.sslconfig.pekko.PekkoSSLConfig
import org.apache.pekko
import pekko.NotUsed
import pekko.pattern.{ after => later }
@ -42,6 +40,8 @@ import pekko.testkit.WithLogCapturing
import pekko.util.ByteString
import pekko.util.JavaVersion
import com.typesafe.sslconfig.pekko.PekkoSSLConfig
object DeprecatedTlsSpec {
val rnd = new Random

View file

@ -23,7 +23,6 @@ import scala.concurrent.duration._
import scala.util.Success
import com.google.common.jimfs.{ Configuration, Jimfs }
import org.scalatest.concurrent.ScalaFutures
import org.apache.pekko
import pekko.dispatch.ExecutionContexts
@ -35,6 +34,8 @@ import pekko.stream.testkit._
import pekko.stream.testkit.Utils._
import pekko.util.ByteString
import org.scalatest.concurrent.ScalaFutures
@nowarn
class FileSinkSpec extends StreamSpec(UnboundedMailboxConfig) with ScalaFutures {

View file

@ -18,8 +18,6 @@ import java.io.OutputStream
import scala.annotation.nowarn
import scala.util.Success
import org.scalatest.concurrent.ScalaFutures
import org.apache.pekko
import pekko.Done
import pekko.stream.{ ActorMaterializer, ActorMaterializerSettings, IOOperationIncompleteException }
@ -29,6 +27,8 @@ import pekko.stream.testkit.Utils._
import pekko.testkit.TestProbe
import pekko.util.ByteString
import org.scalatest.concurrent.ScalaFutures
@nowarn
class OutputStreamSinkSpec extends StreamSpec(UnboundedMailboxConfig) with ScalaFutures {

View file

@ -25,11 +25,6 @@ import scala.concurrent.Future
import scala.concurrent.Promise
import scala.concurrent.duration._
import com.typesafe.config.Config
import com.typesafe.config.ConfigFactory
import org.scalatest.concurrent.PatienceConfiguration
import org.scalatest.concurrent.PatienceConfiguration.Timeout
import org.apache.pekko
import pekko.Done
import pekko.NotUsed
@ -59,6 +54,12 @@ import pekko.testkit.TestProbe
import pekko.testkit.WithLogCapturing
import pekko.util.ByteString
import org.scalatest.concurrent.PatienceConfiguration
import org.scalatest.concurrent.PatienceConfiguration.Timeout
import com.typesafe.config.Config
import com.typesafe.config.ConfigFactory
@nowarn("msg=never used")
class NonResolvingDnsActor(cache: SimpleDnsCache, config: Config) extends Actor {
def receive = {
@ -1021,12 +1022,12 @@ class TcpSpec extends StreamSpec("""
import java.security.KeyStore
import javax.net.ssl._
import com.typesafe.sslconfig.pekko.PekkoSSLConfig
import org.apache.pekko
import pekko.stream.TLSClientAuth
import pekko.stream.TLSProtocol
import com.typesafe.sslconfig.pekko.PekkoSSLConfig
val sslConfig = PekkoSSLConfig(system)
// Don't hardcode your password in actual code

View file

@ -13,15 +13,15 @@
package org.apache.pekko.stream.io.compression
import org.scalatest.BeforeAndAfterAll
import org.scalatest.Suite
import org.scalatest.matchers.should.Matchers
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.testkit.TestKit
import pekko.util.ByteString
import org.scalatest.BeforeAndAfterAll
import org.scalatest.Suite
import org.scalatest.matchers.should.Matchers
trait CodecSpecSupport extends Matchers with BeforeAndAfterAll { self: Suite =>
def readAs(string: String, charset: String = "UTF8") =

View file

@ -22,15 +22,15 @@ import scala.concurrent.Await
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import org.scalatest.Inspectors
import org.scalatest.wordspec.AnyWordSpec
import org.apache.pekko
import pekko.NotUsed
import pekko.stream.impl.io.compression.Compressor
import pekko.stream.scaladsl.{ Compression, Flow, Sink, Source }
import pekko.util.ByteString
import org.scalatest.Inspectors
import org.scalatest.wordspec.AnyWordSpec
abstract class CoderSpec(codecName: String) extends AnyWordSpec with CodecSpecSupport with Inspectors {
import CompressionTestingTools._

View file

@ -16,8 +16,6 @@ package org.apache.pekko.stream.scaladsl
import scala.annotation.nowarn
import scala.concurrent.duration._
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.Done
import pekko.actor.{ ActorRef, Status }
@ -26,6 +24,8 @@ import pekko.stream.testkit._
import pekko.stream.testkit.Utils._
import pekko.stream.testkit.scaladsl._
import org.reactivestreams.Publisher
@nowarn("msg=deprecated")
class ActorRefSourceSpec extends StreamSpec {

View file

@ -17,16 +17,17 @@ import scala.collection.mutable.ListBuffer
import scala.concurrent.Await
import scala.concurrent.duration._
import com.typesafe.config.{ ConfigFactory, ConfigValueFactory }
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.stream.OverflowStrategy
import pekko.stream.testkit.{ StreamSpec, TestPublisher, TestSubscriber }
import pekko.testkit.{ ExplicitlyTriggeredScheduler, PekkoSpec }
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
import com.typesafe.config.{ ConfigFactory, ConfigValueFactory }
class AggregateWithBoundarySpec extends StreamSpec {
"split aggregator by size" in {

View file

@ -14,22 +14,24 @@
package org.apache.pekko.stream.scaladsl
import java.util.concurrent.{ CompletionStage, TimeUnit }
import scala.annotation.nowarn
import com.typesafe.config.ConfigFactory
import org.apache.pekko
import pekko.{ Done, NotUsed }
import pekko.actor.ActorSystem
import pekko.dispatch.Dispatchers
import pekko.stream.ActorAttributes.Dispatcher
import pekko.stream._
import pekko.stream.ActorAttributes.Dispatcher
import pekko.stream.Attributes._
import pekko.stream.javadsl
import pekko.stream.stage._
import pekko.stream.snapshot.MaterializerState
import pekko.stream.stage._
import pekko.stream.testkit._
import pekko.testkit.TestKit
import com.typesafe.config.ConfigFactory
object AttributesSpec {
class AttributesSource(_initialAttributes: Attributes = Attributes.none)

View file

@ -19,11 +19,6 @@ import scala.util.Success
import scala.util.Try
import scala.xml.Node
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
import org.scalatest.Assertion
import org.apache.pekko
import pekko.Done
import pekko.NotUsed
@ -32,6 +27,12 @@ import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl.TestSource
import pekko.testkit.TestProbe
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
import org.scalatest.Assertion
class CoupledTerminationFlowSpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
""") with ScriptedTest {

View file

@ -13,14 +13,15 @@
package org.apache.pekko.stream.scaladsl
import org.reactivestreams.Subscriber
import org.scalatest.matchers.should.Matchers
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.stream.testkit.StreamSpec
import pekko.stream.testkit.TestSubscriber
import org.reactivestreams.Subscriber
import org.scalatest.matchers.should.Matchers
class FlowAppendSpec extends StreamSpec with River {
"Flow" should {

View file

@ -17,12 +17,12 @@ import scala.annotation.nowarn
import scala.collection.immutable.Seq
import scala.concurrent.Future
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.NotUsed
import pekko.stream.testkit.StreamSpec
import org.reactivestreams.Publisher
@nowarn // unused vars are used in shouldNot compile tests
class FlowCompileSpec extends StreamSpec {

View file

@ -13,14 +13,15 @@
package org.apache.pekko.stream.scaladsl
import java.util.StringJoiner
import java.util.concurrent.atomic.AtomicBoolean
import scala.util.control.NoStackTrace
import org.apache.pekko
import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl.TestSink
import java.util.StringJoiner
import java.util.concurrent.atomic.AtomicBoolean
import scala.util.control.NoStackTrace
class FlowConcatAllLazySpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
pekko.stream.materializer.max-input-buffer-size = 2

View file

@ -19,9 +19,6 @@ import scala.concurrent.Await
import scala.concurrent.Promise
import scala.concurrent.duration._
import org.reactivestreams.Publisher
import org.scalatest.concurrent.ScalaFutures
import org.apache.pekko
import pekko.NotUsed
import pekko.stream.testkit.BaseTwoStreamsSetup
@ -30,6 +27,10 @@ import pekko.stream.testkit.TestSubscriber
import pekko.stream.testkit.scaladsl.StreamTestKit._
import pekko.stream.testkit.scaladsl.TestSink
import org.reactivestreams.Publisher
import org.scalatest.concurrent.ScalaFutures
abstract class AbstractFlowConcatSpec extends BaseTwoStreamsSetup {
override type Outputs = Int

View file

@ -17,10 +17,6 @@ import scala.concurrent.Await
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import org.scalatest.concurrent.PatienceConfiguration
import org.scalatest.time.Milliseconds
import org.scalatest.time.Span
import org.apache.pekko
import pekko.Done
import pekko.stream._
@ -33,6 +29,10 @@ import pekko.stream.testkit.scaladsl.TestSink
import pekko.testkit.TestDuration
import pekko.testkit.TimingTest
import org.scalatest.concurrent.PatienceConfiguration
import org.scalatest.time.Milliseconds
import org.scalatest.time.Span
class FlowDelaySpec extends StreamSpec {
"A Delay" must {

View file

@ -16,8 +16,6 @@ package org.apache.pekko.stream.scaladsl
import scala.concurrent._
import scala.concurrent.duration._
import org.scalatest.exceptions.TestFailedException
import org.apache.pekko
import pekko.NotUsed
import pekko.stream._
@ -33,6 +31,8 @@ import pekko.stream.testkit.scaladsl.TestSink
import pekko.testkit.TestLatch
import pekko.util.OptionVal
import org.scalatest.exceptions.TestFailedException
class FlowFlattenMergeSpec extends StreamSpec {
import system.dispatcher

View file

@ -19,8 +19,6 @@ import scala.concurrent.Future
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import org.scalatest.concurrent.PatienceConfiguration.Timeout
import org.apache.pekko
import pekko.NotUsed
import pekko.stream.ActorAttributes.supervisionStrategy
@ -31,6 +29,8 @@ import pekko.stream.testkit._
import pekko.stream.testkit.Utils._
import pekko.testkit.LongRunningTest
import org.scalatest.concurrent.PatienceConfiguration.Timeout
class FlowFoldAsyncSpec extends StreamSpec {
implicit def ec: ExecutionContextExecutor = system.dispatcher

View file

@ -22,9 +22,6 @@ import scala.concurrent.Await
import scala.concurrent.Promise
import scala.concurrent.duration._
import org.reactivestreams.Publisher
import org.scalatest.concurrent.PatienceConfiguration.Timeout
import org.apache.pekko
import pekko.Done
import pekko.NotUsed
@ -41,6 +38,10 @@ import pekko.stream.testkit.scaladsl.TestSource
import pekko.testkit.TestLatch
import pekko.util.ByteString
import org.reactivestreams.Publisher
import org.scalatest.concurrent.PatienceConfiguration.Timeout
object FlowGroupBySpec {
implicit class Lift[M](val f: SubFlow[Int, M, Source[Int, M]#Repr, RunnableGraph[M]]) extends AnyVal {

View file

@ -13,13 +13,13 @@
package org.apache.pekko.stream.scaladsl
import java.util.StringJoiner
import org.apache.pekko
import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl.StreamTestKit._
import pekko.stream.testkit.scaladsl.TestSink
import java.util.StringJoiner
class FlowInterleaveAllSpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
pekko.stream.materializer.max-input-buffer-size = 2

View file

@ -13,12 +13,12 @@
package org.apache.pekko.stream.scaladsl
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl.StreamTestKit._
import org.reactivestreams.Publisher
class FlowInterleaveSpec extends BaseTwoStreamsSetup {
override type Outputs = Int

View file

@ -15,14 +15,14 @@ package org.apache.pekko.stream.scaladsl
import scala.collection.immutable
import org.scalatest.time._
import org.apache.pekko
import pekko.stream.FlowShape
import pekko.stream.OverflowStrategy
import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl._
import org.scalatest.time._
class FlowJoinSpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
""") {

View file

@ -24,8 +24,6 @@ import scala.concurrent.Promise
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import org.scalatest.concurrent.PatienceConfiguration.Timeout
import org.apache.pekko
import pekko.stream.ActorAttributes
import pekko.stream.ActorAttributes.supervisionStrategy
@ -37,6 +35,8 @@ import pekko.stream.testkit.scaladsl.TestSink
import pekko.testkit.TestLatch
import pekko.testkit.TestProbe
import org.scalatest.concurrent.PatienceConfiguration.Timeout
class FlowMapAsyncSpec extends StreamSpec {
"A Flow with mapAsync" must {

View file

@ -23,8 +23,6 @@ import scala.concurrent.Promise
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import org.scalatest.concurrent.PatienceConfiguration.Timeout
import org.apache.pekko
import pekko.stream.ActorAttributes.supervisionStrategy
import pekko.stream.Supervision.resumingDecider
@ -33,6 +31,8 @@ import pekko.stream.testkit.scaladsl._
import pekko.testkit.TestLatch
import pekko.testkit.TestProbe
import org.scalatest.concurrent.PatienceConfiguration.Timeout
class FlowMapAsyncUnorderedSpec extends StreamSpec {
"A Flow with mapAsyncUnordered" must {

View file

@ -13,12 +13,12 @@
package org.apache.pekko.stream.scaladsl
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl.StreamTestKit._
import org.reactivestreams.Publisher
class FlowMergeSpec extends BaseTwoStreamsSetup {
override type Outputs = Int

View file

@ -17,12 +17,13 @@
package org.apache.pekko.stream.scaladsl
import org.apache.pekko.stream.testkit.StreamSpec
import org.apache.pekko.stream.testkit.scaladsl.TestSink
import scala.concurrent.TimeoutException
import scala.util.control.NoStackTrace
import org.apache.pekko
import pekko.stream.testkit.StreamSpec
import pekko.stream.testkit.scaladsl.TestSink
class FlowOnErrorCompleteSpec extends StreamSpec {
val ex = new RuntimeException("ex") with NoStackTrace

View file

@ -20,8 +20,6 @@ import scala.concurrent.Promise
import scala.concurrent.duration._
import scala.util.Failure
import org.scalatest.matchers.should.Matchers
import org.apache.pekko
import pekko.pattern
import pekko.stream.ActorAttributes
@ -32,6 +30,8 @@ import pekko.stream.testkit.TestSubscriber.Probe
import pekko.stream.testkit.Utils.TE
import pekko.stream.testkit.scaladsl._
import org.scalatest.matchers.should.Matchers
class FlowScanAsyncSpec extends StreamSpec with Matchers {
implicit val executionContext: ExecutionContextExecutor = system.dispatcher

View file

@ -14,13 +14,14 @@
package org.apache.pekko.stream.scaladsl
import java.util.concurrent.ThreadLocalRandom
import java.util.concurrent.atomic.AtomicLong
import scala.annotation.nowarn
import scala.collection.immutable
import scala.concurrent.Await
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import scala.annotation.nowarn
import com.typesafe.config.ConfigFactory
import org.reactivestreams.{ Publisher, Subscriber }
import org.apache.pekko
import pekko.NotUsed
import pekko.stream._
@ -30,7 +31,9 @@ import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl.{ TestSink, TestSource }
import pekko.testkit.TestDuration
import java.util.concurrent.atomic.AtomicLong
import org.reactivestreams.{ Publisher, Subscriber }
import com.typesafe.config.ConfigFactory
object FlowSpec {
class Fruit extends Serializable

View file

@ -16,8 +16,6 @@ package org.apache.pekko.stream.scaladsl
import scala.concurrent.Await
import scala.concurrent.duration._
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.NotUsed
import pekko.stream._
@ -29,6 +27,8 @@ import pekko.stream.testkit.TestPublisher
import pekko.stream.testkit.TestSubscriber
import pekko.stream.testkit.Utils._
import org.reactivestreams.Publisher
object FlowSplitAfterSpec {
implicit class Lift[M](val f: SubFlow[Int, M, Source[Int, M]#Repr, RunnableGraph[M]]) extends AnyVal {

View file

@ -17,8 +17,6 @@ import scala.concurrent.Await
import scala.concurrent.Future
import scala.concurrent.duration._
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.Done
import pekko.NotUsed
@ -30,6 +28,8 @@ import pekko.stream.testkit._
import pekko.stream.testkit.Utils._
import pekko.stream.testkit.scaladsl.TestSink
import org.reactivestreams.Publisher
class FlowSplitWhenSpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
pekko.stream.materializer.max-input-buffer-size = 2

View file

@ -13,6 +13,7 @@
package org.apache.pekko.stream.scaladsl
import scala.annotation.nowarn
import scala.util.control.NoStackTrace
import org.apache.pekko
@ -21,8 +22,6 @@ import pekko.stream.Supervision
import pekko.stream.testkit._
import pekko.stream.testkit.scaladsl.TestSink
import scala.annotation.nowarn
@nowarn("msg=deprecated")
class FlowStatefulMapConcatSpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2

View file

@ -13,12 +13,12 @@
package org.apache.pekko.stream.scaladsl
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.stream.testkit.{ BaseTwoStreamsSetup, TestSubscriber }
import pekko.stream.testkit.scaladsl.StreamTestKit._
import org.reactivestreams.Publisher
class FlowZipAllSpec extends BaseTwoStreamsSetup {
override type Outputs = (Int, Int)

View file

@ -17,16 +17,17 @@
package org.apache.pekko.stream.scaladsl
import java.util.concurrent.CopyOnWriteArrayList
import scala.concurrent.Await
import scala.concurrent.duration.DurationInt
import org.apache.pekko
import pekko.Done
import pekko.japi.Util
import pekko.stream.testkit.StreamSpec
import pekko.stream.testkit.scaladsl.TestSink
import java.util.concurrent.CopyOnWriteArrayList
import scala.concurrent.Await
import scala.concurrent.duration.DurationInt
class ForComprehensionsCompileSpec extends StreamSpec {
"A Source" must {
"be able to be used in a for comprehension which yield" in {

View file

@ -15,14 +15,14 @@ package org.apache.pekko.stream.scaladsl
import scala.annotation.nowarn
import org.reactivestreams.Subscriber
import org.apache.pekko
import pekko.stream._
import pekko.stream.ActorMaterializer
import pekko.stream.ActorMaterializerSettings
import pekko.stream.testkit._
import org.reactivestreams.Subscriber
object GraphFlowSpec {
val source1 = Source(0 to 3)

View file

@ -17,8 +17,6 @@ import scala.concurrent.Future
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.Done
import pekko.NotUsed
@ -30,6 +28,8 @@ import pekko.testkit.EventFilter
import pekko.testkit.TestProbe
import pekko.util.unused
import org.reactivestreams.Publisher
class GraphUnzipWithSpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 2
""") {

View file

@ -17,7 +17,6 @@ import scala.concurrent.duration._
import scala.language.postfixOps
import org.scalacheck.Gen
import org.scalatest.concurrent.ScalaFutures
import org.scalatestplus.scalacheck.ScalaCheckPropertyChecks
import org.apache.pekko
@ -29,6 +28,8 @@ import pekko.stream.testkit.TestSubscriber
import pekko.stream.testkit.scaladsl.TestSink
import pekko.stream.testkit.scaladsl.TestSource
import org.scalatest.concurrent.ScalaFutures
object GraphZipLatestSpec {
val someString = "someString"
val someInt = 1

View file

@ -16,13 +16,13 @@ package org.apache.pekko.stream.scaladsl
import scala.concurrent.duration._
import scala.language.postfixOps
import org.reactivestreams.Publisher
import org.apache.pekko
import pekko.stream._
import pekko.stream.testkit._
import pekko.testkit.EventFilter
import org.reactivestreams.Publisher
class GraphZipLatestWithSpec extends TwoStreamsSetup {
import GraphDSL.Implicits._

View file

@ -18,14 +18,14 @@ import java.util.concurrent.atomic.AtomicBoolean
import scala.annotation.nowarn
import scala.concurrent.Future
import org.scalatest.concurrent.ScalaFutures
import org.apache.pekko
import pekko.Done
import pekko.stream.testkit.StreamSpec
import pekko.stream.testkit.TestSubscriber
import pekko.testkit.DefaultTimeout
import org.scalatest.concurrent.ScalaFutures
@nowarn("msg=deprecated") // tests deprecated methods
class LazilyAsyncSpec extends StreamSpec with DefaultTimeout with ScalaFutures {

View file

@ -19,8 +19,6 @@ import scala.collection.immutable.Seq
import scala.concurrent.Future
import scala.concurrent.Promise
import org.scalatest.concurrent.ScalaFutures
import org.apache.pekko
import pekko.Done
import pekko.NotUsed
@ -36,6 +34,8 @@ import pekko.stream.testkit.Utils.TE
import pekko.testkit.DefaultTimeout
import pekko.testkit.TestProbe
import org.scalatest.concurrent.ScalaFutures
class LazySourceSpec extends StreamSpec with DefaultTimeout with ScalaFutures {
import system.dispatcher

View file

@ -17,8 +17,6 @@ import scala.annotation.nowarn
import scala.concurrent._
import scala.concurrent.duration._
import org.scalatest.time.Span
import org.apache.pekko
import pekko.Done
import pekko.actor.Status
@ -32,6 +30,8 @@ import pekko.stream.testkit.TestSubscriber
import pekko.stream.testkit.scaladsl.TestSink
import pekko.testkit.TestProbe
import org.scalatest.time.Span
class QueueSourceSpec extends StreamSpec {
implicit val ec: ExecutionContextExecutor = system.dispatcher
val pause = 300.millis

View file

@ -16,14 +16,14 @@ package org.apache.pekko.stream.scaladsl
import scala.concurrent.duration._
import scala.util.{ Failure, Success, Try }
import org.scalatest.matchers.{ MatchResult, Matcher }
import org.apache.pekko
import pekko.NotUsed
import pekko.stream.OverflowStrategy
import pekko.stream.testkit.{ StreamSpec, TestPublisher, TestSubscriber }
import pekko.stream.testkit.scaladsl.{ TestSink, TestSource }
import org.scalatest.matchers.{ MatchResult, Matcher }
class RetryFlowSpec extends StreamSpec("""
pekko.stream.materializer.initial-input-buffer-size = 1
pekko.stream.materializer.max-input-buffer-size = 1

View file

@ -18,7 +18,6 @@ import scala.concurrent.{ Await, Future }
import scala.concurrent.duration._
import org.apache.pekko
import org.scalatest.concurrent.ScalaFutures
import pekko.Done
import pekko.stream._
import pekko.stream.testkit._
@ -27,6 +26,8 @@ import pekko.testkit.DefaultTimeout
import org.reactivestreams.Publisher
import org.scalatest.concurrent.ScalaFutures
class SinkSpec extends StreamSpec with DefaultTimeout with ScalaFutures {
import GraphDSL.Implicits._

View file

@ -13,15 +13,15 @@
package org.apache.pekko.stream.scaladsl
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AsyncWordSpecLike
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.stream.Attributes
import pekko.stream.testkit.TestPublisher
import pekko.testkit.TestKit
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AsyncWordSpecLike
class SourceFromPublisherSpec
extends TestKit(ActorSystem("source-from-publisher-spec"))
with AsyncWordSpecLike

View file

@ -26,9 +26,6 @@ import java.util.stream.Collectors
import scala.concurrent.Await
import scala.concurrent.duration._
import org.scalatest.time.Millis
import org.scalatest.time.Span
import org.apache.pekko
import pekko.stream.ActorAttributes
import pekko.stream.testkit.StreamSpec
@ -36,6 +33,9 @@ import pekko.stream.testkit.Utils.TE
import pekko.testkit.DefaultTimeout
import pekko.util.ByteString
import org.scalatest.time.Millis
import org.scalatest.time.Span
class StreamConvertersSpec extends StreamSpec with DefaultTimeout {
implicit val config: PatienceConfig = PatienceConfig(timeout = Span(timeout.duration.toMillis, Millis))

View file

@ -19,8 +19,6 @@ import scala.concurrent.Promise
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import com.typesafe.config._
import org.apache.pekko
import pekko.{ Done, NotUsed }
import pekko.actor.{ Actor, ActorIdentity, ActorLogging, ActorRef, ActorSystem, ActorSystemImpl, Identify, Props }
@ -34,6 +32,8 @@ import pekko.stream.testkit.scaladsl._
import pekko.testkit.{ PekkoSpec, TestKit, TestProbe }
import pekko.util.ByteString
import com.typesafe.config._
object StreamRefsSpec {
object DataSourceActor {

View file

@ -15,14 +15,17 @@ package com.typesafe.sslconfig.pekko
import java.util.Collections
import javax.net.ssl._
import com.typesafe.sslconfig.pekko.util.PekkoLoggerFactory
import com.typesafe.sslconfig.ssl._
import com.typesafe.sslconfig.util.LoggerFactory
import scala.annotation.nowarn
import org.apache.pekko
import pekko.actor._
import pekko.annotation.InternalApi
import pekko.event.Logging
import scala.annotation.nowarn
import com.typesafe.sslconfig.pekko.util.PekkoLoggerFactory
import com.typesafe.sslconfig.ssl._
import com.typesafe.sslconfig.util.LoggerFactory
@deprecated("Use Tcp and TLS with SSLEngine parameters instead. Setup the SSLEngine with needed parameters.",
"Akka 2.6.0")

View file

@ -13,13 +13,13 @@
package com.typesafe.sslconfig.pekko.util
import com.typesafe.sslconfig.util.{ LoggerFactory, NoDepsLogger }
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.event.{ DummyClassForStringSources, EventStream }
import pekko.event.Logging._
import com.typesafe.sslconfig.util.{ LoggerFactory, NoDepsLogger }
final class PekkoLoggerFactory(system: ActorSystem) extends LoggerFactory {
override def apply(clazz: Class[_]): NoDepsLogger = new PekkoLoggerBridge(system.eventStream, clazz)

View file

@ -15,13 +15,10 @@ package org.apache.pekko.stream
import java.util.concurrent.TimeUnit
import scala.annotation.nowarn
import scala.concurrent.duration._
import scala.util.control.NoStackTrace
import scala.annotation.nowarn
import com.typesafe.config.Config
import com.typesafe.config.ConfigFactory
import org.apache.pekko
import pekko.actor.ActorContext
import pekko.actor.ActorRef
@ -36,6 +33,9 @@ import pekko.stream.impl._
import pekko.stream.stage.GraphStageLogic
import pekko.util.Helpers.toRootLowerCase
import com.typesafe.config.Config
import com.typesafe.config.ConfigFactory
object ActorMaterializer {
/**

View file

@ -13,11 +13,10 @@
package org.apache.pekko.stream
import scala.annotation.nowarn
import scala.util.{ Failure, Success, Try }
import scala.util.control.NoStackTrace
import scala.annotation.nowarn
import org.apache.pekko
import pekko.Done

View file

@ -19,8 +19,8 @@ package org.apache.pekko.stream
import scala.collection.mutable
import scala.concurrent.Future
import scala.util.control.{ NoStackTrace, NonFatal }
import scala.util.{ Failure, Success, Try }
import scala.util.control.{ NoStackTrace, NonFatal }
import org.apache.pekko
import pekko.annotation.InternalApi

View file

@ -13,11 +13,10 @@
package org.apache.pekko.stream
import scala.annotation.{ implicitNotFound, nowarn }
import scala.concurrent.ExecutionContextExecutor
import scala.concurrent.duration.FiniteDuration
import scala.annotation.{ implicitNotFound, nowarn }
import org.apache.pekko
import pekko.actor.ActorRef
import pekko.actor.ActorSystem

View file

@ -14,6 +14,7 @@
package org.apache.pekko.stream
import scala.concurrent.duration.FiniteDuration
import org.apache.pekko
import pekko.event.Logging
import pekko.event.Logging.LogLevel

View file

@ -15,16 +15,16 @@ package org.apache.pekko.stream
import java.util.concurrent.TimeUnit
import scala.concurrent.duration._
import scala.annotation.nowarn
import com.typesafe.config.Config
import scala.concurrent.duration._
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.annotation.DoNotInherit
import pekko.stream.impl.streamref.StreamRefSettingsImpl
import com.typesafe.config.Config
@nowarn("msg=deprecated")
object StreamRefSettings {

View file

@ -17,12 +17,12 @@
package org.apache.pekko.stream
import org.apache.pekko
import pekko.annotation.DoNotInherit
import scala.concurrent.TimeoutException
import scala.util.control.NoStackTrace
import org.apache.pekko
import pekko.annotation.DoNotInherit
/**
* Base class for timeout exceptions specific to Pekko Streams
*

View file

@ -15,10 +15,10 @@ package org.apache.pekko.stream
import scala.util.control.NoStackTrace
import org.reactivestreams.Subscription
import org.apache.pekko.annotation.DoNotInherit
import org.reactivestreams.Subscription
/**
* Extension of Subscription that allows to pass a cause when a subscription is cancelled.
*

View file

@ -13,10 +13,10 @@
package org.apache.pekko.stream
import SubstreamCancelStrategies._
import scala.annotation.nowarn
import SubstreamCancelStrategies._
/**
* Represents a strategy that decides how to deal with substream events.
*/

View file

@ -13,11 +13,10 @@
package org.apache.pekko.stream
import scala.annotation.nowarn
import scala.concurrent.Await
import scala.concurrent.Promise
import scala.annotation.nowarn
import org.apache.pekko
import pekko.actor.ActorSystem
import pekko.actor.ClassicActorSystemProvider

View file

@ -15,10 +15,11 @@ package org.apache.pekko.stream.impl
import java.util.concurrent.atomic.AtomicBoolean
import scala.annotation.nowarn
import scala.collection.immutable
import scala.concurrent.ExecutionContextExecutor
import scala.concurrent.duration._
import scala.annotation.nowarn
import org.apache.pekko
import pekko.actor._
import pekko.annotation.DoNotInherit

View file

@ -13,8 +13,6 @@
package org.apache.pekko.stream.impl
import org.reactivestreams.{ Processor, Subscriber, Subscription }
import org.apache.pekko
import pekko.actor._
import pekko.annotation.InternalApi
@ -24,6 +22,8 @@ import pekko.stream.ActorAttributes
import pekko.stream.impl.ActorSubscriberMessage.{ OnComplete, OnError, OnNext, OnSubscribe }
import pekko.util.unused
import org.reactivestreams.{ Processor, Subscriber, Subscription }
/**
* INTERNAL API
*/

View file

@ -19,13 +19,13 @@ import scala.annotation.tailrec
import scala.collection.immutable
import scala.util.control.NoStackTrace
import org.reactivestreams.{ Publisher, Subscriber }
import org.reactivestreams.Subscription
import org.apache.pekko
import pekko.actor.{ Actor, ActorRef, Terminated }
import pekko.annotation.InternalApi
import org.reactivestreams.{ Publisher, Subscriber }
import org.reactivestreams.Subscription
/**
* INTERNAL API
*/

View file

@ -13,16 +13,16 @@
package org.apache.pekko.stream.impl
import java.util
import org.apache.pekko
import pekko.actor._
import pekko.annotation.InternalApi
import pekko.stream.Attributes.InputBuffer
import pekko.stream._
import pekko.stream.Attributes.InputBuffer
import pekko.stream.impl.Stages.DefaultAttributes
import pekko.stream.stage._
import java.util
/**
* INTERNAL API
*/

View file

@ -13,13 +13,13 @@
package org.apache.pekko.stream.impl
import org.reactivestreams.Subscription
import org.apache.pekko
import pekko.actor.DeadLetterSuppression
import pekko.actor.NoSerializationVerificationNeeded
import pekko.annotation.InternalApi
import org.reactivestreams.Subscription
/**
* INTERNAL API
*/

View file

@ -14,6 +14,7 @@
package org.apache.pekko.stream.impl
import java.{ util => ju }
import org.apache.pekko
import pekko.annotation.{ InternalApi, InternalStableApi }
import pekko.stream._

View file

@ -13,10 +13,10 @@
package org.apache.pekko.stream.impl
import org.reactivestreams.{ Publisher, Subscriber, Subscription }
import org.apache.pekko.annotation.InternalApi
import org.reactivestreams.{ Publisher, Subscriber, Subscription }
/**
* INTERNAL API
*/

View file

@ -13,8 +13,6 @@
package org.apache.pekko.stream.impl
import org.reactivestreams.{ Subscriber, Subscription }
import org.apache.pekko
import pekko.actor._
import pekko.annotation.{ DoNotInherit, InternalApi }
@ -23,6 +21,8 @@ import pekko.stream.ActorAttributes
import pekko.stream.Attributes
import pekko.util.unused
import org.reactivestreams.{ Subscriber, Subscription }
/**
* INTERNAL API
*/

View file

@ -15,8 +15,6 @@ package org.apache.pekko.stream.impl
import scala.collection.immutable
import org.reactivestreams.Subscription
import org.apache.pekko
import pekko.actor._
import pekko.annotation.{ DoNotInherit, InternalApi }
@ -25,6 +23,8 @@ import pekko.stream.ActorAttributes
import pekko.stream.Attributes
import pekko.util.unused
import org.reactivestreams.Subscription
/**
* INTERNAL API
*/

View file

@ -13,8 +13,6 @@
package org.apache.pekko.stream.impl
import org.reactivestreams.Subscriber
import org.apache.pekko
import pekko.actor.Actor
import pekko.actor.ActorRef
@ -26,6 +24,8 @@ import pekko.stream.Attributes
import pekko.stream.StreamSubscriptionTimeoutTerminationMode
import pekko.util.OptionVal
import org.reactivestreams.Subscriber
/**
* INTERNAL API
*/

View file

@ -14,6 +14,7 @@
package org.apache.pekko.stream.impl
import scala.annotation.switch
import org.apache.pekko
import pekko.annotation.InternalApi
import pekko.stream.scaladsl.Framing.FramingException

View file

@ -15,10 +15,11 @@ package org.apache.pekko.stream.impl
import scala.concurrent.{ Future, Promise }
import scala.util.control.NonFatal
import org.apache.pekko
import pekko.annotation.InternalApi
import pekko.stream.Attributes.SourceLocation
import pekko.stream._
import pekko.stream.Attributes.SourceLocation
import pekko.stream.impl.Stages.DefaultAttributes
import pekko.stream.scaladsl.{ Keep, Source }
import pekko.stream.stage._

View file

@ -13,9 +13,8 @@
package org.apache.pekko.stream.impl
import scala.concurrent.Promise
import scala.annotation.nowarn
import scala.concurrent.Promise
import org.apache.pekko
import pekko.actor.Actor

View file

@ -15,8 +15,6 @@ package org.apache.pekko.stream.impl
import scala.annotation.unchecked.uncheckedVariance
import org.reactivestreams._
import org.apache.pekko
import pekko.NotUsed
import pekko.annotation.{ DoNotInherit, InternalApi }
@ -24,6 +22,8 @@ import pekko.event.Logging
import pekko.stream._
import pekko.stream.impl.StreamLayout.AtomicModule
import org.reactivestreams._
/**
* INTERNAL API
*/

View file

@ -16,15 +16,11 @@ package org.apache.pekko.stream.impl
import java.util
import java.util.concurrent.atomic.AtomicBoolean
import scala.annotation.nowarn
import scala.collection.immutable.Map
import scala.concurrent.ExecutionContextExecutor
import scala.concurrent.duration.FiniteDuration
import scala.annotation.nowarn
import org.reactivestreams.Processor
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.apache.pekko
import pekko.NotUsed
import pekko.actor.ActorContext
@ -55,6 +51,10 @@ import pekko.stream.stage.InHandler
import pekko.stream.stage.OutHandler
import pekko.util.OptionVal
import org.reactivestreams.Processor
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
/**
* INTERNAL API
*/

View file

@ -15,12 +15,12 @@ package org.apache.pekko.stream.impl
import scala.util.control.NonFatal
import org.reactivestreams.{ Subscriber, Subscription }
import org.apache.pekko
import pekko.annotation.InternalApi
import pekko.stream.SubscriptionWithCancelException
import org.reactivestreams.{ Subscriber, Subscription }
/**
* INTERNAL API
*/

View file

@ -16,10 +16,11 @@ package org.apache.pekko.stream.impl
import scala.concurrent.Future
import scala.concurrent.Promise
import scala.util.control.NonFatal
import org.apache.pekko
import pekko.annotation.InternalApi
import pekko.stream.Attributes.SourceLocation
import pekko.stream._
import pekko.stream.Attributes.SourceLocation
import pekko.stream.scaladsl.Flow
import pekko.stream.scaladsl.Keep
import pekko.stream.scaladsl.Sink

View file

@ -15,12 +15,12 @@ package org.apache.pekko.stream.impl
import scala.concurrent.Promise
import org.reactivestreams.{ Subscriber, Subscription }
import org.apache.pekko
import pekko.Done
import pekko.annotation.InternalApi
import org.reactivestreams.{ Subscriber, Subscription }
/**
* INTERNAL API
*/

View file

@ -14,6 +14,7 @@
package org.apache.pekko.stream.impl
import java.util.function.BinaryOperator
import scala.collection.immutable
import scala.collection.mutable
import scala.concurrent.Future
@ -22,8 +23,7 @@ import scala.util.Failure
import scala.util.Success
import scala.util.Try
import scala.util.control.NonFatal
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.apache.pekko
import pekko.NotUsed
import pekko.annotation.DoNotInherit
@ -42,6 +42,9 @@ import pekko.stream.scaladsl.{ Keep, Sink, SinkQueueWithCancel, Source }
import pekko.stream.stage._
import pekko.util.ccompat._
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
/**
* INTERNAL API
*/

View file

@ -18,17 +18,17 @@ import java.util.concurrent.atomic.AtomicReference
import scala.annotation.tailrec
import scala.util.control.NonFatal
import org.reactivestreams.Processor
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
import org.apache.pekko
import pekko.annotation.InternalApi
import pekko.stream._
import pekko.stream.impl.Stages.DefaultAttributes
import pekko.util.OptionVal
import org.reactivestreams.Processor
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
/**
* INTERNAL API
*/

View file

@ -13,18 +13,18 @@
package org.apache.pekko.stream.impl
import scala.annotation.nowarn
import scala.concurrent.duration.FiniteDuration
import scala.util.control.NoStackTrace
import scala.annotation.nowarn
import org.reactivestreams._
import org.apache.pekko
import pekko.actor._
import pekko.annotation.InternalApi
import pekko.stream.StreamSubscriptionTimeoutSettings
import pekko.stream.StreamSubscriptionTimeoutTerminationMode.{ CancelTermination, NoopTermination, WarnTermination }
import org.reactivestreams._
/**
* INTERNAL API
*/

View file

@ -13,16 +13,16 @@
package org.apache.pekko.stream.impl
import scala.concurrent.duration.{ FiniteDuration, _ }
import org.apache.pekko
import pekko.annotation.InternalApi
import pekko.stream.ThrottleMode.Enforcing
import pekko.stream._
import pekko.stream.ThrottleMode.Enforcing
import pekko.stream.impl.fusing.GraphStages.SimpleLinearGraphStage
import pekko.stream.stage._
import pekko.util.NanoTimeTokenBucket
import scala.concurrent.duration.{ FiniteDuration, _ }
/**
* INTERNAL API
*/

View file

@ -13,6 +13,12 @@
package org.apache.pekko.stream.impl
import java.util.Optional
import java.util.concurrent.CompletionStage
import scala.concurrent.Future
import scala.util.{ Failure, Success, Try }
import org.apache.pekko
import pekko.annotation.InternalApi
import pekko.japi.{ function, Pair }
@ -20,11 +26,6 @@ import pekko.stream._
import pekko.stream.impl.Stages.DefaultAttributes
import pekko.stream.stage.{ GraphStage, GraphStageLogic, OutHandler }
import java.util.Optional
import java.util.concurrent.CompletionStage
import scala.concurrent.Future
import scala.util.{ Failure, Success, Try }
/**
* INTERNAL API
*/

View file

@ -13,19 +13,19 @@
package org.apache.pekko.stream.impl
import scala.concurrent.{ ExecutionContext, Future }
import scala.util.{ Failure, Success, Try }
import scala.util.control.NonFatal
import org.apache.pekko
import pekko.Done
import pekko.annotation.InternalApi
import pekko.dispatch.ExecutionContexts.parasitic
import pekko.stream.ActorAttributes.SupervisionStrategy
import pekko.stream._
import pekko.stream.ActorAttributes.SupervisionStrategy
import pekko.stream.impl.Stages.DefaultAttributes
import pekko.stream.stage._
import scala.concurrent.{ ExecutionContext, Future }
import scala.util.control.NonFatal
import scala.util.{ Failure, Success, Try }
/**
* INTERNAL API
*/

View file

@ -22,10 +22,6 @@ import scala.collection.immutable
import scala.concurrent.Promise
import scala.util.control.NonFatal
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
import org.apache.pekko
import pekko.Done
import pekko.actor._
@ -45,6 +41,10 @@ import pekko.stream.stage.InHandler
import pekko.stream.stage.OutHandler
import pekko.util.OptionVal
import org.reactivestreams.Publisher
import org.reactivestreams.Subscriber
import org.reactivestreams.Subscription
/**
* INTERNAL API
*/

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