Scala3 doc build does not like java @Deprecated mixed with Scala @deprecated (#406)

* Scala3 doc build does not like java `@Deprecated` mixed with Scala `@deprecated`

* Update ActorSource.scala
This commit is contained in:
PJ Fanning 2023-06-16 15:27:11 +01:00 committed by GitHub
parent a250fb9121
commit 01379c4171
No known key found for this signature in database
GPG key ID: 4AEE18F83AFDEB23
27 changed files with 0 additions and 152 deletions

View file

@ -1717,7 +1717,6 @@ object LogMarker {
apply(name, properties.asScala.toMap)
}
@Deprecated
@deprecated("use org.apache.pekko.event.LogEventWithMarker#marker instead", since = "Akka 2.5.12")
def extractFromMDC(mdc: MDC): Option[String] =
mdc.get(MDCKey) match {

View file

@ -26,7 +26,6 @@ import pekko.util.JavaDurationConverters._
/**
* @deprecated This API is superseded by the [[BackoffOpts]] object.
*/
@Deprecated
@deprecated("Use new API from BackoffOpts object instead", since = "Akka 2.5.22")
object Backoff {
@ -194,7 +193,6 @@ object Backoff {
* The supervisor will terminate itself after the maxNoOfRetries is reached.
* In order to restart infinitely pass in `-1`.
*/
@Deprecated
@deprecated("Use BackoffOpts.onFailure instead", "Akka 2.5.22")
def onFailure(
childProps: Props,
@ -251,7 +249,6 @@ object Backoff {
* 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
@deprecated("Use the overloaded one which accepts maxNrOfRetries instead.", "Akka 2.5.17")
def onFailure(
childProps: Props,
@ -446,7 +443,6 @@ object Backoff {
* The supervisor will terminate itself after the maxNoOfRetries is reached.
* In order to restart infinitely pass in `-1`.
*/
@Deprecated
@deprecated("Use BackoffOpts.onStop instead", "Akka 2.5.22")
def onStop(
childProps: Props,
@ -510,7 +506,6 @@ object Backoff {
* 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
@deprecated("Use the overloaded one which accepts maxNrOfRetries instead.", "Akka 2.5.17")
def onStop(
childProps: Props,
@ -531,7 +526,6 @@ object Backoff {
* }}}
*/
@DoNotInherit
@Deprecated
@deprecated("Use new API from BackoffOpts object instead", since = "Akka 2.5.22")
trait BackoffOptions {

View file

@ -297,7 +297,6 @@ final class ORMap[A, B <: ReplicatedData] private[pekko] (
* If there is no current value for the `key` the `initial` value will be
* passed to the `modify` function.
*/
@Deprecated
@deprecated("use update for the Java API as updated is ambiguous with the Scala API", "Akka 2.5.20")
def updated(node: Cluster, key: A, initial: B, modify: java.util.function.Function[B, B]): ORMap[A, B] =
updated(node.selfUniqueAddress, key, initial)(value => modify.apply(value))
@ -311,7 +310,6 @@ final class ORMap[A, B <: ReplicatedData] private[pekko] (
def update(node: SelfUniqueAddress, key: A, initial: B, modify: java.util.function.Function[B, B]): ORMap[A, B] =
updated(node.uniqueAddress, key, initial)(value => modify.apply(value))
@Deprecated
@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))

View file

@ -181,7 +181,6 @@ final class ORMultiMap[A, B] private[pekko] (
put(node.uniqueAddress, key, value.asScala.toSet)
}
@Deprecated
@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._
@ -278,7 +277,6 @@ final class ORMultiMap[A, B] private[pekko] (
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 = "Akka 2.5.20")
def removeBinding(node: Cluster, key: A, element: B): ORMultiMap[A, B] =
removeBinding(node.selfUniqueAddress, key, element)

View file

@ -339,7 +339,6 @@ final class ORSet[A] private[pekko] (
/** 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 = "Akka 2.5.20")
def add(node: Cluster, element: A): ORSet[A] = add(node.selfUniqueAddress, element)

View file

@ -163,7 +163,6 @@ 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 = "Akka 2.5.20")
def decrement(node: Cluster, n: java.math.BigInteger): PNCounter = decrement(node.selfUniqueAddress, n)

View file

@ -444,7 +444,6 @@ object PersistentFSM {
}
@InternalApi
@Deprecated
@deprecated(
"Internal API easily to be confused with regular FSM's using. Use regular events (`applying`). Internally, `copy` can be used instead.",
"Akka 2.5.5")

View file

@ -135,7 +135,6 @@ object ActorSource {
*
* @deprecated Use actorRefWithBackpressure instead
*/
@Deprecated
@deprecated("Use actorRefWithBackpressure instead", "Akka 2.6.0")
def actorRefWithAck[T, Ack](
ackTo: ActorRef[Ack],

View file

@ -16,7 +16,6 @@ package org.apache.pekko.stream
import scala.annotation.unchecked.uncheckedVariance
import scala.collection.immutable
@Deprecated
@deprecated(
"FanInShape1N was removed because it was not used anywhere. Use a custom shape extending from FanInShape directly.",
"Akka 2.5.5")

View file

@ -128,7 +128,6 @@ object OverflowStrategy {
* @deprecated Use {@link pekko.stream.javadsl.Source#queue(int,org.apache.pekko.stream.OverflowStrategy)} instead
*/
@deprecated("Use Source.queue instead", "Akka 2.6.11")
@Deprecated
def dropNew: OverflowStrategy = DropNew(Logging.DebugLevel)
/**

View file

@ -36,7 +36,6 @@ class UniformFanOutShape[-I, +O](n: Int, _init: FanOutShape.Init[I @uncheckedVar
final override def outlets: immutable.Seq[Outlet[O @uncheckedVariance]] =
super.outlets.asInstanceOf[immutable.Seq[Outlet[O]]]
@Deprecated
@deprecated("use 'outlets' or 'out(id)' instead", "Akka 2.5.5")
def outArray: Array[Outlet[O @uncheckedVariance]] = _outArray

View file

@ -104,7 +104,6 @@ object BidiFlow {
* every second in one direction, but no elements are flowing in the other direction. I.e. this operator considers
* the *joint* frequencies of the elements in both directions.
*/
@Deprecated
@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))

View file

@ -1322,7 +1322,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
* `maxNumber` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@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
@ -1367,7 +1366,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
* `maxWeight` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def groupedWeightedWithin(
maxWeight: Long,
@ -1451,7 +1449,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
* @param of time to shift all messages
* @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 = "Akka 2.5.12")
def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): Flow[In, Out, Mat] =
new Flow(delegate.delay(of, strategy))
@ -1547,7 +1544,6 @@ 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 = "Akka 2.5.12")
def dropWithin(duration: FiniteDuration): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.dropWithin(duration))
@ -1755,7 +1751,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
*
* @deprecated use `recoverWithRetries` instead
*/
@Deprecated
@deprecated("Use recoverWithRetries instead.", "Akka 2.6.6")
def recoverWith(
clazz: Class[_ <: Throwable],
@ -1870,7 +1865,6 @@ 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 = "Akka 2.5.12")
def takeWithin(duration: FiniteDuration): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.takeWithin(duration))
@ -3378,7 +3372,6 @@ 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 = "Akka 2.5.12")
def initialTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.initialTimeout(timeout))
@ -3411,7 +3404,6 @@ 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 = "Akka 2.5.12")
def completionTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.completionTimeout(timeout))
@ -3445,7 +3437,6 @@ 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 = "Akka 2.5.12")
def idleTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.idleTimeout(timeout))
@ -3480,7 +3471,6 @@ 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 = "Akka 2.5.12")
def backpressureTimeout(timeout: FiniteDuration): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.backpressureTimeout(timeout))
@ -3519,7 +3509,6 @@ 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 = "Akka 2.5.12")
def keepAlive(maxIdle: FiniteDuration, injectedElem: function.Creator[Out]): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.keepAlive(maxIdle, () => injectedElem.create()))
@ -3612,7 +3601,6 @@ 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 = "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))
@ -3697,7 +3685,6 @@ 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 = "Akka 2.5.12")
def throttle(
cost: Int,
@ -3800,7 +3787,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@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))
@ -3815,7 +3801,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: java.time.Duration, mode: ThrottleMode): javadsl.Flow[In, Out, Mat] =
throttleEven(elements, per.asScala, mode)
@ -3830,7 +3815,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -3849,7 +3833,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -3888,7 +3871,6 @@ final class Flow[In, Out, Mat](delegate: scaladsl.Flow[In, Out, Mat]) extends Gr
*
* The `combine` function is used to combine the `FlowMonitor` with this flow's materialized value.
*/
@Deprecated
@deprecated("Use monitor() or monitorMat(combine) instead", "Akka 2.5.17")
def monitor[M]()(combine: function.Function2[Mat, FlowMonitor[Out], M]): javadsl.Flow[In, Out, M] =
new Flow(delegate.monitorMat(combinerToScala(combine)))
@ -3927,7 +3909,6 @@ 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 = "Akka 2.5.12")
def initialDelay(delay: FiniteDuration): javadsl.Flow[In, Out, Mat] =
new Flow(delegate.initialDelay(delay))

