akka

dispatch

package dispatch

Content Hierarchy Learn more about scaladoc diagrams
Visibility
  1. Public
  2. All

Type Members

  1. abstract class AbstractNodeQueue[T] extends AtomicReference[Node[T]]

  2. class BalancingDispatcherConfigurator extends MessageDispatcherConfigurator

    Configurator for creating akka.dispatch.BalancingDispatcher.

    Configurator for creating akka.dispatch.BalancingDispatcher. Returns the same dispatcher instance for for each invocation of the dispatcher() method.

  3. case class BoundedDequeBasedMailbox(capacity: Int, pushTimeOut: FiniteDuration) extends MailboxType with ProducesMessageQueue[dispatch.BoundedDequeBasedMailbox.MessageQueue] with Product with Serializable

    BoundedDequeBasedMailbox is an bounded MailboxType, backed by a Deque.

  4. trait BoundedDequeBasedMessageQueue extends DequeBasedMessageQueue with BoundedDequeBasedMessageQueueSemantics

    BoundedMessageQueueSemantics adds bounded semantics to a DequeBasedMessageQueue, i.e.

    BoundedMessageQueueSemantics adds bounded semantics to a DequeBasedMessageQueue, i.e. blocking enqueue with timeout.

  5. trait BoundedDequeBasedMessageQueueSemantics extends DequeBasedMessageQueueSemantics with BoundedMessageQueueSemantics

  6. case class BoundedMailbox(capacity: Int, pushTimeOut: FiniteDuration) extends MailboxType with ProducesMessageQueue[dispatch.BoundedMailbox.MessageQueue] with Product with Serializable

    BoundedMailbox is the default bounded MailboxType used by Akka Actors.

  7. trait BoundedMessageQueueSemantics extends AnyRef

    BoundedMessageQueueSemantics adds bounded semantics to a QueueBasedMessageQueue, i.e.

    BoundedMessageQueueSemantics adds bounded semantics to a QueueBasedMessageQueue, i.e. blocking enqueue with timeout.

  8. class BoundedPriorityMailbox extends MailboxType with ProducesMessageQueue[dispatch.BoundedPriorityMailbox.MessageQueue]

    BoundedPriorityMailbox is a bounded mailbox that allows for prioritization of its contents.

    BoundedPriorityMailbox is a bounded mailbox that allows for prioritization of its contents. Extend this class and provide the Comparator in the constructor.

  9. trait BoundedQueueBasedMessageQueue extends QueueBasedMessageQueue with BoundedMessageQueueSemantics

  10. class DefaultExecutorServiceConfigurator extends ExecutorServiceConfigurator

  11. trait DequeBasedMessageQueue extends QueueBasedMessageQueue with DequeBasedMessageQueueSemantics

  12. trait DequeBasedMessageQueueSemantics extends AnyRef

    DequeBasedMessageQueue refines QueueBasedMessageQueue to be backed by a java.util.Deque.

  13. class Dispatcher extends MessageDispatcher

    The event-based Dispatcher binds a set of Actors to a thread pool backed up by a BlockingQueue.

    The event-based Dispatcher binds a set of Actors to a thread pool backed up by a BlockingQueue.

    The preferred way of creating dispatchers is to define configuration of it and use the the lookup method in akka.dispatch.Dispatchers.

  14. class DispatcherConfigurator extends MessageDispatcherConfigurator

    Configurator for creating akka.dispatch.Dispatcher.

    Configurator for creating akka.dispatch.Dispatcher. Returns the same dispatcher instance for for each invocation of the dispatcher() method.

  15. trait DispatcherPrerequisites extends AnyRef

    DispatcherPrerequisites represents useful contextual pieces when constructing a MessageDispatcher

  16. class Dispatchers extends AnyRef

    Dispatchers are to be defined in configuration to allow for tuning for different environments.

    Dispatchers are to be defined in configuration to allow for tuning for different environments. Use the lookup method to create a dispatcher as specified in configuration.

    Look in akka.actor.default-dispatcher section of the reference.conf for documentation of dispatcher options.

  17. final case class Envelope extends Product with Serializable

  18. abstract class ExecutorServiceConfigurator extends ExecutorServiceFactoryProvider

    An ExecutorServiceConfigurator is a class that given some prerequisites and a configuration can create instances of ExecutorService

  19. trait ExecutorServiceDelegate extends ExecutorService

    As the name says

  20. trait ExecutorServiceFactory extends AnyRef

    Function0 without the fun stuff (mostly for the sake of the Java API side of things)

  21. trait ExecutorServiceFactoryProvider extends AnyRef

    Generic way to specify an ExecutorService to a Dispatcher, create it with the given name if desired

  22. abstract class Foreach[-T] extends UnitFunctionBridge[T]

    Callback for the Future.foreach operation that will be invoked if the Future that this callback is registered on becomes completed with a success.

    Callback for the Future.foreach operation that will be invoked if the Future that this callback is registered on becomes completed with a success. This method is essentially the same operation as onSuccess.

    SAM (Single Abstract Method) class Java API

  23. class ForkJoinExecutorConfigurator extends ExecutorServiceConfigurator

  24. trait MailboxType extends AnyRef

    MailboxType is a factory to create MessageQueues for an optionally provided ActorContext.

    MailboxType is a factory to create MessageQueues for an optionally provided ActorContext.

    Possibly Important Notice

    When implementing a custom mailbox type, be aware that there is special semantics attached to system.actorOf() in that sending to the returned ActorRef may—for a short period of time—enqueue the messages first in a dummy queue. Top-level actors are created in two steps, and only after the guardian actor has performed that second step will all previously sent messages be transferred from the dummy queue into the real mailbox.

  25. abstract class Mapper[-T, +R] extends AbstractFunction1[T, R]

    Callback for the Future.map and Future.flatMap operations that will be invoked if the Future that this callback is registered on becomes completed with a success.

    Callback for the Future.map and Future.flatMap operations that will be invoked if the Future that this callback is registered on becomes completed with a success. This callback is the equivalent of an akka.japi.Function

    Override "apply" normally, or "checkedApply" if you need to throw checked exceptions.

    SAM (Single Abstract Method) class

    Java API

  26. abstract class MessageDispatcher extends AbstractMessageDispatcher with BatchingExecutor with ExecutionContextExecutor

  27. abstract class MessageDispatcherConfigurator extends AnyRef

    Base class to be used for hooking in new dispatchers into Dispatchers.

  28. trait MessageQueue extends AnyRef

    A MessageQueue is one of the core components in forming an Akka Mailbox.

    A MessageQueue is one of the core components in forming an Akka Mailbox. The MessageQueue is where the normal messages that are sent to Actors will be enqueued (and subsequently dequeued) It needs to at least support N producers and 1 consumer thread-safely.

  29. case class MonitorableThreadFactory(name: String, daemonic: Boolean, contextClassLoader: Option[ClassLoader], exceptionHandler: UncaughtExceptionHandler = MonitorableThreadFactory.doNothing, counter: AtomicLong = new AtomicLong) extends ThreadFactory with ForkJoinWorkerThreadFactory with Product with Serializable

  30. trait MultipleConsumerSemantics extends AnyRef

    This is a marker trait for message queues which support multiple consumers, as is required by the BalancingDispatcher.

  31. class NodeMessageQueue extends AbstractNodeQueue[Envelope] with MessageQueue with UnboundedMessageQueueSemantics

  32. abstract class OnComplete[-T] extends CallbackBridge[Try[T]]

    Callback for when a Future is completed with either failure or a success SAM (Single Abstract Method) class

    Callback for when a Future is completed with either failure or a success SAM (Single Abstract Method) class

    Java API

  33. abstract class OnFailure extends CallbackBridge[Throwable]

    Callback for when a Future is completed with a failure SAM (Single Abstract Method) class

    Callback for when a Future is completed with a failure SAM (Single Abstract Method) class

    Java API

  34. abstract class OnSuccess[-T] extends CallbackBridge[T]

    Callback for when a Future is completed successfully SAM (Single Abstract Method) class

    Callback for when a Future is completed successfully SAM (Single Abstract Method) class

    Java API

  35. class PinnedDispatcher extends Dispatcher

    Dedicates a unique thread for each actor passed in as reference.

    Dedicates a unique thread for each actor passed in as reference. Served through its messageQueue.

    The preferred way of creating dispatchers is to define configuration of it and use the the lookup method in akka.dispatch.Dispatchers.

  36. class PinnedDispatcherConfigurator extends MessageDispatcherConfigurator

    Configurator for creating akka.dispatch.PinnedDispatcher.

    Configurator for creating akka.dispatch.PinnedDispatcher. Returns new dispatcher instance for for each invocation of the dispatcher() method.

  37. abstract class PriorityGenerator extends Comparator[Envelope]

    A PriorityGenerator is a convenience API to create a Comparator that orders the messages of a PriorityDispatcher

  38. trait ProducesMessageQueue[T <: MessageQueue] extends AnyRef

  39. trait QueueBasedMessageQueue extends MessageQueue with MultipleConsumerSemantics

    A QueueBasedMessageQueue is a MessageQueue backed by a java.util.Queue.

  40. abstract class Recover[+T] extends RecoverBridge[T]

    Callback for the Future.recover operation that conditionally turns failures into successes.

    Callback for the Future.recover operation that conditionally turns failures into successes.

    SAM (Single Abstract Method) class

    Java API

  41. trait RequiresMessageQueue[T] extends AnyRef

    Trait to signal that an Actor requires a certain type of message queue semantics.

    Trait to signal that an Actor requires a certain type of message queue semantics.

    The mailbox type will be looked up by mapping the type T via akka.actor.mailbox.requirements in the config, to a mailbox configuration. If no mailbox is assigned on Props or in deployment config then this one will be used.

    The queue type of the created mailbox will be checked against the type T and actor creation will fail if it doesn't fulfill the requirements.

  42. class SaneRejectedExecutionHandler extends RejectedExecutionHandler

    The RejectedExecutionHandler used by Akka, it improves on CallerRunsPolicy by throwing a RejectedExecutionException if the executor isShutdown.

    The RejectedExecutionHandler used by Akka, it improves on CallerRunsPolicy by throwing a RejectedExecutionException if the executor isShutdown. (CallerRunsPolicy silently discards the runnable in this case, which is arguably broken)

  43. case class SingleConsumerOnlyUnboundedMailbox() extends MailboxType with ProducesMessageQueue[NodeMessageQueue] with Product with Serializable

    SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType, with the drawback that you can't have multiple consumers, which rules out using it with BalancingPool (BalancingDispatcher) for instance.

    SingleConsumerOnlyUnboundedMailbox is a high-performance, multiple producer—single consumer, unbounded MailboxType, with the drawback that you can't have multiple consumers, which rules out using it with BalancingPool (BalancingDispatcher) for instance.

    Currently this queue is slower for some benchmarks than the ConcurrentLinkedQueue from JDK 8 that is used by default, so be sure to measure the performance in your particular setting in order to determine which one to use.

  44. final case class TaskInvocation(eventStream: EventStream, runnable: Runnable, cleanup: () ⇒ Unit) extends Batchable with Product with Serializable

  45. case class ThreadPoolConfig(allowCorePoolTimeout: Boolean = ..., corePoolSize: Int = ..., maxPoolSize: Int = ThreadPoolConfig.defaultMaxPoolSize, threadTimeout: Duration = ThreadPoolConfig.defaultTimeout, queueFactory: QueueFactory = ..., rejectionPolicy: RejectedExecutionHandler = ...) extends ExecutorServiceFactoryProvider with Product with Serializable

    A small configuration DSL to create ThreadPoolExecutors that can be provided as an ExecutorServiceFactoryProvider to Dispatcher

  46. case class ThreadPoolConfigBuilder(config: ThreadPoolConfig) extends Product with Serializable

    A DSL to configure and create a MessageDispatcher with a ThreadPoolExecutor

  47. class ThreadPoolExecutorConfigurator extends ExecutorServiceConfigurator

  48. case class UnboundedDequeBasedMailbox() extends MailboxType with ProducesMessageQueue[dispatch.UnboundedDequeBasedMailbox.MessageQueue] with Product with Serializable

    UnboundedDequeBasedMailbox is an unbounded MailboxType, backed by a Deque.

  49. trait UnboundedDequeBasedMessageQueue extends DequeBasedMessageQueue with UnboundedDequeBasedMessageQueueSemantics

    UnboundedDequeBasedMessageQueueSemantics adds unbounded semantics to a DequeBasedMessageQueue, i.e.

    UnboundedDequeBasedMessageQueueSemantics adds unbounded semantics to a DequeBasedMessageQueue, i.e. a non-blocking enqueue and dequeue.

  50. trait UnboundedDequeBasedMessageQueueSemantics extends DequeBasedMessageQueueSemantics with UnboundedMessageQueueSemantics

  51. case class UnboundedMailbox() extends MailboxType with ProducesMessageQueue[dispatch.UnboundedMailbox.MessageQueue] with Product with Serializable

    UnboundedMailbox is the default unbounded MailboxType used by Akka Actors.

  52. trait UnboundedMessageQueueSemantics extends AnyRef

    UnboundedMessageQueueSemantics adds unbounded semantics to a QueueBasedMessageQueue, i.e.

    UnboundedMessageQueueSemantics adds unbounded semantics to a QueueBasedMessageQueue, i.e. a non-blocking enqueue and dequeue.

  53. class UnboundedPriorityMailbox extends MailboxType with ProducesMessageQueue[dispatch.UnboundedPriorityMailbox.MessageQueue]

    UnboundedPriorityMailbox is an unbounded mailbox that allows for prioritization of its contents.

    UnboundedPriorityMailbox is an unbounded mailbox that allows for prioritization of its contents. Extend this class and provide the Comparator in the constructor.

  54. trait UnboundedQueueBasedMessageQueue extends QueueBasedMessageQueue with UnboundedMessageQueueSemantics

  55. class BalancingDispatcher extends Dispatcher

    An executor based event driven dispatcher which will try to redistribute work from busy actors to idle actors.

    An executor based event driven dispatcher which will try to redistribute work from busy actors to idle actors. It is assumed that all actors using the same instance of this dispatcher can process all messages that have been sent to one of the actors. I.e. the actors belong to a pool of actors, and to the client there is no guarantee about which actor instance actually processes a given message.

    Although the technique used in this implementation is commonly known as "work stealing", the actual implementation is probably best described as "work donating" because the actor of which work is being stolen takes the initiative.

    The preferred way of creating dispatchers is to define configuration of it and use the the lookup method in akka.dispatch.Dispatchers.

    Annotations
    @deprecated
    Deprecated

    (Since version 2.3) Use BalancingPool instead of BalancingDispatcher

    See also

    akka.dispatch.Dispatchers

    akka.dispatch.BalancingDispatcher

