+build Add sort imports support. (#28780)

* Add scalafix plugin for jdk 9.
* Add command alias sortImports.
* Excludes some sources from SortImports.
* Update SortImports to 0.4.0
* Sort imports with `sortImports` command.
This commit is contained in:
kerr 2020-04-27 20:32:18 +08:00 committed by GitHub
parent ea7205eaf7
commit 0e4d41ad33
No known key found for this signature in database
GPG key ID: 4AEE18F83AFDEB23
1534 changed files with 7454 additions and 6165 deletions

View file

@ -6,17 +6,17 @@ package akka.cluster.ddata.typed.internal
import scala.concurrent.duration._
import akka.annotation.InternalApi
import akka.cluster.{ ddata => dd }
import akka.pattern.ask
import akka.actor.typed.ActorRef
import akka.actor.typed.Behavior
import akka.actor.typed.Terminated
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.util.Timeout
import akka.util.JavaDurationConverters._
import akka.annotation.InternalApi
import akka.cluster.{ ddata => dd }
import akka.cluster.ddata.ReplicatedData
import akka.actor.typed.Terminated
import akka.pattern.ask
import akka.util.JavaDurationConverters._
import akka.util.Timeout
/**
* INTERNAL API

View file

@ -6,11 +6,11 @@ package akka.cluster.ddata.typed.javadsl
import java.util.function.{ Function => JFunction }
import akka.actor.typed.ActorRef
import akka.actor.typed.ActorSystem
import akka.actor.typed.Behavior
import akka.actor.typed.Extension
import akka.actor.typed.ExtensionId
import akka.actor.typed.ActorRef
import akka.actor.typed.Behavior
import akka.actor.typed.ExtensionSetup
import akka.actor.typed.javadsl.Behaviors
import akka.annotation.DoNotInherit

View file

@ -7,16 +7,16 @@ package akka.cluster.ddata.typed.javadsl
import java.time.Duration
import java.util.function.{ Function => JFunction }
import akka.actor.typed.ActorRef
import akka.actor.typed.Behavior
import akka.actor.DeadLetterSuppression
import akka.actor.NoSerializationVerificationNeeded
import akka.actor.typed.ActorRef
import akka.actor.typed.Behavior
import akka.annotation.DoNotInherit
import akka.annotation.InternalApi
import akka.cluster.{ ddata => dd }
import akka.cluster.ddata.Key
import akka.cluster.ddata.ReplicatedData
import akka.cluster.ddata.typed.internal.ReplicatorBehavior
import akka.cluster.{ ddata => dd }
import akka.util.JavaDurationConverters._
/**

View file

@ -10,13 +10,14 @@ import java.util.function.{ Function => JFunction }
import scala.util.Failure
import scala.util.Success
import akka.util.JavaDurationConverters._
import com.github.ghik.silencer.silent
import akka.actor.typed.ActorRef
import akka.actor.typed.javadsl.ActorContext
import akka.cluster.ddata.Key
import akka.cluster.ddata.ReplicatedData
import akka.util.JavaDurationConverters._
import akka.util.Timeout
import com.github.ghik.silencer.silent
/**
* When interacting with the `Replicator` from an actor this class provides convenient

View file

@ -4,10 +4,11 @@
package akka.cluster.ddata.typed.javadsl
import akka.cluster.{ ddata => dd }
import com.typesafe.config.Config
import akka.actor.typed.ActorSystem
import akka.actor.typed.scaladsl.adapter._
import com.typesafe.config.Config
import akka.cluster.{ ddata => dd }
object ReplicatorSettings {

View file

@ -6,18 +6,19 @@ package akka.cluster.ddata.typed.scaladsl
import scala.concurrent.duration.FiniteDuration
import akka.actor.typed.{ ActorRef, ActorSystem, Extension, ExtensionId, Props }
import org.slf4j.LoggerFactory
import akka.actor.ExtendedActorSystem
import akka.actor.typed.{ ActorRef, ActorSystem, Extension, ExtensionId, Props }
import akka.actor.typed.Behavior
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.LoggerOps
import akka.annotation.InternalApi
import akka.cluster.{ ddata => dd }
import akka.cluster.Cluster
import akka.cluster.ddata.ReplicatedData
import akka.cluster.{ ddata => dd }
import akka.cluster.ddata.SelfUniqueAddress
import akka.util.JavaDurationConverters._
import org.slf4j.LoggerFactory
object DistributedData extends ExtensionId[DistributedData] {
def get(system: ActorSystem[_]): DistributedData = apply(system)

View file

@ -6,11 +6,11 @@ package akka.cluster.ddata.typed.scaladsl
import scala.concurrent.duration.FiniteDuration
import akka.actor.typed.ActorRef
import akka.actor.typed.Behavior
import akka.cluster.{ ddata => dd }
import akka.cluster.ddata.Key
import akka.cluster.ddata.ReplicatedData
import akka.actor.typed.ActorRef
import akka.actor.typed.Behavior
import akka.cluster.ddata.typed.internal.ReplicatorBehavior
/**

View file

@ -4,11 +4,12 @@
package akka.cluster.ddata.typed.scaladsl
import akka.cluster.{ ddata => dd }
import com.typesafe.config.Config
import akka.actor.typed.ActorSystem
import akka.actor.typed.scaladsl.adapter._
import akka.annotation.InternalApi
import com.typesafe.config.Config
import akka.cluster.{ ddata => dd }
/**
* @see [[akka.cluster.ddata.ReplicatorSettings]].

View file

@ -4,16 +4,16 @@
package akka.cluster.typed
import scala.collection.immutable
import akka.actor.Address
import akka.annotation.DoNotInherit
import akka.cluster.ClusterEvent.{ ClusterDomainEvent, CurrentClusterState }
import akka.cluster._
import akka.japi.Util
import akka.actor.typed.{ ActorRef, ActorSystem, Extension, ExtensionId }
import akka.actor.typed.ExtensionSetup
import akka.annotation.DoNotInherit
import akka.cluster._
import akka.cluster.ClusterEvent.{ ClusterDomainEvent, CurrentClusterState }
import akka.cluster.typed.internal.AdapterClusterImpl
import scala.collection.immutable
import akka.japi.Util
/**
* Messages for subscribing to changes in the cluster state

View file

@ -4,6 +4,13 @@
package akka.cluster.typed
import scala.concurrent.duration._
import scala.concurrent.duration.{ Duration, FiniteDuration }
import com.typesafe.config.Config
import akka.actor.typed.{ ActorRef, ActorSystem, Behavior, Extension, ExtensionId, Props }
import akka.actor.typed.ExtensionSetup
import akka.annotation.{ DoNotInherit, InternalApi }
import akka.cluster.ClusterSettings.DataCenter
import akka.cluster.singleton.{
@ -11,13 +18,7 @@ import akka.cluster.singleton.{
ClusterSingletonManagerSettings => ClassicClusterSingletonManagerSettings
}
import akka.cluster.typed.internal.AdaptedClusterSingletonImpl
import akka.actor.typed.{ ActorRef, ActorSystem, Behavior, Extension, ExtensionId, Props }
import akka.util.JavaDurationConverters._
import com.typesafe.config.Config
import scala.concurrent.duration._
import scala.concurrent.duration.{ Duration, FiniteDuration }
import akka.actor.typed.ExtensionSetup
object ClusterSingletonSettings {
def apply(system: ActorSystem[_]): ClusterSingletonSettings =

View file

@ -4,17 +4,17 @@
package akka.cluster.typed.internal
import akka.actor.typed.{ ActorRef, ActorSystem, Terminated }
import akka.actor.typed.Behavior
import akka.actor.typed.Props
import akka.actor.typed.SupervisorStrategy
import akka.annotation.InternalApi
import akka.cluster.ClusterEvent.MemberEvent
import akka.cluster.{ ClusterEvent, Member, MemberStatus }
import akka.actor.typed.{ ActorRef, ActorSystem, Terminated }
import akka.cluster.typed._
import akka.actor.typed.internal.adapter.ActorSystemAdapter
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.annotation.InternalApi
import akka.cluster.{ ClusterEvent, Member, MemberStatus }
import akka.cluster.ClusterEvent.MemberEvent
import akka.cluster.typed._
/**
* INTERNAL API:

View file

@ -7,16 +7,16 @@ package akka.cluster.typed.internal
import java.util.concurrent.ConcurrentHashMap
import java.util.function.{ Function => JFunction }
import akka.actor.typed.internal.{ PoisonPill, PoisonPillInterceptor }
import akka.actor.{ ExtendedActorSystem, InvalidActorNameException }
import akka.annotation.InternalApi
import akka.cluster.singleton.{ ClusterSingletonProxy, ClusterSingletonManager => OldSingletonManager }
import akka.cluster.typed.{ Cluster, ClusterSingleton, ClusterSingletonImpl, ClusterSingletonSettings }
import akka.actor.typed.{ ActorRef, ActorSystem, Behavior }
import akka.actor.typed.internal.{ PoisonPill, PoisonPillInterceptor }
import akka.actor.typed.internal.adapter.ActorSystemAdapter
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.{ ActorRef, ActorSystem, Behavior }
import akka.annotation.InternalApi
import akka.cluster.ClusterSettings.DataCenter
import akka.cluster.singleton.{ ClusterSingletonProxy, ClusterSingletonManager => OldSingletonManager }
import akka.cluster.typed
import akka.cluster.typed.{ Cluster, ClusterSingleton, ClusterSingletonImpl, ClusterSingletonSettings }
/**
* INTERNAL API:
@ -28,6 +28,7 @@ private[akka] final class AdaptedClusterSingletonImpl(system: ActorSystem[_]) ex
"only adapted actor systems can be used for the typed cluster singleton")
import ClusterSingletonImpl._
import akka.actor.typed.scaladsl.adapter._
private lazy val cluster = Cluster(system)

View file

@ -9,12 +9,12 @@ import java.io.NotSerializableException
import akka.actor.ExtendedActorSystem
import akka.actor.typed.ActorRefResolver
import akka.actor.typed.internal.pubsub.TopicImpl
import akka.annotation.InternalApi
import akka.serialization.{ BaseSerializer, SerializerWithStringManifest }
import akka.actor.typed.scaladsl.adapter._
import akka.annotation.InternalApi
import akka.cluster.typed.internal.protobuf.ClusterMessages
import akka.cluster.typed.internal.receptionist.ClusterReceptionist.Entry
import akka.remote.serialization.WrappedPayloadSupport
import akka.serialization.{ BaseSerializer, SerializerWithStringManifest }
/**
* INTERNAL API

View file

@ -6,7 +6,6 @@ package akka.cluster.typed.internal.delivery
import java.io.NotSerializableException
import akka.util.ccompat.JavaConverters._
import akka.actor.typed.ActorRefResolver
import akka.actor.typed.delivery.ConsumerController
import akka.actor.typed.delivery.DurableProducerQueue
@ -19,6 +18,7 @@ import akka.cluster.typed.internal.protobuf.ReliableDelivery.Confirmed
import akka.remote.serialization.WrappedPayloadSupport
import akka.serialization.BaseSerializer
import akka.serialization.SerializerWithStringManifest
import akka.util.ccompat.JavaConverters._
/**
* INTERNAL API

View file

@ -4,30 +4,30 @@
package akka.cluster.typed.internal.receptionist
import scala.concurrent.duration._
import akka.actor.Address
import akka.actor.typed.{ ActorRef, Behavior }
import akka.actor.typed.internal.receptionist.{ AbstractServiceKey, ReceptionistBehaviorProvider, ReceptionistMessages }
import akka.actor.typed.receptionist.Receptionist.Command
import akka.actor.typed.receptionist.ServiceKey
import akka.actor.typed.scaladsl.adapter._
import akka.actor.typed.scaladsl.{ ActorContext, Behaviors, LoggerOps }
import akka.actor.typed.{ ActorRef, Behavior }
import akka.actor.typed.scaladsl.adapter._
import akka.annotation.InternalApi
import akka.cluster.ClusterEvent.MemberRemoved
import akka.cluster.ddata.{ ORMultiMap, ORMultiMapKey, Replicator }
import akka.cluster.{ Cluster, ClusterEvent, UniqueAddress }
import akka.remote.AddressUidExtension
import akka.util.TypedMultiMap
import scala.concurrent.duration._
import akka.actor.Address
import akka.cluster.ClusterEvent.ClusterDomainEvent
import akka.cluster.ClusterEvent.ClusterShuttingDown
import akka.cluster.ClusterEvent.MemberJoined
import akka.cluster.ClusterEvent.MemberRemoved
import akka.cluster.ClusterEvent.MemberUp
import akka.cluster.ClusterEvent.MemberWeaklyUp
import akka.cluster.ClusterEvent.ReachabilityEvent
import akka.cluster.ClusterEvent.ReachableMember
import akka.cluster.ClusterEvent.UnreachableMember
import akka.cluster.ddata.{ ORMultiMap, ORMultiMapKey, Replicator }
import akka.cluster.ddata.SelfUniqueAddress
import akka.remote.AddressUidExtension
import akka.util.TypedMultiMap
// just to provide a log class
/** INTERNAL API */

View file

@ -4,9 +4,10 @@
package akka.cluster.typed.internal.receptionist
import com.typesafe.config.Config
import akka.annotation.InternalApi
import akka.cluster.{ ConfigValidation, JoinConfigCompatChecker, Valid }
import com.typesafe.config.Config
/**
* INTERNAL API

View file

@ -4,16 +4,17 @@
package akka.cluster.typed.internal.receptionist
import scala.concurrent.duration._
import scala.concurrent.duration.{ FiniteDuration, MILLISECONDS }
import com.typesafe.config.Config
import akka.actor.typed.ActorSystem
import akka.annotation.InternalApi
import akka.cluster.ddata.Replicator
import akka.cluster.ddata.Replicator.WriteConsistency
import akka.util.Helpers.toRootLowerCase
import com.typesafe.config.Config
import scala.concurrent.duration._
import scala.concurrent.duration.{ FiniteDuration, MILLISECONDS }
import akka.cluster.ddata.ReplicatorSettings
import akka.util.Helpers.toRootLowerCase
/**
* Internal API

View file

@ -4,14 +4,15 @@
package akka.cluster.typed
import scala.concurrent.duration._
import com.typesafe.config.ConfigFactory
import akka.actor.testkit.typed.scaladsl.TestProbe
import akka.actor.typed.scaladsl.adapter._
import akka.cluster.{ MemberStatus, MultiNodeClusterSpec }
import akka.remote.testconductor.RoleName
import akka.remote.testkit.{ MultiNodeConfig, MultiNodeSpec }
import akka.actor.testkit.typed.scaladsl.TestProbe
import com.typesafe.config.ConfigFactory
import scala.concurrent.duration._
object MultiDcClusterSingletonSpecConfig extends MultiNodeConfig {
val first: RoleName = role("first")
@ -41,8 +42,8 @@ abstract class MultiDcClusterSingletonSpec
extends MultiNodeSpec(MultiDcClusterSingletonSpecConfig)
with MultiNodeTypedClusterSpec {
import MultiDcPinger._
import MultiDcClusterSingletonSpecConfig._
import MultiDcPinger._
"A cluster with multiple data centers" must {
"be able to form" in {

View file

@ -6,26 +6,27 @@ package akka.cluster.typed
import java.util.concurrent.ConcurrentHashMap
import scala.concurrent.Await
import scala.concurrent.Future
import scala.concurrent.duration._
import scala.language.implicitConversions
import org.scalatest.Suite
import org.scalatest.matchers.should.Matchers
import akka.actor.{ Address, Scheduler }
import akka.actor.typed.ActorRef
import akka.actor.typed.ActorSystem
import akka.actor.typed.Behavior
import akka.actor.typed.Props
import akka.actor.typed.SpawnProtocol
import akka.actor.typed.scaladsl.adapter._
import akka.actor.typed.scaladsl.AskPattern._
import akka.actor.{ Address, Scheduler }
import akka.actor.typed.scaladsl.adapter._
import akka.cluster.{ ClusterEvent, MemberStatus }
import akka.remote.testconductor.RoleName
import akka.remote.testkit.{ MultiNodeSpec, STMultiNodeSpec }
import akka.testkit.WatchedByCoroner
import akka.util.Timeout
import org.scalatest.Suite
import org.scalatest.matchers.should.Matchers
import scala.concurrent.Await
import scala.concurrent.Future
import scala.concurrent.duration._
import scala.language.implicitConversions
trait MultiNodeTypedClusterSpec extends Suite with STMultiNodeSpec with WatchedByCoroner with Matchers {
self: MultiNodeSpec =>

View file

@ -4,6 +4,8 @@
package akka.cluster.typed
import com.typesafe.config.ConfigFactory
import akka.actor.testkit.typed.scaladsl.TestProbe
import akka.actor.typed.ActorRef
import akka.actor.typed.internal.pubsub.TopicImpl
@ -14,7 +16,6 @@ import akka.remote.testconductor.RoleName
import akka.remote.testkit.MultiNodeConfig
import akka.remote.testkit.MultiNodeSpec
import akka.serialization.jackson.CborSerializable
import com.typesafe.config.ConfigFactory
object PubSubSpecConfig extends MultiNodeConfig {
val first: RoleName = role("first")

View file

@ -4,6 +4,10 @@
package akka.cluster.typed.internal
import scala.concurrent.duration._
import com.typesafe.config.ConfigFactory
import akka.actor.testkit.typed.scaladsl.TestProbe
import akka.actor.typed.receptionist.Receptionist
import akka.actor.typed.receptionist.ServiceKey
@ -16,9 +20,6 @@ import akka.cluster.typed.MultiNodeTypedClusterSpec
import akka.remote.testkit.MultiNodeConfig
import akka.remote.testkit.MultiNodeSpec
import akka.remote.transport.ThrottlerTransportAdapter.Direction
import com.typesafe.config.ConfigFactory
import scala.concurrent.duration._
object ClusterReceptionistUnreachabilitySpecConfig extends MultiNodeConfig {
val first = role("first")

View file

@ -4,9 +4,10 @@
package akka.cluster.ddata.typed.scaladsl
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import org.scalatest.wordspec.AnyWordSpecLike
class ReplicatorSpec extends ScalaTestWithActorTestKit with AnyWordSpecLike with LogCapturing {
"Replicator" must {

View file

@ -4,16 +4,17 @@
package akka.cluster.typed
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.actor.typed.{ ActorRef, ActorRefResolver, ActorSystem }
import akka.actor.{ ExtendedActorSystem, IgnoreActorRef }
import com.typesafe.config.ConfigFactory
import org.scalatest.BeforeAndAfterAll
import org.scalatest.concurrent.ScalaFutures
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpec
import akka.{ actor => classic }
import akka.actor.{ ExtendedActorSystem, IgnoreActorRef }
import akka.actor.typed.{ ActorRef, ActorRefResolver, ActorSystem }
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
class ActorRefIgnoreSerializationSpec extends AnyWordSpec with ScalaFutures with Matchers with BeforeAndAfterAll {

View file

@ -11,27 +11,28 @@ import scala.concurrent.Promise
import scala.concurrent.duration._
import scala.util.control.NonFatal
import com.typesafe.config.ConfigFactory
import org.scalatest._
import org.scalatest.concurrent.Eventually
import org.scalatest.concurrent.ScalaFutures
import org.scalatest.matchers.should.Matchers
import org.scalatest.time.Span
import org.scalatest.wordspec.AnyWordSpec
import akka.Done
import akka.actor.CoordinatedShutdown
import akka.actor.ExtendedActorSystem
import akka.actor.InvalidMessageException
import akka.actor.testkit.typed.scaladsl.TestInbox
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.TestInbox
import akka.actor.typed.ActorRef
import akka.actor.typed.ActorRefResolver
import akka.actor.typed.ActorSystem
import akka.actor.typed.Behavior
import akka.actor.typed.PostStop
import akka.actor.typed.scaladsl.adapter._
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.serialization.SerializerWithStringManifest
import com.typesafe.config.ConfigFactory
import org.scalatest._
import org.scalatest.concurrent.Eventually
import org.scalatest.concurrent.ScalaFutures
import org.scalatest.time.Span
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpec
object ActorSystemSpec {

View file

@ -4,15 +4,16 @@
package akka.cluster.typed
import com.typesafe.config.ConfigFactory
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.ExtendedActorSystem
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.LoggingTestKit
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.typed.internal.ActorMdc
import akka.actor.typed.scaladsl.Behaviors
import com.typesafe.config.ConfigFactory
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
object ClusterActorLoggingSpec {
def config = ConfigFactory.parseString("""

View file

@ -4,17 +4,18 @@
package akka.cluster.typed
import com.typesafe.config.ConfigFactory
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.Address
import akka.actor.testkit.typed.TestKitSettings
import akka.actor.testkit.typed.scaladsl.ActorTestKit
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.testkit.typed.scaladsl.TestProbe
import akka.actor.typed.scaladsl.adapter._
import akka.cluster.ClusterEvent._
import akka.cluster.MemberStatus
import akka.actor.testkit.typed.scaladsl.TestProbe
import akka.actor.testkit.typed.TestKitSettings
import akka.actor.testkit.typed.scaladsl.ActorTestKit
import com.typesafe.config.ConfigFactory
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.testkit.typed.scaladsl.LogCapturing
import org.scalatest.wordspec.AnyWordSpecLike
object ClusterApiSpec {
val config =

View file

@ -4,9 +4,10 @@
package akka.cluster.typed
import akka.actor.typed.scaladsl.DispatcherSelectorSpec
import com.typesafe.config.ConfigFactory
import akka.actor.typed.scaladsl.DispatcherSelectorSpec
class ClusterDispatcherSelectorSpec
extends DispatcherSelectorSpec(ConfigFactory.parseString("""
akka.actor.provider = cluster

View file

@ -7,6 +7,9 @@ package akka.cluster.typed
import scala.concurrent.Await
import scala.concurrent.duration._
import com.typesafe.config.ConfigFactory
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.testkit.typed.TestKitSettings
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
@ -15,8 +18,6 @@ import akka.actor.typed.ActorRef
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.serialization.jackson.CborSerializable
import com.typesafe.config.ConfigFactory
import org.scalatest.wordspec.AnyWordSpecLike
object ClusterSingletonApiSpec {

View file

@ -4,17 +4,18 @@
package akka.cluster.typed
import scala.concurrent.duration._
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.testkit.typed.TestKitSettings
import akka.actor.testkit.typed.scaladsl.{ ScalaTestWithActorTestKit, TestProbe }
import akka.actor.typed.internal.PoisonPill
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.typed.{ ActorRef, Behavior }
import akka.actor.typed.internal.PoisonPill
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.cluster.typed.ClusterSingletonPoisonPillSpec.GetSelf
import scala.concurrent.duration._
import akka.actor.testkit.typed.scaladsl.LogCapturing
import org.scalatest.wordspec.AnyWordSpecLike
object ClusterSingletonPoisonPillSpec {

View file

@ -4,16 +4,17 @@
package akka.cluster.typed
import scala.concurrent.Promise
import com.typesafe.config.ConfigFactory
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.testkit.typed.scaladsl.{ LogCapturing, ScalaTestWithActorTestKit }
import akka.actor.typed.{ ActorRef, ActorSystem, Behavior }
import akka.actor.typed.receptionist.{ Receptionist, ServiceKey }
import akka.actor.typed.scaladsl.{ Behaviors, GroupRouter, Routers }
import akka.serialization.jackson.CborSerializable
import akka.util.Timeout
import com.typesafe.config.ConfigFactory
import scala.concurrent.Promise
import org.scalatest.wordspec.AnyWordSpecLike
object GroupRouterSpec {
def config = ConfigFactory.parseString(s"""
@ -68,6 +69,7 @@ class GroupRouterSpec extends ScalaTestWithActorTestKit(GroupRouterSpec.config)
def checkGroupRouterBehavior[T](groupRouter: GroupRouter[Ping.type], settings: GroupRouterSpecSettings)(
resultCheck: (Seq[ActorRef[Ping.type]], Seq[ActorRef[Ping.type]]) => T): T = {
import scala.concurrent.duration._
import akka.actor.typed.scaladsl.AskPattern._
implicit val system1 =
createSystem(

View file

@ -8,6 +8,9 @@ import scala.concurrent.duration._
import scala.util.Failure
import scala.util.Success
import com.typesafe.config.ConfigFactory
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.testkit.typed.scaladsl.TestProbe
@ -19,8 +22,6 @@ import akka.actor.typed.receptionist.ServiceKey
import akka.actor.typed.scaladsl.Behaviors
import akka.serialization.jackson.CborSerializable
import akka.util.Timeout
import com.typesafe.config.ConfigFactory
import org.scalatest.wordspec.AnyWordSpecLike
object RemoteContextAskSpec {
def config = ConfigFactory.parseString(s"""

View file

@ -4,17 +4,18 @@
package akka.cluster.typed
import akka.actor.typed.ActorSystem
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.testkit.typed.scaladsl.TestProbe
import com.typesafe.config.ConfigFactory
import scala.concurrent.duration._
import akka.actor.testkit.typed.scaladsl.ActorTestKit
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.testkit.typed.scaladsl.LogCapturing
import com.typesafe.config.ConfigFactory
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.testkit.typed.scaladsl.ActorTestKit
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.testkit.typed.scaladsl.TestProbe
import akka.actor.typed.ActorSystem
import akka.actor.typed.scaladsl.Behaviors
object RemoteDeployNotAllowedSpec {
def config = ConfigFactory.parseString(s"""
akka {

View file

@ -6,15 +6,16 @@ package akka.cluster.typed
import scala.concurrent.Promise
import com.typesafe.config.ConfigFactory
import akka.Done
import akka.actor.{ ActorSystem => ClassicActorSystem }
import akka.actor.typed.ActorRef
import akka.actor.typed.ActorRefResolver
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.actor.{ ActorSystem => ClassicActorSystem }
import akka.serialization.jackson.CborSerializable
import akka.testkit.AkkaSpec
import com.typesafe.config.ConfigFactory
object RemoteMessageSpec {
def config = ConfigFactory.parseString(s"""

View file

@ -4,14 +4,15 @@
package akka.cluster.typed.internal
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.ExtendedActorSystem
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.cluster.typed.internal.receptionist.ClusterReceptionist
import akka.serialization.SerializationExtension
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.typed.scaladsl.Behaviors
import org.scalatest.wordspec.AnyWordSpecLike
class AkkaClusterTypedSerializerSpec extends ScalaTestWithActorTestKit with AnyWordSpecLike with LogCapturing {

View file

@ -4,6 +4,8 @@
package akka.cluster.typed.internal.delivery
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.ExtendedActorSystem
import akka.actor.testkit.typed.scaladsl.LogCapturing
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
@ -14,7 +16,6 @@ import akka.actor.typed.delivery.internal.ProducerControllerImpl
import akka.actor.typed.scaladsl.Behaviors
import akka.actor.typed.scaladsl.adapter._
import akka.serialization.SerializationExtension
import org.scalatest.wordspec.AnyWordSpecLike
class ReliableDeliverySerializerSpec extends ScalaTestWithActorTestKit with AnyWordSpecLike with LogCapturing {

View file

@ -9,6 +9,10 @@ import java.util.concurrent.ThreadLocalRandom
import scala.concurrent.Await
import scala.concurrent.duration._
import com.typesafe.config.ConfigFactory
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpec
import akka.actor.RootActorPath
import akka.actor.testkit.typed.FishingOutcome
import akka.actor.testkit.typed.scaladsl.ActorTestKit
@ -26,9 +30,6 @@ import akka.cluster.typed.Join
import akka.cluster.typed.JoinSeedNodes
import akka.cluster.typed.Leave
import akka.serialization.jackson.CborSerializable
import com.typesafe.config.ConfigFactory
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpec
object ClusterReceptionistSpec {
val config = ConfigFactory.parseString(s"""

View file

@ -4,6 +4,12 @@
package akka.cluster.typed.internal.receptionist
import scala.concurrent.duration._
import scala.concurrent.duration.Deadline
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
import akka.actor.Address
import akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit
import akka.actor.typed.internal.receptionist.AbstractServiceKey
@ -11,11 +17,6 @@ import akka.actor.typed.receptionist.ServiceKey
import akka.cluster.UniqueAddress
import akka.cluster.typed.internal.receptionist.ClusterReceptionist.SubscriptionsKV
import akka.util.TypedMultiMap
import org.scalatest.matchers.should.Matchers
import org.scalatest.wordspec.AnyWordSpecLike
import scala.concurrent.duration.Deadline
import scala.concurrent.duration._
class ClusterReceptionistStateSpec extends ScalaTestWithActorTestKit with AnyWordSpecLike with Matchers {