View file

@ -52,7 +52,6 @@ object RestartFlow {
* In order to skip this additional delay pass in `0`.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def withBackoff[In, Out](
minBackoff: FiniteDuration,
@ -86,7 +85,6 @@ object RestartFlow {
* In order to skip this additional delay pass in `0`.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[In, Out](
@ -123,7 +121,6 @@ object RestartFlow {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def withBackoff[In, Out](
minBackoff: FiniteDuration,
@ -160,7 +157,6 @@ object RestartFlow {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[In, Out](
@ -223,7 +219,6 @@ object RestartFlow {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def onFailuresWithBackoff[In, Out](
minBackoff: FiniteDuration,
@ -260,7 +255,6 @@ object RestartFlow {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def onFailuresWithBackoff[In, Out](

View file

@ -53,7 +53,6 @@ object RestartSink {
* In order to skip this additional delay pass in `0`.
* @param sinkFactory A factory for producing the [[Sink]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def withBackoff[T](
minBackoff: FiniteDuration,
@ -88,7 +87,6 @@ object RestartSink {
* In order to skip this additional delay pass in `0`.
* @param sinkFactory A factory for producing the [[Sink]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](
@ -126,7 +124,6 @@ object RestartSink {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sinkFactory A factory for producing the [[Sink]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def withBackoff[T](
minBackoff: FiniteDuration,
@ -164,7 +161,6 @@ object RestartSink {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sinkFactory A factory for producing the [[Sink]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](

View file

@ -49,7 +49,6 @@ object RestartSource {
* In order to skip this additional delay pass in `0`.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def withBackoff[T](
minBackoff: FiniteDuration,
@ -80,7 +79,6 @@ object RestartSource {
* In order to skip this additional delay pass in `0`.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](
@ -115,7 +113,6 @@ object RestartSource {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def withBackoff[T](
minBackoff: FiniteDuration,
@ -150,7 +147,6 @@ object RestartSource {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](
@ -205,7 +201,6 @@ object RestartSource {
* In order to skip this additional delay pass in `0`.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def onFailuresWithBackoff[T](
minBackoff: FiniteDuration,
@ -235,7 +230,6 @@ object RestartSource {
* In order to skip this additional delay pass in `0`.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def onFailuresWithBackoff[T](
@ -268,7 +262,6 @@ object RestartSource {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def onFailuresWithBackoff[T](
minBackoff: FiniteDuration,
@ -301,7 +294,6 @@ object RestartSource {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def onFailuresWithBackoff[T](

View file

@ -327,7 +327,6 @@ object Sink {
*
* @deprecated Use actorRefWithBackpressure instead
*/
@Deprecated
@deprecated("Use actorRefWithBackpressure instead", "Akka 2.6.0")
def actorRefWithAck[In](
ref: ActorRef,

View file

@ -234,7 +234,6 @@ object Source {
* element is produced it will not receive that tick element later. It will
* 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 = "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))
@ -520,7 +519,6 @@ object Source {
* @param bufferSize The size of the buffer in element count
* @param overflowStrategy Strategy that is used when incoming elements cannot fit inside the buffer
*/
@Deprecated
@deprecated("Use variant accepting completion and failure matchers", "Akka 2.6.0")
def actorRef[T](bufferSize: Int, overflowStrategy: OverflowStrategy): Source[T, ActorRef] =
new Source(scaladsl.Source.actorRef({
@ -579,7 +577,6 @@ object Source {
*
* @deprecated Use actorRefWithBackpressure instead
*/
@Deprecated
@deprecated("Use actorRefWithBackpressure instead", "Akka 2.6.0")
def actorRefWithAck[T](
ackMessage: Any,
@ -620,7 +617,6 @@ object Source {
* The actor will be stopped when the stream is completed, failed or canceled from downstream,
* i.e. you can watch it to get notified when that happens.
*/
@Deprecated
@deprecated("Use actorRefWithBackpressure accepting completion and failure matchers", "Akka 2.6.0")
def actorRefWithAck[T](ackMessage: Any): Source[T, ActorRef] =
new Source(scaladsl.Source.actorRefWithBackpressure(ackMessage,
@ -2299,7 +2295,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
*
* @deprecated use `recoverWithRetries` instead
*/
@Deprecated
@deprecated("Use recoverWithRetries instead.", "Akka 2.6.6")
@nowarn("msg=deprecated")
def recoverWith(
@ -2988,7 +2983,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* `maxNumber` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def groupedWithin(
maxNumber: Int,
@ -3037,7 +3031,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* `maxWeight` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def groupedWeightedWithin(
maxWeight: Long,
@ -3121,7 +3114,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* @param of time to shift all messages
* @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 = "Akka 2.5.12")
def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): Source[Out, Mat] =
new Source(delegate.delay(of, strategy))
@ -3217,7 +3209,6 @@ 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 = "Akka 2.5.12")
def dropWithin(duration: FiniteDuration): javadsl.Source[Out, Mat] =
new Source(delegate.dropWithin(duration))
@ -3337,7 +3328,6 @@ 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 = "Akka 2.5.12")
def takeWithin(duration: FiniteDuration): javadsl.Source[Out, Mat] =
new Source(delegate.takeWithin(duration))
@ -3931,7 +3921,6 @@ 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 = "Akka 2.5.12")
def initialTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] =
new Source(delegate.initialTimeout(timeout))
@ -3964,7 +3953,6 @@ 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 = "Akka 2.5.12")
def completionTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] =
new Source(delegate.completionTimeout(timeout))
@ -3998,7 +3986,6 @@ 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 = "Akka 2.5.12")
def idleTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] =
new Source(delegate.idleTimeout(timeout))
@ -4033,7 +4020,6 @@ 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 = "Akka 2.5.12")
def backpressureTimeout(timeout: FiniteDuration): javadsl.Source[Out, Mat] =
new Source(delegate.backpressureTimeout(timeout))
@ -4072,7 +4058,6 @@ 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 = "Akka 2.5.12")
def keepAlive(maxIdle: FiniteDuration, injectedElem: function.Creator[Out]): javadsl.Source[Out, Mat] =
new Source(delegate.keepAlive(maxIdle, () => injectedElem.create()))
@ -4165,7 +4150,6 @@ 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 = "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))
@ -4287,7 +4271,6 @@ 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 = "Akka 2.5.12")
def throttle(
cost: Int,
@ -4353,7 +4336,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: FiniteDuration, mode: ThrottleMode): javadsl.Source[Out, Mat] =
new Source(delegate.throttleEven(elements, per, mode))
@ -4368,7 +4350,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: java.time.Duration, mode: ThrottleMode): javadsl.Source[Out, Mat] =
throttleEven(elements, per.asScala, mode)
@ -4383,7 +4364,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -4402,7 +4382,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -4440,7 +4419,6 @@ final class Source[Out, Mat](delegate: scaladsl.Source[Out, Mat]) extends Graph[
* event, and may therefor affect performance.
* The `combine` function is used to combine the `FlowMonitor` with this flow's materialized value.
*/
@Deprecated
@deprecated("Use monitor() or monitorMat(combine) instead", "Akka 2.5.17")
def monitor[M]()(combine: function.Function2[Mat, FlowMonitor[Out], M]): javadsl.Source[Out, M] =
new Source(delegate.monitorMat(combinerToScala(combine)))
@ -4478,7 +4456,6 @@ 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 = "Akka 2.5.12")
def initialDelay(delay: FiniteDuration): javadsl.Source[Out, Mat] =
new Source(delegate.initialDelay(delay))

View file

@ -103,7 +103,6 @@ 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 = "Akka 2.5.12")
def asInputStream(readTimeout: FiniteDuration): Sink[ByteString, InputStream] =
new Sink(scaladsl.StreamConverters.asInputStream(readTimeout))
@ -179,7 +178,6 @@ 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 = "Akka 2.5.12")
def asOutputStream(writeTimeout: FiniteDuration): javadsl.Source[ByteString, OutputStream] =
new Source(scaladsl.StreamConverters.asOutputStream(writeTimeout))

View file

@ -723,7 +723,6 @@ class SubFlow[In, Out, Mat](
* `maxNumber` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def groupedWithin(
maxNumber: Int,
@ -772,7 +771,6 @@ class SubFlow[In, Out, Mat](
* `maxWeight` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def groupedWeightedWithin(
maxWeight: Long,
@ -856,7 +854,6 @@ class SubFlow[In, Out, Mat](
* @param of time to shift all messages
* @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 = "Akka 2.5.12")
def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): SubFlow[In, Out, Mat] =
new SubFlow(delegate.delay(of, strategy))
@ -952,7 +949,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -1181,7 +1177,6 @@ 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 = "Akka 2.5.12")
def takeWithin(duration: FiniteDuration): SubFlow[In, Out, Mat] =
new SubFlow(delegate.takeWithin(duration))
@ -2016,7 +2011,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2049,7 +2043,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2083,7 +2076,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2118,7 +2110,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2157,7 +2148,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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()))
@ -2250,7 +2240,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def throttle(
elements: Int,
@ -2376,7 +2365,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def throttle(
cost: Int,
@ -2442,7 +2430,6 @@ class SubFlow[In, Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: FiniteDuration, mode: ThrottleMode): javadsl.SubFlow[In, Out, Mat] =
new SubFlow(delegate.throttleEven(elements, per, mode))
@ -2457,7 +2444,6 @@ class SubFlow[In, Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: java.time.Duration, mode: ThrottleMode): javadsl.SubFlow[In, Out, Mat] =
throttleEven(elements, per.asScala, mode)
@ -2472,7 +2458,6 @@ class SubFlow[In, Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -2491,7 +2476,6 @@ class SubFlow[In, Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -2525,7 +2509,6 @@ class SubFlow[In, Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))

View file

@ -712,7 +712,6 @@ class SubSource[Out, Mat](
* `maxNumber` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@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
@ -759,7 +758,6 @@ class SubSource[Out, Mat](
* `maxWeight` must be positive, and `duration` must be greater than 0 seconds, otherwise
* IllegalArgumentException is thrown.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def groupedWeightedWithin(
maxWeight: Long,
@ -844,7 +842,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -947,7 +944,6 @@ class SubSource[Out, Mat](
* @param of time to shift all messages
* @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 = "Akka 2.5.12")
def delay(of: FiniteDuration, strategy: DelayOverflowStrategy): SubSource[Out, Mat] =
new SubSource(delegate.delay(of, strategy))
@ -1159,7 +1155,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels or timer fires
*/
@Deprecated
@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))
@ -1993,7 +1988,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2026,7 +2020,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2060,7 +2053,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2095,7 +2087,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2134,7 +2125,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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()))
@ -2227,7 +2217,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))
@ -2349,7 +2338,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def throttle(
cost: Int,
@ -2415,7 +2403,6 @@ class SubSource[Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: FiniteDuration, mode: ThrottleMode): javadsl.SubSource[Out, Mat] =
new SubSource(delegate.throttleEven(elements, per, mode))
@ -2430,7 +2417,6 @@ class SubSource[Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: java.time.Duration, mode: ThrottleMode): javadsl.SubSource[Out, Mat] =
throttleEven(elements, per.asScala, mode)
@ -2445,7 +2431,6 @@ class SubSource[Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -2464,7 +2449,6 @@ class SubSource[Out, Mat](
* [[throttle]] with maximumBurst attribute.
* @see [[#throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(
cost: Int,
@ -2498,7 +2482,6 @@ class SubSource[Out, Mat](
*
* '''Cancels when''' downstream cancels
*/
@Deprecated
@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))

View file

@ -2608,7 +2608,6 @@ trait FlowOps[+Out, +Mat] {
* [[throttle]] with maximumBurst attribute.
* @see [[throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(elements: Int, per: FiniteDuration, mode: ThrottleMode): Repr[Out] =
throttle(elements, per, Throttle.AutomaticMaximumBurst, ConstantFun.oneInt, mode)
@ -2623,7 +2622,6 @@ trait FlowOps[+Out, +Mat] {
* [[throttle]] with maximumBurst attribute.
* @see [[throttle]]
*/
@Deprecated
@deprecated("Use throttle without `maximumBurst` parameter instead.", "Akka 2.5.12")
def throttleEven(cost: Int, per: FiniteDuration, costCalculation: (Out) => Int, mode: ThrottleMode): Repr[Out] =
throttle(cost, per, Throttle.AutomaticMaximumBurst, costCalculation, mode)
@ -3951,7 +3949,6 @@ trait FlowOpsMat[+Out, +Mat] extends FlowOps[Out, Mat] {
*
* The `combine` function is used to combine the `FlowMonitor` with this flow's materialized value.
*/
@Deprecated
@deprecated("Use monitor() or monitorMat(combine) instead", "Akka 2.5.17")
def monitor[Mat2]()(combine: (Mat, FlowMonitor[Out]) => Mat2): ReprMat[Out, Mat2] =
viaMat(GraphStages.monitor)(combine)

View file

@ -943,7 +943,6 @@ final class Balance[T](val outputPorts: Int, val waitForAllDownstreams: Boolean,
// one output might seem counter intuitive but saves us from special handling in other places
require(outputPorts >= 1, "A Balance must have one or more output ports")
@Deprecated
@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)

View file

@ -60,7 +60,6 @@ object RestartFlow {
* In order to skip this additional delay pass in `0`.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[In, Out](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)(
@ -94,7 +93,6 @@ object RestartFlow {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[In, Out](
@ -153,7 +151,6 @@ object RestartFlow {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param flowFactory A factory for producing the [[Flow]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def onFailuresWithBackoff[In, Out](

View file

@ -53,7 +53,6 @@ object RestartSink {
* In order to skip this additional delay pass in `0`.
* @param sinkFactory A factory for producing the [[Sink]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)(
@ -88,7 +87,6 @@ object RestartSink {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sinkFactory A factory for producing the [[Sink]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double, maxRestarts: Int)(

View file

@ -49,7 +49,6 @@ object RestartSource {
* In order to skip this additional delay pass in `0`.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)(
@ -81,7 +80,6 @@ object RestartSource {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def withBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double, maxRestarts: Int)(
@ -129,7 +127,6 @@ object RestartSource {
* In order to skip this additional delay pass in `0`.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def onFailuresWithBackoff[T](minBackoff: FiniteDuration, maxBackoff: FiniteDuration, randomFactor: Double)(
@ -160,7 +157,6 @@ object RestartSource {
* Passing `0` will cause no restarts and a negative number will not cap the amount of restarts.
* @param sourceFactory A factory for producing the [[Source]] to wrap.
*/
@Deprecated
@deprecated("Use the overloaded method which accepts org.apache.pekko.stream.RestartSettings instead.",
since = "Akka 2.6.10")
def onFailuresWithBackoff[T](

View file

@ -79,7 +79,6 @@ 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 = "Akka 2.5.12")
def dilated(d: FiniteDuration): FiniteDuration = d.dilated(getSystem)
@ -153,7 +152,6 @@ class TestKit(system: ActorSystem) {
* block or throw an [[AssertionError]] if no `within` block surrounds this
* call.
*/
@Deprecated
@deprecated("Use getRemaining which returns java.time.Duration instead.", since = "Akka 2.5.12")
def remaining: FiniteDuration = tp.remaining
@ -168,7 +166,6 @@ class TestKit(system: ActorSystem) {
* Obtain time remaining for execution of the innermost enclosing `within`
* block or missing that it returns the given duration.
*/
@Deprecated
@deprecated("Use getRemainingOr which returns java.time.Duration instead.", since = "Akka 2.5.12")
def remainingOr(fd: FiniteDuration): FiniteDuration = tp.remainingOr(fd)
@ -183,7 +180,6 @@ class TestKit(system: ActorSystem) {
* block or missing that it returns the properly dilated default for this
* case from settings (key "pekko.test.single-expect-default").
*/
@Deprecated
@deprecated("Use getRemainingOrDefault which returns java.time.Duration instead.", since = "Akka 2.5.12")
def remainingOrDefault: FiniteDuration = tp.remainingOrDefault
@ -212,7 +208,6 @@ class TestKit(system: ActorSystem) {
*
* }}}
*/
@Deprecated
@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)
@ -255,7 +250,6 @@ class TestKit(system: ActorSystem) {
*
* }}}
*/
@Deprecated
@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)
@ -301,7 +295,6 @@ class TestKit(system: ActorSystem) {
* Note that the timeout is scaled using Duration.dilated,
* which uses the configuration entry "pekko.test.timefactor".
*/
@Deprecated
@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)
@ -327,7 +320,6 @@ class TestKit(system: ActorSystem) {
* Note that the timeout is scaled using Duration.dilated,
* which uses the configuration entry "pekko.test.timefactor".
*/
@Deprecated
@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)
@ -355,7 +347,6 @@ class TestKit(system: ActorSystem) {
* Note that the timeout is scaled using Duration.dilated,
* which uses the configuration entry "pekko.test.timefactor".
*/
@Deprecated
@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)
@ -399,7 +390,6 @@ class TestKit(system: ActorSystem) {
* Note that the timeout is scaled using Duration.dilated,
* which uses the configuration entry "pekko.test.timefactor".
*/
@Deprecated
@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)
@ -426,7 +416,6 @@ 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 = "Akka 2.5.13")
def awaitAssert[A](max: Duration, interval: Duration, a: Supplier[A]): A = tp.awaitAssert(a.get, max, interval)
@ -454,7 +443,6 @@ class TestKit(system: ActorSystem) {
*
* @return the received object
*/
@Deprecated
@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)
@ -477,7 +465,6 @@ class TestKit(system: ActorSystem) {
* given object. Wait time is bounded by the given duration, with an
* AssertionFailure being thrown in case of timeout.
*/
@Deprecated
@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)
@ -493,7 +480,6 @@ class TestKit(system: ActorSystem) {
* given object. Wait time is bounded by the given duration, with an
* AssertionFailure being thrown in case of timeout.
*/
@Deprecated
@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)
@ -556,7 +542,6 @@ class TestKit(system: ActorSystem) {
* the given class. Wait time is bounded by the given duration, with an
* AssertionFailure being thrown in case of timeout.
*/
@Deprecated
@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)
@ -579,7 +564,6 @@ class TestKit(system: ActorSystem) {
* AssertionFailure being thrown in case of timeout.
*/
@varargs
@Deprecated
@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: _*)
@ -605,7 +589,6 @@ class TestKit(system: ActorSystem) {
* given duration, with an AssertionFailure being thrown in case of timeout.
*/
@varargs
@Deprecated
@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
@ -632,7 +615,6 @@ class TestKit(system: ActorSystem) {
* with an AssertionFailure being thrown in case of timeout.
*/
@varargs
@Deprecated
@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]
@ -671,7 +653,6 @@ class TestKit(system: ActorSystem) {
* Assert that no message is received for the specified time.
* Supplied value is not dilated.
*/
@Deprecated
@deprecated("Use the overloaded one which accepts java.time.Duration instead.", since = "Akka 2.5.12")
def expectNoMessage(max: FiniteDuration): Unit = tp.expectNoMessage(max)
@ -769,7 +750,6 @@ 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 = "Akka 2.5.12")
def receiveN(n: Int, max: FiniteDuration): JList[AnyRef] =
tp.receiveN(n, max).asJava
@ -785,7 +765,6 @@ 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 = "Akka 2.5.13")
def receiveOne(max: Duration): AnyRef = tp.receiveOne(max)
@ -808,7 +787,6 @@ class TestKit(system: ActorSystem) {
* One possible use of this method is for testing whether messages of
* certain characteristics are generated at a certain rate:
*/
@Deprecated
@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] {
@ -841,7 +819,6 @@ class TestKit(system: ActorSystem) {
.asJava
}
@Deprecated
@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] {