akka.testkit

package akka.testkit

Type members

Classlikes

Dispatcher which runs invocations on the current thread only. This dispatcher does not create any new threads, but it can be used from different threads concurrently for the same actor. The dispatch strategy is to run on the current thread unless the target actor is either suspendSwitch or already running on the current thread (if it is running on a different thread, then this thread will block until that other invocation is finished); if the invocation is not run, it is queued in a thread-local queue to be executed once the active invocation further up the call stack finishes. This leads to completely deterministic execution order if only one thread is used.

Dispatcher which runs invocations on the current thread only. This dispatcher does not create any new threads, but it can be used from different threads concurrently for the same actor. The dispatch strategy is to run on the current thread unless the target actor is either suspendSwitch or already running on the current thread (if it is running on a different thread, then this thread will block until that other invocation is finished); if the invocation is not run, it is queued in a thread-local queue to be executed once the active invocation further up the call stack finishes. This leads to completely deterministic execution order if only one thread is used.

Suspending and resuming are global actions for one actor, meaning they can affect different threads, which leads to complications. If messages are queued (thread-locally) during the suspendSwitch period, the only thread to run them upon resume is the thread actually calling the resume method. Hence, all thread-local queues which are not currently being drained (possible, since suspend-queue-resume might happen entirely during an invocation on a different thread) are scooped up into the current thread-local queue which is then executed. It is possible to suspend an actor from within its call stack.

Since:

1.1

Companion:
object
Source:
CallingThreadDispatcher.scala
final case class CustomEventFilter(test: PartialFunction[LogEvent, Boolean])(occurrences: Int) extends EventFilter

Custom event filter when the others do not fit the bill.

Custom event filter when the others do not fit the bill.

If the partial function is defined and returns true, filter the event.

Source:
TestEventListener.scala
final case class DeadLettersFilter(messageClass: Class[_])(occurrences: Int) extends EventFilter

Filter which matches DeadLetter events, if the wrapped message conforms to the given type.

Filter which matches DeadLetter events, if the wrapped message conforms to the given type.

Companion:
object
Source:
TestEventListener.scala
final case class DebugFilter(source: Option[String], message: Either[String, Regex], complete: Boolean)(occurrences: Int) extends EventFilter

Filter which matches Debug events, if they satisfy the given criteria:

Filter which matches Debug events, if they satisfy the given criteria:

  • source, if given, applies a filter on the event’s origin

  • message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined)

If you want to match all Debug events, the most efficient is to use Left("").

Source:
TestEventListener.scala
final case class ErrorFilter(throwable: Class[_], source: Option[String], message: Either[String, Regex], complete: Boolean)(occurrences: Int) extends EventFilter

Filter which matches Error events, if they satisfy the given criteria:

Filter which matches Error events, if they satisfy the given criteria:

  • throwable applies an upper bound on the type of exception contained in the Error event

  • source, if given, applies a filter on the event’s origin

  • message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined); if the message itself does not match, the match is retried with the contained Exception’s message; if both are null, the filter always matches if at the same time the Exception’s stack trace is empty (this catches JVM-omitted “fast-throw” exceptions)

If you want to match all Error events, the most efficient is to use Left("").

Source:
TestEventListener.scala
abstract class EventFilter(occurrences: Int)

Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.

Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.

See the companion object for convenient factory methods.

If the occurrences is set to Int.MaxValue, no tracking is done.

Companion:
object
Source:
TestEventListener.scala

Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.

Facilities for selectively filtering out expected events from logging so that you can keep your test run’s console output clean and do not miss real error messages.

'''Also have a look at the akka.testkit package object’s filterEvents and filterException methods.'''

The source filters do accept Class[_] arguments, matching any object which is an instance of the given class, e.g.

EventFilter.info(source = classOf[MyActor]) // will match Info events from any MyActor instance

The message object will be converted to a string before matching ("null" if it is null).

Companion:
class
Source:
TestEventListener.scala
class ExplicitlyTriggeredScheduler(@unused config: Config, log: LoggingAdapter, @unused tf: ThreadFactory) extends Scheduler

For testing: scheduler that does not look at the clock, but must be progressed manually by calling timePasses.

For testing: scheduler that does not look at the clock, but must be progressed manually by calling timePasses.

This allows for faster and less timing-sensitive specs, as jobs will be executed on the test thread instead of using the original {ExecutionContext}. This means recreating specific scenario's becomes easier, but these tests might fail to catch race conditions that only happen when tasks are scheduled in parallel in 'real time'.

Source:
ExplicitlyTriggeredScheduler.scala
final case class InfoFilter(source: Option[String], message: Either[String, Regex], complete: Boolean)(occurrences: Int) extends EventFilter

Filter which matches Info events, if they satisfy the given criteria:

Filter which matches Info events, if they satisfy the given criteria:

  • source, if given, applies a filter on the event’s origin

  • message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined)

If you want to match all Info events, the most efficient is to use Left("").

Source:
TestEventListener.scala
trait JavaSerializable extends Serializable

Marker trait for test messages that will use Java serialization via akka.testkit.TestJavaSerializer

