-
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.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.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.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.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$ 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 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$ 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 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$ 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 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$ 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 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$ 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.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.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.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.persistence.fsm.AbstractPersistentFSM Use EventSourcedBehavior. Since 2.6.0.akka.persistence.fsm.AbstractPersistentFSMBase Use EventSourcedBehavior. Since 2.6.0.akka.persistence.fsm.AbstractPersistentFSMBase$ Use EventSourcedBehavior. Since 2.6.0.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$ Use EventSourcedBehavior. Since 2.6.0.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.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.remote.AddressUidExtension Use ExtendedActorSystem.uid instead. Since 2.8.0.akka.remote.AddressUidExtension$ Use ExtendedActorSystem.uid instead. Since 2.8.0.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.stream.ActorMaterializer The Materializer now has all methods the ActorMaterializer used to have. Since 2.6.0.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$ Use Tcp and TLS with SSLEngine parameters instead. Setup the SSLEngine with needed parameters. Since 2.6.0.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.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.ActorSystem.Settings.EnableAdditionalSerializationBindings() Always enabled from Akka 2.6.0. Since 2.6.0.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.ORMap.updated(Cluster, A, B, Function<B, B>) use update for the Java API as updated is ambiguous with the Scala API. Since 2.5.20.akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORMapDeltaOp.valueOf(int) akka.cluster.ddata.protobuf.msg.ReplicatedDataMessages.ORSetDeltaOp.valueOf(int) 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.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.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.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.ContainerFormats.PatternType.valueOf(int) akka.remote.SystemMessageFormats.SystemMessage.Type.valueOf(int) akka.remote.testconductor.Conductor.throttle(RoleName, RoleName, Direction, double) Throttle is not implemented, use blackhole and passThrough. Since 2.8.0.akka.remote.testconductor.TestConductorProtocol.BarrierOp.valueOf(int) akka.remote.testconductor.TestConductorProtocol.Direction.valueOf(int) akka.remote.testconductor.TestConductorProtocol.FailType.valueOf(int) 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.copy(List<Attributes.Attribute>) Don't use copy on Attributes. Since 2.8.0.akka.stream.Attributes.getFirst(ClassTag<T>) Attributes should always be most specific, use get[T]. Since 2.5.7.akka.stream.Attributes.productArity() Use explicit methods on Attributes to interact, not the ones provided by Product. Since 2.8.0.akka.stream.Attributes.productElement(int) Use explicit methods on Attributes to interact, not the ones provided by Product. Since 2.8.0.akka.stream.Attributes.unapply(Attributes) Use explicit methods on Attributes to interact, not the synthetic case class ones. Since 2.8.0.akka.stream.Attributes$.unapply(Attributes) Use explicit methods on Attributes to interact, not the synthetic case class ones. Since 2.8.0.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.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.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.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$.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(Duration, Duration, double, int, Creator<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartFlow.withBackoff(Duration, Duration, double, Creator<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartFlow$.onFailuresWithBackoff(Duration, Duration, double, int, Creator<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartFlow$.withBackoff(Duration, Duration, double, Creator<Flow<In, Out, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartSink.withBackoff(Duration, Duration, double, Creator<Sink<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartSink$.withBackoff(Duration, Duration, double, Creator<Sink<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartSource.onFailuresWithBackoff(Duration, Duration, double, Creator<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartSource.withBackoff(Duration, Duration, double, Creator<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartSource$.onFailuresWithBackoff(Duration, Duration, double, Creator<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.RestartSource$.withBackoff(Duration, Duration, double, Creator<Source<T, ?>>) Use the overloaded method which accepts akka.stream.RestartSettings instead. Since 2.6.10.akka.stream.javadsl.Sink.actorRefWithAck(ActorRef, Object, Object, Object, Function<Throwable, Object>) Use actorRefWithBackpressure insteadakka.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$.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.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.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$.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.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.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.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.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$.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.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.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.javadsl.TestSink.probe(ActorSystem) Use `TestSink.create` with ClassicActorSystemProvider instead. Since 2.7.0.akka.stream.testkit.javadsl.TestSink$.probe(ActorSystem) Use `TestSink.create` with ClassicActorSystemProvider instead. Since 2.7.0.akka.stream.testkit.javadsl.TestSource.probe(ActorSystem) Use `TestSource.create` with ClassicActorSystemProvider instead. Since 2.7.0.akka.stream.testkit.javadsl.TestSource$.probe(ActorSystem) Use `TestSource.create` with ClassicActorSystemProvider instead. Since 2.7.0.akka.stream.testkit.scaladsl.TestSink.probe(ActorSystem) Use `TestSink()` with implicit ClassicActorSystemProvider instead. Since 2.7.0.akka.stream.testkit.scaladsl.TestSink$.probe(ActorSystem) Use `TestSink()` with implicit ClassicActorSystemProvider instead. Since 2.7.0.akka.stream.testkit.scaladsl.TestSource.probe(ActorSystem) Use `TestSource()` with implicit ClassicActorSystemProvider instead. Since 2.7.0.akka.stream.testkit.scaladsl.TestSource$.probe(ActorSystem) Use `TestSource()` with implicit ClassicActorSystemProvider instead. Since 2.7.0.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.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.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.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.