Issue references to FIXMEs in Typed (#26513)

* Issue references to FIXMEs in Typed

* comment out ctx.ask example with 2 param

* doesn't compile with 2.13, separarate issue created
This commit is contained in:
Patrik Nordwall 2019-03-14 10:07:08 +01:00 committed by Arnout Engelen
parent 357be2036e
commit 48a43e1e74
17 changed files with 31 additions and 25 deletions

View file

@ -67,7 +67,7 @@ abstract class ActorContextSpec extends ScalaTestWithActorTestKit("""
akka.loggers = [akka.testkit.TestEventListener] akka.loggers = [akka.testkit.TestEventListener]
""") with WordSpecLike { """) with WordSpecLike {
// FIXME eventfilter support in typed testkit // FIXME #24348: eventfilter support in typed testkit
import scaladsl.adapter._ import scaladsl.adapter._
implicit val untypedSystem = system.toUntyped implicit val untypedSystem = system.toUntyped

View file

@ -31,10 +31,10 @@ class AskSpec extends ScalaTestWithActorTestKit("""
akka.loggers = [ akka.testkit.TestEventListener ] akka.loggers = [ akka.testkit.TestEventListener ]
""") with WordSpecLike { """) with WordSpecLike {
// FIXME eventfilter support in typed testkit // FIXME #24348: eventfilter support in typed testkit
import AskSpec._ import AskSpec._
// FIXME eventfilter support in typed testkit // FIXME #24348: eventfilter support in typed testkit
import scaladsl.adapter._ import scaladsl.adapter._
implicit val untypedSystem = system.toUntyped implicit val untypedSystem = system.toUntyped

View file

@ -37,7 +37,7 @@ class DeferredSpec extends ScalaTestWithActorTestKit("""
import DeferredSpec._ import DeferredSpec._
implicit val testSettings = TestKitSettings(system) implicit val testSettings = TestKitSettings(system)
// FIXME eventfilter support in typed testkit // FIXME #24348: eventfilter support in typed testkit
import scaladsl.adapter._ import scaladsl.adapter._
implicit val untypedSystem = system.toUntyped implicit val untypedSystem = system.toUntyped

View file

@ -26,7 +26,7 @@ class InterceptSpec extends ScalaTestWithActorTestKit("""
import BehaviorInterceptor._ import BehaviorInterceptor._
import InterceptSpec._ import InterceptSpec._
// FIXME eventfilter support in typed testkit // FIXME #24348: eventfilter support in typed testkit
import scaladsl.adapter._ import scaladsl.adapter._
implicit val untypedSystem = system.toUntyped implicit val untypedSystem = system.toUntyped

View file

@ -254,7 +254,7 @@ class SupervisionSpec extends ScalaTestWithActorTestKit("""
private val nameCounter = Iterator.from(0) private val nameCounter = Iterator.from(0)
private def nextName(prefix: String = "a"): String = s"$prefix-${nameCounter.next()}" private def nextName(prefix: String = "a"): String = s"$prefix-${nameCounter.next()}"
// FIXME eventfilter support in typed testkit // FIXME #24348: eventfilter support in typed testkit
import akka.actor.typed.scaladsl.adapter._ import akka.actor.typed.scaladsl.adapter._
implicit val untypedSystem = system.toUntyped implicit val untypedSystem = system.toUntyped

View file

@ -22,7 +22,7 @@ class TimerSpec extends ScalaTestWithActorTestKit("""
akka.loggers = [ akka.testkit.TestEventListener ] akka.loggers = [ akka.testkit.TestEventListener ]
""") with WordSpecLike { """) with WordSpecLike {
// FIXME eventfilter support in typed testkit // FIXME #24348: eventfilter support in typed testkit
import scaladsl.adapter._ import scaladsl.adapter._
implicit val untypedSystem = system.toUntyped implicit val untypedSystem = system.toUntyped

View file

@ -33,7 +33,7 @@ object ActorContextAskSpec {
class ActorContextAskSpec extends ScalaTestWithActorTestKit(ActorContextAskSpec.config) with WordSpecLike { class ActorContextAskSpec extends ScalaTestWithActorTestKit(ActorContextAskSpec.config) with WordSpecLike {
implicit val untyped = system.toUntyped // FIXME no typed event filter yet implicit val untyped = system.toUntyped // FIXME #24348: eventfilter support in typed testkit
"The Scala DSL ActorContext" must { "The Scala DSL ActorContext" must {

View file

@ -33,7 +33,7 @@ object MessageAdapterSpec {
class MessageAdapterSpec extends ScalaTestWithActorTestKit(MessageAdapterSpec.config) with WordSpecLike { class MessageAdapterSpec extends ScalaTestWithActorTestKit(MessageAdapterSpec.config) with WordSpecLike {
implicit val untyped = system.toUntyped // FIXME no typed event filter yet implicit val untyped = system.toUntyped // FIXME #24348: eventfilter support in typed testkit
"Message adapters" must { "Message adapters" must {

View file

@ -8,7 +8,7 @@ import akka.actor.typed.Behavior
import akka.annotation.DoNotInherit import akka.annotation.DoNotInherit
import akka.annotation.InternalApi import akka.annotation.InternalApi
// FIXME see if we can completely eliminate this with the help of BehaviorInterceptor instead // FIXME #26504: see if we can completely eliminate this with the help of BehaviorInterceptor instead
/** /**
* INTERNAL API * INTERNAL API

View file

@ -56,7 +56,7 @@ private[akka] object LocalReceptionist extends ReceptionistBehaviorProvider {
/* /*
* Hack to allow multiple termination notifications per target * Hack to allow multiple termination notifications per target
* FIXME: replace by simple map in our state * FIXME #26505: replace by simple map in our state
*/ */
def watchWith(ctx: ActorContext[Any], target: ActorRef[_], msg: InternalCommand): Unit = def watchWith(ctx: ActorContext[Any], target: ActorRef[_], msg: InternalCommand): Unit =
ctx.spawnAnonymous[Nothing](Behaviors.setup[Nothing] { innerCtx => ctx.spawnAnonymous[Nothing](Behaviors.setup[Nothing] { innerCtx =>

View file

@ -23,7 +23,6 @@ object Routers {
* until the deregistration is complete to minimize the risk of lost messages. * until the deregistration is complete to minimize the risk of lost messages.
*/ */
def group[T](key: ServiceKey[T]): GroupRouter[T] = def group[T](key: ServiceKey[T]): GroupRouter[T] =
// fixme: potential detection of cluster and selecting a different impl https://github.com/akka/akka/issues/26355
new GroupRouterBuilder[T](key) new GroupRouterBuilder[T](key)
/** /**

View file

@ -160,7 +160,7 @@ class ClusterShardingPersistenceSpec
p.expectTerminated(ref, p.remainingOrDefault) p.expectTerminated(ref, p.remainingOrDefault)
// also make sure that the entity is removed from the Shard before continuing // also make sure that the entity is removed from the Shard before continuing
// FIXME rewrite this with Typed API when region queries are supported // FIXME #24466: rewrite this with Typed API when region queries are supported
import akka.actor.typed.scaladsl.adapter._ import akka.actor.typed.scaladsl.adapter._
val regionStateProbe = TestProbe[CurrentShardRegionState]() val regionStateProbe = TestProbe[CurrentShardRegionState]()
val untypedRegion = UntypedClusterSharding(system.toUntyped) val untypedRegion = UntypedClusterSharding(system.toUntyped)

View file

@ -338,10 +338,6 @@ class ClusterShardingSpec extends ScalaTestWithActorTestKit(ClusterShardingSpec.
val p = TestProbe[TheReply]() val p = TestProbe[TheReply]()
spawn(Behaviors.setup[TheReply] { ctx => spawn(Behaviors.setup[TheReply] { ctx =>
// FIXME is the implicit ClassTag difficult to use?
// it works fine when there is a single parameter apply,
// but trouble when more parameters and this doesn't compile
//ctx.ask(aliceRef)(x => WhoAreYou(x)) {
ctx.ask(aliceRef)(WhoAreYou) { ctx.ask(aliceRef)(WhoAreYou) {
case Success(name) => TheReply(name) case Success(name) => TheReply(name)
case Failure(ex) => TheReply(ex.getMessage) case Failure(ex) => TheReply(ex.getMessage)
@ -356,6 +352,19 @@ class ClusterShardingSpec extends ScalaTestWithActorTestKit(ClusterShardingSpec.
p.receiveMessage().s should startWith("I'm alice") p.receiveMessage().s should startWith("I'm alice")
aliceRef ! StopPlz() aliceRef ! StopPlz()
// FIXME #26514: doesn't compile with Scala 2.13.0-M5
/*
// make sure request with multiple parameters compile
Behaviors.setup[TheReply] { ctx =>
ctx.ask(aliceRef)(WhoAreYou2(17, _)) {
case Success(name) => TheReply(name)
case Failure(ex) => TheReply(ex.getMessage)
}
Behaviors.empty
}
*/
} }
"EntityRef - AskTimeoutException" in { "EntityRef - AskTimeoutException" in {

View file

@ -40,7 +40,7 @@ import akka.actor.typed.Terminated
val untypedReplicator = underlyingReplicator match { val untypedReplicator = underlyingReplicator match {
case Some(ref) => ref case Some(ref) => ref
case None => case None =>
// FIXME perhaps add supervisor for restarting // FIXME perhaps add supervisor for restarting, see PR https://github.com/akka/akka/pull/25988
val untypedReplicatorProps = dd.Replicator.props(settings) val untypedReplicatorProps = dd.Replicator.props(settings)
ctx.actorOf(untypedReplicatorProps, name = "underlying") ctx.actorOf(untypedReplicatorProps, name = "underlying")
} }

View file

@ -122,7 +122,7 @@ private[typed] object ClusterReceptionist extends ReceptionistBehaviorProvider {
/* /*
* Hack to allow multiple termination notifications per target * Hack to allow multiple termination notifications per target
* FIXME: replace by simple map in our state * FIXME #26505: replace by simple map in our state
*/ */
def watchWith(ctx: ActorContext[Command], target: ActorRef[_], msg: InternalCommand): Unit = def watchWith(ctx: ActorContext[Command], target: ActorRef[_], msg: InternalCommand): Unit =
ctx.spawnAnonymous[Nothing](Behaviors.setup[Nothing] { innerCtx => ctx.spawnAnonymous[Nothing](Behaviors.setup[Nothing] { innerCtx =>

View file

@ -14,8 +14,7 @@ import akka.actor.testkit.typed.javadsl.TestProbe;
import com.typesafe.config.Config; import com.typesafe.config.Config;
import com.typesafe.config.ConfigFactory; import com.typesafe.config.ConfigFactory;
// FIXME these tests are awaiting typed Java testkit to be able to await cluster forming like in // FIXME use awaitAssert to await cluster forming like in BasicClusterExampleSpec
// BasicClusterExampleSpec
public class BasicClusterExampleTest { // extends JUnitSuite { public class BasicClusterExampleTest { // extends JUnitSuite {
private Config clusterConfig = private Config clusterConfig =

View file

@ -488,7 +488,7 @@ class EventSourcedBehaviorStashSpec
"discard when stash has reached limit with default dropped setting" in { "discard when stash has reached limit with default dropped setting" in {
val probe = TestProbe[AnyRef]() val probe = TestProbe[AnyRef]()
system.toUntyped.eventStream.subscribe(probe.ref.toUntyped, classOf[Dropped]) system.toUntyped.eventStream.subscribe(probe.ref.toUntyped, classOf[Dropped])
val behavior = EventSourcedBehavior[String, String, Boolean](PersistenceId("stash-is-full-drop"), val behavior = EventSourcedBehavior[String, String, Boolean](persistenceId = PersistenceId("stash-is-full-drop"),
emptyState = false, emptyState = false,
commandHandler = { (state, command) => commandHandler = { (state, command) =>
state match { state match {
@ -510,8 +510,7 @@ class EventSourcedBehaviorStashSpec
Effect Effect
.persist("unstash") .persist("unstash")
.thenUnstashAll() .thenUnstashAll()
// FIXME this is run before unstash, so not sequentially as the docs say // FIXME #26489: this is run before unstash, so not sequentially as the docs say
// https://github.com/akka/akka/issues/26489
.thenRun(_ => .thenRun(_ =>
probe.ref ! "done-unstashing") probe.ref ! "done-unstashing")
case _ => case _ =>
@ -587,6 +586,6 @@ class EventSourcedBehaviorStashSpec
} }
} }
// FIXME test combination with PoisonPill // FIXME #24687: test combination with PoisonPill
} }