Marker trait for test messages that will use Java serialization via akka.testkit.TestJavaSerializer

Source:
JavaSerializable.scala
object SocketUtil

Utilities to get free socket address.

Utilities to get free socket address.

Source:
SocketUtil.scala
object TestActor
Companion:
class
Source:
TestKit.scala
class TestActor(queue: BlockingDeque[Message]) extends Actor
Companion:
object
Source:
TestKit.scala
class TestActorRef[T <: Actor](_system: ActorSystem, _props: Props, _supervisor: ActorRef, name: String) extends LocalActorRef

This special ActorRef is exclusively for use during unit testing in a single-threaded environment. Therefore, it overrides the dispatcher to CallingThreadDispatcher and sets the receiveTimeout to None. Otherwise, it acts just like a normal ActorRef. You may retrieve a reference to the underlying actor to test internal logic.

This special ActorRef is exclusively for use during unit testing in a single-threaded environment. Therefore, it overrides the dispatcher to CallingThreadDispatcher and sets the receiveTimeout to None. Otherwise, it acts just like a normal ActorRef. You may retrieve a reference to the underlying actor to test internal logic.

Since:

1.1

Companion:
object
Source:
TestActorRef.scala
Companion:
class
Source:
TestActorRef.scala
object TestActors

A collection of common actor patterns used in tests.

A collection of common actor patterns used in tests.

Source:
TestActors.scala

A cyclic barrier wrapper for use in testing. It always uses a timeout when waiting and timeouts are specified as durations. Timeouts will always throw an exception. The default timeout is 5 seconds. Timeouts are multiplied by the testing time factor for Jenkins builds.

A cyclic barrier wrapper for use in testing. It always uses a timeout when waiting and timeouts are specified as durations. Timeouts will always throw an exception. The default timeout is 5 seconds. Timeouts are multiplied by the testing time factor for Jenkins builds.

Companion:
class
Source:
TestBarrier.scala
class TestBarrier(count: Int)
Companion:
object
Source:
TestBarrier.scala
class TestBarrierTimeoutException(message: String) extends RuntimeException
final implicit implicit class TestDuration(val duration: FiniteDuration) extends AnyVal

Scala API. Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'. Implicit class providing dilated method.

Scala API. Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'. Implicit class providing dilated method.

import scala.concurrent.duration._
import akka.testkit._
10.milliseconds.dilated

Corresponding Java API is available in JavaTestKit.dilated()

Source:
package.scala
sealed trait TestEvent

Implementation helpers of the EventFilter facilities: send Mute to the TestEventListener to install a filter, and UnMute to uninstall it.

Implementation helpers of the EventFilter facilities: send Mute to the TestEventListener to install a filter, and UnMute to uninstall it.

You should always prefer the filter methods in the package object (see akka.testkit filterEvents and filterException) or on the EventFilter implementations.

Companion:
object
Source:
TestEventListener.scala
object TestEvent

Implementation helpers of the EventFilter facilities: send Mute to the TestEventFilter to install a filter, and UnMute to uninstall it.

Implementation helpers of the EventFilter facilities: send Mute to the TestEventFilter to install a filter, and UnMute to uninstall it.

You should always prefer the filter methods in the package object (see akka.testkit filterEvents and filterException) or on the EventFilter implementations.

Companion:
class
Source:
TestEventListener.scala

EventListener for running tests, which allows selectively filtering out expected messages. To use it, include something like this into akka.test.conf and run your tests with system property "akka.mode" set to "test":

EventListener for running tests, which allows selectively filtering out expected messages. To use it, include something like this into akka.test.conf and run your tests with system property "akka.mode" set to "test":


akka {
 loggers = ["akka.testkit.TestEventListener"]
}

Source:
TestEventListener.scala
final case class TestException(message: String) extends RuntimeException with NoStackTrace

A predefined exception that can be used in tests. It doesn't include a stack trace.

A predefined exception that can be used in tests. It doesn't include a stack trace.

Source:
TestException.scala
class TestFSMRef[S, D, T <: Actor](system: ActorSystem, props: Props, supervisor: ActorRef, name: String)(implicit ev: T <:< FSM[S, D]) extends TestActorRef[T]

This is a specialized form of the TestActorRef with support for querying and setting the state of a FSM. Use a LoggingFSM with this class if you also need to inspect event traces.

This is a specialized form of the TestActorRef with support for querying and setting the state of a FSM. Use a LoggingFSM with this class if you also need to inspect event traces.


val fsm = TestFSMRef(new Actor with LoggingFSM[Int, Null] {
   override def logDepth = 12
   startWith(1, null)
   when(1) {
     case Event("hello", _) => goto(2)
   }
   when(2) {
     case Event("world", _) => goto(1)
   }
 })
assert (fsm.stateName == 1)
fsm ! "hallo"
assert (fsm.stateName == 2)
assert (fsm.underlyingActor.getLog == IndexedSeq(FSMLogEntry(1, null, "hallo")))

Since:

1.2