Value Members

  1. object BoundedDequeBasedMailbox extends Serializable

  2. object BoundedMailbox extends Serializable

  3. object BoundedPriorityMailbox

  4. object Dispatchers

  5. object Envelope extends Serializable

  6. object ExecutionContexts

    ExecutionContexts is the Java API for ExecutionContexts

  7. object Filter

    Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.

    Java API (not recommended): Callback for the Future.filter operation that creates a new Future which will conditionally contain the success of another Future.

    Unfortunately it is not possible to express the type of a Scala filter in Java: Function1[T, Boolean], where “Boolean” is the primitive type. It is possible to use Future.filter by constructing such a function indirectly:

    import static akka.dispatch.Filter.filterOf;
    Future<String> f = ...;
    f.filter(filterOf(new Function<String, Boolean>() {
      @Override
      public Boolean apply(String s) {
        ...
      }
    }));

    However, Future.filter exists mainly to support Scala’s for-comprehensions, thus Java users should prefer Future.map, translating non-matching values to failure cases.

  8. object ForkJoinExecutorConfigurator

  9. object Futures

    Futures is the Java API for Futures and Promises

  10. object Mailboxes

  11. object MonitorableThreadFactory extends Serializable

  12. object PriorityGenerator

  13. object ThreadPoolConfig extends Serializable

  14. object UnboundedDequeBasedMailbox extends Serializable

  15. object UnboundedMailbox extends Serializable

  16. object UnboundedPriorityMailbox

  17. object japi

    This class contains bridge classes between Scala and Java.

    This class contains bridge classes between Scala and Java. Internal use only.

Ungrouped