Remove fqcn
This commit is contained in:
parent
bed33cd4f0
commit
2df2e0294f
11 changed files with 15 additions and 14 deletions
|
|
@ -13,7 +13,6 @@
|
|||
|
||||
package docs.org.apache.pekko.typed
|
||||
|
||||
import org.apache.pekko.actor.typed.DispatcherSelector
|
||||
// #pool
|
||||
import org.apache.pekko
|
||||
import pekko.actor.testkit.typed.scaladsl.{ LogCapturing, ScalaTestWithActorTestKit }
|
||||
|
|
@ -22,6 +21,7 @@ import pekko.actor.typed.receptionist.{ Receptionist, ServiceKey }
|
|||
import pekko.actor.typed.scaladsl.{ Behaviors, Routers }
|
||||
|
||||
// #pool
|
||||
import pekko.actor.typed.DispatcherSelector
|
||||
import org.scalatest.wordspec.AnyWordSpecLike
|
||||
object RouterSpec {
|
||||
|
||||
|
|
|
|||
|
|
@ -41,7 +41,7 @@ class ActorRefResolverSpec extends AnyWordSpec with ScalaFutures with Matchers {
|
|||
}
|
||||
|
||||
// we can't detect that for MinimalActorRef
|
||||
import org.apache.pekko.actor.typed.scaladsl.adapter._
|
||||
import pekko.actor.typed.scaladsl.adapter._
|
||||
|
||||
val minRef1: pekko.actor.ActorRef = new MinimalActorRef {
|
||||
override def provider: ActorRefProvider = system1.toClassic.asInstanceOf[ActorSystemImpl].provider
|
||||
|
|
|
|||
|
|
@ -77,7 +77,7 @@ object DistributedData extends ExtensionId[DistributedData] {
|
|||
* and classic actors can share the same data.
|
||||
*/
|
||||
class DistributedData(system: ActorSystem[_]) extends Extension {
|
||||
import org.apache.pekko.actor.typed.scaladsl.adapter._
|
||||
import pekko.actor.typed.scaladsl.adapter._
|
||||
|
||||
private val settings: ReplicatorSettings = ReplicatorSettings(system)
|
||||
|
||||
|
|
|
|||
|
|
@ -106,7 +106,7 @@ final case class TimestampOffset(timestamp: Instant, readTimestamp: Instant, see
|
|||
|
||||
/** Java API */
|
||||
def getSeen(): java.util.Map[String, java.lang.Long] = {
|
||||
import org.apache.pekko.util.ccompat.JavaConverters._
|
||||
import pekko.util.ccompat.JavaConverters._
|
||||
seen.map { case (pid, seqNr) => pid -> java.lang.Long.valueOf(seqNr) }.asJava
|
||||
}
|
||||
|
||||
|
|
|
|||
|
|
@ -16,10 +16,11 @@ package org.apache.pekko.remote.testconductor
|
|||
import java.net.InetAddress
|
||||
import java.net.InetSocketAddress
|
||||
|
||||
import org.apache.pekko.actor.{ AddressFromURIString, PoisonPill, Props }
|
||||
import org.apache.pekko.remote.testconductor.Controller.NodeInfo
|
||||
import org.apache.pekko.testkit.PekkoSpec
|
||||
import org.apache.pekko.testkit.ImplicitSender
|
||||
import org.apache.pekko
|
||||
import pekko.actor.{ AddressFromURIString, PoisonPill, Props }
|
||||
import pekko.remote.testconductor.Controller.NodeInfo
|
||||
import pekko.testkit.PekkoSpec
|
||||
import pekko.testkit.ImplicitSender
|
||||
|
||||
object ControllerSpec {
|
||||
val config = """
|
||||
|
|
|
|||
|
|
@ -20,7 +20,7 @@ import org.agrona.collections.Hashing
|
|||
import org.agrona.collections.Object2IntHashMap
|
||||
|
||||
import org.apache.pekko
|
||||
import org.apache.pekko.util.HashCode
|
||||
import pekko.util.HashCode
|
||||
|
||||
/**
|
||||
* INTERNAL API: Versioned compression table to be advertised between systems
|
||||
|
|
|
|||
|
|
@ -58,7 +58,7 @@ class ProtobufSerializer(val system: ExtendedActorSystem) extends BaseSerializer
|
|||
private val toByteArrayMethodBindingRef = new AtomicReference[Map[Class[_], Method]](Map.empty)
|
||||
|
||||
private val allowedClassNames: Set[String] = {
|
||||
import org.apache.pekko.util.ccompat.JavaConverters._
|
||||
import pekko.util.ccompat.JavaConverters._
|
||||
system.settings.config.getStringList("pekko.serialization.protobuf.allowed-classes").asScala.toSet
|
||||
}
|
||||
|
||||
|
|
|
|||
|
|
@ -217,7 +217,7 @@ private[remote] object PekkoPduProtobufCodec$ extends PekkoPduCodec {
|
|||
val ackAndEnvelope = AckAndEnvelopeContainer.parseFrom(raw.toArrayUnsafe())
|
||||
|
||||
val ackOption = if (ackAndEnvelope.hasAck) {
|
||||
import org.apache.pekko.util.ccompat.JavaConverters._
|
||||
import pekko.util.ccompat.JavaConverters._
|
||||
Some(
|
||||
Ack(
|
||||
SeqNo(ackAndEnvelope.getAck.getCumulativeAck),
|
||||
|
|
|
|||
|
|
@ -49,7 +49,7 @@ private[remote] class PekkoProtocolSettings(config: Config) {
|
|||
|
||||
import config._
|
||||
|
||||
import org.apache.pekko.util.Helpers.ConfigOps
|
||||
import pekko.util.Helpers.ConfigOps
|
||||
|
||||
val TransportFailureDetectorConfig: Config = getConfig("pekko.remote.classic.transport-failure-detector")
|
||||
val TransportFailureDetectorImplementationClass: String =
|
||||
|
|
|
|||
|
|
@ -81,7 +81,7 @@ object Transport {
|
|||
*/
|
||||
@deprecated("Classic remoting is deprecated, use Artery", "Akka 2.6.0")
|
||||
trait Transport {
|
||||
import org.apache.pekko.remote.transport.Transport._
|
||||
import pekko.remote.transport.Transport._
|
||||
|
||||
/**
|
||||
* Returns a string that will be used as the scheme part of the URLs corresponding to this transport
|
||||
|
|
|
|||
|
|
@ -76,7 +76,7 @@ abstract class RemoteFeaturesSpec(c: Config) extends ArteryMultiNodeSpec(c) with
|
|||
}
|
||||
mute()
|
||||
|
||||
import org.apache.pekko.remote.artery.RemoteWatcherSpec.TestRemoteWatcher
|
||||
import pekko.remote.artery.RemoteWatcherSpec.TestRemoteWatcher
|
||||
protected val monitor = system.actorOf(Props(new TestRemoteWatcher), "monitor1")
|
||||
|
||||
protected val watcher = system.actorOf(Props(new EmptyActor), "a1").asInstanceOf[InternalActorRef]
|
||||
|
|
|
|||
Loading…
Add table
Add a link
Reference in a new issue