From d0238d8bf73fef3aaa24eaef8583abccf64b23b0 Mon Sep 17 00:00:00 2001 From: PJ Fanning Date: Thu, 9 Feb 2023 14:39:56 +0100 Subject: [PATCH] with deprecated code, highlight versions are Akka versions (#154) * with deprecated code, highlight versions are Akka versions * scalafmt issue --- .../actor/typed/javadsl/TimerScheduler.scala | 2 +- .../actor/typed/scaladsl/TimerScheduler.scala | 2 +- .../main/scala/org/apache/pekko/Main.scala | 2 +- .../apache/pekko/actor/AbstractActor.scala | 4 +- .../org/apache/pekko/actor/AbstractFSM.scala | 6 +- .../apache/pekko/actor/AbstractProps.scala | 3 +- .../org/apache/pekko/actor/ActorRef.scala | 2 +- .../apache/pekko/actor/ActorSelection.scala | 4 +- .../org/apache/pekko/actor/ActorSystem.scala | 2 +- .../pekko/actor/CoordinatedShutdown.scala | 8 +-- .../scala/org/apache/pekko/actor/FSM.scala | 2 +- .../org/apache/pekko/actor/Scheduler.scala | 10 ++-- .../scala/org/apache/pekko/actor/Timers.scala | 4 +- .../org/apache/pekko/actor/TypedActor.scala | 6 +- .../org/apache/pekko/event/Logging.scala | 2 +- .../org/apache/pekko/pattern/Backoff.scala | 4 +- .../pekko/pattern/BackoffSupervisor.scala | 22 +++---- .../apache/pekko/pattern/CircuitBreaker.scala | 4 +- .../org/apache/pekko/pattern/Patterns.scala | 46 +++++++-------- .../pekko/serialization/Serialization.scala | 2 +- .../typed/ClusterShardingSettings.scala | 6 +- .../sharding/ClusterShardingSettings.scala | 20 +++---- .../pekko/cluster/client/ClusterClient.scala | 28 ++++----- .../apache/pekko/cluster/ClusterEvent.scala | 4 +- .../org/apache/pekko/cluster/Member.scala | 10 ++-- .../cluster/routing/ClusterRouterConfig.scala | 20 +++---- .../org/apache/pekko/cluster/ddata/GSet.scala | 2 +- .../apache/pekko/cluster/ddata/GCounter.scala | 4 +- .../apache/pekko/cluster/ddata/LWWMap.scala | 12 ++-- .../pekko/cluster/ddata/LWWRegister.scala | 12 ++-- .../apache/pekko/cluster/ddata/ORMap.scala | 12 ++-- .../pekko/cluster/ddata/ORMultiMap.scala | 20 +++---- .../apache/pekko/cluster/ddata/ORSet.scala | 10 ++-- .../pekko/cluster/ddata/PNCounter.scala | 20 +++---- .../pekko/cluster/ddata/PNCounterMap.scala | 10 ++-- .../pekko/cluster/ddata/VersionVector.scala | 4 +- .../fsm/japi/pf/FSMStateFunctionBuilder.java | 2 +- .../fsm/japi/pf/FSMStopBuilder.java | 2 +- .../persistence/fsm/PersistentFSMBase.scala | 4 +- .../javadsl/DurableStateUpdateStore.scala | 2 +- .../scaladsl/DurableStateUpdateStore.scala | 2 +- .../FailureInjectorTransportAdapter.scala | 2 +- .../pekko/remote/transport/Transport.scala | 2 +- .../pekko/stream/testkit/StreamTestKit.scala | 8 +-- .../apache/pekko/stream/Materializer.scala | 2 +- .../pekko/stream/StreamRefSettings.scala | 8 +-- .../pekko/stream/javadsl/BidiFlow.scala | 2 +- .../apache/pekko/stream/javadsl/Flow.scala | 28 ++++----- .../pekko/stream/javadsl/RestartFlow.scala | 12 ++-- .../pekko/stream/javadsl/RestartSink.scala | 8 +-- .../pekko/stream/javadsl/RestartSource.scala | 16 ++--- .../apache/pekko/stream/javadsl/Sink.scala | 2 +- .../apache/pekko/stream/javadsl/Source.scala | 28 ++++----- .../stream/javadsl/StreamConverters.scala | 4 +- .../apache/pekko/stream/javadsl/SubFlow.scala | 26 ++++----- .../pekko/stream/javadsl/SubSource.scala | 26 ++++----- .../apache/pekko/stream/scaladsl/Graph.scala | 2 +- .../pekko/stream/scaladsl/RestartFlow.scala | 6 +- .../pekko/stream/scaladsl/RestartSink.scala | 4 +- .../pekko/stream/scaladsl/RestartSource.scala | 8 +-- .../apache/pekko/stream/scaladsl/Sink.scala | 2 +- .../pekko/stream/stage/GraphStage.scala | 12 ++-- .../org/apache/pekko/testkit/TestFSMRef.scala | 2 +- .../org/apache/pekko/testkit/TestKit.scala | 4 +- .../pekko/testkit/javadsl/TestKit.scala | 58 +++++++++---------- 65 files changed, 308 insertions(+), 307 deletions(-) diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/javadsl/TimerScheduler.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/javadsl/TimerScheduler.scala index 09bdfad1db..9bd235c14f 100644 --- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/javadsl/TimerScheduler.scala +++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/javadsl/TimerScheduler.scala @@ -225,7 +225,7 @@ trait TimerScheduler[T] { @deprecated( "Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") def startPeriodicTimer(key: Any, msg: T, interval: Duration): Unit /** diff --git a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/scaladsl/TimerScheduler.scala b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/scaladsl/TimerScheduler.scala index 8ae27728d9..d3afa174c4 100644 --- a/actor-typed/src/main/scala/org/apache/pekko/actor/typed/scaladsl/TimerScheduler.scala +++ b/actor-typed/src/main/scala/org/apache/pekko/actor/typed/scaladsl/TimerScheduler.scala @@ -225,7 +225,7 @@ trait TimerScheduler[T] { @deprecated( "Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") def startPeriodicTimer(key: Any, msg: T, interval: FiniteDuration): Unit /** diff --git a/actor/src/main/scala/org/apache/pekko/Main.scala b/actor/src/main/scala/org/apache/pekko/Main.scala index 30693b55b9..55675477a4 100644 --- a/actor/src/main/scala/org/apache/pekko/Main.scala +++ b/actor/src/main/scala/org/apache/pekko/Main.scala @@ -29,7 +29,7 @@ import pekko.actor.Terminated * top level application supervisor actor. It will shutdown * the actor system when the top level actor is terminated. */ -@deprecated("Implement your own main class instead, from which you start the ActorSystem and actors.", "2.6.0") +@deprecated("Implement your own main class instead, from which you start the ActorSystem and actors.", "Akka 2.6.0") object Main { /** diff --git a/actor/src/main/scala/org/apache/pekko/actor/AbstractActor.scala b/actor/src/main/scala/org/apache/pekko/actor/AbstractActor.scala index 99386129df..f3c7afd52f 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/AbstractActor.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/AbstractActor.scala @@ -279,8 +279,8 @@ abstract class AbstractActor extends Actor { @throws(classOf[Exception]) override def postStop(): Unit = super.postStop() - // TODO In 2.6.0 we can remove deprecation and make the method final - @deprecated("Override preRestart with message parameter with Optional type instead", "2.5.0") + // TODO In Pekko 1.1.0, we can remove deprecation and make the method final + @deprecated("Override preRestart with message parameter with Optional type instead", "Akka 2.5.0") @throws(classOf[Exception]) @nowarn("msg=deprecated") override def preRestart(reason: Throwable, message: Option[Any]): Unit = { diff --git a/actor/src/main/scala/org/apache/pekko/actor/AbstractFSM.scala b/actor/src/main/scala/org/apache/pekko/actor/AbstractFSM.scala index 607210e826..fcca91bb2a 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/AbstractFSM.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/AbstractFSM.scala @@ -511,7 +511,7 @@ abstract class AbstractFSM[S, D] extends FSM[S, D] { * @param msg message to be delivered * @param timeout delay of first message delivery and between subsequent messages */ - @deprecated("Use startSingleTimer instead.", since = "2.6.0") + @deprecated("Use startSingleTimer instead.", since = "Akka 2.6.0") final def setTimer(name: String, msg: Any, timeout: FiniteDuration): Unit = setTimer(name, msg, timeout, repeat = false) @@ -523,7 +523,7 @@ abstract class AbstractFSM[S, D] extends FSM[S, D] { * @param msg message to be delivered * @param timeout delay of first message delivery and between subsequent messages */ - @deprecated("Use startSingleTimer instead.", since = "2.6.0") + @deprecated("Use startSingleTimer instead.", since = "Akka 2.6.0") final def setTimer(name: String, msg: Any, timeout: java.time.Duration): Unit = { setTimer(name, msg, timeout.asScala, false) } @@ -540,7 +540,7 @@ abstract class AbstractFSM[S, D] extends FSM[S, D] { @deprecated( "Use startSingleTimer, startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final def setTimer(name: String, msg: Any, timeout: java.time.Duration, repeat: Boolean): Unit = { setTimer(name, msg, timeout.asScala, repeat) } diff --git a/actor/src/main/scala/org/apache/pekko/actor/AbstractProps.scala b/actor/src/main/scala/org/apache/pekko/actor/AbstractProps.scala index 7dfed5d84d..a707da08bd 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/AbstractProps.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/AbstractProps.scala @@ -56,7 +56,8 @@ private[pekko] trait AbstractProps { * * Use the Props.create(actorClass, creator) instead. */ - @deprecated("Use Props.create(actorClass, creator) instead, since this can't be used with Java 8 lambda.", "2.5.18") + @deprecated("Use Props.create(actorClass, creator) instead, since this can't be used with Java 8 lambda.", + "Akka 2.5.18") def create[T <: Actor](creator: Creator[T]): Props = { val cc = creator.getClass checkCreatorClosingOver(cc) diff --git a/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala b/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala index 4db99fa8db..d91593b6d1 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/ActorRef.scala @@ -195,7 +195,7 @@ abstract class ActorRef extends java.lang.Comparable[ActorRef] with Serializable * There are implicit conversions in package.scala * from ActorRef -> ScalaActorRef and back */ -@deprecated("tell method is now provided by ActorRef trait", "2.6.13") +@deprecated("tell method is now provided by ActorRef trait", "Akka 2.6.13") trait ScalaActorRef { ref: ActorRef with InternalActorRef with ActorRefScope => /** diff --git a/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala b/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala index 0f9df0694e..ac0126d258 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/ActorSelection.scala @@ -107,7 +107,7 @@ abstract class ActorSelection extends Serializable { * no such actor exists or the identification didn't complete within the * supplied `timeout`. */ - @deprecated("Use the overloaded method resolveOne which accepts java.time.Duration instead.", since = "2.5.20") + @deprecated("Use the overloaded method resolveOne which accepts java.time.Duration instead.", since = "Akka 2.5.20") def resolveOneCS(timeout: FiniteDuration): CompletionStage[ActorRef] = FutureConverters.toJava[ActorRef](resolveOne(timeout)) @@ -120,7 +120,7 @@ abstract class ActorSelection extends Serializable { * no such actor exists or the identification didn't complete within the * supplied `timeout`. */ - @deprecated("Use the overloaded method resolveOne which accepts java.time.Duration instead.", since = "2.5.20") + @deprecated("Use the overloaded method resolveOne which accepts java.time.Duration instead.", since = "Akka 2.5.20") def resolveOneCS(timeout: java.time.Duration): CompletionStage[ActorRef] = resolveOne(timeout) /** diff --git a/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala b/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala index c660605924..cd77bc9766 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/ActorSystem.scala @@ -422,7 +422,7 @@ object ActorSystem { final val UnstartedPushTimeout: Timeout = Timeout(config.getMillisDuration("pekko.actor.unstarted-push-timeout")) final val AllowJavaSerialization: Boolean = getBoolean("pekko.actor.allow-java-serialization") - @deprecated("Always enabled from Akka 2.6.0", "2.6.0") + @deprecated("Always enabled from Akka 2.6.0", "Akka 2.6.0") final val EnableAdditionalSerializationBindings: Boolean = true final val SerializeAllMessages: Boolean = getBoolean("pekko.actor.serialize-messages") final val SerializeAllCreators: Boolean = getBoolean("pekko.actor.serialize-creators") diff --git a/actor/src/main/scala/org/apache/pekko/actor/CoordinatedShutdown.scala b/actor/src/main/scala/org/apache/pekko/actor/CoordinatedShutdown.scala index d11c51ca75..e35806b7b3 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/CoordinatedShutdown.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/CoordinatedShutdown.scala @@ -697,7 +697,7 @@ final class CoordinatedShutdown private[pekko] ( */ def run(reason: Reason): Future[Done] = run(reason, None) - @deprecated("Use the method with `reason` parameter instead", since = "2.5.8") + @deprecated("Use the method with `reason` parameter instead", since = "Akka 2.5.8") def run(): Future[Done] = run(UnknownReason) /** @@ -709,7 +709,7 @@ final class CoordinatedShutdown private[pekko] ( */ def runAll(reason: Reason): CompletionStage[Done] = run(reason).toJava - @deprecated("Use the method with `reason` parameter instead", since = "2.5.8") + @deprecated("Use the method with `reason` parameter instead", since = "Akka 2.5.8") def runAll(): CompletionStage[Done] = runAll(UnknownReason) /** @@ -784,7 +784,7 @@ final class CoordinatedShutdown private[pekko] ( runPromise.future } - @deprecated("Use the method with `reason` parameter instead", since = "2.5.8") + @deprecated("Use the method with `reason` parameter instead", since = "Akka 2.5.8") def run(fromPhase: Option[String]): Future[Done] = run(UnknownReason, fromPhase) @@ -798,7 +798,7 @@ final class CoordinatedShutdown private[pekko] ( def run(reason: Reason, fromPhase: Optional[String]): CompletionStage[Done] = run(reason, fromPhase.asScala).toJava - @deprecated("Use the method with `reason` parameter instead", since = "2.5.8") + @deprecated("Use the method with `reason` parameter instead", since = "Akka 2.5.8") def run(fromPhase: Optional[String]): CompletionStage[Done] = run(UnknownReason, fromPhase) diff --git a/actor/src/main/scala/org/apache/pekko/actor/FSM.scala b/actor/src/main/scala/org/apache/pekko/actor/FSM.scala index c003b3e877..faa1d01f96 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/FSM.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/FSM.scala @@ -605,7 +605,7 @@ trait FSM[S, D] extends Actor with Listeners with ActorLogging { @deprecated( "Use startSingleTimer, startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final def setTimer(name: String, msg: Any, timeout: FiniteDuration, repeat: Boolean = false): Unit = { // repeat => FixedRateMode for compatibility val mode = if (repeat) FixedRateMode else SingleMode diff --git a/actor/src/main/scala/org/apache/pekko/actor/Scheduler.scala b/actor/src/main/scala/org/apache/pekko/actor/Scheduler.scala index 4f1186a010..b3e8b7f327 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/Scheduler.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/Scheduler.scala @@ -369,7 +369,7 @@ trait Scheduler { @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") @nowarn("msg=deprecated") final def schedule(initialDelay: FiniteDuration, interval: FiniteDuration, receiver: ActorRef, message: Any)( implicit @@ -392,7 +392,7 @@ trait Scheduler { @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final def schedule( initialDelay: java.time.Duration, interval: java.time.Duration, @@ -410,7 +410,7 @@ trait Scheduler { @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final def schedule(initialDelay: FiniteDuration, interval: FiniteDuration)(f: => Unit)( implicit executor: ExecutionContext): Cancellable = @@ -422,7 +422,7 @@ trait Scheduler { @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") def schedule(initialDelay: FiniteDuration, interval: FiniteDuration, runnable: Runnable)( implicit executor: ExecutionContext): Cancellable @@ -432,7 +432,7 @@ trait Scheduler { @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") def schedule(initialDelay: java.time.Duration, interval: java.time.Duration, runnable: Runnable)( implicit executor: ExecutionContext): Cancellable = { import JavaDurationConverters._ diff --git a/actor/src/main/scala/org/apache/pekko/actor/Timers.scala b/actor/src/main/scala/org/apache/pekko/actor/Timers.scala index f0d3455c5a..4695a6be8d 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/Timers.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/Timers.scala @@ -294,7 +294,7 @@ abstract class AbstractActorWithTimers extends AbstractActor with Timers { @deprecated( "Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") def startPeriodicTimer(key: Any, msg: Any, interval: FiniteDuration): Unit /** @@ -303,7 +303,7 @@ abstract class AbstractActorWithTimers extends AbstractActor with Timers { @deprecated( "Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final def startPeriodicTimer(key: Any, msg: Any, interval: java.time.Duration): Unit = startPeriodicTimer(key, msg, interval.asScala) diff --git a/actor/src/main/scala/org/apache/pekko/actor/TypedActor.scala b/actor/src/main/scala/org/apache/pekko/actor/TypedActor.scala index 8f42ca36b8..d647cc9274 100644 --- a/actor/src/main/scala/org/apache/pekko/actor/TypedActor.scala +++ b/actor/src/main/scala/org/apache/pekko/actor/TypedActor.scala @@ -40,7 +40,7 @@ import pekko.util.Timeout /** * A TypedActorFactory is something that can created TypedActor instances. */ -@deprecated("Use 'org.apache.pekko.actor.typed' API.", since = "2.6.0") +@deprecated("Use 'org.apache.pekko.actor.typed' API.", since = "Akka 2.6.0") trait TypedActorFactory { /** @@ -115,7 +115,7 @@ trait TypedActorFactory { /** * This represents the TypedActor Akka Extension, access to the functionality is done through a given ActorSystem. */ -@deprecated("Use 'org.apache.pekko.actor.typed' API.", since = "2.6.0") +@deprecated("Use 'org.apache.pekko.actor.typed' API.", since = "Akka 2.6.0") object TypedActor extends ExtensionId[TypedActorExtension] with ExtensionIdProvider { override def get(system: ActorSystem): TypedActorExtension = super.get(system) override def get(system: ClassicActorSystemProvider): TypedActorExtension = super.get(system) @@ -128,7 +128,7 @@ object TypedActor extends ExtensionId[TypedActorExtension] with ExtensionIdProvi * will be children to the specified context, this allows for creating hierarchies of TypedActors. * Do _not_ let this instance escape the TypedActor since that will not be thread-safe. */ - @deprecated("Use 'org.apache.pekko.actor.typed' API.", since = "2.6.0") + @deprecated("Use 'org.apache.pekko.actor.typed' API.", since = "Akka 2.6.0") def apply(context: ActorContext): TypedActorFactory = ContextualTypedActorFactory(apply(context.system), context) /** diff --git a/actor/src/main/scala/org/apache/pekko/event/Logging.scala b/actor/src/main/scala/org/apache/pekko/event/Logging.scala index e6e9c3fe25..5eeb249328 100644 --- a/actor/src/main/scala/org/apache/pekko/event/Logging.scala +++ b/actor/src/main/scala/org/apache/pekko/event/Logging.scala @@ -1718,7 +1718,7 @@ object LogMarker { } @Deprecated - @deprecated("use org.apache.pekko.event.LogEventWithMarker#marker instead", since = "2.5.12") + @deprecated("use org.apache.pekko.event.LogEventWithMarker#marker instead", since = "Akka 2.5.12") def extractFromMDC(mdc: MDC): Option[String] = mdc.get(MDCKey) match { case Some(v) => Some(v.toString) diff --git a/actor/src/main/scala/org/apache/pekko/pattern/Backoff.scala b/actor/src/main/scala/org/apache/pekko/pattern/Backoff.scala index 2cdfeeb4da..fa1c5e751b 100644 --- a/actor/src/main/scala/org/apache/pekko/pattern/Backoff.scala +++ b/actor/src/main/scala/org/apache/pekko/pattern/Backoff.scala @@ -27,7 +27,7 @@ import pekko.util.JavaDurationConverters._ * @deprecated This API is superseded by the [[BackoffOpts]] object. */ @Deprecated -@deprecated("Use new API from BackoffOpts object instead", since = "2.5.22") +@deprecated("Use new API from BackoffOpts object instead", since = "Akka 2.5.22") object Backoff { /** @@ -532,7 +532,7 @@ object Backoff { */ @DoNotInherit @Deprecated -@deprecated("Use new API from BackoffOpts object instead", since = "2.5.22") +@deprecated("Use new API from BackoffOpts object instead", since = "Akka 2.5.22") trait BackoffOptions { /** diff --git a/actor/src/main/scala/org/apache/pekko/pattern/BackoffSupervisor.scala b/actor/src/main/scala/org/apache/pekko/pattern/BackoffSupervisor.scala index 17d8f28652..78370f6341 100644 --- a/actor/src/main/scala/org/apache/pekko/pattern/BackoffSupervisor.scala +++ b/actor/src/main/scala/org/apache/pekko/pattern/BackoffSupervisor.scala @@ -44,7 +44,7 @@ object BackoffSupervisor { * random delay based on this factor is added, e.g. `0.2` adds up to `20%` delay. * In order to skip this additional delay pass in `0`. */ - @deprecated("Use props with BackoffOpts instead", since = "2.5.22") + @deprecated("Use props with BackoffOpts instead", since = "Akka 2.5.22") def props( childProps: Props, childName: String, @@ -80,7 +80,7 @@ object BackoffSupervisor { * The supervisor will terminate itself after the maxNoOfRetries is reached. * In order to restart infinitely pass in `-1`. */ - @deprecated("Use props with BackoffOpts instead", since = "2.5.22") + @deprecated("Use props with BackoffOpts instead", since = "Akka 2.5.22") def props( childProps: Props, childName: String, @@ -112,7 +112,7 @@ object BackoffSupervisor { * random delay based on this factor is added, e.g. `0.2` adds up to `20%` delay. * In order to skip this additional delay pass in `0`. */ - @deprecated("Use props with BackoffOpts instead", since = "2.5.22") + @deprecated("Use props with BackoffOpts instead", since = "Akka 2.5.22") def props( childProps: Props, childName: String, @@ -142,7 +142,7 @@ object BackoffSupervisor { * The supervisor will terminate itself after the maxNoOfRetries is reached. * In order to restart infinitely pass in `-1`. */ - @deprecated("Use props with BackoffOpts instead", since = "2.5.22") + @deprecated("Use props with BackoffOpts instead", since = "Akka 2.5.22") def props( childProps: Props, childName: String, @@ -174,7 +174,7 @@ object BackoffSupervisor { * in the child. As the BackoffSupervisor creates a separate actor to handle the * backoff process, only a [[OneForOneStrategy]] makes sense here. */ - @deprecated("Use props with BackoffOpts instead", since = "2.5.22") + @deprecated("Use props with BackoffOpts instead", since = "Akka 2.5.22") def propsWithSupervisorStrategy( childProps: Props, childName: String, @@ -219,7 +219,7 @@ object BackoffSupervisor { * in the child. As the BackoffSupervisor creates a separate actor to handle the * backoff process, only a [[OneForOneStrategy]] makes sense here. */ - @deprecated("Use props with BackoffOpts instead", since = "2.5.22") + @deprecated("Use props with BackoffOpts instead", since = "Akka 2.5.22") def propsWithSupervisorStrategy( childProps: Props, childName: String, @@ -235,7 +235,7 @@ object BackoffSupervisor { * * @param options the [[BackoffOptions]] that specify how to construct a backoff-supervisor. */ - @deprecated("Use new API from BackoffOpts object instead", since = "2.5.22") + @deprecated("Use new API from BackoffOpts object instead", since = "Akka 2.5.22") def props(options: BackoffOptions): Props = options.props /** @@ -333,7 +333,7 @@ object BackoffSupervisor { } } -final class BackoffSupervisor @deprecated("Use `BackoffSupervisor.props` method instead", since = "2.5.22") ( +final class BackoffSupervisor @deprecated("Use `BackoffSupervisor.props` method instead", since = "Akka 2.5.22") ( override val childProps: Props, override val childName: String, minBackoff: FiniteDuration, @@ -355,7 +355,7 @@ final class BackoffSupervisor @deprecated("Use `BackoffSupervisor.props` method finalStopMessage) { // for binary compatibility with 2.5.18 - @deprecated("Use `BackoffSupervisor.props` method instead", since = "2.5.22") + @deprecated("Use `BackoffSupervisor.props` method instead", since = "Akka 2.5.22") def this( childProps: Props, childName: String, @@ -368,7 +368,7 @@ final class BackoffSupervisor @deprecated("Use `BackoffSupervisor.props` method this(childProps, childName, minBackoff, maxBackoff, reset, randomFactor, strategy, replyWhileStopped, None) // for binary compatibility with 2.4.1 - @deprecated("Use `BackoffSupervisor.props` method instead", since = "2.5.22") + @deprecated("Use `BackoffSupervisor.props` method instead", since = "Akka 2.5.22") def this( childProps: Props, childName: String, @@ -388,7 +388,7 @@ final class BackoffSupervisor @deprecated("Use `BackoffSupervisor.props` method None) // for binary compatibility with 2.4.0 - @deprecated("Use `BackoffSupervisor.props` method instead", since = "2.5.22") + @deprecated("Use `BackoffSupervisor.props` method instead", since = "Akka 2.5.22") def this( childProps: Props, childName: String, diff --git a/actor/src/main/scala/org/apache/pekko/pattern/CircuitBreaker.scala b/actor/src/main/scala/org/apache/pekko/pattern/CircuitBreaker.scala index 51d11f62fc..f848b068e0 100644 --- a/actor/src/main/scala/org/apache/pekko/pattern/CircuitBreaker.scala +++ b/actor/src/main/scala/org/apache/pekko/pattern/CircuitBreaker.scala @@ -79,7 +79,7 @@ object CircuitBreaker { * @param callTimeout [[scala.concurrent.duration.FiniteDuration]] of time after which to consider a call a failure * @param resetTimeout [[scala.concurrent.duration.FiniteDuration]] of time after which to attempt to close the circuit */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def create( scheduler: Scheduler, maxFailures: Int, @@ -183,7 +183,7 @@ class CircuitBreaker( CircuitBreakerNoopTelemetry)(executor) } - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def this( executor: ExecutionContext, scheduler: Scheduler, diff --git a/actor/src/main/scala/org/apache/pekko/pattern/Patterns.scala b/actor/src/main/scala/org/apache/pekko/pattern/Patterns.scala index 91f2ce3a7d..3e5d5165ae 100644 --- a/actor/src/main/scala/org/apache/pekko/pattern/Patterns.scala +++ b/actor/src/main/scala/org/apache/pekko/pattern/Patterns.scala @@ -468,7 +468,7 @@ object Patterns { * Returns a [[scala.concurrent.Future]] that will be completed with the success or failure of the provided Callable * after the specified duration. */ - @deprecated("Use the overload one which accepts a Callable of Future instead.", since = "2.5.22") + @deprecated("Use the overload one which accepts a Callable of Future instead.", since = "Akka 2.5.22") def after[T](duration: FiniteDuration, scheduler: Scheduler, context: ExecutionContext, value: Future[T]): Future[T] = scalaAfter(duration, scheduler)(value)(context) @@ -476,7 +476,7 @@ object Patterns { * Returns a [[java.util.concurrent.CompletionStage]] that will be completed with the success or failure of the provided value * after the specified duration. */ - @deprecated("Use the overloaded one which accepts a Callable of CompletionStage instead.", since = "2.5.22") + @deprecated("Use the overloaded one which accepts a Callable of CompletionStage instead.", since = "Akka 2.5.22") def after[T]( duration: java.time.Duration, scheduler: Scheduler, @@ -649,7 +649,7 @@ object Patterns { * * For working with Scala [[scala.concurrent.Future]] from Java you may want to use [[pekko.pattern.Patterns]] instead. */ -@deprecated("Use Patterns instead.", since = "2.5.19") +@deprecated("Use Patterns instead.", since = "Akka 2.5.19") object PatternsCS { import scala.concurrent.duration._ @@ -685,7 +685,7 @@ object PatternsCS { * f.thenRun(result -> nextActor.tell(new EnrichedResult(request, result))); * }}} */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.15") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.15") def ask(actor: ActorRef, message: Any, timeout: Timeout): CompletionStage[AnyRef] = scalaAsk(actor, message)(timeout).toJava.asInstanceOf[CompletionStage[AnyRef]] @@ -716,7 +716,7 @@ object PatternsCS { * f.thenRun(result -> nextActor.tell(new EnrichedResult(request, result))); * }}} */ - @deprecated("Use Patterns.ask instead.", since = "2.5.19") + @deprecated("Use Patterns.ask instead.", since = "Akka 2.5.19") def ask(actor: ActorRef, message: Any, timeout: java.time.Duration): CompletionStage[AnyRef] = ask(actor, message, Timeout.create(timeout)) @@ -735,7 +735,7 @@ object PatternsCS { * @param messageFactory function taking an actor ref and returning the message to be sent * @param timeout the timeout for the response before failing the returned completion operator */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.15") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.15") def askWithReplyTo( actor: ActorRef, messageFactory: japi.function.Function[ActorRef, Any], @@ -757,7 +757,7 @@ object PatternsCS { * @param messageFactory function taking an actor ref and returning the message to be sent * @param timeout the timeout for the response before failing the returned completion stage */ - @deprecated("Use Pattens.askWithReplyTo instead.", since = "2.5.19") + @deprecated("Use Pattens.askWithReplyTo instead.", since = "Akka 2.5.19") def askWithReplyTo( actor: ActorRef, messageFactory: japi.function.Function[ActorRef, Any], @@ -791,7 +791,7 @@ object PatternsCS { * f.thenRun(result -> nextActor.tell(new EnrichedResult(request, result))); * }}} */ - @deprecated("Use Pattens.ask which accepts java.time.Duration instead.", since = "2.5.19") + @deprecated("Use Pattens.ask which accepts java.time.Duration instead.", since = "Akka 2.5.19") def ask(actor: ActorRef, message: Any, timeoutMillis: Long): CompletionStage[AnyRef] = scalaAsk(actor, message)(new Timeout(timeoutMillis, TimeUnit.MILLISECONDS)).toJava .asInstanceOf[CompletionStage[AnyRef]] @@ -811,7 +811,7 @@ object PatternsCS { * @param messageFactory function taking an actor ref to reply to and returning the message to be sent * @param timeoutMillis the timeout for the response before failing the returned completion operator */ - @deprecated("Use Pattens.askWithReplyTo which accepts java.time.Duration instead.", since = "2.5.19") + @deprecated("Use Pattens.askWithReplyTo which accepts java.time.Duration instead.", since = "Akka 2.5.19") def askWithReplyTo( actor: ActorRef, messageFactory: japi.function.Function[ActorRef, Any], @@ -845,7 +845,7 @@ object PatternsCS { * f.thenRun(result -> nextActor.tell(new EnrichedResult(request, result))); * }}} */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.15") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.15") def ask(selection: ActorSelection, message: Any, timeout: Timeout): CompletionStage[AnyRef] = scalaAsk(selection, message)(timeout).toJava.asInstanceOf[CompletionStage[AnyRef]] @@ -876,7 +876,7 @@ object PatternsCS { * f.thenRun(result -> nextActor.tell(new EnrichedResult(request, result))); * }}} */ - @deprecated("Use Patterns.ask instead.", since = "2.5.19") + @deprecated("Use Patterns.ask instead.", since = "Akka 2.5.19") def ask(selection: ActorSelection, message: Any, timeout: java.time.Duration): CompletionStage[AnyRef] = ask(selection, message, Timeout.create(timeout)) @@ -907,7 +907,7 @@ object PatternsCS { * f.thenRun(result -> nextActor.tell(new EnrichedResult(request, result))); * }}} */ - @deprecated("Use Pattens.ask which accepts java.time.Duration instead.", since = "2.5.19") + @deprecated("Use Pattens.ask which accepts java.time.Duration instead.", since = "Akka 2.5.19") def ask(selection: ActorSelection, message: Any, timeoutMillis: Long): CompletionStage[AnyRef] = scalaAsk(selection, message)(new Timeout(timeoutMillis, TimeUnit.MILLISECONDS)).toJava .asInstanceOf[CompletionStage[AnyRef]] @@ -923,7 +923,7 @@ object PatternsCS { * timeout); * }}} */ - @deprecated("Use Pattens.askWithReplyTo which accepts java.time.Duration instead.", since = "2.5.19") + @deprecated("Use Pattens.askWithReplyTo which accepts java.time.Duration instead.", since = "Akka 2.5.19") def askWithReplyTo( selection: ActorSelection, messageFactory: japi.Function[ActorRef, Any], @@ -950,7 +950,7 @@ object PatternsCS { * PatternsCS.pipe(transformed, context).to(nextActor); * }}} */ - @deprecated("Use Patterns.pipe instead.", since = "2.5.19") + @deprecated("Use Patterns.pipe instead.", since = "Akka 2.5.19") def pipe[T](future: CompletionStage[T], context: ExecutionContext): PipeableCompletionStage[T] = pipeCompletionStage(future)(context) @@ -964,7 +964,7 @@ object PatternsCS { * If the target actor isn't terminated within the timeout the [[java.util.concurrent.CompletionStage]] * is completed with failure [[pekko.pattern.AskTimeoutException]]. */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def gracefulStop(target: ActorRef, timeout: FiniteDuration): CompletionStage[java.lang.Boolean] = scalaGracefulStop(target, timeout).toJava.asInstanceOf[CompletionStage[java.lang.Boolean]] @@ -978,7 +978,7 @@ object PatternsCS { * If the target actor isn't terminated within the timeout the [[java.util.concurrent.CompletionStage]] * is completed with failure [[pekko.pattern.AskTimeoutException]]. */ - @deprecated("Use Patterns.gracefulStop instead.", since = "2.5.19") + @deprecated("Use Patterns.gracefulStop instead.", since = "Akka 2.5.19") def gracefulStop(target: ActorRef, timeout: java.time.Duration): CompletionStage[java.lang.Boolean] = scalaGracefulStop(target, timeout.asScala).toJava.asInstanceOf[CompletionStage[java.lang.Boolean]] @@ -995,7 +995,7 @@ object PatternsCS { * If the target actor isn't terminated within the timeout the [[java.util.concurrent.CompletionStage]] * is completed with failure [[pekko.pattern.AskTimeoutException]]. */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def gracefulStop(target: ActorRef, timeout: FiniteDuration, stopMessage: Any): CompletionStage[java.lang.Boolean] = scalaGracefulStop(target, timeout, stopMessage).toJava.asInstanceOf[CompletionStage[java.lang.Boolean]] @@ -1012,7 +1012,7 @@ object PatternsCS { * If the target actor isn't terminated within the timeout the [[java.util.concurrent.CompletionStage]] * is completed with failure [[pekko.pattern.AskTimeoutException]]. */ - @deprecated("Use Patterns.gracefulStop instead.", since = "2.5.19") + @deprecated("Use Patterns.gracefulStop instead.", since = "Akka 2.5.19") def gracefulStop( target: ActorRef, timeout: java.time.Duration, @@ -1023,7 +1023,7 @@ object PatternsCS { * Returns a [[java.util.concurrent.CompletionStage]] that will be completed with the success or failure of the provided Callable * after the specified duration. */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def after[T]( duration: FiniteDuration, scheduler: Scheduler, @@ -1035,7 +1035,7 @@ object PatternsCS { * Returns a [[java.util.concurrent.CompletionStage]] that will be completed with the success or failure of the provided Callable * after the specified duration. */ - @deprecated("Use Patterns.after instead.", since = "2.5.19") + @deprecated("Use Patterns.after instead.", since = "Akka 2.5.19") def after[T]( duration: java.time.Duration, scheduler: Scheduler, @@ -1049,7 +1049,7 @@ object PatternsCS { */ @deprecated( "Use Patterns.after which accepts java.time.Duration and Callable of CompletionStage instead.", - since = "2.5.22") + since = "Akka 2.5.22") def after[T]( duration: FiniteDuration, scheduler: Scheduler, @@ -1063,7 +1063,7 @@ object PatternsCS { */ @deprecated( "Use Patterns.after which accepts java.time.Duration and Callable of CompletionStage instead.", - since = "2.5.22") + since = "Akka 2.5.22") def after[T]( duration: java.time.Duration, scheduler: Scheduler, @@ -1079,7 +1079,7 @@ object PatternsCS { * Note that the attempt function will be invoked on the given execution context for subsequent tries * and therefore must be thread safe (not touch unsafe mutable state). */ - @deprecated("Use Patterns.retry instead.", since = "2.5.19") + @deprecated("Use Patterns.retry instead.", since = "Akka 2.5.19") def retry[T]( attempt: Callable[CompletionStage[T]], attempts: Int, diff --git a/actor/src/main/scala/org/apache/pekko/serialization/Serialization.scala b/actor/src/main/scala/org/apache/pekko/serialization/Serialization.scala index 84004e77fd..c2e9c47067 100644 --- a/actor/src/main/scala/org/apache/pekko/serialization/Serialization.scala +++ b/actor/src/main/scala/org/apache/pekko/serialization/Serialization.scala @@ -183,7 +183,7 @@ class Serialization(val system: ExtendedActorSystem) extends Extension { * using the optional type hint to the Serializer. * Returns either the resulting object or an Exception if one was thrown. */ - @deprecated("Use deserialize that accepts the `manifest` as a class name.", since = "2.6.0") + @deprecated("Use deserialize that accepts the `manifest` as a class name.", since = "Akka 2.6.0") def deserialize[T](bytes: Array[Byte], serializerId: Int, clazz: Option[Class[_ <: T]]): Try[T] = Try { val serializer = diff --git a/cluster-sharding-typed/src/main/scala/org/apache/pekko/cluster/sharding/typed/ClusterShardingSettings.scala b/cluster-sharding-typed/src/main/scala/org/apache/pekko/cluster/sharding/typed/ClusterShardingSettings.scala index 01c2b5dcf6..b7cd722e0e 100644 --- a/cluster-sharding-typed/src/main/scala/org/apache/pekko/cluster/sharding/typed/ClusterShardingSettings.scala +++ b/cluster-sharding-typed/src/main/scala/org/apache/pekko/cluster/sharding/typed/ClusterShardingSettings.scala @@ -993,15 +993,15 @@ final class ClusterShardingSettings( rememberEntitiesStoreMode: ClusterShardingSettings.RememberEntitiesStoreMode): ClusterShardingSettings = copy(rememberEntitiesStoreMode = rememberEntitiesStoreMode) - @deprecated("See passivationStrategySettings.idleEntitySettings instead", since = "2.6.18") + @deprecated("See passivationStrategySettings.idleEntitySettings instead", since = "Akka 2.6.18") def passivateIdleEntityAfter: FiniteDuration = passivationStrategySettings.idleEntitySettings.fold(Duration.Zero)(_.timeout) - @deprecated("Use withPassivationStrategy instead", since = "2.6.18") + @deprecated("Use withPassivationStrategy instead", since = "Akka 2.6.18") def withPassivateIdleEntityAfter(duration: FiniteDuration): ClusterShardingSettings = copy(passivationStrategySettings = passivationStrategySettings.withOldIdleStrategy(duration)) - @deprecated("Use withPassivationStrategy instead", since = "2.6.18") + @deprecated("Use withPassivationStrategy instead", since = "Akka 2.6.18") def withPassivateIdleEntityAfter(duration: java.time.Duration): ClusterShardingSettings = copy(passivationStrategySettings = passivationStrategySettings.withOldIdleStrategy(duration.asScala)) diff --git a/cluster-sharding/src/main/scala/org/apache/pekko/cluster/sharding/ClusterShardingSettings.scala b/cluster-sharding/src/main/scala/org/apache/pekko/cluster/sharding/ClusterShardingSettings.scala index e378b98b4e..5ad9456857 100644 --- a/cluster-sharding/src/main/scala/org/apache/pekko/cluster/sharding/ClusterShardingSettings.scala +++ b/cluster-sharding/src/main/scala/org/apache/pekko/cluster/sharding/ClusterShardingSettings.scala @@ -942,7 +942,7 @@ object ClusterShardingSettings { @deprecated( "Use the ClusterShardingSettings factory methods or the constructor including " + "leastShardAllocationAbsoluteLimit and leastShardAllocationRelativeLimit instead", - since = "2.6.10") + since = "Akka 2.6.10") def this( coordinatorFailureBackoff: FiniteDuration, retryInterval: FiniteDuration, @@ -990,7 +990,7 @@ object ClusterShardingSettings { @deprecated( "Use the ClusterShardingSettings factory methods or the constructor including " + "coordinatorStateWriteMajorityPlus and coordinatorStateReadMajorityPlus instead", - since = "2.6.5") + since = "Akka 2.6.5") def this( coordinatorFailureBackoff: FiniteDuration, retryInterval: FiniteDuration, @@ -1031,7 +1031,7 @@ object ClusterShardingSettings { coordinatorStateReadMajorityPlus = 5) // included for binary compatibility - @deprecated("Use the ClusterShardingSettings factory methods or the full constructor instead", since = "2.6.5") + @deprecated("Use the ClusterShardingSettings factory methods or the full constructor instead", since = "Akka 2.6.5") def this( coordinatorFailureBackoff: FiniteDuration, retryInterval: FiniteDuration, @@ -1070,7 +1070,7 @@ object ClusterShardingSettings { } // included for binary compatibility - @deprecated("Use the ClusterShardingSettings factory methods or the full constructor instead", since = "2.6.5") + @deprecated("Use the ClusterShardingSettings factory methods or the full constructor instead", since = "Akka 2.6.5") def this( coordinatorFailureBackoff: FiniteDuration, retryInterval: FiniteDuration, @@ -1225,7 +1225,7 @@ final class ClusterShardingSettings( // bin compat for 2.5.23 @deprecated( "Use the ClusterShardingSettings factory methods or the constructor including shardRegionQueryTimeout instead", - since = "2.6.0") + since = "Akka 2.6.0") def this( role: Option[String], rememberEntities: Boolean, @@ -1251,7 +1251,7 @@ final class ClusterShardingSettings( // bin compat for 2.5.21 @deprecated( "Use the ClusterShardingSettings factory methods or the constructor including shardRegionQueryTimeout instead", - since = "2.5.21") + since = "Akka 2.5.21") def this( role: Option[String], rememberEntities: Boolean, @@ -1276,7 +1276,7 @@ final class ClusterShardingSettings( // included for binary compatibility reasons @deprecated( "Use the ClusterShardingSettings factory methods or the constructor including passivateIdleEntityAfter instead", - since = "2.5.18") + since = "Akka 2.5.18") def this( role: Option[String], rememberEntities: Boolean, @@ -1328,15 +1328,15 @@ final class ClusterShardingSettings( def withStateStoreMode(stateStoreMode: String): ClusterShardingSettings = copy(stateStoreMode = stateStoreMode) - @deprecated("See passivationStrategySettings.idleEntitySettings instead", since = "2.6.18") + @deprecated("See passivationStrategySettings.idleEntitySettings instead", since = "Akka 2.6.18") def passivateIdleEntityAfter: FiniteDuration = passivationStrategySettings.idleEntitySettings.fold(Duration.Zero)(_.timeout) - @deprecated("Use withPassivationStrategy instead", since = "2.6.18") + @deprecated("Use withPassivationStrategy instead", since = "Akka 2.6.18") def withPassivateIdleAfter(duration: FiniteDuration): ClusterShardingSettings = copy(passivationStrategySettings = passivationStrategySettings.withOldIdleStrategy(duration)) - @deprecated("Use withPassivationStrategy instead", since = "2.6.18") + @deprecated("Use withPassivationStrategy instead", since = "Akka 2.6.18") def withPassivateIdleAfter(duration: java.time.Duration): ClusterShardingSettings = copy(passivationStrategySettings = passivationStrategySettings.withOldIdleStrategy(duration.asScala)) diff --git a/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala b/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala index d5d864353d..fceeaaf909 100644 --- a/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala +++ b/cluster-tools/src/main/scala/org/apache/pekko/cluster/client/ClusterClient.scala @@ -57,7 +57,7 @@ import pekko.util.ccompat._ @ccompatUsedUntil213 @deprecated( "Use Pekko gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-pekko-grpc", - since = "2.6.0") + since = "Akka 2.6.0") object ClusterClientSettings { /** @@ -128,7 +128,7 @@ object ClusterClientSettings { */ @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final class ClusterClientSettings( val initialContacts: Set[ActorPath], val establishingGetContactsInterval: FiniteDuration, @@ -293,7 +293,7 @@ final case class ContactPoints(contactPoints: Set[ActorPath]) { @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") object ClusterClient { /** @@ -301,14 +301,14 @@ object ClusterClient { */ @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") def props(settings: ClusterClientSettings): Props = Props(new ClusterClient(settings)).withDeploy(Deploy.local) @SerialVersionUID(1L) @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final case class Send(path: String, msg: Any, localAffinity: Boolean) { /** @@ -319,13 +319,13 @@ object ClusterClient { @SerialVersionUID(1L) @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final case class SendToAll(path: String, msg: Any) @SerialVersionUID(1L) @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final case class Publish(topic: String, msg: Any) /** @@ -382,7 +382,7 @@ object ClusterClient { */ @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final class ClusterClient(settings: ClusterClientSettings) extends Actor with ActorLogging { import ClusterClient._ @@ -566,7 +566,7 @@ final class ClusterClient(settings: ClusterClientSettings) extends Actor with Ac @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") object ClusterClientReceptionist extends ExtensionId[ClusterClientReceptionist] with ExtensionIdProvider { override def get(system: ActorSystem): ClusterClientReceptionist = super.get(system) override def get(system: ClassicActorSystemProvider): ClusterClientReceptionist = super.get(system) @@ -584,7 +584,7 @@ object ClusterClientReceptionist extends ExtensionId[ClusterClientReceptionist] */ @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final class ClusterClientReceptionist(system: ExtendedActorSystem) extends Extension { private val config = system.settings.config.getConfig("pekko.cluster.client.receptionist") @@ -662,7 +662,7 @@ final class ClusterClientReceptionist(system: ExtendedActorSystem) extends Exten @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") object ClusterReceptionistSettings { /** @@ -714,7 +714,7 @@ object ClusterReceptionistSettings { */ @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final class ClusterReceptionistSettings( val role: Option[String], val numberOfContacts: Int, @@ -876,7 +876,7 @@ final case class ClusterClients(clusterClients: Set[ActorRef]) { @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") object ClusterReceptionist { /** @@ -953,7 +953,7 @@ object ClusterReceptionist { */ @deprecated( "Use Akka gRPC instead, see https://pekko.apache.org/docs/pekko/current/cluster-client.html#migration-to-akka-grpc", - since = "2.6.0") + since = "Akka 2.6.0") final class ClusterReceptionist(pubSubMediator: ActorRef, settings: ClusterReceptionistSettings) extends Actor with ActorLogging { diff --git a/cluster/src/main/scala/org/apache/pekko/cluster/ClusterEvent.scala b/cluster/src/main/scala/org/apache/pekko/cluster/ClusterEvent.scala index 144ba48da7..ad0b49a3e1 100644 --- a/cluster/src/main/scala/org/apache/pekko/cluster/ClusterEvent.scala +++ b/cluster/src/main/scala/org/apache/pekko/cluster/ClusterEvent.scala @@ -115,7 +115,7 @@ object ClusterEvent { with Serializable { // for binary compatibility - @deprecated("use main constructor", since = "2.6.10") + @deprecated("use main constructor", since = "Akka 2.6.10") def this( members: immutable.SortedSet[Member], unreachable: Set[Member], @@ -126,7 +126,7 @@ object ClusterEvent { this(members, unreachable, seenBy, leader, roleLeaderMap, unreachableDataCenters, Set.empty) // for binary compatibility - @deprecated("use main constructor", since = "2.6.10") + @deprecated("use main constructor", since = "Akka 2.6.10") def this( members: immutable.SortedSet[Member] = immutable.SortedSet.empty, unreachable: Set[Member] = Set.empty, diff --git a/cluster/src/main/scala/org/apache/pekko/cluster/Member.scala b/cluster/src/main/scala/org/apache/pekko/cluster/Member.scala index 65c7c8dbdd..d00ab8b40f 100644 --- a/cluster/src/main/scala/org/apache/pekko/cluster/Member.scala +++ b/cluster/src/main/scala/org/apache/pekko/cluster/Member.scala @@ -176,7 +176,7 @@ object Member { a.isOlderThan(b) } - @deprecated("Was accidentally made a public API, internal", since = "2.5.4") + @deprecated("Was accidentally made a public API, internal", since = "Akka 2.5.4") def pickHighestPriority(a: Set[Member], b: Set[Member]): Set[Member] = pickHighestPriority(a, b, Map.empty) @@ -316,7 +316,7 @@ object MemberStatus { object UniqueAddress extends AbstractFunction2[Address, Int, UniqueAddress] { // for binary compatibility - @deprecated("Use Long UID apply instead", since = "2.4.11") + @deprecated("Use Long UID apply instead", since = "Akka 2.4.11") def apply(address: Address, uid: Int) = new UniqueAddress(address, uid.toLong) def apply(remoteUniqueAddress: pekko.remote.UniqueAddress): UniqueAddress = @@ -363,17 +363,17 @@ final class UniqueAddress(val address: Address, val longUid: Long) // for binary compatibility - @deprecated("Use Long UID constructor instead", since = "2.4.11") + @deprecated("Use Long UID constructor instead", since = "Akka 2.4.11") def this(address: Address, uid: Int) = this(address, uid.toLong) - @deprecated("Use longUid instead", since = "2.4.11") + @deprecated("Use longUid instead", since = "Akka 2.4.11") def uid = longUid.toInt /** * For binary compatibility * Stops `copy(Address, Long)` copy from being generated, use `apply` instead. */ - @deprecated("Use Long UID constructor instead", since = "2.4.11") + @deprecated("Use Long UID constructor instead", since = "Akka 2.4.11") @nowarn("msg=deprecated") def copy(address: Address = address, uid: Int = uid) = new UniqueAddress(address, uid.toLong) diff --git a/cluster/src/main/scala/org/apache/pekko/cluster/routing/ClusterRouterConfig.scala b/cluster/src/main/scala/org/apache/pekko/cluster/routing/ClusterRouterConfig.scala index 06c7d3d72b..7a01cc5e78 100644 --- a/cluster/src/main/scala/org/apache/pekko/cluster/routing/ClusterRouterConfig.scala +++ b/cluster/src/main/scala/org/apache/pekko/cluster/routing/ClusterRouterConfig.scala @@ -42,7 +42,7 @@ import pekko.util.HashCode import pekko.util.ccompat.JavaConverters._ object ClusterRouterGroupSettings { - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def apply( totalInstances: Int, routeesPaths: immutable.Seq[String], @@ -123,10 +123,10 @@ final class ClusterRouterGroupSettings( s"ClusterRouterGroupSettings($totalInstances,$routeesPaths,$allowLocalRoutees,$useRoles)" // For binary compatibility - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def useRole: Option[String] = useRoles.headOption - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def this( totalInstances: Int, routeesPaths: immutable.Seq[String], @@ -137,7 +137,7 @@ final class ClusterRouterGroupSettings( /** * Java API */ - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def this(totalInstances: Int, routeesPaths: java.lang.Iterable[String], allowLocalRoutees: Boolean, useRole: String) = this(totalInstances, immutableSeq(routeesPaths), allowLocalRoutees, Option(useRole).toSet) @@ -152,7 +152,7 @@ final class ClusterRouterGroupSettings( this(totalInstances, immutableSeq(routeesPaths), allowLocalRoutees, useRoles.asScala.toSet) // For binary compatibility - @deprecated("Use constructor with useRoles instead", since = "2.5.4") + @deprecated("Use constructor with useRoles instead", since = "Akka 2.5.4") @nowarn("msg=deprecated") def copy( totalInstances: Int = totalInstances, @@ -194,7 +194,7 @@ object ClusterRouterPoolSettings { useRoles: Set[String]): ClusterRouterPoolSettings = new ClusterRouterPoolSettings(totalInstances, maxInstancesPerNode, allowLocalRoutees, useRoles) - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def apply( totalInstances: Int, maxInstancesPerNode: Int, @@ -270,17 +270,17 @@ final class ClusterRouterPoolSettings( s"ClusterRouterPoolSettings($totalInstances,$maxInstancesPerNode,$allowLocalRoutees,$useRoles)" // For binary compatibility - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def useRole: Option[String] = useRoles.headOption - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def this(totalInstances: Int, maxInstancesPerNode: Int, allowLocalRoutees: Boolean, useRole: Option[String]) = this(totalInstances, maxInstancesPerNode, allowLocalRoutees, useRole.toSet) /** * Java API */ - @deprecated("useRole has been replaced with useRoles", since = "2.5.4") + @deprecated("useRole has been replaced with useRoles", since = "Akka 2.5.4") def this(totalInstances: Int, maxInstancesPerNode: Int, allowLocalRoutees: Boolean, useRole: String) = this(totalInstances, maxInstancesPerNode, allowLocalRoutees, Option(useRole).toSet) @@ -291,7 +291,7 @@ final class ClusterRouterPoolSettings( this(totalInstances, maxInstancesPerNode, allowLocalRoutees, useRoles.asScala.toSet) // For binary compatibility - @deprecated("Use copy with useRoles instead", since = "2.5.4") + @deprecated("Use copy with useRoles instead", since = "Akka 2.5.4") @nowarn("msg=deprecated") def copy( totalInstances: Int = totalInstances, diff --git a/distributed-data/src/main/scala-2/org/apache/pekko/cluster/ddata/GSet.scala b/distributed-data/src/main/scala-2/org/apache/pekko/cluster/ddata/GSet.scala index f4544ab31e..da22d0775a 100644 --- a/distributed-data/src/main/scala-2/org/apache/pekko/cluster/ddata/GSet.scala +++ b/distributed-data/src/main/scala-2/org/apache/pekko/cluster/ddata/GSet.scala @@ -98,7 +98,7 @@ final case class GSet[A] private (elements: Set[A])(override val delta: Option[G def copy(e: Set[A]) = new GSet[A](e)(delta) - @deprecated("Kept for binary compatibility", since = "2.6.16") + @deprecated("Kept for binary compatibility", since = "Akka 2.6.16") private[ddata] def copy$default$1(): Set[A] = elements } diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/GCounter.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/GCounter.scala index 620c6fe420..76104c7160 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/GCounter.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/GCounter.scala @@ -84,7 +84,7 @@ final class GCounter private[pekko] ( */ def :+(n: Long)(implicit node: SelfUniqueAddress): GCounter = increment(node.uniqueAddress, n) - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(n: Long)(implicit node: Cluster): GCounter = increment(node.selfUniqueAddress, n) /** @@ -93,7 +93,7 @@ final class GCounter private[pekko] ( */ def increment(node: SelfUniqueAddress, n: Long): GCounter = increment(node.uniqueAddress, n) - @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def increment(node: Cluster, n: Long = 1): GCounter = increment(node.selfUniqueAddress, n) /** diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWMap.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWMap.scala index c012ea6a84..6a0e957710 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWMap.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWMap.scala @@ -105,7 +105,7 @@ final class LWWMap[A, B] private[pekko] (private[pekko] val underlying: ORMap[A, put(node, key, value) } - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(entry: (A, B))(implicit node: Cluster): LWWMap[A, B] = { val (key, value) = entry put(node, key, value) @@ -117,7 +117,7 @@ final class LWWMap[A, B] private[pekko] (private[pekko] val underlying: ORMap[A, def put(node: SelfUniqueAddress, key: A, value: B): LWWMap[A, B] = put(node.uniqueAddress, key, value, defaultClock[B]) - @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def put(node: Cluster, key: A, value: B): LWWMap[A, B] = put(node.selfUniqueAddress, key, value, defaultClock[B]) @@ -132,7 +132,7 @@ final class LWWMap[A, B] private[pekko] (private[pekko] val underlying: ORMap[A, def put(node: SelfUniqueAddress, key: A, value: B, clock: Clock[B]): LWWMap[A, B] = put(node.uniqueAddress, key, value, clock) - @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def put(node: Cluster, key: A, value: B, clock: Clock[B]): LWWMap[A, B] = put(node.selfUniqueAddress, key, value, clock) @@ -144,7 +144,7 @@ final class LWWMap[A, B] private[pekko] (private[pekko] val underlying: ORMap[A, * increasing version number from a database record that is used for optimistic * concurrency control. */ - @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def put(key: A, value: B)(implicit node: Cluster, clock: Clock[B] = defaultClock[B]): LWWMap[A, B] = put(node.selfUniqueAddress, key, value, clock) @@ -164,7 +164,7 @@ final class LWWMap[A, B] private[pekko] (private[pekko] val underlying: ORMap[A, * Note that if there is a conflicting update on another node the entry will * not be removed after merge. */ - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def -(key: A)(implicit node: Cluster): LWWMap[A, B] = remove(node, key) /** @@ -175,7 +175,7 @@ final class LWWMap[A, B] private[pekko] (private[pekko] val underlying: ORMap[A, def remove(node: SelfUniqueAddress, key: A): LWWMap[A, B] = remove(node.uniqueAddress, key) - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def remove(node: Cluster, key: A): LWWMap[A, B] = remove(node.selfUniqueAddress, key) diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWRegister.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWRegister.scala index 8d1c88bf91..fd3c5f90c3 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWRegister.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/LWWRegister.scala @@ -65,7 +65,7 @@ object LWWRegister { def apply[A](node: SelfUniqueAddress, initialValue: A, clock: Clock[A]): LWWRegister[A] = apply(node.uniqueAddress, initialValue, clock) - @deprecated("Use `apply` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `apply` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def apply[A](initialValue: A)(implicit node: Cluster, clock: Clock[A] = defaultClock[A]): LWWRegister[A] = apply(node.selfUniqueAddress, initialValue, clock) @@ -79,14 +79,14 @@ object LWWRegister { /** * Java API */ - @deprecated("Use `create` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `create` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def create[A](node: Cluster, initialValue: A): LWWRegister[A] = apply(initialValue)(node) /** * Java API */ - @deprecated("Use `create` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `create` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def create[A](node: Cluster, initialValue: A, clock: Clock[A]): LWWRegister[A] = apply(node.selfUniqueAddress, initialValue, clock) @@ -179,15 +179,15 @@ final class LWWRegister[A] private[pekko] (private[pekko] val node: UniqueAddres def withValueOf(value: A)(implicit node: SelfUniqueAddress, clock: Clock[A] = defaultClock[A]): LWWRegister[A] = withValue(node, value, clock) - @deprecated("Use `withValueOf` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `withValueOf` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def withValue(value: A)(implicit node: Cluster, clock: Clock[A] = defaultClock[A]): LWWRegister[A] = withValue(node, value, clock) - @deprecated("Use `withValue` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `withValue` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def withValue(node: Cluster, value: A): LWWRegister[A] = withValue(node, value, defaultClock[A]) - @deprecated("Use `withValue` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `withValue` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def withValue(node: Cluster, value: A, clock: Clock[A]): LWWRegister[A] = withValue(node.selfUniqueAddress, value, clock) diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMap.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMap.scala index be29b7193e..2be1fe05fe 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMap.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMap.scala @@ -237,7 +237,7 @@ final class ORMap[A, B <: ReplicatedData] private[pekko] ( put(node.uniqueAddress, key, value) } - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(entry: (A, B))(implicit node: Cluster): ORMap[A, B] = { val (key, value) = entry put(node.selfUniqueAddress, key, value) @@ -259,7 +259,7 @@ final class ORMap[A, B <: ReplicatedData] private[pekko] ( */ def put(node: SelfUniqueAddress, key: A, value: B): ORMap[A, B] = put(node.uniqueAddress, key, value) - @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def put(node: Cluster, key: A, value: B): ORMap[A, B] = put(node.selfUniqueAddress, key, value) /** @@ -287,7 +287,7 @@ final class ORMap[A, B <: ReplicatedData] private[pekko] ( def updated(node: SelfUniqueAddress, key: A, initial: B)(modify: B => B): ORMap[A, B] = updated(node.uniqueAddress, key, initial)(modify) - @deprecated("Use `updated` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `updated` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def updated(node: Cluster, key: A, initial: B)(modify: B => B): ORMap[A, B] = updated(node.selfUniqueAddress, key, initial)(modify) @@ -312,7 +312,7 @@ final class ORMap[A, B <: ReplicatedData] private[pekko] ( updated(node.uniqueAddress, key, initial)(value => modify.apply(value)) @Deprecated - @deprecated("Use `update` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `update` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def update(node: Cluster, key: A, initial: B, modify: java.util.function.Function[B, B]): ORMap[A, B] = updated(node, key, initial)(value => modify.apply(value)) @@ -363,10 +363,10 @@ final class ORMap[A, B <: ReplicatedData] private[pekko] ( */ def remove(node: SelfUniqueAddress, key: A): ORMap[A, B] = remove(node.uniqueAddress, key) - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def -(key: A)(implicit node: Cluster): ORMap[A, B] = remove(node.selfUniqueAddress, key) - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def remove(node: Cluster, key: A): ORMap[A, B] = remove(node.selfUniqueAddress, key) /** diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMultiMap.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMultiMap.scala index 964346ac83..e9d63c0afb 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMultiMap.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORMultiMap.scala @@ -155,7 +155,7 @@ final class ORMultiMap[A, B] private[pekko] ( put(node.uniqueAddress, key, value) } - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(entry: (A, Set[B]))(implicit node: Cluster): ORMultiMap[A, B] = { val (key, value) = entry put(node.selfUniqueAddress, key, value) @@ -168,7 +168,7 @@ final class ORMultiMap[A, B] private[pekko] ( def put(node: SelfUniqueAddress, key: A, value: Set[B]): ORMultiMap[A, B] = put(node.uniqueAddress, key, value) - @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def put(node: Cluster, key: A, value: Set[B]): ORMultiMap[A, B] = put(node.selfUniqueAddress, key, value) @@ -182,7 +182,7 @@ final class ORMultiMap[A, B] private[pekko] ( } @Deprecated - @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `put` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def put(node: Cluster, key: A, value: java.util.Set[B]): ORMultiMap[A, B] = { import pekko.util.ccompat.JavaConverters._ put(node.selfUniqueAddress, key, value.asScala.toSet) @@ -210,7 +210,7 @@ final class ORMultiMap[A, B] private[pekko] ( * Convenience for remove. Requires an implicit Cluster. * @see [[ORMultiMap#remove(node:akka\.cluster\.ddata\.SelfUniqueAddress*]] */ - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def -(key: A)(implicit node: Cluster): ORMultiMap[A, B] = remove(node.selfUniqueAddress, key) /** @@ -219,7 +219,7 @@ final class ORMultiMap[A, B] private[pekko] ( */ def remove(node: SelfUniqueAddress, key: A): ORMultiMap[A, B] = remove(node.uniqueAddress, key) - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def remove(node: Cluster, key: A): ORMultiMap[A, B] = remove(node.selfUniqueAddress, key) /** @@ -246,11 +246,11 @@ final class ORMultiMap[A, B] private[pekko] ( def addBindingBy(key: A, element: B)(implicit node: SelfUniqueAddress): ORMultiMap[A, B] = addBinding(node, key, element) - @deprecated("Use `addBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `addBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def addBinding(key: A, element: B)(implicit node: Cluster): ORMultiMap[A, B] = addBinding(node.selfUniqueAddress, key, element) - @deprecated("Use `addBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `addBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def addBinding(node: Cluster, key: A, element: B): ORMultiMap[A, B] = addBinding(node.selfUniqueAddress, key, element) @@ -274,12 +274,12 @@ final class ORMultiMap[A, B] private[pekko] ( def removeBindingBy(key: A, element: B)(implicit node: SelfUniqueAddress): ORMultiMap[A, B] = removeBinding(node, key, element) - @deprecated("Use `removeBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `removeBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def removeBinding(key: A, element: B)(implicit node: Cluster): ORMultiMap[A, B] = removeBinding(node.selfUniqueAddress, key, element) @Deprecated - @deprecated("Use `removeBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `removeBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def removeBinding(node: Cluster, key: A, element: B): ORMultiMap[A, B] = removeBinding(node.selfUniqueAddress, key, element) @@ -312,7 +312,7 @@ final class ORMultiMap[A, B] private[pekko] ( def replaceBindingBy(key: A, oldElement: B, newElement: B)(implicit node: SelfUniqueAddress): ORMultiMap[A, B] = replaceBinding(node, key, oldElement, newElement) - @deprecated("Use `replaceBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `replaceBinding` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def replaceBinding(key: A, oldElement: B, newElement: B)(implicit node: Cluster): ORMultiMap[A, B] = replaceBinding(node.selfUniqueAddress, key, oldElement, newElement) diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORSet.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORSet.scala index 190ef2deac..5e520a5f3b 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORSet.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/ORSet.scala @@ -333,14 +333,14 @@ final class ORSet[A] private[pekko] ( /** Adds an element to the set. */ def :+(element: A)(implicit node: SelfUniqueAddress): ORSet[A] = add(node, element) - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(element: A)(implicit node: Cluster): ORSet[A] = add(node.selfUniqueAddress, element) /** Adds an element to the set. */ def add(node: SelfUniqueAddress, element: A): ORSet[A] = add(node.uniqueAddress, element) @Deprecated - @deprecated("Use `add` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `add` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def add(node: Cluster, element: A): ORSet[A] = add(node.selfUniqueAddress, element) /** @@ -375,13 +375,13 @@ final class ORSet[A] private[pekko] ( /** * Removes an element from the set. */ - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def -(element: A)(implicit node: Cluster): ORSet[A] = remove(node.selfUniqueAddress, element) /** * Removes an element from the set. */ - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def remove(node: Cluster, element: A): ORSet[A] = remove(node.selfUniqueAddress, element) /** @@ -405,7 +405,7 @@ final class ORSet[A] private[pekko] ( */ def clear(@unused node: SelfUniqueAddress): ORSet[A] = clear() - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def clear(@unused node: Cluster): ORSet[A] = clear() /** diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounter.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounter.scala index bbf236be3b..94da10519e 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounter.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounter.scala @@ -76,7 +76,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def :+(n: Long)(implicit node: SelfUniqueAddress): PNCounter = increment(node.uniqueAddress, n) - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(n: Long)(implicit node: Cluster): PNCounter = increment(node.selfUniqueAddress, n) /** @@ -85,7 +85,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def :+(n: BigInt)(implicit node: SelfUniqueAddress): PNCounter = increment(node.uniqueAddress, n) - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(n: BigInt)(implicit node: Cluster): PNCounter = increment(node.selfUniqueAddress, n) /** @@ -94,7 +94,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def increment(n: Long)(implicit node: SelfUniqueAddress): PNCounter = increment(node.uniqueAddress, n) - @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def increment(node: Cluster, n: Long = 1): PNCounter = increment(node.selfUniqueAddress, n) /** @@ -103,7 +103,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def increment(n: BigInt)(implicit node: SelfUniqueAddress): PNCounter = increment(node.uniqueAddress, n) - @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def increment(node: Cluster, n: BigInt): PNCounter = increment(node.selfUniqueAddress, n) /** @@ -118,7 +118,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def increment(node: SelfUniqueAddress, n: Long): PNCounter = increment(node.uniqueAddress, n) - @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def increment(node: Cluster, n: java.math.BigInteger): PNCounter = increment(node.selfUniqueAddress, n) /** @@ -127,7 +127,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def decrement(n: Long)(implicit node: SelfUniqueAddress): PNCounter = decrement(node.uniqueAddress, n) - @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def -(n: Long)(implicit node: Cluster): PNCounter = decrement(node.selfUniqueAddress, n) /** @@ -136,7 +136,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def decrement(n: BigInt)(implicit node: SelfUniqueAddress): PNCounter = decrement(node.uniqueAddress, n) - @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def -(n: BigInt)(implicit node: Cluster): PNCounter = decrement(node.selfUniqueAddress, n) /** @@ -145,7 +145,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def decrement(node: SelfUniqueAddress, n: Long): PNCounter = decrement(node.uniqueAddress, n) - @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def decrement(node: Cluster, n: Long = 1): PNCounter = decrement(node.selfUniqueAddress, n) /** @@ -154,7 +154,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p */ def decrement(node: SelfUniqueAddress, n: BigInt): PNCounter = decrement(node.uniqueAddress, n) - @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def decrement(node: Cluster, n: BigInt): PNCounter = decrement(node.selfUniqueAddress, n) /** @@ -164,7 +164,7 @@ final class PNCounter private[pekko] (private[pekko] val increments: GCounter, p def decrement(node: SelfUniqueAddress, n: java.math.BigInteger): PNCounter = decrement(node.uniqueAddress, n) @Deprecated - @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def decrement(node: Cluster, n: java.math.BigInteger): PNCounter = decrement(node.selfUniqueAddress, n) /** Internal API */ diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounterMap.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounterMap.scala index 7452276f37..98d7749a04 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounterMap.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/PNCounterMap.scala @@ -105,7 +105,7 @@ final class PNCounterMap[A] private[pekko] (private[pekko] val underlying: ORMap def increment(node: SelfUniqueAddress, key: A, delta: Long): PNCounterMap[A] = increment(node.uniqueAddress, key, delta) - @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def increment(node: Cluster, key: A, delta: Long): PNCounterMap[A] = increment(node.selfUniqueAddress, key, delta) @@ -131,7 +131,7 @@ final class PNCounterMap[A] private[pekko] (private[pekko] val underlying: ORMap def decrement(node: SelfUniqueAddress, key: A, delta: Long): PNCounterMap[A] = decrement(node.uniqueAddress, key, delta) - @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def decrement(key: A, delta: Long = 1)(implicit node: Cluster): PNCounterMap[A] = decrement(node.selfUniqueAddress, key, delta) @@ -139,7 +139,7 @@ final class PNCounterMap[A] private[pekko] (private[pekko] val underlying: ORMap * Decrement the counter with the delta specified. * If the delta is negative then it will increment instead of decrement. */ - @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `decrement` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def decrement(node: Cluster, key: A, delta: Long): PNCounterMap[A] = decrement(node.selfUniqueAddress, key, delta) @@ -158,11 +158,11 @@ final class PNCounterMap[A] private[pekko] (private[pekko] val underlying: ORMap def remove(key: A)(implicit node: SelfUniqueAddress): PNCounterMap[A] = remove(node.uniqueAddress, key) - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def remove(node: Cluster, key: A): PNCounterMap[A] = remove(node.selfUniqueAddress, key) - @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `remove` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def -(key: A)(implicit node: Cluster): PNCounterMap[A] = remove(node, key) /** diff --git a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/VersionVector.scala b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/VersionVector.scala index 6cc250f662..455ee8766b 100644 --- a/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/VersionVector.scala +++ b/distributed-data/src/main/scala/org/apache/pekko/cluster/ddata/VersionVector.scala @@ -120,7 +120,7 @@ sealed abstract class VersionVector extends ReplicatedData with ReplicatedDataSe */ def :+(node: SelfUniqueAddress): VersionVector = increment(node) - @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `:+` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def +(node: Cluster): VersionVector = increment(node.selfUniqueAddress) /** @@ -134,7 +134,7 @@ sealed abstract class VersionVector extends ReplicatedData with ReplicatedDataSe */ def increment(node: SelfUniqueAddress): VersionVector = increment(node.uniqueAddress) - @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "2.5.20") + @deprecated("Use `increment` that takes a `SelfUniqueAddress` parameter instead.", since = "Akka 2.5.20") def increment(node: Cluster): VersionVector = increment(node.selfUniqueAddress) def isEmpty: Boolean diff --git a/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStateFunctionBuilder.java b/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStateFunctionBuilder.java index fde4748f9d..29aa7f7ffa 100644 --- a/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStateFunctionBuilder.java +++ b/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStateFunctionBuilder.java @@ -22,7 +22,7 @@ import java.util.List; /** * Builder used to create a partial function for {@link org.apache.pekko.actor.FSM#whenUnhandled}. * - * @deprecated use EventSourcedBehavior since 2.6.0 + * @deprecated use EventSourcedBehavior since Akka 2.6.0 * @param the state type * @param the data type * @param the domain event type diff --git a/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStopBuilder.java b/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStopBuilder.java index ef438b3c97..04832178df 100644 --- a/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStopBuilder.java +++ b/persistence/src/main/java/org/apache/pekko/persistence/fsm/japi/pf/FSMStopBuilder.java @@ -21,7 +21,7 @@ import scala.runtime.BoxedUnit; /** * Builder used to create a partial function for {@link org.apache.pekko.actor.FSM#onTermination}. * - * @deprecated use EventSourcedBehavior since 2.6.0 + * @deprecated use EventSourcedBehavior since Akka 2.6.0 * @param the state type * @param the data type */ diff --git a/persistence/src/main/scala/org/apache/pekko/persistence/fsm/PersistentFSMBase.scala b/persistence/src/main/scala/org/apache/pekko/persistence/fsm/PersistentFSMBase.scala index 03fcc92b6c..8b07ab2af7 100644 --- a/persistence/src/main/scala/org/apache/pekko/persistence/fsm/PersistentFSMBase.scala +++ b/persistence/src/main/scala/org/apache/pekko/persistence/fsm/PersistentFSMBase.scala @@ -282,7 +282,7 @@ trait PersistentFSMBase[S, D, E] extends Actor with Listeners with ActorLogging @deprecated( "Use startSingleTimer, startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final def setTimer(name: String, msg: Any, timeout: FiniteDuration, repeat: Boolean = false): Unit = { // repeat => FixedRateMode for compatibility val mode = if (repeat) FixedRateMode else SingleMode @@ -1167,7 +1167,7 @@ abstract class AbstractPersistentFSMBase[S, D, E] extends PersistentFSMBase[S, D * @param msg message to be delivered * @param timeout delay of first message delivery and between subsequent messages */ - @deprecated("Use startSingleTimer instead.", since = "2.6.0") + @deprecated("Use startSingleTimer instead.", since = "Akka 2.6.0") final def setTimer(name: String, msg: Any, timeout: FiniteDuration): Unit = setTimer(name, msg, timeout, false) diff --git a/persistence/src/main/scala/org/apache/pekko/persistence/state/javadsl/DurableStateUpdateStore.scala b/persistence/src/main/scala/org/apache/pekko/persistence/state/javadsl/DurableStateUpdateStore.scala index 232f7a73fd..3533299f29 100644 --- a/persistence/src/main/scala/org/apache/pekko/persistence/state/javadsl/DurableStateUpdateStore.scala +++ b/persistence/src/main/scala/org/apache/pekko/persistence/state/javadsl/DurableStateUpdateStore.scala @@ -30,7 +30,7 @@ trait DurableStateUpdateStore[A] extends DurableStateStore[A] { */ def upsertObject(persistenceId: String, revision: Long, value: A, tag: String): CompletionStage[Done] - @deprecated(message = "Use the deleteObject overload with revision instead.", since = "2.6.20") + @deprecated(message = "Use the deleteObject overload with revision instead.", since = "Akka 2.6.20") def deleteObject(persistenceId: String): CompletionStage[Done] def deleteObject(persistenceId: String, revision: Long): CompletionStage[Done] diff --git a/persistence/src/main/scala/org/apache/pekko/persistence/state/scaladsl/DurableStateUpdateStore.scala b/persistence/src/main/scala/org/apache/pekko/persistence/state/scaladsl/DurableStateUpdateStore.scala index 57482e4908..f24fe46987 100644 --- a/persistence/src/main/scala/org/apache/pekko/persistence/state/scaladsl/DurableStateUpdateStore.scala +++ b/persistence/src/main/scala/org/apache/pekko/persistence/state/scaladsl/DurableStateUpdateStore.scala @@ -30,7 +30,7 @@ trait DurableStateUpdateStore[A] extends DurableStateStore[A] { */ def upsertObject(persistenceId: String, revision: Long, value: A, tag: String): Future[Done] - @deprecated(message = "Use the deleteObject overload with revision instead.", since = "2.6.20") + @deprecated(message = "Use the deleteObject overload with revision instead.", since = "Akka 2.6.20") def deleteObject(persistenceId: String): Future[Done] def deleteObject(persistenceId: String, revision: Long): Future[Done] diff --git a/remote/src/main/scala/org/apache/pekko/remote/transport/FailureInjectorTransportAdapter.scala b/remote/src/main/scala/org/apache/pekko/remote/transport/FailureInjectorTransportAdapter.scala index 8010b5d8de..b8ad2960bd 100644 --- a/remote/src/main/scala/org/apache/pekko/remote/transport/FailureInjectorTransportAdapter.scala +++ b/remote/src/main/scala/org/apache/pekko/remote/transport/FailureInjectorTransportAdapter.scala @@ -197,7 +197,7 @@ private[remote] final case class FailureInjectorHandle( @deprecated( message = "Use method that states reasons to make sure disassociation reasons are logged.", - since = "2.5.3") + since = "Akka 2.5.3") @nowarn("msg=deprecated") override def disassociate(): Unit = wrappedHandle.disassociate() diff --git a/remote/src/main/scala/org/apache/pekko/remote/transport/Transport.scala b/remote/src/main/scala/org/apache/pekko/remote/transport/Transport.scala index 45e5729926..0ce186644c 100644 --- a/remote/src/main/scala/org/apache/pekko/remote/transport/Transport.scala +++ b/remote/src/main/scala/org/apache/pekko/remote/transport/Transport.scala @@ -284,7 +284,7 @@ trait AssociationHandle { */ @deprecated( message = "Use method that states reasons to make sure disassociation reasons are logged.", - since = "2.5.3") + since = "Akka 2.5.3") def disassociate(): Unit /** diff --git a/stream-testkit/src/main/scala/org/apache/pekko/stream/testkit/StreamTestKit.scala b/stream-testkit/src/main/scala/org/apache/pekko/stream/testkit/StreamTestKit.scala index 440a4fe957..6805e01e5f 100644 --- a/stream-testkit/src/main/scala/org/apache/pekko/stream/testkit/StreamTestKit.scala +++ b/stream-testkit/src/main/scala/org/apache/pekko/stream/testkit/StreamTestKit.scala @@ -155,7 +155,7 @@ object TestPublisher { * Expect no messages. * NOTE! Timeout value is automatically multiplied by timeFactor. */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.5") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.5") def expectNoMsg(): Self = executeAfterSubscription { probe.expectNoMsg() self @@ -165,7 +165,7 @@ object TestPublisher { * Expect no messages for a given duration. * NOTE! Timeout value is automatically multiplied by timeFactor. */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.5") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.5") def expectNoMsg(max: FiniteDuration): Self = executeAfterSubscription { probe.expectNoMsg(max) self @@ -649,7 +649,7 @@ object TestSubscriber { * Same as `expectNoMsg(remaining)`, but correctly treating the timeFactor. * NOTE! Timeout value is automatically multiplied by timeFactor. */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.5") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.5") def expectNoMsg(): Self = { probe.expectNoMsg() self @@ -661,7 +661,7 @@ object TestSubscriber { * Assert that no message is received for the specified time. * NOTE! Timeout value is automatically multiplied by timeFactor. */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.5") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.5") def expectNoMsg(remaining: FiniteDuration): Self = { probe.expectNoMsg(remaining) self diff --git a/stream/src/main/scala/org/apache/pekko/stream/Materializer.scala b/stream/src/main/scala/org/apache/pekko/stream/Materializer.scala index 278412def4..c293dcc5b2 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/Materializer.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/Materializer.scala @@ -154,7 +154,7 @@ abstract class Materializer { @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") def schedulePeriodically(initialDelay: FiniteDuration, interval: FiniteDuration, task: Runnable): Cancellable /** diff --git a/stream/src/main/scala/org/apache/pekko/stream/StreamRefSettings.scala b/stream/src/main/scala/org/apache/pekko/stream/StreamRefSettings.scala index 4f3515a2de..eef6750e5f 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/StreamRefSettings.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/StreamRefSettings.scala @@ -31,13 +31,13 @@ object StreamRefSettings { /** Java API */ @deprecated( "Use attributes on the Runnable graph or change the defaults in configuration, see migration guide for details https://doc.akka.io/docs/akka/2.6/project/migration-guide-2.5.x-2.6.x.html", - since = "2.6.0") + since = "Akka 2.6.0") def create(system: ActorSystem): StreamRefSettings = apply(system) /** Scala API */ @deprecated( "Use attributes on the Runnable graph or change the defaults in configuration, see migration guide for details https://doc.akka.io/docs/akka/2.6/project/migration-guide-2.5.x-2.6.x.html", - since = "2.6.0") + since = "Akka 2.6.0") def apply(system: ActorSystem): StreamRefSettings = { apply(system.settings.config.getConfig("pekko.stream.materializer.stream-ref")) } @@ -45,13 +45,13 @@ object StreamRefSettings { /** Java API */ @deprecated( "Use attributes on the Runnable graph or change the defaults in configuration, see migration guide for details https://doc.akka.io/docs/akka/2.6/project/migration-guide-2.5.x-2.6.x.html", - since = "2.6.0") + since = "Akka 2.6.0") def create(c: Config): StreamRefSettings = apply(c) /** Scala API */ @deprecated( "Use attributes on the Runnable graph or change the defaults in configuration, see migration guide for details https://doc.akka.io/docs/akka/2.6/project/migration-guide-2.5.x-2.6.x.html", - since = "2.6.0") + since = "Akka 2.6.0") def apply(c: Config): StreamRefSettings = { StreamRefSettingsImpl( bufferCapacity = c.getInt("buffer-capacity"), diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/BidiFlow.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/BidiFlow.scala index ccde159c40..81cd402d8c 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/BidiFlow.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/BidiFlow.scala @@ -105,7 +105,7 @@ object BidiFlow { * the *joint* frequencies of the elements in both directions. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def bidirectionalIdleTimeout[I, O](timeout: FiniteDuration): BidiFlow[I, I, O, O, NotUsed] = new BidiFlow(scaladsl.BidiFlow.bidirectionalIdleTimeout(timeout)) diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/Flow.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/Flow.scala index 29881fd5e8..87c87d7010 100755 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/Flow.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/Flow.scala @@ -1323,7 +1323,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWithin(maxNumber: Int, duration: FiniteDuration): javadsl.Flow[In, java.util.List[Out], Mat] = new Flow(delegate.groupedWithin(maxNumber, duration).map(_.asJava)) // TODO optimize to one step @@ -1368,7 +1368,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWeightedWithin( maxWeight: Long, costFn: function.Function[Out, java.lang.Long], @@ -1452,7 +1452,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * @param strategy Strategy that is used when incoming elements cannot fit inside the buffer */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): Flow[In, Out, Mat] = new Flow(delegate.delay(of, strategy)) @@ -1548,7 +1548,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def dropWithin(duration: FiniteDuration): javadsl.Flow[In, Out, Mat] = new Flow(delegate.dropWithin(duration)) @@ -1872,7 +1872,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * See also [[Flow.limit]], [[Flow.limitWeighted]] */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def takeWithin(duration: FiniteDuration): javadsl.Flow[In, Out, Mat] = new Flow(delegate.takeWithin(duration)) @@ -3380,7 +3380,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] = new Flow(delegate.initialTimeout(timeout)) @@ -3413,7 +3413,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def completionTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] = new Flow(delegate.completionTimeout(timeout)) @@ -3447,7 +3447,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def idleTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] = new Flow(delegate.idleTimeout(timeout)) @@ -3482,7 +3482,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def backpressureTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] = new Flow(delegate.backpressureTimeout(timeout)) @@ -3521,7 +3521,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def keepAlive(maxIdle: FiniteDuration, injectedElem: function.Creator[Out]): javadsl.Flow[In, Out, Mat] = new Flow(delegate.keepAlive(maxIdle, () => injectedElem.create())) @@ -3614,7 +3614,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle(elements: Int, per: FiniteDuration, maximumBurst: Int, mode: ThrottleMode): javadsl.Flow[In, Out, Mat] = new Flow(delegate.throttle(elements, per, maximumBurst, mode)) @@ -3699,7 +3699,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle( cost: Int, per: FiniteDuration, @@ -3802,7 +3802,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * @see [[#throttle]] */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttleEven(elements: Int, per: FiniteDuration, mode: ThrottleMode): javadsl.Flow[In, Out, Mat] = new Flow(delegate.throttleEven(elements, per, mode)) @@ -3929,7 +3929,7 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialDelay(delay: FiniteDuration): javadsl.Flow[In, Out, Mat] = new Flow(delegate.initialDelay(delay)) diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartFlow.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartFlow.scala index 9b00716cdb..a380494c4e 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartFlow.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartFlow.scala @@ -53,7 +53,7 @@ object RestartFlow { * @param flowFactory A factory for producing the [[Flow]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def withBackoff[In, Out]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -88,7 +88,7 @@ object RestartFlow { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[In, Out]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, @@ -124,7 +124,7 @@ object RestartFlow { * @param flowFactory A factory for producing the [[Flow]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def withBackoff[In, Out]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -162,7 +162,7 @@ object RestartFlow { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[In, Out]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, @@ -224,7 +224,7 @@ object RestartFlow { * @param flowFactory A factory for producing the [[Flow]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def onFailuresWithBackoff[In, Out]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -262,7 +262,7 @@ object RestartFlow { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def onFailuresWithBackoff[In, Out]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSink.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSink.scala index d504082f0a..4c6942091d 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSink.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSink.scala @@ -54,7 +54,7 @@ object RestartSink { * @param sinkFactory A factory for producing the [[Sink]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def withBackoff[T]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -90,7 +90,7 @@ object RestartSink { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, @@ -127,7 +127,7 @@ object RestartSink { * @param sinkFactory A factory for producing the [[Sink]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def withBackoff[T]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -166,7 +166,7 @@ object RestartSink { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSource.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSource.scala index 76eaf6c33b..222e3e70fb 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSource.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/RestartSource.scala @@ -50,7 +50,7 @@ object RestartSource { * @param sourceFactory A factory for producing the [[Source]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def withBackoff[T]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -82,7 +82,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, @@ -116,7 +116,7 @@ object RestartSource { * @param sourceFactory A factory for producing the [[Source]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def withBackoff[T]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -152,7 +152,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, @@ -206,7 +206,7 @@ object RestartSource { * @param sourceFactory A factory for producing the [[Source]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def onFailuresWithBackoff[T]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -237,7 +237,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def onFailuresWithBackoff[T]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, @@ -269,7 +269,7 @@ object RestartSource { * @param sourceFactory A factory for producing the [[Source]] to wrap. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def onFailuresWithBackoff[T]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -303,7 +303,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def onFailuresWithBackoff[T]( minBackoff: java.time.Duration, maxBackoff: java.time.Duration, diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/Sink.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/Sink.scala index 4351e82aa6..c7f1652f0a 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/Sink.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/Sink.scala @@ -166,7 +166,7 @@ object Sink { */ @deprecated( "Use `foreachAsync` instead, it allows you to choose how to run the procedure, by calling some other API returning a CompletionStage or using CompletableFuture.supplyAsync.", - since = "2.5.17") + since = "Akka 2.5.17") def foreachParallel[T](parallel: Int)(f: function.Procedure[T])( ec: ExecutionContext): Sink[T, CompletionStage[Done]] = new Sink(scaladsl.Sink.foreachParallel(parallel)(f.apply)(ec).toCompletionStage()) diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/Source.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/Source.scala index 920a795ce6..4d2d64f18d 100755 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/Source.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/Source.scala @@ -235,7 +235,7 @@ object Source { * receive new tick elements as soon as it has requested more elements. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def tick[O](initialDelay: FiniteDuration, interval: FiniteDuration, tick: O): javadsl.Source[O, Cancellable] = new Source(scaladsl.Source.tick(initialDelay, interval, tick)) @@ -2992,7 +2992,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWithin( maxNumber: Int, duration: FiniteDuration): javadsl.Source[java.util.List[Out @uncheckedVariance], Mat] = @@ -3041,7 +3041,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWeightedWithin( maxWeight: Long, costFn: function.Function[Out, java.lang.Long], @@ -3125,7 +3125,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * @param strategy Strategy that is used when incoming elements cannot fit inside the buffer */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): Source[Out, Mat] = new Source(delegate.delay(of, strategy)) @@ -3221,7 +3221,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def dropWithin(duration: FiniteDuration): javadsl.Source[Out, Mat] = new Source(delegate.dropWithin(duration)) @@ -3341,7 +3341,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels or timer fires */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def takeWithin(duration: FiniteDuration): javadsl.Source[Out, Mat] = new Source(delegate.takeWithin(duration)) @@ -3935,7 +3935,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] = new Source(delegate.initialTimeout(timeout)) @@ -3968,7 +3968,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def completionTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] = new Source(delegate.completionTimeout(timeout)) @@ -4002,7 +4002,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def idleTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] = new Source(delegate.idleTimeout(timeout)) @@ -4037,7 +4037,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def backpressureTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] = new Source(delegate.backpressureTimeout(timeout)) @@ -4076,7 +4076,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def keepAlive(maxIdle: FiniteDuration, injectedElem: function.Creator[Out]): javadsl.Source[Out, Mat] = new Source(delegate.keepAlive(maxIdle, () => injectedElem.create())) @@ -4169,7 +4169,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle(elements: Int, per: FiniteDuration, maximumBurst: Int, mode: ThrottleMode): javadsl.Source[Out, Mat] = new Source(delegate.throttle(elements, per, maximumBurst, mode)) @@ -4291,7 +4291,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle( cost: Int, per: FiniteDuration, @@ -4482,7 +4482,7 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[ * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialDelay(delay: FiniteDuration): javadsl.Source[Out, Mat] = new Source(delegate.initialDelay(delay)) diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/StreamConverters.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/StreamConverters.scala index ef3aa29a37..2b1d7d0e22 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/StreamConverters.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/StreamConverters.scala @@ -104,7 +104,7 @@ object StreamConverters { * @param readTimeout the max time the read operation on the materialized InputStream should block */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def asInputStream(readTimeout: FiniteDuration): Sink[ByteString, InputStream] = new Sink(scaladsl.StreamConverters.asInputStream(readTimeout)) @@ -180,7 +180,7 @@ object StreamConverters { * @param writeTimeout the max time the write operation on the materialized OutputStream should block */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def asOutputStream(writeTimeout: FiniteDuration): javadsl.Source[ByteString, OutputStream] = new Source(scaladsl.StreamConverters.asOutputStream(writeTimeout)) diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubFlow.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubFlow.scala index 74347eb76a..7d0ad63ab8 100755 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubFlow.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubFlow.scala @@ -724,7 +724,7 @@ class SubFlow[In, Out, Mat]( * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWithin( maxNumber: Int, duration: FiniteDuration): SubFlow[In, java.util.List[Out @uncheckedVariance], Mat] = @@ -773,7 +773,7 @@ class SubFlow[In, Out, Mat]( * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWeightedWithin( maxWeight: Long, costFn: function.Function[Out, java.lang.Long], @@ -857,7 +857,7 @@ class SubFlow[In, Out, Mat]( * @param strategy Strategy that is used when incoming elements cannot fit inside the buffer */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): SubFlow[In, Out, Mat] = new SubFlow(delegate.delay(of, strategy)) @@ -953,7 +953,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def dropWithin(duration: FiniteDuration): SubFlow[In, Out, Mat] = new SubFlow(delegate.dropWithin(duration)) @@ -1183,7 +1183,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels or timer fires */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def takeWithin(duration: FiniteDuration): SubFlow[In, Out, Mat] = new SubFlow(delegate.takeWithin(duration)) @@ -2018,7 +2018,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialTimeout(timeout: FiniteDuration): SubFlow[In, Out, Mat] = new SubFlow(delegate.initialTimeout(timeout)) @@ -2051,7 +2051,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def completionTimeout(timeout: FiniteDuration): SubFlow[In, Out, Mat] = new SubFlow(delegate.completionTimeout(timeout)) @@ -2085,7 +2085,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def idleTimeout(timeout: FiniteDuration): SubFlow[In, Out, Mat] = new SubFlow(delegate.idleTimeout(timeout)) @@ -2120,7 +2120,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def backpressureTimeout(timeout: FiniteDuration): SubFlow[In, Out, Mat] = new SubFlow(delegate.backpressureTimeout(timeout)) @@ -2159,7 +2159,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def keepAlive(maxIdle: FiniteDuration, injectedElem: function.Creator[Out]): SubFlow[In, Out, Mat] = new SubFlow(delegate.keepAlive(maxIdle, () => injectedElem.create())) @@ -2252,7 +2252,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle( elements: Int, per: FiniteDuration, @@ -2378,7 +2378,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle( cost: Int, per: FiniteDuration, @@ -2527,7 +2527,7 @@ class SubFlow[In, Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialDelay(delay: FiniteDuration): SubFlow[In, Out, Mat] = new SubFlow(delegate.initialDelay(delay)) diff --git a/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubSource.scala b/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubSource.scala index b90f47b9b1..9207afc02a 100755 --- a/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubSource.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/javadsl/SubSource.scala @@ -713,7 +713,7 @@ class SubSource[Out, Mat]( * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWithin(maxNumber: Int, duration: FiniteDuration): SubSource[java.util.List[Out @uncheckedVariance], Mat] = new SubSource(delegate.groupedWithin(maxNumber, duration).map(_.asJava)) // TODO optimize to one step @@ -760,7 +760,7 @@ class SubSource[Out, Mat]( * IllegalArgumentException is thrown. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def groupedWeightedWithin( maxWeight: Long, costFn: function.Function[Out, java.lang.Long], @@ -845,7 +845,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def dropWithin(duration: FiniteDuration): SubSource[Out, Mat] = new SubSource(delegate.dropWithin(duration)) @@ -948,7 +948,7 @@ class SubSource[Out, Mat]( * @param strategy Strategy that is used when incoming elements cannot fit inside the buffer */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): SubSource[Out, Mat] = new SubSource(delegate.delay(of, strategy)) @@ -1161,7 +1161,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels or timer fires */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def takeWithin(duration: FiniteDuration): SubSource[Out, Mat] = new SubSource(delegate.takeWithin(duration)) @@ -1995,7 +1995,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialTimeout(timeout: FiniteDuration): SubSource[Out, Mat] = new SubSource(delegate.initialTimeout(timeout)) @@ -2028,7 +2028,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def completionTimeout(timeout: FiniteDuration): SubSource[Out, Mat] = new SubSource(delegate.completionTimeout(timeout)) @@ -2062,7 +2062,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def idleTimeout(timeout: FiniteDuration): SubSource[Out, Mat] = new SubSource(delegate.idleTimeout(timeout)) @@ -2097,7 +2097,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def backpressureTimeout(timeout: FiniteDuration): SubSource[Out, Mat] = new SubSource(delegate.backpressureTimeout(timeout)) @@ -2136,7 +2136,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def keepAlive(maxIdle: FiniteDuration, injectedElem: function.Creator[Out]): SubSource[Out, Mat] = new SubSource(delegate.keepAlive(maxIdle, () => injectedElem.create())) @@ -2229,7 +2229,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle(elements: Int, per: FiniteDuration, maximumBurst: Int, mode: ThrottleMode): javadsl.SubSource[Out, Mat] = new SubSource(delegate.throttle(elements, per, maximumBurst, mode)) @@ -2351,7 +2351,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def throttle( cost: Int, per: FiniteDuration, @@ -2500,7 +2500,7 @@ class SubSource[Out, Mat]( * '''Cancels when''' downstream cancels */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def initialDelay(delay: FiniteDuration): SubSource[Out, Mat] = new SubSource(delegate.initialDelay(delay)) diff --git a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Graph.scala b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Graph.scala index 043d7ca9c0..71cfd22453 100755 --- a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Graph.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Graph.scala @@ -944,7 +944,7 @@ final class Balance[T](val outputPorts: Int, val waitForAllDownstreams: Boolean, require(outputPorts >= 1, "A Balance must have one or more output ports") @Deprecated - @deprecated("Use the constructor which also specifies the `eagerCancel` parameter", since = "2.5.12") + @deprecated("Use the constructor which also specifies the `eagerCancel` parameter", since = "Akka 2.5.12") def this(outputPorts: Int, waitForAllDownstreams: Boolean) = this(outputPorts, waitForAllDownstreams, false) val in: Inlet[T] = Inlet[T]("Balance.in") diff --git a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartFlow.scala b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartFlow.scala index 1a15c37195..e49dc1b690 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartFlow.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartFlow.scala @@ -62,7 +62,7 @@ object RestartFlow { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[In, Out](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)( flowFactory: () => Flow[In, Out, _]): Flow[In, Out, NotUsed] = { val settings = RestartSettings(minBackoff, maxBackoff, randomFactor) @@ -96,7 +96,7 @@ object RestartFlow { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[In, Out]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, @@ -155,7 +155,7 @@ object RestartFlow { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def onFailuresWithBackoff[In, Out]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, diff --git a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSink.scala b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSink.scala index 06b0d541bd..572cfe7998 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSink.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSink.scala @@ -55,7 +55,7 @@ object RestartSink { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)( sinkFactory: () => Sink[T, _]): Sink[T, NotUsed] = { val settings = RestartSettings(minBackoff, maxBackoff, randomFactor) @@ -90,7 +90,7 @@ object RestartSink { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double, maxRestarts: Int)( sinkFactory: () => Sink[T, _]): Sink[T, NotUsed] = { val settings = RestartSettings(minBackoff, maxBackoff, randomFactor).withMaxRestarts(maxRestarts, minBackoff) diff --git a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSource.scala b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSource.scala index e06d6eaccc..6e0663e794 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSource.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/RestartSource.scala @@ -51,7 +51,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)( sourceFactory: () => Source[T, _]): Source[T, NotUsed] = { val settings = RestartSettings(minBackoff, maxBackoff, randomFactor) @@ -83,7 +83,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double, maxRestarts: Int)( sourceFactory: () => Source[T, _]): Source[T, NotUsed] = { val settings = RestartSettings(minBackoff, maxBackoff, randomFactor).withMaxRestarts(maxRestarts, minBackoff) @@ -131,7 +131,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def onFailuresWithBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)( sourceFactory: () => Source[T, _]): Source[T, NotUsed] = { val settings = RestartSettings(minBackoff, maxBackoff, randomFactor) @@ -162,7 +162,7 @@ object RestartSource { */ @Deprecated @deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.", - since = "2.6.10") + since = "Akka 2.6.10") def onFailuresWithBackoff[T]( minBackoff: FiniteDuration, maxBackoff: FiniteDuration, diff --git a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Sink.scala b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Sink.scala index 18a5fb4418..07d5207843 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Sink.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/scaladsl/Sink.scala @@ -370,7 +370,7 @@ object Sink { */ @deprecated( "Use `foreachAsync` instead, it allows you to choose how to run the procedure, by calling some other API returning a Future or spawning a new Future.", - since = "2.5.17") + since = "Akka 2.5.17") def foreachParallel[T](parallelism: Int)(f: T => Unit)(implicit ec: ExecutionContext): Sink[T, Future[Done]] = Flow[T].mapAsyncUnordered(parallelism)(t => Future(f(t))).toMat(Sink.ignore)(Keep.right) diff --git a/stream/src/main/scala/org/apache/pekko/stream/stage/GraphStage.scala b/stream/src/main/scala/org/apache/pekko/stream/stage/GraphStage.scala index 6727a5b9d4..05adf1bd0c 100644 --- a/stream/src/main/scala/org/apache/pekko/stream/stage/GraphStage.scala +++ b/stream/src/main/scala/org/apache/pekko/stream/stage/GraphStage.scala @@ -1798,7 +1798,7 @@ abstract class TimerGraphStageLogic(_shape: Shape) extends GraphStageLogic(_shap @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final protected def schedulePeriodicallyWithInitialDelay( timerKey: Any, initialDelay: FiniteDuration, @@ -1814,7 +1814,7 @@ abstract class TimerGraphStageLogic(_shape: Shape) extends GraphStageLogic(_shap @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final protected def schedulePeriodicallyWithInitialDelay( timerKey: Any, initialDelay: java.time.Duration, @@ -1831,7 +1831,7 @@ abstract class TimerGraphStageLogic(_shape: Shape) extends GraphStageLogic(_shap @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final protected def schedulePeriodically(timerKey: Any, interval: FiniteDuration): Unit = schedulePeriodicallyWithInitialDelay(timerKey, interval, interval) @@ -1843,7 +1843,7 @@ abstract class TimerGraphStageLogic(_shape: Shape) extends GraphStageLogic(_shap @deprecated( "Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as " + "scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") final protected def schedulePeriodically(timerKey: Any, interval: java.time.Duration): Unit = { import pekko.util.JavaDurationConverters._ schedulePeriodically(timerKey, interval.asScala) @@ -1917,8 +1917,8 @@ trait OutHandler { * be called for this port. */ @throws(classOf[Exception]) - @deprecatedOverriding("Override `def onDownstreamFinish(cause: Throwable)`, instead.", since = "2.6.0") // warns when overriding - @deprecated("Call onDownstreamFinish with a cancellation cause.", since = "2.6.0") // warns when calling + @deprecatedOverriding("Override `def onDownstreamFinish(cause: Throwable)`, instead.", since = "Akka 2.6.0") // warns when overriding + @deprecated("Call onDownstreamFinish with a cancellation cause.", since = "Akka 2.6.0") // warns when calling def onDownstreamFinish(): Unit = { val thisStage = GraphInterpreter.currentInterpreter.activeStage require( diff --git a/testkit/src/main/scala/org/apache/pekko/testkit/TestFSMRef.scala b/testkit/src/main/scala/org/apache/pekko/testkit/TestFSMRef.scala index 084ab1d16c..f6a613b19d 100644 --- a/testkit/src/main/scala/org/apache/pekko/testkit/TestFSMRef.scala +++ b/testkit/src/main/scala/org/apache/pekko/testkit/TestFSMRef.scala @@ -97,7 +97,7 @@ class TestFSMRef[S, D, T <: Actor](system: ActorSystem, props: Props, supervisor @deprecated( "Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as " + "startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred.", - since = "2.6.0") + since = "Akka 2.6.0") def setTimer(name: String, msg: Any, timeout: FiniteDuration, repeat: Boolean = false): Unit = { fsm.setTimer(name, msg, timeout, repeat) } diff --git a/testkit/src/main/scala/org/apache/pekko/testkit/TestKit.scala b/testkit/src/main/scala/org/apache/pekko/testkit/TestKit.scala index a9699aaaa9..d51d71ee2d 100644 --- a/testkit/src/main/scala/org/apache/pekko/testkit/TestKit.scala +++ b/testkit/src/main/scala/org/apache/pekko/testkit/TestKit.scala @@ -724,14 +724,14 @@ trait TestKitBase { * `pekko.test.expect-no-message-default`. * That timeout is scaled using the configuration entry "pekko.test.timefactor". */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.5") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.5") def expectNoMsg(): Unit = expectNoMessage() /** * Assert that no message is received for the specified time. * NOTE! Supplied value is always dilated. */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.5") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.5") def expectNoMsg(max: FiniteDuration): Unit = { expectNoMsg_internal(max.dilated) } diff --git a/testkit/src/main/scala/org/apache/pekko/testkit/javadsl/TestKit.scala b/testkit/src/main/scala/org/apache/pekko/testkit/javadsl/TestKit.scala index a034f4b7a7..eb1a8c32a3 100644 --- a/testkit/src/main/scala/org/apache/pekko/testkit/javadsl/TestKit.scala +++ b/testkit/src/main/scala/org/apache/pekko/testkit/javadsl/TestKit.scala @@ -80,7 +80,7 @@ class TestKit(system: ActorSystem) { * Scale timeouts (durations) during tests with the configured */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def dilated(d: FiniteDuration): FiniteDuration = d.dilated(getSystem) /** @@ -154,7 +154,7 @@ class TestKit(system: ActorSystem) { * call. */ @Deprecated - @deprecated("Use getRemaining which returns java.time.Duration instead.", since = "2.5.12") + @deprecated("Use getRemaining which returns java.time.Duration instead.", since = "Akka 2.5.12") def remaining: FiniteDuration = tp.remaining /** @@ -169,7 +169,7 @@ class TestKit(system: ActorSystem) { * block or missing that it returns the given duration. */ @Deprecated - @deprecated("Use getRemainingOr which returns java.time.Duration instead.", since = "2.5.12") + @deprecated("Use getRemainingOr which returns java.time.Duration instead.", since = "Akka 2.5.12") def remainingOr(fd: FiniteDuration): FiniteDuration = tp.remainingOr(fd) /** @@ -184,7 +184,7 @@ class TestKit(system: ActorSystem) { * case from settings (key "pekko.test.single-expect-default"). */ @Deprecated - @deprecated("Use getRemainingOrDefault which returns java.time.Duration instead.", since = "2.5.12") + @deprecated("Use getRemainingOrDefault which returns java.time.Duration instead.", since = "Akka 2.5.12") def remainingOrDefault: FiniteDuration = tp.remainingOrDefault /** @@ -213,7 +213,7 @@ class TestKit(system: ActorSystem) { * }}} */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def within[T](min: FiniteDuration, max: FiniteDuration, f: Supplier[T]): T = tp.within(min, max)(f.get) /** @@ -256,7 +256,7 @@ class TestKit(system: ActorSystem) { * }}} */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def within[T](max: FiniteDuration, f: Supplier[T]): T = tp.within(max)(f.get) /** @@ -302,7 +302,7 @@ class TestKit(system: ActorSystem) { * which uses the configuration entry "pekko.test.timefactor". */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def awaitCond(max: Duration, p: Supplier[Boolean]): Unit = tp.awaitCond(p.get, max) /** @@ -328,7 +328,7 @@ class TestKit(system: ActorSystem) { * which uses the configuration entry "pekko.test.timefactor". */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def awaitCond(max: Duration, interval: Duration, p: Supplier[Boolean]): Unit = tp.awaitCond(p.get, max, interval) @@ -356,7 +356,7 @@ class TestKit(system: ActorSystem) { * which uses the configuration entry "pekko.test.timefactor". */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def awaitCond(max: Duration, interval: Duration, message: String, p: Supplier[Boolean]): Unit = tp.awaitCond(p.get, max, interval, message) @@ -400,7 +400,7 @@ class TestKit(system: ActorSystem) { * which uses the configuration entry "pekko.test.timefactor". */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.13") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.13") def awaitAssert[A](max: Duration, a: Supplier[A]): A = tp.awaitAssert(a.get, max) /** @@ -427,7 +427,7 @@ class TestKit(system: ActorSystem) { * @return an arbitrary value that would be returned from awaitAssert if successful, if not interested in such value you can return null. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.13") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.13") def awaitAssert[A](max: Duration, interval: Duration, a: Supplier[A]): A = tp.awaitAssert(a.get, max, interval) /** @@ -455,7 +455,7 @@ class TestKit(system: ActorSystem) { * @return the received object */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectMsgEquals[T](max: FiniteDuration, obj: T): T = tp.expectMsg(max, obj) /** @@ -478,7 +478,7 @@ class TestKit(system: ActorSystem) { * AssertionFailure being thrown in case of timeout. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectMsg[T](max: FiniteDuration, obj: T): T = tp.expectMsg(max, obj) /** @@ -494,7 +494,7 @@ class TestKit(system: ActorSystem) { * AssertionFailure being thrown in case of timeout. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectMsg[T](max: FiniteDuration, obj: T, hint: String): T = tp.expectMsg(max, hint, obj) /** @@ -527,7 +527,7 @@ class TestKit(system: ActorSystem) { * Use this variant to implement more complicated or conditional * processing. */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.6.0") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.6.0") def expectMsgPF[T](max: Duration, hint: String, f: JFunction[Any, T]): T = { tp.expectMsgPF(max, hint)(new CachingPartialFunction[Any, T] { @throws(classOf[Exception]) @@ -557,7 +557,7 @@ class TestKit(system: ActorSystem) { * AssertionFailure being thrown in case of timeout. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectMsgClass[T](max: FiniteDuration, c: Class[T]): T = tp.expectMsgClass(max, c) /** @@ -580,7 +580,7 @@ class TestKit(system: ActorSystem) { */ @varargs @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectMsgAnyOf[T](max: FiniteDuration, objs: T*): T = tp.expectMsgAnyOf(max, objs: _*) /** @@ -606,7 +606,7 @@ class TestKit(system: ActorSystem) { */ @varargs @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectMsgAllOf[T](max: FiniteDuration, objs: T*): JList[T] = tp.expectMsgAllOf(max, objs: _*).asJava /** @@ -633,7 +633,7 @@ class TestKit(system: ActorSystem) { */ @varargs @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectMsgAnyClassOf[T](max: FiniteDuration, objs: Class[_]*): T = tp.expectMsgAnyClassOf(max, objs: _*).asInstanceOf[T] @@ -651,7 +651,7 @@ class TestKit(system: ActorSystem) { * `pekko.actor.testkit.expect-no-message-default`. * That timeout is scaled using the configuration entry "pekko.actor.testkit.typed.timefactor". */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.10") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.10") def expectNoMsg(): Unit = tp.expectNoMessage() /** @@ -664,7 +664,7 @@ class TestKit(system: ActorSystem) { /** * Assert that no message is received for the specified time. */ - @deprecated(message = "Use expectNoMessage instead", since = "2.5.10") + @deprecated(message = "Use expectNoMessage instead", since = "Akka 2.5.10") def expectNoMsg(max: FiniteDuration): Unit = tp.expectNoMessage(max) /** @@ -672,7 +672,7 @@ class TestKit(system: ActorSystem) { * Supplied value is not dilated. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def expectNoMessage(max: FiniteDuration): Unit = tp.expectNoMessage(max) /** @@ -690,7 +690,7 @@ class TestKit(system: ActorSystem) { * @param target the actor ref expected to be Terminated * @return the received Terminated message */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.6.0") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.6.0") def expectTerminated(max: Duration, target: ActorRef): Terminated = tp.expectTerminated(target, max) /** @@ -722,7 +722,7 @@ class TestKit(system: ActorSystem) { * @return the last received message, i.e. the first one for which the * partial function returned true */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.6.0") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.6.0") def fishForMessage(max: Duration, hint: String, f: JFunction[Any, Boolean]): Any = tp.fishForMessage(max, hint)(new CachingPartialFunction[Any, Boolean] { @throws(classOf[Exception]) @@ -744,7 +744,7 @@ class TestKit(system: ActorSystem) { /** * Same as `fishForMessage`, but gets a different partial function and returns properly typed message. */ - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.6.0") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.6.0") def fishForSpecificMessage[T](max: Duration, hint: String, f: JFunction[Any, T]): T = { tp.fishForSpecificMessage(max, hint)(new CachingPartialFunction[Any, T] { @throws(classOf[Exception]) @@ -770,7 +770,7 @@ class TestKit(system: ActorSystem) { * Receive N messages in a row before the given deadline. */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.12") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12") def receiveN(n: Int, max: FiniteDuration): JList[AnyRef] = tp.receiveN(n, max).asJava @@ -786,7 +786,7 @@ class TestKit(system: ActorSystem) { * This method does NOT automatically scale its Duration parameter! */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.13") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.13") def receiveOne(max: Duration): AnyRef = tp.receiveOne(max) /** @@ -809,7 +809,7 @@ class TestKit(system: ActorSystem) { * certain characteristics are generated at a certain rate: */ @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.13") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.13") def receiveWhile[T](max: Duration, idle: Duration, messages: Int, f: JFunction[AnyRef, T]): JList[T] = { tp.receiveWhile(max, idle, messages)(new CachingPartialFunction[AnyRef, T] { @throws(classOf[Exception]) @@ -842,7 +842,7 @@ class TestKit(system: ActorSystem) { } @Deprecated - @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "2.5.13") + @deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.13") def receiveWhile[T](max: Duration, f: JFunction[AnyRef, T]): JList[T] = { tp.receiveWhile(max = max)(new CachingPartialFunction[AnyRef, T] { @throws(classOf[Exception])