-
Interfaces Interface Description akka.actor.ScalaActorRef tell method is now provided by ActorRef trait. Since 2.6.13.akka.actor.TypedActorFactory Use 'akka.actor.typed' API. Since 2.6.0.akka.event.jul.JavaLogging Use SLF4J or direct java.util.logging instead. Since 2.6.0.akka.io.DnsProvider Overriding the DNS implementation will be removed in future versions of Akka. Since 2.6.0.akka.pattern.BackoffOptions Use new API from BackoffOpts object instead. Since 2.5.22.akka.persistence.fsm.LoggingPersistentFSM Use EventSourcedBehavior. Since 2.6.0.akka.persistence.fsm.PersistentFSM Use EventSourcedBehavior. Since 2.6.0.akka.persistence.fsm.PersistentFSMBase Use EventSourcedBehavior. Since 2.6.0.akka.remote.AssociationEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.HasSequenceNumber Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemotingLifecycleEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.AssociationHandle Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.SSLEngineProvider Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.SchemeAugmenter Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.Transport Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.TransportAdapterProvider Classic remoting is deprecated, use Artery. Since 2.6.0.com.typesafe.sslconfig.akka.SSLEngineConfigurator Use Tcp and TLS with SSLEngine parameters instead. Setup the SSLEngine with needed parameters. Since 2.6.0.
-
Classes Class Description akka.actor.TypedActor Use 'akka.actor.typed' API. Since 2.6.0.akka.actor.TypedActor$ Use 'akka.actor.typed' API. Since 2.6.0.akka.cluster.client.ClusterClient Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterClient.Publish Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterClient.Publish$ . Since .akka.cluster.client.ClusterClient.Send Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterClient.Send$ . Since .akka.cluster.client.ClusterClient.SendToAll Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterClient.SendToAll$ . Since .akka.cluster.client.ClusterClient$ . Since .akka.cluster.client.ClusterClientReceptionist Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterClientReceptionist$ . Since .akka.cluster.client.ClusterClientSettings Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterClientSettings$ . Since .akka.cluster.client.ClusterReceptionist Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterReceptionist$ . Since .akka.cluster.client.ClusterReceptionistSettings Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterReceptionistSettings$ . Since .akka.cluster.sharding.PersistentShardCoordinator Use `ddata` mode, persistence mode is deprecated. Since 2.6.0.akka.dispatch.ExecutionContexts.sameThreadExecutionContext$ Use ExecutionContexts.parasitic instead. Since 2.6.4.akka.dispatch.japi.BooleanFunctionBridge Do not use this directly, use subclasses of this. Since 2.0.akka.dispatch.japi.CallbackBridge Do not use this directly, use subclasses of this. Since 2.0.akka.dispatch.japi.RecoverBridge Do not use this directly, use 'Recover'. Since 2.0.akka.dispatch.japi.UnitFunctionBridge Do not use this directly, use subclasses of this. Since 2.0.akka.event.jul.JavaLogger Use Slf4jLogger instead. Since 2.6.0.akka.event.jul.JavaLoggingFilter Use Slf4jLoggingFilter instead. Since 2.6.0.akka.event.jul.Logger Use SLF4J or direct java.util.logging instead. Since 2.6.0.akka.event.jul.Logger$ Use SLF4J or direct java.util.logging instead. Since 2.6.0.akka.io.Dns.Resolve Use cached(DnsProtocol.Resolve). Since 2.6.0.akka.io.Dns.Resolve$ . Since .akka.io.Dns.Resolved Use cached(DnsProtocol.Resolved). Since 2.6.0.akka.io.Dns.Resolved$ Use cached(DnsProtocol.Resolved). Since 2.6.0.akka.io.Tcp.WriteFile Use WritePath instead. Since 2.5.10.akka.io.Tcp.WriteFile$ . Since .akka.Main Implement your own main class instead, from which you start the ActorSystem and actors. Since 2.6.0.akka.Main$ Implement your own main class instead, from which you start the ActorSystem and actors. Since 2.6.0.akka.pattern.Backoff This API is superseded by theBackoffOpts
object.akka.pattern.Backoff$ This API is superseded by theBackoffOpts
object.akka.pattern.PatternsCS Use Patterns instead. Since 2.5.19.akka.pattern.PatternsCS$ Use Patterns instead. Since 2.5.19.akka.persistence.fsm.AbstractPersistentFSM Use EventSourcedBehavior. Since 2.6.0.akka.persistence.fsm.AbstractPersistentFSMBase Use EventSourcedBehavior. Since 2.6.0.akka.persistence.fsm.AbstractPersistentFSMBase$ . Since .akka.persistence.fsm.AbstractPersistentLoggingFSM Use EventSourcedBehavior. Since 2.6.0.akka.persistence.fsm.japi.pf.FSMStateFunctionBuilder use EventSourcedBehavior since 2.6.0akka.persistence.fsm.japi.pf.FSMStopBuilder use EventSourcedBehavior since 2.6.0akka.persistence.fsm.PersistentFSM$ . Since .akka.persistence.journal.leveldb.LeveldbJournal$ . Since .akka.persistence.journal.leveldb.SharedLeveldbStore Use another journal implementation or the in-mem journal in combination with the journal-proxy. Since 2.6.15.akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal Use another journal implementation. Since 2.6.15.akka.persistence.query.journal.leveldb.javadsl.LeveldbReadJournal$ . Since .akka.persistence.query.journal.leveldb.LeveldbReadJournalProvider Use another journal/query implementation. Since 2.6.15.akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal Use another journal implementation. Since 2.6.15.akka.persistence.query.journal.leveldb.scaladsl.LeveldbReadJournal$ . Since .akka.remote.Ack Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.Ack$ . Since .akka.remote.AckedReceiveBuffer Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.AckedReceiveBuffer$ . Since .akka.remote.AckedSendBuffer Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.AckedSendBuffer$ . Since .akka.remote.AssociatedEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.AssociatedEvent$ . Since .akka.remote.AssociationErrorEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.AssociationErrorEvent$ . Since .akka.remote.DisassociatedEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.DisassociatedEvent$ . Since .akka.remote.GracefulShutdownQuarantinedEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.GracefulShutdownQuarantinedEvent$ . Since .akka.remote.HasSequenceNumber$ . Since .akka.remote.QuarantinedEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.QuarantinedEvent$ . Since .akka.remote.RemotingErrorEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemotingErrorEvent$ . Since .akka.remote.RemotingShutdownEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemotingShutdownEvent$ Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.SeqNo Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.SeqNo$ . Since .akka.remote.serialization.ByteStringSerializer Moved to akka.serialization.ByteStringSerializer in akka-actor. Since 2.6.0.akka.remote.serialization.IntSerializer Moved to akka.serialization.IntSerializer in akka-actor. Since 2.6.0.akka.remote.serialization.LongSerializer Moved to akka.serialization.LongSerializer in akka-actor. Since 2.6.0.akka.remote.serialization.StringSerializer Moved to akka.serialization.StringSerializer in akka-actor. Since 2.6.0.akka.remote.ThisActorSystemQuarantinedEvent Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.ThisActorSystemQuarantinedEvent$ . Since .akka.remote.transport.AbstractTransportAdapter Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.AbstractTransportAdapterHandle Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.ActorTransportAdapter Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.ActorTransportAdapter$ . Since .akka.remote.transport.ActorTransportAdapterManager Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.AssociationHandle$ . Since .akka.remote.transport.AssociationRegistry Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.AssociationRegistry$ Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.FailureInjectorException$ . Since .akka.remote.transport.FailureInjectorProvider Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.ConfigSSLEngineProvider Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.NettyFutureBridge Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.NettyFutureBridge$ Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.NettyTransport Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.NettyTransport$ . Since .akka.remote.transport.netty.NettyTransportSettings Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.TestAssociationHandle Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.TestAssociationHandle$ . Since .akka.remote.transport.TestTransport Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.TestTransport$ . Since .akka.remote.transport.ThrottlerProvider Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.ThrottlerTransportAdapter Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.ThrottlerTransportAdapter$ . Since .akka.remote.transport.Transport$ . Since .akka.remote.transport.TransportAdapters Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.TransportAdaptersExtension Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.TransportAdaptersExtension$ Classic remoting is deprecated, use Artery. Since 2.6.0.akka.stream.AbruptIOTerminationException$ . Since .akka.stream.ActorMaterializer The Materializer now has all methods the ActorMaterializer used to have. Since 2.6.0.akka.stream.ActorMaterializer$ . Since .akka.stream.FanInShape1N FanInShape1N was removed because it was not used anywhere. Use a custom shape extending from FanInShape directly. Since 2.5.5.com.typesafe.sslconfig.akka.AkkaSSLConfig Use Tcp and TLS with SSLEngine parameters instead. Setup the SSLEngine with needed parameters. Since 2.6.0.com.typesafe.sslconfig.akka.AkkaSSLConfig$ . Since .com.typesafe.sslconfig.akka.DefaultSSLEngineConfigurator Use Tcp and TLS with SSLEngine parameters instead. Setup the SSLEngine with needed parameters. Since 2.6.0.
-
Exceptions Exceptions Description akka.remote.ResendBufferCapacityReachedException Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.ResendUnfulfillableException Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.FailureInjectorException Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.NettyTransportException Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.transport.netty.NettyTransportExceptionNoStack Classic remoting is deprecated, use Artery. Since 2.6.0.akka.stream.AbruptIOTerminationException use IOOperationIncompleteException. Since 2.6.0.akka.stream.BindFailedException$ BindFailedException object will never be thrown. Match on the class instead. Since 2.4.19.
-
Methods Method Description akka.actor.AbstractActor.preRestart(Throwable, Option<Object>) Override preRestart with message parameter with Optional type instead. Since 2.5.0.akka.actor.AbstractFSM.setTimer(String, Object, FiniteDuration) Use startSingleTimer instead. Since 2.6.0.akka.actor.AbstractProps.create(Creator<T>) Use Props.create(actorClass, creator) instead, since this can't be used with Java 8 lambda. Since 2.5.18.akka.actor.AbstractScheduler.schedule(FiniteDuration, FiniteDuration, Runnable, ExecutionContext) akka.actor.ActorSelection.resolveOneCS(FiniteDuration) Use the overloaded method resolveOne which accepts java.time.Duration instead. Since 2.5.20.akka.actor.ActorSystem.Settings.EnableAdditionalSerializationBindings() Always enabled from Akka 2.6.0. Since 2.6.0.akka.actor.CoordinatedShutdown.run() Use the method with `reason` parameter instead. Since 2.5.8.akka.actor.CoordinatedShutdown.runAll() Use the method with `reason` parameter instead. Since 2.5.8.akka.actor.FSM.setTimer(String, Object, FiniteDuration, boolean) Use startSingleTimer, startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred. Since 2.6.0.akka.actor.Scheduler.schedule(FiniteDuration, FiniteDuration, ActorRef, Object, ExecutionContext, ActorRef) Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred. Since 2.6.0.akka.actor.testkit.typed.scaladsl.LoggingTestKit.intercept(Function0<T>, ActorSystem<?>) Use expect instead. Since 2.6.0.akka.actor.testkit.typed.scaladsl.ScalaTestWithActorTestKit.styleName() The styleName lifecycle method has been deprecated and will be removed in a future version of ScalaTest with no replacement. Since 3.1.0.akka.actor.TimerScheduler.startPeriodicTimer(Object, Object, FiniteDuration) Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred. Since 2.6.0.akka.actor.typed.javadsl.TimerScheduler.startPeriodicTimer(Object, T, Duration) Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred. Since 2.6.0.akka.actor.typed.scaladsl.TimerScheduler.startPeriodicTimer(Object, T, FiniteDuration) Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred. Since 2.6.0.akka.actor.TypedActor.apply(ActorContext) Use 'akka.actor.typed' API. Since 2.6.0.akka.actor.TypedActor$.apply(ActorContext) Use 'akka.actor.typed' API. Since 2.6.0.akka.cluster.client.ClusterClient.props(ClusterClientSettings) Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.client.ClusterClient$.props(ClusterClientSettings) Use Akka gRPC instead, see https://doc.akka.io/libraries/akka-core/2.6/cluster-client.html#migration-to-akka-grpc. Since 2.6.0.akka.cluster.ddata.GCounter.$plus(long, Cluster) Use `:+` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.GCounter.increment(Cluster, long) Use `increment` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWMap.$minus(A, Cluster) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWMap.$plus(Tuple2<A, B>, Cluster) Use `:+` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWMap.put(Cluster, A, B) Use `put` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWMap.remove(Cluster, A) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWRegister.apply(A, Cluster, LWWRegister.Clock<A>) Use `apply` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWRegister.create(Cluster, A) Use `create` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWRegister.withValue(A, Cluster, LWWRegister.Clock<A>) Use `withValueOf` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWRegister$.apply(A, Cluster, LWWRegister.Clock<A>) Use `apply` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.LWWRegister$.create(Cluster, A) Use `create` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMap.$minus(A, Cluster) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMap.$plus(Tuple2<A, B>, Cluster) Use `:+` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMap.put(Cluster, A, B) Use `put` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMap.remove(Cluster, A) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMap.update(Cluster, A, B, Function<B, B>) Use `update` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMap.updated(Cluster, A, B, Function1<B, B>) Use `updated` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMultiMap.$minus(A, Cluster) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMultiMap.$plus(Tuple2<A, Set<B>>, Cluster) Use `:+` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMultiMap.addBinding(A, B, Cluster) Use `addBinding` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMultiMap.put(Cluster, A, Set<B>) Use `put` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMultiMap.remove(Cluster, A) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMultiMap.removeBinding(A, B, Cluster) Use `removeBinding` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORMultiMap.replaceBinding(A, B, B, Cluster) Use `replaceBinding` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORSet.$minus(A, Cluster) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORSet.$plus(A, Cluster) Use `:+` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORSet.add(Cluster, A) Use `add` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORSet.clear(Cluster) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.ORSet.remove(Cluster, A) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounter.$minus(long, Cluster) Use `decrement` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounter.$plus(long, Cluster) Use `:+` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounter.decrement(Cluster, long) Use `decrement` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounter.increment(Cluster, long) Use `increment` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounterMap.$minus(A, Cluster) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounterMap.decrement(A, long, Cluster) Use `decrement` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounterMap.increment(Cluster, A, long) Use `increment` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.PNCounterMap.remove(Cluster, A) Use `remove` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapDeltaOp.valueOf(int) akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetDeltaOp.valueOf(int) akka.cluster.ddata.VersionVector.$plus(Cluster) Use `:+` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.ddata.VersionVector.increment(Cluster) Use `increment` that takes a `SelfUniqueAddress` parameter instead. Since 2.5.20.akka.cluster.Member.pickHighestPriority(Set<Member>, Set<Member>) Was accidentally made a public API, internal. Since 2.5.4.akka.cluster.Member$.pickHighestPriority(Set<Member>, Set<Member>) Was accidentally made a public API, internal. Since 2.5.4.akka.cluster.metrics.protobuf.msg.ClusterMetricsMessages.NodeMetrics.NumberType.valueOf(int) akka.cluster.protobuf.msg.ClusterMessages.ConfigCheck.Type.valueOf(int) akka.cluster.protobuf.msg.ClusterMessages.MemberStatus.valueOf(int) akka.cluster.protobuf.msg.ClusterMessages.ReachabilityStatus.valueOf(int) akka.cluster.routing.ClusterRouterGroupSettings.apply(int, Seq<String>, boolean, Option<String>) useRole has been replaced with useRoles. Since 2.5.4.akka.cluster.routing.ClusterRouterGroupSettings.copy(int, Seq<String>, boolean, Option<String>) Use constructor with useRoles instead. Since 2.5.4.akka.cluster.routing.ClusterRouterGroupSettings.useRole() useRole has been replaced with useRoles. Since 2.5.4.akka.cluster.routing.ClusterRouterGroupSettings$.apply(int, Seq<String>, boolean, Option<String>) useRole has been replaced with useRoles. Since 2.5.4.akka.cluster.routing.ClusterRouterPoolSettings.apply(int, int, boolean, Option<String>) useRole has been replaced with useRoles. Since 2.5.4.akka.cluster.routing.ClusterRouterPoolSettings.copy(int, int, boolean, Option<String>) Use copy with useRoles instead. Since 2.5.4.akka.cluster.routing.ClusterRouterPoolSettings.useRole() useRole has been replaced with useRoles. Since 2.5.4.akka.cluster.routing.ClusterRouterPoolSettings$.apply(int, int, boolean, Option<String>) useRole has been replaced with useRoles. Since 2.5.4.akka.cluster.sharding.ClusterShardingSettings.passivateIdleEntityAfter() See passivationStrategySettings.idleEntitySettings instead. Since 2.6.18.akka.cluster.sharding.ClusterShardingSettings.withPassivateIdleAfter(FiniteDuration) Use withPassivationStrategy instead. Since 2.6.18.akka.cluster.sharding.typed.ClusterShardingSettings.passivateIdleEntityAfter() See passivationStrategySettings.idleEntitySettings instead. Since 2.6.18.akka.cluster.sharding.typed.ClusterShardingSettings.withPassivateIdleEntityAfter(FiniteDuration) Use withPassivationStrategy instead. Since 2.6.18.akka.cluster.sharding.typed.delivery.ShardingProducerController.Settings.resendFirsUnconfirmedIdleTimeout() use resendFirstUnconfirmedIdleTimeout. Since 2.6.19.akka.cluster.sharding.typed.delivery.ShardingProducerController.Settings.withResendFirsUnconfirmedIdleTimeout(FiniteDuration) use resendFirstUnconfirmedIdleTimeout. Since 2.6.19.akka.cluster.UniqueAddress.apply(Address, int) Use Long UID apply instead. Since 2.4.11.akka.cluster.UniqueAddress.copy(Address, int) Use Long UID constructor instead. Since 2.4.11.akka.cluster.UniqueAddress.uid() Use longUid instead. Since 2.4.11.akka.cluster.UniqueAddress$.apply(Address, int) Use Long UID apply instead. Since 2.4.11.akka.event.LogMarker.extractFromMDC(Map<String, Object>) use akka.event.LogEventWithMarker#marker instead. Since 2.5.12.akka.event.LogMarker$.extractFromMDC(Map<String, Object>) use akka.event.LogEventWithMarker#marker instead. Since 2.5.12.akka.io.Dns.cached(String) Use cached(DnsProtocol.Resolve). Since 2.6.0.akka.io.Dns.resolve(String, ActorSystem, ActorRef) Use resolve(DnsProtocol.Resolve). Since 2.6.0.akka.io.Dns.Resolved$.apply(DnsProtocol.Resolved) Use cached(DnsProtocol.Resolve). Since 2.6.0.akka.io.Dns$.cached(String, ActorSystem) use cached(DnsProtocol.Resolve). Since 2.6.0.akka.io.Dns$.resolve(String, ActorSystem, ActorRef) use resolve(DnsProtocol.Resolve). Since 2.6.0.akka.io.InetAddressDnsResolver.negativeTtl() Use negativeCacheDuration instead. Since 2.5.17.akka.io.InetAddressDnsResolver.positiveTtl() Use positiveCacheDuration instead. Since 2.5.17.akka.pattern.Backoff.onFailure(Props, String, FiniteDuration, FiniteDuration, double, int) Use BackoffOpts.onFailure instead. Since 2.5.22.akka.pattern.Backoff.onStop(Props, String, FiniteDuration, FiniteDuration, double, int) Use BackoffOpts.onStop instead. Since 2.5.22.akka.pattern.Backoff$.onFailure(Props, String, FiniteDuration, FiniteDuration, double, int) Use BackoffOpts.onFailure instead. Since 2.5.22.akka.pattern.Backoff$.onStop(Props, String, FiniteDuration, FiniteDuration, double, int) Use BackoffOpts.onStop instead. Since 2.5.22.akka.pattern.BackoffSupervisor.props(Props, String, FiniteDuration, FiniteDuration, double) Use props with BackoffOpts instead. Since 2.5.22.akka.pattern.BackoffSupervisor.propsWithSupervisorStrategy(Props, String, FiniteDuration, FiniteDuration, double, SupervisorStrategy) Use props with BackoffOpts instead. Since 2.5.22.akka.pattern.BackoffSupervisor$.props(Props, String, FiniteDuration, FiniteDuration, double) Use props with BackoffOpts instead. Since 2.5.22.akka.pattern.BackoffSupervisor$.propsWithSupervisorStrategy(Props, String, FiniteDuration, FiniteDuration, double, SupervisorStrategy) Use props with BackoffOpts instead. Since 2.5.22.akka.pattern.CircuitBreaker.create(Scheduler, int, FiniteDuration, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.pattern.CircuitBreaker$.create(Scheduler, int, FiniteDuration, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.pattern.Patterns.after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) Use the overload one which accepts a Callable of Future instead. Since 2.5.22.akka.pattern.Patterns$.after(FiniteDuration, Scheduler, ExecutionContext, Future<T>) Use the overload one which accepts a Callable of Future instead. Since 2.5.22.akka.pattern.PatternsCS.after(FiniteDuration, Scheduler, ExecutionContext, Callable<CompletionStage<T>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.pattern.PatternsCS.ask(ActorRef, Object, Timeout) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.15.akka.pattern.PatternsCS.askWithReplyTo(ActorRef, Function<ActorRef, Object>, Timeout) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.15.akka.pattern.PatternsCS.gracefulStop(ActorRef, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.pattern.PatternsCS.pipe(CompletionStage<T>, ExecutionContext) Use Patterns.pipe instead. Since 2.5.19.akka.pattern.PatternsCS.retry(Callable<CompletionStage<T>>, int, Duration, Scheduler, ExecutionContext) Use Patterns.retry instead. Since 2.5.19.akka.pattern.PatternsCS$.after(FiniteDuration, Scheduler, ExecutionContext, Callable<CompletionStage<T>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.pattern.PatternsCS$.ask(ActorRef, Object, Timeout) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.15.akka.pattern.PatternsCS$.askWithReplyTo(ActorRef, Function<ActorRef, Object>, Timeout) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.15.akka.pattern.PatternsCS$.gracefulStop(ActorRef, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.pattern.PatternsCS$.pipe(CompletionStage<T>, ExecutionContext) Use Patterns.pipe instead. Since 2.5.19.akka.pattern.PatternsCS$.retry(Callable<CompletionStage<T>>, int, Duration, Scheduler, ExecutionContext) Use Patterns.retry instead. Since 2.5.19.akka.persistence.fsm.AbstractPersistentFSMBase.setTimer(String, Object, FiniteDuration) Use startSingleTimer instead. Since 2.6.0.akka.persistence.fsm.PersistentFSMBase.initialize() Removed from API, called internally. Since 2.4.5.akka.persistence.fsm.PersistentFSMBase.setTimer(String, Object, FiniteDuration, boolean) Use startSingleTimer, startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred. Since 2.6.0.akka.persistence.PluginSpec.styleName() The styleName lifecycle method has been deprecated and will be removed in a future version of ScalaTest with no replacement. Since 3.1.0.akka.persistence.query.EventEnvelope.apply(Offset, String, long, Object) for binary compatibility. Since 2.6.2.akka.persistence.query.EventEnvelope$.apply(Offset, String, long, Object) for binary compatibility. Since 2.6.2.akka.persistence.state.javadsl.DurableStateUpdateStore.deleteObject(String) Use the deleteObject overload with revision instead. Since 2.6.20.akka.persistence.state.scaladsl.DurableStateUpdateStore.deleteObject(String) Use the deleteObject overload with revision instead. Since 2.6.20.akka.persistence.typed.javadsl.EventSourcedBehavior.snapshotSelectionCriteria() override recovery instead. Since 2.6.5.akka.persistence.typed.scaladsl.EventSourcedBehavior.withSnapshotSelectionCriteria(SnapshotSelectionCriteria) use withRecovery(Recovery.withSnapshotSelectionCriteria(...)). Since 2.6.5.akka.persistence.typed.serialization.ReplicatedEventSourcing.ORSetDeltaOp.valueOf(int) akka.remote.AddressUidExtension.addressUid() Use longAddressUid instead. Since 2.4.x.akka.remote.ContainerFormats.PatternType.valueOf(int) akka.remote.QuarantinedEvent.apply(Address, int) Use long uid apply. Since 2.4.x.akka.remote.QuarantinedEvent.uid() Use long uid. Since 2.4.x.akka.remote.QuarantinedEvent$.apply(Address, int) Use long uid apply. Since 2.4.x.akka.remote.RemoteSettings.Adapters() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.BackoffPeriod() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.CommandAckTimeout() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.Dispatcher() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.FlushWait() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.InitialSysMsgDeliveryTimeout() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.LogBufferSizeExceeding() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.LogFrameSizeExceeding() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.LogReceive() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.LogSend() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.QuarantineDuration() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.QuarantineSilentSystemTimeout() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.RemoteLifecycleEventsLogLevel() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.RetryGateClosedFor() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.ShutdownTimeout() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.StartupTimeout() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.SysMsgAckTimeout() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.SysMsgBufferSize() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.SysResendLimit() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.SysResendTimeout() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.TrustedSelectionPaths() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.UntrustedMode() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.RemoteSettings.UsePassiveConnections() Classic remoting is deprecated, use Artery. Since 2.6.0.akka.remote.SystemMessageFormats.SystemMessage.Type.valueOf(int) akka.remote.testconductor.TestConductorProtocol.BarrierOp.valueOf(int) akka.remote.testconductor.TestConductorProtocol.Direction.valueOf(int) akka.remote.testconductor.TestConductorProtocol.FailType.valueOf(int) akka.remote.transport.AssociationHandle.disassociate() Use method that states reasons to make sure disassociation reasons are logged. Since 2.5.3.akka.remote.transport.netty.NettyTransportSettings.BindPortSelector() WARNING: This should only be used by professionals. Since 2.4.akka.remote.transport.netty.NettyTransportSettings.PortSelector() WARNING: This should only be used by professionals. Since 2.0.akka.remote.WireFormats.CommandType.valueOf(int) akka.remote.WireFormats.TimeUnit.valueOf(int) akka.serialization.Serialization.deserialize(byte[], int, Option<Class<? extends T>>) Use deserialize that accepts the `manifest` as a class name. Since 2.6.0.akka.stream.ActorMaterializer.apply(Option<ActorMaterializerSettings>, Option<String>, ActorRefFactory) Use the system wide materializer with stream attributes or configuration settings to change defaults. Since 2.6.0.akka.stream.ActorMaterializer.create(ActorRefFactory) Use the system wide materializer or Materializer.create(actorContext) with stream attributes or configuration settings to change defaults. Since 2.6.0.akka.stream.ActorMaterializer.settings() Use attributes to access settings from stages, see https://doc.akka.io/libraries/akka-core/2.6/project/migration-guide-2.5.x-2.6.x.html. Since 2.6.0.akka.stream.ActorMaterializer$.apply(Option<ActorMaterializerSettings>, Option<String>, ActorRefFactory) Use the system wide materializer with stream attributes or configuration settings to change defaults. Since 2.6.0.akka.stream.ActorMaterializer$.create(ActorRefFactory) Use the system wide materializer or Materializer.create(actorContext) with stream attributes or configuration settings to change defaults. Since 2.6.0.akka.stream.ActorMaterializerSettings.apply(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) Use config or attributes to configure the materializer. See migration guide for details https://doc.akka.io/libraries/akka-core/2.6/project/migration-guide-2.5.x-2.6.x.html. Since 2.6.0.akka.stream.ActorMaterializerSettings.autoFusing() No longer has any effect. Since 2.6.0.akka.stream.ActorMaterializerSettings.blockingIoDispatcher() Use attribute 'ActorAttributes.BlockingIoDispatcher' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.create(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) Use config or attributes to configure the materializer. See migration guide for details https://doc.akka.io/libraries/akka-core/2.6/project/migration-guide-2.5.x-2.6.x.html. Since 2.6.0.akka.stream.ActorMaterializerSettings.debugLogging() Use attribute 'ActorAttributes.DebugLogging' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.dispatcher() Use attribute 'ActorAttributes.Dispatcher' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.fuzzingMode() Use attribute 'ActorAttributes.FuzzingMode' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.initialInputBufferSize() Use attribute 'Attributes.InputBuffer' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.maxFixedBufferSize() Use attribute 'ActorAttributes.MaxFixedBufferSize' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.maxInputBufferSize() Use attribute 'Attributes.InputBuffer' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.outputBurstLimit() Use attribute 'ActorAttributes.OutputBurstLimit' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.supervisionDecider() Use attribute 'ActorAttributes.SupervisionStrategy' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.syncProcessingLimit() Use attribute 'ActorAttributes.SyncProcessingLimit' to read the concrete setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withBlockingIoDispatcher(String) Use attribute 'ActorAttributes.BlockingIoDispatcher' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withDebugLogging(boolean) Use attribute 'ActorAttributes.DebugLogging' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withDispatcher(String) Use attribute 'ActorAttributes.Dispatcher' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withFuzzing(boolean) Use attribute 'ActorAttributes.FuzzingMode' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withInputBuffer(int, int) Use attribute 'Attributes.InputBuffer' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withMaxFixedBufferSize(int) Use attribute 'ActorAttributes.MaxFixedBufferSize' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withOutputBurstLimit(int) Use attribute 'ActorAttributes.OutputBurstLimit' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withSupervisionStrategy(Function1<Throwable, Supervision.Directive>) Use attribute 'ActorAttributes.supervisionStrategy' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings.withSyncProcessingLimit(int) Use attribute 'ActorAttributes.SyncProcessingLimit' to change setting value. Since 2.6.0.akka.stream.ActorMaterializerSettings$.apply(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) Use config or attributes to configure the materializer. See migration guide for details https://doc.akka.io/libraries/akka-core/2.6/project/migration-guide-2.5.x-2.6.x.html. Since 2.6.0.akka.stream.ActorMaterializerSettings$.create(int, int, String, Function1<Throwable, Supervision.Directive>, StreamSubscriptionTimeoutSettings, boolean, int, boolean, boolean, int) Use config or attributes to configure the materializer. See migration guide for details https://doc.akka.io/libraries/akka-core/2.6/project/migration-guide-2.5.x-2.6.x.html. Since 2.6.0.akka.stream.Attributes.getFirst(T, ClassTag<T>) Attributes should always be most specific, use get[T]. Since 2.5.7.akka.stream.Attributes.getFirstAttribute(Class<T>, T) Attributes should always be most specific, use getAttribute[T]. Since 2.5.7.akka.stream.FanInShape1N.in1Seq() Use 'inlets' or 'in(id)' instead. Since 2.5.5.akka.stream.IOResult.createFailed(long, Throwable) use IOOperationIncompleteException. Since 2.6.0.akka.stream.IOResult.getError() status is always set to Success(Done). Since 2.6.0.akka.stream.IOResult.status() status is always set to Success(Done). Since 2.6.0.akka.stream.IOResult.wasSuccessful() status is always set to Success(Done). Since 2.6.0.akka.stream.IOResult.withStatus(Try<Done>) status is always set to Success(Done). Since 2.6.0.akka.stream.IOResult$.createFailed(long, Throwable) use IOOperationIncompleteException. Since 2.6.0.akka.stream.IOSettings.apply(ActorSystem) Use setting 'akka.stream.materializer.io.tcp.write-buffer-size' or attribute TcpAttributes.writeBufferSize instead. Since 2.6.0.akka.stream.IOSettings.create(Config) Use setting 'akka.stream.materializer.io.tcp.write-buffer-size' or attribute TcpAttributes.writeBufferSize instead. Since 2.6.0.akka.stream.IOSettings.tcpWriteBufferSize() Use attribute 'TcpAttributes.TcpWriteBufferSize' to read the concrete setting value. Since 2.6.0.akka.stream.IOSettings$.apply(ActorSystem) Use setting 'akka.stream.materializer.io.tcp.write-buffer-size' or attribute TcpAttributes.writeBufferSize instead. Since 2.6.0.akka.stream.IOSettings$.create(Config) Use setting 'akka.stream.materializer.io.tcp.write-buffer-size' or attribute TcpAttributes.writeBufferSize instead. Since 2.6.0.akka.stream.javadsl.BidiFlow.bidirectionalIdleTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.BidiFlow$.bidirectionalIdleTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.CoupledTerminationFlow.fromSinkAndSource(Sink<I, M1>, Source<O, M2>) Use `Flow.fromSinkAndSourceCoupledMat(..., ..., Keep.both())` instead. Since 2.5.2.akka.stream.javadsl.CoupledTerminationFlow$.fromSinkAndSource(Sink<I, M1>, Source<O, M2>) Use `Flow.fromSinkAndSourceCoupledMat(..., ..., Keep.both())` instead. Since 2.5.2.akka.stream.javadsl.FileIO.fromFile(File) Use `fromPath` instead. Since 2.4.5.akka.stream.javadsl.FileIO.toFile(File) Use `toPath` instead. Since 2.4.5.akka.stream.javadsl.FileIO$.fromFile(File) Use `fromPath` instead. Since 2.4.5.akka.stream.javadsl.FileIO$.toFile(File) Use `toPath` instead. Since 2.4.5.akka.stream.javadsl.Flow.backpressureTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.completionTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.delay(FiniteDuration, DelayOverflowStrategy) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.dropWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.groupedWeightedWithin(long, Function<Out, Long>, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.groupedWithin(int, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.idleTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.initialDelay(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.initialTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.keepAlive(FiniteDuration, Creator<Out>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.lazyInit(Function<I, CompletionStage<Flow<I, O, M>>>, Creator<M>) Use 'Flow.completionStageFlow' in combination with prefixAndTail(1) instead, see `completionStageFlow` operator docs for details. Since 2.6.0.akka.stream.javadsl.Flow.lazyInitAsync(Creator<CompletionStage<Flow<I, O, M>>>) Use 'Flow.lazyCompletionStageFlow' instead. Since 2.6.0.akka.stream.javadsl.Flow.monitor(Function2<Mat, FlowMonitor<Out>, M>) Use monitor() or monitorMat(combine) instead. Since 2.5.17.akka.stream.javadsl.Flow.recoverWith(Class<? extends Throwable>, Supplier<Graph<SourceShape<Out>, NotUsed>>) userecoverWithRetries
insteadakka.stream.javadsl.Flow.setup(BiFunction<ActorMaterializer, Attributes, Flow<I, O, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.javadsl.Flow.takeWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.throttle(int, FiniteDuration, int, ThrottleMode) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow.throttleEven(int, FiniteDuration, ThrottleMode) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Flow$.lazyInit(Function<I, CompletionStage<Flow<I, O, M>>>, Creator<M>) Use 'Flow.completionStageFlow' in combination with prefixAndTail(1) instead, see `completionStageFlow` operator docs for details. Since 2.6.0.akka.stream.javadsl.Flow$.lazyInitAsync(Creator<CompletionStage<Flow<I, O, M>>>) Use 'Flow.lazyCompletionStageFlow' instead. Since 2.6.0.akka.stream.javadsl.Flow$.setup(BiFunction<ActorMaterializer, Attributes, Flow<I, O, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.javadsl.RestartFlow.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, int, Creator<Flow<In, Out, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartFlow.withBackoff(FiniteDuration, FiniteDuration, double, Creator<Flow<In, Out, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartFlow$.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, int, Creator<Flow<In, Out, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartFlow$.withBackoff(FiniteDuration, FiniteDuration, double, Creator<Flow<In, Out, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartSink.withBackoff(FiniteDuration, FiniteDuration, double, Creator<Sink<T, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartSink$.withBackoff(FiniteDuration, FiniteDuration, double, Creator<Sink<T, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartSource.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, Creator<Source<T, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartSource.withBackoff(FiniteDuration, FiniteDuration, double, Creator<Source<T, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartSource$.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, Creator<Source<T, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.RestartSource$.withBackoff(FiniteDuration, FiniteDuration, double, Creator<Source<T, ?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Sink.actorRefWithAck(ActorRef, Object, Object, Object, Function<Throwable, Object>) Use actorRefWithBackpressure insteadakka.stream.javadsl.Sink.foreachParallel(int, Procedure<T>, ExecutionContext) 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.akka.stream.javadsl.Sink.lazyInit(Function<T, CompletionStage<Sink<T, M>>>, Creator<M>) Use 'Sink.lazyCompletionStageSink' in combination with 'Flow.prefixAndTail(1)' instead. Since 2.6.0.akka.stream.javadsl.Sink.lazyInitAsync(Creator<CompletionStage<Sink<T, M>>>) Use 'Sink.lazyCompletionStageSink' instead. Since 2.6.0.akka.stream.javadsl.Sink.setup(BiFunction<ActorMaterializer, Attributes, Sink<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.javadsl.Sink$.actorRefWithAck(ActorRef, Object, Object, Object, Function<Throwable, Object>) Use actorRefWithBackpressure insteadakka.stream.javadsl.Sink$.foreachParallel(int, Procedure<T>, ExecutionContext) 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.akka.stream.javadsl.Sink$.lazyInit(Function<T, CompletionStage<Sink<T, M>>>, Creator<M>) Use 'Sink.lazyCompletionStageSink' in combination with 'Flow.prefixAndTail(1)' instead. Since 2.6.0.akka.stream.javadsl.Sink$.lazyInitAsync(Creator<CompletionStage<Sink<T, M>>>) Use 'Sink.lazyCompletionStageSink' instead. Since 2.6.0.akka.stream.javadsl.Sink$.setup(BiFunction<ActorMaterializer, Attributes, Sink<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.javadsl.Source.actorRef(int, OverflowStrategy) Use variant accepting completion and failure matchers. Since 2.6.0.akka.stream.javadsl.Source.actorRefWithAck(Object, Function<Object, Optional<CompletionStrategy>>, Function<Object, Optional<Throwable>>) Use actorRefWithBackpressure insteadakka.stream.javadsl.Source.backpressureTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.completionTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.delay(FiniteDuration, DelayOverflowStrategy) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.dropWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.fromCompletionStage(CompletionStage<O>) Use 'Source.completionStage' instead. Since 2.6.0.akka.stream.javadsl.Source.fromFuture(Future<O>) Use 'Source.future' instead. Since 2.6.0.akka.stream.javadsl.Source.fromFutureSource(Future<? extends Graph<SourceShape<T>, M>>) Use 'Source.futureSource' (potentially together with `Source.fromGraph`) instead. Since 2.6.0.akka.stream.javadsl.Source.fromSourceCompletionStage(CompletionStage<? extends Graph<SourceShape<T>, M>>) Use 'Source.completionStageSource' (potentially together with `Source.fromGraph`) instead. Since 2.6.0.akka.stream.javadsl.Source.groupedWeightedWithin(long, Function<Out, Long>, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.groupedWithin(int, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.idleTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.initialDelay(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.initialTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.keepAlive(FiniteDuration, Creator<Out>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.lazily(Creator<Source<T, M>>) Use 'Source.lazySource' instead. Since 2.6.0.akka.stream.javadsl.Source.lazilyAsync(Creator<CompletionStage<T>>) Use 'Source.lazyCompletionStage' instead. Since 2.6.0.akka.stream.javadsl.Source.monitor(Function2<Mat, FlowMonitor<Out>, M>) Use monitor() or monitorMat(combine) instead. Since 2.5.17.akka.stream.javadsl.Source.recoverWith(PartialFunction<Throwable, ? extends Graph<SourceShape<Out>, NotUsed>>) userecoverWithRetries
insteadakka.stream.javadsl.Source.setup(BiFunction<ActorMaterializer, Attributes, Source<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.javadsl.Source.takeWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.throttle(int, FiniteDuration, int, ThrottleMode) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source.throttleEven(int, FiniteDuration, ThrottleMode) Use throttle without `maximumBurst` parameter instead. Since 2.5.12.akka.stream.javadsl.Source.tick(FiniteDuration, FiniteDuration, O) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.Source$.actorRef(int, OverflowStrategy) Use variant accepting completion and failure matchers. Since 2.6.0.akka.stream.javadsl.Source$.actorRefWithAck(Object, Function<Object, Optional<CompletionStrategy>>, Function<Object, Optional<Throwable>>) Use actorRefWithBackpressure insteadakka.stream.javadsl.Source$.fromCompletionStage(CompletionStage<O>) Use 'Source.completionStage' instead. Since 2.6.0.akka.stream.javadsl.Source$.fromFuture(Future<O>) Use 'Source.future' instead. Since 2.6.0.akka.stream.javadsl.Source$.fromFutureSource(Future<? extends Graph<SourceShape<T>, M>>) Use 'Source.futureSource' (potentially together with `Source.fromGraph`) instead. Since 2.6.0.akka.stream.javadsl.Source$.fromSourceCompletionStage(CompletionStage<? extends Graph<SourceShape<T>, M>>) Use 'Source.completionStageSource' (potentially together with `Source.fromGraph`) instead. Since 2.6.0.akka.stream.javadsl.Source$.lazily(Creator<Source<T, M>>) Use 'Source.lazySource' instead. Since 2.6.0.akka.stream.javadsl.Source$.lazilyAsync(Creator<CompletionStage<T>>) Use 'Source.lazyCompletionStage' instead. Since 2.6.0.akka.stream.javadsl.Source$.setup(BiFunction<ActorMaterializer, Attributes, Source<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.javadsl.Source$.tick(FiniteDuration, FiniteDuration, O) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.StreamConverters.asInputStream(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.StreamConverters.asOutputStream(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.StreamConverters$.asInputStream(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.StreamConverters$.asOutputStream(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.backpressureTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.completionTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.delay(FiniteDuration, DelayOverflowStrategy) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.dropWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.groupedWeightedWithin(long, Function<Out, Long>, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.groupedWithin(int, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.idleTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.initialDelay(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.initialTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.keepAlive(FiniteDuration, Creator<Out>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.recoverWith(PartialFunction<Throwable, Graph<SourceShape<Out>, NotUsed>>) Use recoverWithRetries instead. Since 2.4.4.akka.stream.javadsl.SubFlow.takeWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.throttle(int, FiniteDuration, int, ThrottleMode) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubFlow.throttleEven(int, FiniteDuration, ThrottleMode) Use throttle without `maximumBurst` parameter instead. Since 2.5.12.akka.stream.javadsl.SubSource.backpressureTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.completionTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.delay(FiniteDuration, DelayOverflowStrategy) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.dropWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.groupedWeightedWithin(long, Function<Out, Long>, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.groupedWithin(int, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.idleTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.initialDelay(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.initialTimeout(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.keepAlive(FiniteDuration, Creator<Out>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.recoverWith(PartialFunction<Throwable, Graph<SourceShape<Out>, NotUsed>>) Use recoverWithRetries instead. Since 2.4.4.akka.stream.javadsl.SubSource.takeWithin(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.throttle(int, FiniteDuration, int, ThrottleMode) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.stream.javadsl.SubSource.throttleEven(int, FiniteDuration, ThrottleMode) Use throttle without `maximumBurst` parameter instead. Since 2.5.12.akka.stream.javadsl.Tcp.bind(String, int, int, Iterable<Inet.SocketOption>, boolean, Duration) Use bind that takes a java.time.Duration parameter instead. Since 2.6.0.akka.stream.javadsl.Tcp.bindTls(String, int, SSLContext, TLSProtocol.NegotiateNewSession, int, Iterable<Inet.SocketOption>, boolean, Duration) Use bindWithTls that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.javadsl.Tcp.outgoingConnection(InetSocketAddress, Optional<InetSocketAddress>, Iterable<Inet.SocketOption>, boolean, Duration, Duration) Use bind that takes a java.time.Duration parameter instead. Since 2.6.0.akka.stream.javadsl.Tcp.outgoingTlsConnection(String, int, SSLContext, TLSProtocol.NegotiateNewSession) Use outgoingConnectionWithTls that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.javadsl.TLS.create(SSLContext, Optional<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole) Use create that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.javadsl.TLS$.create(SSLContext, Optional<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole) Use create that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.Materializer.schedulePeriodically(FiniteDuration, FiniteDuration, Runnable) Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred. Since 2.6.0.akka.stream.Materializer.settings() Use attributes to access settings from stages. Since 2.6.0.akka.stream.OverflowStrategy.dropNew() UseSource.queue(int,akka.stream.OverflowStrategy)
insteadakka.stream.OverflowStrategy$.dropNew() UseSource.queue(int,akka.stream.OverflowStrategy)
insteadakka.stream.scaladsl.CoupledTerminationFlow.fromSinkAndSource(Sink<I, M1>, Source<O, M2>) Use `Flow.fromSinkAndSourceCoupledMat(..., ...)(Keep.both)` instead. Since 2.5.2.akka.stream.scaladsl.CoupledTerminationFlow$.fromSinkAndSource(Sink<I, M1>, Source<O, M2>) Use `Flow.fromSinkAndSourceCoupledMat(..., ...)(Keep.both)` instead. Since 2.5.2.akka.stream.scaladsl.FileIO.fromFile(File, int) Use `fromPath` instead. Since 2.4.5.akka.stream.scaladsl.FileIO.toFile(File, Set<OpenOption>) Use `toPath` instead. Since 2.4.5.akka.stream.scaladsl.FileIO$.fromFile(File, int) Use `fromPath` instead. Since 2.4.5.akka.stream.scaladsl.FileIO$.toFile(File, Set<OpenOption>) Use `toPath` instead. Since 2.4.5.akka.stream.scaladsl.Flow.lazyInit(Function1<I, Future<Flow<I, O, M>>>, Function0<M>) Use 'Flow.futureFlow' in combination with prefixAndTail(1) instead, see `futureFlow` operator docs for details. Since 2.6.0.akka.stream.scaladsl.Flow.lazyInitAsync(Function0<Future<Flow<I, O, M>>>) Use 'Flow.lazyFutureFlow' instead. Since 2.6.0.akka.stream.scaladsl.Flow.setup(Function2<ActorMaterializer, Attributes, Flow<T, U, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.scaladsl.Flow$.lazyInit(Function1<I, Future<Flow<I, O, M>>>, Function0<M>) Use 'Flow.futureFlow' in combination with prefixAndTail(1) instead, see `futureFlow` operator docs for details. Since 2.6.0.akka.stream.scaladsl.Flow$.lazyInitAsync(Function0<Future<Flow<I, O, M>>>) Use 'Flow.lazyFutureFlow' instead. Since 2.6.0.akka.stream.scaladsl.Flow$.setup(Function2<ActorMaterializer, Attributes, Flow<T, U, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.scaladsl.FlowOps.recoverWith(PartialFunction<Throwable, Graph<SourceShape<T>, NotUsed>>) Use recoverWithRetries instead. Since 2.4.4.akka.stream.scaladsl.FlowOps.throttleEven(int, FiniteDuration, ThrottleMode) Use throttle without `maximumBurst` parameter instead. Since 2.5.12.akka.stream.scaladsl.FlowOpsMat.monitor(Function2<Mat, FlowMonitor<Out>, Mat2>) Use monitor() or monitorMat(combine) instead. Since 2.5.17.akka.stream.scaladsl.GraphApply.create(Graph<Shape, Mat>, Function1<GraphDSL.Builder<Mat>, Function1<Shape, S>>) Use createGraph instead. Since 2.6.16.akka.stream.scaladsl.RestartFlow.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, int, Function0<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartFlow.withBackoff(FiniteDuration, FiniteDuration, double, Function0<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartFlow$.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, int, Function0<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartFlow$.withBackoff(FiniteDuration, FiniteDuration, double, Function0<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartSink.withBackoff(FiniteDuration, FiniteDuration, double, Function0<Sink<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartSink$.withBackoff(FiniteDuration, FiniteDuration, double, Function0<Sink<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartSource.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, Function0<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartSource.withBackoff(FiniteDuration, FiniteDuration, double, Function0<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartSource$.onFailuresWithBackoff(FiniteDuration, FiniteDuration, double, Function0<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.RestartSource$.withBackoff(FiniteDuration, FiniteDuration, double, Function0<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.scaladsl.Sink.actorRef(ActorRef, Object) Use variant accepting both on complete and on failure message. Since 2.6.0.akka.stream.scaladsl.Sink.actorRefWithAck(ActorRef, Object, Object, Object, Function1<Throwable, Object>) Use actorRefWithBackpressure accepting completion and failure matchers instead. Since 2.6.0.akka.stream.scaladsl.Sink.foreachParallel(int, Function1<T, BoxedUnit>, ExecutionContext) 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.akka.stream.scaladsl.Sink.lazyInit(Function1<T, Future<Sink<T, M>>>, Function0<M>) Use 'Sink.lazyFutureSink' in combination with 'Flow.prefixAndTail(1)' instead. Since 2.6.0.akka.stream.scaladsl.Sink.lazyInitAsync(Function0<Future<Sink<T, M>>>) Use 'Sink.lazyFutureSink' instead. Since 2.6.0.akka.stream.scaladsl.Sink.setup(Function2<ActorMaterializer, Attributes, Sink<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.scaladsl.Sink$.actorRef(ActorRef, Object) Use variant accepting both on complete and on failure message. Since 2.6.0.akka.stream.scaladsl.Sink$.actorRefWithAck(ActorRef, Object, Object, Object, Function1<Throwable, Object>) Use actorRefWithBackpressure accepting completion and failure matchers instead. Since 2.6.0.akka.stream.scaladsl.Sink$.foreachParallel(int, Function1<T, BoxedUnit>, ExecutionContext) 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.akka.stream.scaladsl.Sink$.lazyInit(Function1<T, Future<Sink<T, M>>>, Function0<M>) Use 'Sink.lazyFutureSink' in combination with 'Flow.prefixAndTail(1)' instead. Since 2.6.0.akka.stream.scaladsl.Sink$.lazyInitAsync(Function0<Future<Sink<T, M>>>) Use 'Sink.lazyFutureSink' instead. Since 2.6.0.akka.stream.scaladsl.Sink$.setup(Function2<ActorMaterializer, Attributes, Sink<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.scaladsl.Source.actorRef(int, OverflowStrategy) Use variant accepting completion and failure matchers instead. Since 2.6.0.akka.stream.scaladsl.Source.actorRefWithAck(Object) Use actorRefWithBackpressure accepting completion and failure matchers instead. Since 2.6.0.akka.stream.scaladsl.Source.combine(Source<T, ?>, Source<T, ?>, Seq<Source<T, ?>>, Function1<Object, Graph<UniformFanInShape<T, U>, NotUsed>>) Use `Source.combine` on companion object instead. Since 2.5.5.akka.stream.scaladsl.Source.fromCompletionStage(CompletionStage<T>) Use 'Source.completionStage' instead. Since 2.6.0.akka.stream.scaladsl.Source.fromFuture(Future<T>) Use 'Source.future' instead. Since 2.6.0.akka.stream.scaladsl.Source.fromFutureSource(Future<Graph<SourceShape<T>, M>>) Use 'Source.futureSource' (potentially together with `Source.fromGraph`) instead. Since 2.6.0.akka.stream.scaladsl.Source.fromSourceCompletionStage(CompletionStage<? extends Graph<SourceShape<T>, M>>) Use scala-compat CompletionStage to future converter and 'Source.futureSource' instead. Since 2.6.0.akka.stream.scaladsl.Source.lazily(Function0<Source<T, M>>) Use 'Source.lazySource' instead. Since 2.6.0.akka.stream.scaladsl.Source.lazilyAsync(Function0<Future<T>>) Use 'Source.lazyFuture' instead. Since 2.6.0.akka.stream.scaladsl.Source.setup(Function2<ActorMaterializer, Attributes, Source<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.scaladsl.Source$.actorRef(int, OverflowStrategy) Use variant accepting completion and failure matchers instead. Since 2.6.0.akka.stream.scaladsl.Source$.actorRefWithAck(Object) Use actorRefWithBackpressure accepting completion and failure matchers instead. Since 2.6.0.akka.stream.scaladsl.Source$.fromCompletionStage(CompletionStage<T>) Use 'Source.completionStage' instead. Since 2.6.0.akka.stream.scaladsl.Source$.fromFuture(Future<T>) Use 'Source.future' instead. Since 2.6.0.akka.stream.scaladsl.Source$.fromFutureSource(Future<Graph<SourceShape<T>, M>>) Use 'Source.futureSource' (potentially together with `Source.fromGraph`) instead. Since 2.6.0.akka.stream.scaladsl.Source$.fromSourceCompletionStage(CompletionStage<? extends Graph<SourceShape<T>, M>>) Use scala-compat CompletionStage to future converter and 'Source.futureSource' instead. Since 2.6.0.akka.stream.scaladsl.Source$.lazily(Function0<Source<T, M>>) Use 'Source.lazySource' instead. Since 2.6.0.akka.stream.scaladsl.Source$.lazilyAsync(Function0<Future<T>>) Use 'Source.lazyFuture' instead. Since 2.6.0.akka.stream.scaladsl.Source$.setup(Function2<ActorMaterializer, Attributes, Source<T, M>>) Use 'fromMaterializer' instead. Since 2.6.0.akka.stream.scaladsl.Tcp.bindAndHandleTls(Flow<ByteString, ByteString, ?>, String, int, SSLContext, TLSProtocol.NegotiateNewSession, int, Iterable<Inet.SocketOption>, Duration, Materializer) Use bindAndHandleWithTls that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.scaladsl.Tcp.bindTls(String, int, SSLContext, TLSProtocol.NegotiateNewSession, int, Iterable<Inet.SocketOption>, Duration) Use bindWithTls that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.scaladsl.Tcp.outgoingTlsConnection(String, int, SSLContext, TLSProtocol.NegotiateNewSession) Use outgoingConnectionWithTls that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.scaladsl.TLS.apply(SSLContext, Option<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole, TLSClosing, Option<Tuple2<String, Object>>) Use apply that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.scaladsl.TLS$.apply(SSLContext, Option<AkkaSSLConfig>, TLSProtocol.NegotiateNewSession, TLSRole, TLSClosing, Option<Tuple2<String, Object>>) Use apply that takes a SSLEngine factory instead. Setup the SSLEngine with needed parameters. Since 2.6.0.akka.stream.scaladsl.ZipWithN.inSeq() use `shape.inlets` or `shape.in(id)` instead. Since 2.5.5.akka.stream.stage.OutHandler.onDownstreamFinish() Call onDownstreamFinish with a cancellation cause. Since 2.6.0.akka.stream.stage.TimerGraphStageLogic.schedulePeriodically(Object, FiniteDuration) Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred. Since 2.6.0.akka.stream.stage.TimerGraphStageLogic.schedulePeriodicallyWithInitialDelay(Object, FiniteDuration, FiniteDuration) Use scheduleWithFixedDelay or scheduleAtFixedRate instead. This has the same semantics as scheduleAtFixedRate, but scheduleWithFixedDelay is often preferred. Since 2.6.0.akka.stream.StreamRefSettings.bufferCapacity() Use attribute 'StreamRefAttributes.BufferCapacity' to read the concrete setting value. Since 2.6.0.akka.stream.StreamRefSettings.demandRedeliveryInterval() Use attribute 'StreamRefAttributes.DemandRedeliveryInterval' to read the concrete setting value. Since 2.6.0.akka.stream.StreamRefSettings.finalTerminationSignalDeadline() Use attribute 'StreamRefAttributes.FinalTerminationSignalDeadline' to read the concrete setting value. Since 2.6.0.akka.stream.StreamRefSettings.subscriptionTimeout() Use attribute 'StreamRefAttributes.SubscriptionTimeout' to read the concrete setting value. Since 2.6.0.akka.stream.StreamRefSettings$.apply(ActorSystem) Use attributes on the Runnable graph or change the defaults in configuration, see migration guide for details https://doc.akka.io/libraries/akka-core/2.6/project/migration-guide-2.5.x-2.6.x.html. Since 2.6.0.akka.stream.StreamRefSettings$.create(ActorSystem) Use attributes on the Runnable graph or change the defaults in configuration, see migration guide for details https://doc.akka.io/libraries/akka-core/2.6/project/migration-guide-2.5.x-2.6.x.html. Since 2.6.0.akka.stream.StreamSubscriptionTimeoutSettings.mode() Use attribute 'ActorAttributes.StreamSubscriptionTimeoutMode' to read the concrete setting value. Since 2.6.0.akka.stream.StreamSubscriptionTimeoutSettings.timeout() Use attribute 'ActorAttributes.StreamSubscriptionTimeout' to read the concrete setting value. Since 2.6.0.akka.stream.testkit.TestPublisher.ManualProbe.expectNoMsg() Use expectNoMessage instead. Since 2.5.5.akka.stream.testkit.TestSubscriber.ManualProbe.expectNoMsg() Use expectNoMessage instead. Since 2.5.5.akka.stream.typed.javadsl.ActorSource.actorRefWithAck(ActorRef<Ack>, Ack, Function<T, Optional<CompletionStrategy>>, Function<T, Optional<Throwable>>) Use actorRefWithBackpressure insteadakka.stream.typed.javadsl.ActorSource$.actorRefWithAck(ActorRef<Ack>, Ack, Function<T, Optional<CompletionStrategy>>, Function<T, Optional<Throwable>>) Use actorRefWithBackpressure insteadakka.stream.typed.scaladsl.ActorSource.actorRefWithAck(ActorRef<Ack>, Ack, PartialFunction<T, CompletionStrategy>, PartialFunction<T, Throwable>) Use actorRefWithBackpressure instead. Since 2.6.0.akka.stream.typed.scaladsl.ActorSource$.actorRefWithAck(ActorRef<Ack>, Ack, PartialFunction<T, CompletionStrategy>, PartialFunction<T, Throwable>) Use actorRefWithBackpressure instead. Since 2.6.0.akka.stream.UniformFanInShape.inSeq() Use 'inlets' or 'in(id)' instead. Since 2.5.5.akka.stream.UniformFanOutShape.outArray() use 'outlets' or 'out(id)' instead. Since 2.5.5.akka.testkit.javadsl.TestKit.awaitAssert(Duration, Supplier<A>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.13.akka.testkit.javadsl.TestKit.awaitCond(Duration, Supplier<Object>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.dilated(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectMsg(FiniteDuration, T) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectMsgAllOf(FiniteDuration, Seq<T>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectMsgAnyClassOf(FiniteDuration, Seq<Class<?>>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectMsgAnyOf(FiniteDuration, Seq<T>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectMsgClass(FiniteDuration, Class<T>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectMsgEquals(FiniteDuration, T) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectMsgPF(Duration, String, Function<Object, T>) Use the overloaded one which accepts java.time.Duration instead. Since 2.6.0.akka.testkit.javadsl.TestKit.expectNoMessage(FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.expectNoMsg() Use expectNoMessage instead. Since 2.5.10.akka.testkit.javadsl.TestKit.expectTerminated(Duration, ActorRef) Use the overloaded one which accepts java.time.Duration instead. Since 2.6.0.akka.testkit.javadsl.TestKit.fishForMessage(Duration, String, Function<Object, Object>) Use the overloaded one which accepts java.time.Duration instead. Since 2.6.0.akka.testkit.javadsl.TestKit.fishForSpecificMessage(Duration, String, Function<Object, T>) Use the overloaded one which accepts java.time.Duration instead. Since 2.6.0.akka.testkit.javadsl.TestKit.receiveN(int, FiniteDuration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.receiveOne(Duration) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.13.akka.testkit.javadsl.TestKit.receiveWhile(Duration, Duration, int, Function<Object, T>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.13.akka.testkit.javadsl.TestKit.remaining() Use getRemaining which returns java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.remainingOr(FiniteDuration) Use getRemainingOr which returns java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.remainingOrDefault() Use getRemainingOrDefault which returns java.time.Duration instead. Since 2.5.12.akka.testkit.javadsl.TestKit.within(FiniteDuration, FiniteDuration, Supplier<T>) Use the overloaded one which accepts java.time.Duration instead. Since 2.5.12.akka.testkit.TestFSMRef.setTimer(String, Object, FiniteDuration, boolean) Use startTimerWithFixedDelay or startTimerAtFixedRate instead. This has the same semantics as startTimerAtFixedRate, but startTimerWithFixedDelay is often preferred. Since 2.6.0.akka.testkit.TestKitBase.expectNoMsg() Use expectNoMessage instead. Since 2.5.5.