Companion:
object
Source:
TestFSMRef.scala
object TestFSMRef
Companion:
class
Source:
TestFSMRef.scala

This Serializer uses standard Java Serialization and is useful for tests where ad-hoc messages are created and sent between actor systems. It needs to be explicitly enabled in the config (or through ActorSystemSetup) like so:

This Serializer uses standard Java Serialization and is useful for tests where ad-hoc messages are created and sent between actor systems. It needs to be explicitly enabled in the config (or through ActorSystemSetup) like so:

akka.actor.serialization-bindings {
 "my.test.AdHocMessage" = java-test
}
Source:
TestJavaSerializer.scala
class TestKit(_system: ActorSystem) extends TestKitBase

Test kit for testing actors. Inheriting from this class enables reception of replies from actors, which are queued by an internal actor and can be examined using the expectMsg... methods. Assertions and bounds concerning timing are available in the form of within blocks.

Test kit for testing actors. Inheriting from this class enables reception of replies from actors, which are queued by an internal actor and can be examined using the expectMsg... methods. Assertions and bounds concerning timing are available in the form of within blocks.

class Test extends TestKit(ActorSystem()) {
 try {

   val test = system.actorOf(Props[SomeActor])

     within (1.second) {
       test ! SomeWork
       expectMsg(Result1) // bounded to 1 second
       expectMsg(Result2) // bounded to the remainder of the 1 second
     }

   } finally {
     system.terminate()
   }

 } finally {
   system.terminate()
 }
}

Beware of two points:

  • the ActorSystem passed into the constructor needs to be shutdown, otherwise thread pools and memory will be leaked
  • this class is not thread-safe (only one actor with one queue, one stack of within blocks); it is expected that the code is executed from a constructor as shown above, which makes this a non-issue, otherwise take care not to run tests within a single test class instance in parallel.

It should be noted that for CI servers and the like all maximum Durations are scaled using their Duration.dilated method, which uses the TestKitExtension.Settings.TestTimeFactor settable via akka.conf entry "akka.test.timefactor".

Since:

1.1

Companion:
object
Source:
TestKit.scala
object TestKit
Companion:
class
Source:
TestKit.scala

Implementation trait behind the akka.testkit.TestKit class: you may use this if inheriting from a concrete class is not possible.

Implementation trait behind the akka.testkit.TestKit class: you may use this if inheriting from a concrete class is not possible.

This trait requires the concrete class mixing it in to provide an akka.actor.ActorSystem which is available before this traits’s constructor is run. The recommended way is this:

class MyTest extends TestKitBase {
 implicit lazy val system = ActorSystem() // may add arguments here
 ...
}
Source:
TestKit.scala
class TestKitSettings(val config: Config) extends Extension
object TestLatch

A count down latch wrapper for use in testing. It always uses a timeout when waiting and timeouts are specified as durations. There's a default timeout of 5 seconds and the default count is 1. Timeouts will always throw an exception (no need to wrap in assert in tests). Timeouts are multiplied by the testing time factor for Jenkins builds.

A count down latch wrapper for use in testing. It always uses a timeout when waiting and timeouts are specified as durations. There's a default timeout of 5 seconds and the default count is 1. Timeouts will always throw an exception (no need to wrap in assert in tests). Timeouts are multiplied by the testing time factor for Jenkins builds.

Companion:
class
Source:
TestLatch.scala
class TestLatch(count: Int)(implicit system: ActorSystem) extends Awaitable[Unit]
Companion:
object
Source:
TestLatch.scala
class TestProbe(_application: ActorSystem, name: String) extends TestKit

TestKit-based probe which allows sending, reception and reply.

TestKit-based probe which allows sending, reception and reply.

Companion:
object
Source:
TestKit.scala
object TestProbe
Companion:
class
Source:
TestKit.scala
final case class WarningFilter(source: Option[String], message: Either[String, Regex], complete: Boolean)(occurrences: Int) extends EventFilter

Filter which matches Warning events, if they satisfy the given criteria:

Filter which matches Warning events, if they satisfy the given criteria:

  • source, if given, applies a filter on the event’s origin

  • message applies a filter on the event’s message (either with String.startsWith or Regex.findFirstIn().isDefined)

If you want to match all Warning events, the most efficient is to use Left("").

Source:
TestEventListener.scala

Value members

Concrete methods

def filterEvents[T](eventFilters: Iterable[EventFilter])(block: => T)(implicit system: ActorSystem): T
def filterEvents[T](eventFilters: EventFilter*)(block: => T)(implicit system: ActorSystem): T
def filterException[T <: Throwable](block: => Unit)(implicit system: ActorSystem, t: ClassTag[T]): Unit

Implicits

Implicits

final implicit def TestDuration(duration: FiniteDuration): TestDuration

Scala API. Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'. Implicit class providing dilated method.

Scala API. Scale timeouts (durations) during tests with the configured 'akka.test.timefactor'. Implicit class providing dilated method.

import scala.concurrent.duration._
import akka.testkit._
10.milliseconds.dilated

Corresponding Java API is available in JavaTestKit.dilated()

Source:
package.scala