Class/Object

com.rbmhtechnology.eventuate

AbstractEventsourcedProcessor

Related Docs: object AbstractEventsourcedProcessor | package eventuate

Permalink

class AbstractEventsourcedProcessor extends AbstractEventsourcedComponent with EventsourcedProcessor with EventSourcedProcessorAdapter with EventsourcedProcessorWriteSuccessHandlerAdapter

Java API for actors that implement EventsourcedProcessor.

See also

EventsourcedProcessor

AbstractEventsourcedView for a detailed usage of the Java API

Linear Supertypes
EventsourcedProcessorWriteSuccessHandlerAdapter, EventSourcedProcessorAdapter, EventsourcedWriterFailureHandlerAdapter, EventsourcedProcessorHandlers, EventsourcedProcessor, ActorLogging, EventsourcedWriter[Long, Long], EventsourcedWriterFailureHandlers, EventsourcedWriterSuccessHandlers[Long, Long], AbstractEventsourcedComponent, ConditionalRequests, EventsourcedVersion, EventsourcedView, Stash, RequiresMessageQueue[DequeBasedMessageQueueSemantics], UnrestrictedStash, StashSupport, Actor, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. AbstractEventsourcedProcessor
  2. EventsourcedProcessorWriteSuccessHandlerAdapter
  3. EventSourcedProcessorAdapter
  4. EventsourcedWriterFailureHandlerAdapter
  5. EventsourcedProcessorHandlers
  6. EventsourcedProcessor
  7. ActorLogging
  8. EventsourcedWriter
  9. EventsourcedWriterFailureHandlers
  10. EventsourcedWriterSuccessHandlers
  11. AbstractEventsourcedComponent
  12. ConditionalRequests
  13. EventsourcedVersion
  14. EventsourcedView
  15. Stash
  16. RequiresMessageQueue
  17. UnrestrictedStash
  18. StashSupport
  19. Actor
  20. AnyRef
  21. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new AbstractEventsourcedProcessor(id: String, eventLog: ActorRef, targetEventLog: ActorRef)

    Permalink

Type Members

  1. type Handler[A] = (Try[A]) ⇒ Unit

    Permalink
    Definition Classes
    EventsourcedView
  2. type Process = PartialFunction[Any, Seq[Any]]

    Permalink

    Type of this processor's event handler.

    Type of this processor's event handler.

    Definition Classes
    EventsourcedProcessor
  3. type Receive = PartialFunction[Any, Unit]

    Permalink
    Definition Classes
    Actor

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def aggregateId: Option[String]

    Permalink

    Optional aggregate id.

    Optional aggregate id. It is used for routing DurableEvents to event-sourced destinations which can be EventsourcedViews or EventsourcedActors. By default, an event is routed to an event-sourced destination with an undefined aggregateId. If a destination's aggregateId is defined it will only receive events with a matching aggregate id in DurableEvent#destinationAggregateIds.

    Definition Classes
    AbstractEventsourcedComponent → EventsourcedView
  5. def aroundPostRestart(reason: Throwable): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
    Annotations
    @InternalApi()
  6. def aroundPostStop(): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
    Annotations
    @InternalApi()
  7. def aroundPreRestart(reason: Throwable, message: Option[Any]): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
    Annotations
    @InternalApi()
  8. def aroundPreStart(): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
    Annotations
    @InternalApi()
  9. def aroundReceive(receive: akka.actor.Actor.Receive, msg: Any): Unit

    Permalink
    Attributes
    protected[akka]
    Definition Classes
    Actor
    Annotations
    @InternalApi()
  10. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  11. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  12. def commandContext: BehaviorContext

    Permalink

    Returns the command BehaviorContext.

    Returns the command BehaviorContext.

    Definition Classes
    EventsourcedView
  13. implicit val context: ActorContext

    Permalink
    Definition Classes
    Actor
  14. def createOnCommand(): akka.actor.AbstractActor.Receive

    Permalink

    Java API of the command handler.

    Java API of the command handler.

    Returns a receive object that defines the actor's command handling behaviour. Use ReceiveBuilder to define the behaviour.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  15. def createOnProcessEvent(): AbstractEventsourcedProcessor.Process

    Permalink

    Java API of event-processing handler.

    Java API of event-processing handler.

    Returns a AbstractEventsourcedProcessor.Process that defines the actor's event processing behaviour. Use ProcessBuilder to define the behaviour.

    Definition Classes
    EventSourcedProcessorAdapter
    See also

    EventsourcedProcessor

  16. def createOnRecovery(): ResultHandler[Unit]

    Permalink

    Java API of the recovery handler.

    Java API of the recovery handler.

    Returns a result handler that defines the actor's recover handling behaviour. Use ResultHandler to define the behaviour.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  17. def createOnSnapshot(): akka.actor.AbstractActor.Receive

    Permalink

    Java API of the snapshot handler.

    Java API of the snapshot handler.

    Returns a receive object that defines the actor's snapshot handling behaviour. Use ReceiveBuilder to define the behaviour.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  18. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  19. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  20. final lazy val eventContext: BehaviorContext

    Permalink

    Returns an command BehaviorContext that doesn't allow event handler behavior changes.

    Returns an command BehaviorContext that doesn't allow event handler behavior changes. An attempt to change the event handler behavior with eventContext.become() will throw an UnsupportedOperationException.

    Definition Classes
    EventsourcedProcessorEventsourcedView
  21. val eventLog: ActorRef

    Permalink

    Event log actor.

    Event log actor.

    Definition Classes
    AbstractEventsourcedProcessorEventsourcedView
  22. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  23. def getAggregateId: Optional[String]

    Permalink

    Java API of aggregateId.

    Java API of aggregateId.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  24. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  25. final def getCommandContext: AbstractEventsourcedComponent.BehaviorContext

    Permalink

    Java API of commandContext.

    Java API of commandContext.

    Returns the command BehaviorContext.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  26. def getContext: ActorContext

    Permalink

    Returns this AbstractActor's ActorContext.

    Returns this AbstractActor's ActorContext. Mimics AbstractActor.getContext.

    Definition Classes
    AbstractEventsourcedComponent
  27. final def getEventContext: AbstractEventsourcedComponent.BehaviorContext

    Permalink

    Java API of eventContext.

    Java API of eventContext.

    Returns the event BehaviorContext.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  28. final def getLastEmitterAggregateId: Optional[String]

    Permalink

    Java API of lastEmitterAggregateId.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  29. final def getLastEmitterId: String

    Permalink

    Java API of lastEmitterId.

    Java API of lastEmitterId.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  30. final def getLastSequenceNr: Long

    Permalink

    Java API of lastSequenceNr.

    Java API of lastSequenceNr.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  31. final def getLastSystemTimestamp: Long

    Permalink

    Java API of lastSystemTimestamp.

    Java API of lastSystemTimestamp.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  32. final def getLastVectorTimestamp: VectorTime

    Permalink

    Java API of lastVectorTimestamp.

    Java API of lastVectorTimestamp.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  33. def getSelf: ActorRef

    Permalink

    Returns the ActorRef for this actor.

    Returns the ActorRef for this actor. Mimics AbstractActor.getSelf.

    Definition Classes
    AbstractEventsourcedComponent
  34. def getSender: ActorRef

    Permalink

    The reference sender Actor of the currently processed message.

    The reference sender Actor of the currently processed message. Mimics AbstractActor.getSender.

    Definition Classes
    AbstractEventsourcedComponent
  35. final def getSnapshotContext: AbstractEventsourcedComponent.BehaviorContext

    Permalink

    Java API of snapshotContext.

    Java API of snapshotContext.

    Returns the snapshot BehaviorContext.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  36. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  37. val id: String

    Permalink

    Global unique actor id.

    Global unique actor id.

    Definition Classes
    AbstractEventsourcedProcessorEventsourcedView
  38. val instanceId: Int

    Permalink
    Definition Classes
    EventsourcedView
  39. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  40. final def isRecovering: Boolean

    Permalink

    Java API of lastEmirecoveringterId.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  41. final def lastEmitterAggregateId: Option[String]

    Permalink

    Emitter aggregate id of the last handled event.

    Emitter aggregate id of the last handled event.

    Definition Classes
    EventsourcedView
  42. final def lastEmitterId: String

    Permalink

    Emitter id of the last handled event.

    Emitter id of the last handled event.

    Definition Classes
    EventsourcedView
  43. final def lastProcessId: String

    Permalink

    Id of the local event log that initially wrote the event.

    Id of the local event log that initially wrote the event.

    Definition Classes
    EventsourcedView
  44. final def lastSequenceNr: Long

    Permalink

    Sequence number of the last handled event.

    Sequence number of the last handled event.

    Definition Classes
    EventsourcedView
  45. final def lastSystemTimestamp: Long

    Permalink

    Wall-clock timestamp of the last handled event.

    Wall-clock timestamp of the last handled event.

    Definition Classes
    EventsourcedView
  46. final def lastVectorTimestamp: VectorTime

    Permalink

    Vector timestamp of the last handled event.

    Vector timestamp of the last handled event.

    Definition Classes
    EventsourcedView
  47. def log: LoggingAdapter

    Permalink
    Definition Classes
    ActorLogging
  48. val logger: LoggingAdapter

    Permalink

    This actor's logging adapter.

    This actor's logging adapter.

    Definition Classes
    EventsourcedView
  49. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  50. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  51. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  52. final def onCommand: Receive

    Permalink

    Command handler.

    Command handler.

    Definition Classes
    AbstractEventsourcedComponent → EventsourcedView
  53. final def onEvent: PartialFunction[Any, Unit]

    Permalink

    Collects processed events generated by processEvent.

    Collects processed events generated by processEvent.

    Definition Classes
    EventsourcedProcessorEventsourcedView
  54. def onReadFailure(cause: Throwable): Unit

    Permalink

    Java API of readFailure.

    Java API of readFailure.

    Definition Classes
    EventsourcedWriterFailureHandlerAdapter
    See also

    EventsourcedWriter

  55. def onReadSuccess(result: Long): Optional[Long]

    Permalink

    Java API of readSuccess.

    Java API of readSuccess.

    See also

    EventsourcedProcessor

  56. final def onRecovery: Handler[Unit]

    Permalink

    Recovery completion handler.

    Recovery completion handler. If called with a Failure, the actor will be stopped in any case, regardless of the action taken by the returned handler. The default handler implementation does nothing and can be overridden by implementations.

    Definition Classes
    AbstractEventsourcedComponent → EventsourcedView
  57. final def onSnapshot: Receive

    Permalink

    Snapshot handler.

    Snapshot handler.

    Definition Classes
    AbstractEventsourcedComponent → EventsourcedView
  58. def onWriteFailure(cause: Throwable): Unit

    Permalink

    Java API of writeFailure.

    Java API of writeFailure.

    Definition Classes
    EventsourcedWriterFailureHandlerAdapter
    See also

    EventsourcedWriter

  59. def onWriteSuccess(result: Long): Unit

    Permalink

    Java API of writeSuccess.

    Java API of writeSuccess.

    Definition Classes
    EventsourcedProcessorWriteSuccessHandlerAdapter
    See also

    EventsourcedProcessor

  60. def postProcessDurableEvent(e: DurableEvent): DurableEvent

    Permalink

    Override to allow post-processing of DurableEvent instances wrapping events generated by processEvent.

    Override to allow post-processing of DurableEvent instances wrapping events generated by processEvent.

    Amongst other things, this can e.g. be used to set different or additional aggregate IDs for custom routing destinations (which by default take the same routing destinations as the original event that was processed).

    Definition Classes
    EventsourcedProcessor
  61. def postRestart(reason: Throwable): Unit

    Permalink
    Definition Classes
    Actor
    Annotations
    @throws( classOf[java.lang.Exception] )
  62. def postStop(): Unit

    Permalink

    Sets recovering to false before calling super.postStop.

    Sets recovering to false before calling super.postStop.

    Definition Classes
    EventsourcedView → UnrestrictedStash → Actor
  63. def preRestart(reason: Throwable, message: Option[Any]): Unit

    Permalink

    Sets recovering to false before calling super.preRestart.

    Sets recovering to false before calling super.preRestart.

    Definition Classes
    EventsourcedView → UnrestrictedStash → Actor
  64. def preStart(): Unit

    Permalink

    Initiates recovery.

    Initiates recovery.

    Definition Classes
    EventsourcedView → Actor
  65. final def processBuilder(): ProcessBuilder

    Permalink

    creates a new empty ProcessBuilder

    creates a new empty ProcessBuilder

    Definition Classes
    EventSourcedProcessorAdapter
  66. final def processEvent: Process

    Permalink
    Definition Classes
    EventSourcedProcessorAdapter → EventsourcedProcessorHandlers
  67. final def read(): Future[Long]

    Permalink

    Asynchronously reads the processing progress from the target event log.

    Asynchronously reads the processing progress from the target event log.

    Definition Classes
    EventsourcedProcessorEventsourcedWriter
  68. final def readFailure(cause: Throwable): Unit

    Permalink
    Definition Classes
    EventsourcedWriterFailureHandlerAdapter → EventsourcedWriterFailureHandlers
  69. final def readSuccess(result: Long): Option[Long]

    Permalink

    Sets the read processing progress for this processor and returns it incremented by 1.

    Sets the read processing progress for this processor and returns it incremented by 1.

    Definition Classes
    AbstractEventsourcedProcessorEventsourcedProcessorEventsourcedWriter → EventsourcedWriterSuccessHandlers
  70. def readTimeout: FiniteDuration

    Permalink

    The default read timeout configured with the eventuate.log.read-timeout parameter.

    The default read timeout configured with the eventuate.log.read-timeout parameter. Can be overridden.

    Definition Classes
    EventsourcedProcessor
  71. final def receive: Receive

    Permalink

    Initialization behavior.

    Initialization behavior.

    Definition Classes
    EventsourcedView → Actor
  72. final def receiveBuilder(): ReceiveBuilder

    Permalink

    Creates a new empty ReceiveBuilder.

    Creates a new empty ReceiveBuilder. Mimics AbstractActor.receiveBuilder.

    Definition Classes
    AbstractEventsourcedComponent
  73. final def recovering: Boolean

    Permalink

    Returns true if this actor is currently recovering internal state by consuming replayed events from the event log.

    Returns true if this actor is currently recovering internal state by consuming replayed events from the event log. Returns false after recovery completed and the actor switches to consuming live events.

    Definition Classes
    EventsourcedView
  74. def replayBatchSize: Int

    Permalink

    Maximum number of events to be replayed to this actor before replaying is suspended.

    Maximum number of events to be replayed to this actor before replaying is suspended. A suspended replay is resumed automatically after all replayed events haven been handled by this actor's event handler (= backpressure). The default value for the maximum replay batch size is given by configuration item eventuate.log.replay-batch-size. Configured values can be overridden by overriding this method.

    Definition Classes
    EventsourcedView
  75. final def replayFromSequenceNr: Option[Long]

    Permalink

    Disallow for EventsourcedWriter and subclasses as event processing progress is determined by read and readSuccess.

    Disallow for EventsourcedWriter and subclasses as event processing progress is determined by read and readSuccess.

    Definition Classes
    EventsourcedWriterEventsourcedView
  76. def save(snapshot: Any, handler: ResultHandler[SnapshotMetadata]): Unit

    Permalink

    Java API of save.

    Java API of save.

    Must be supplied with a ResultHandler to process successful or failed results.

    Definition Classes
    AbstractEventsourcedComponent
    See also

    EventsourcedView

  77. final def save(snapshot: Any)(handler: Handler[SnapshotMetadata]): Unit

    Permalink

    Asynchronously saves the given snapshot and calls handler with the generated snapshot metadata.

    Asynchronously saves the given snapshot and calls handler with the generated snapshot metadata. The handler can obtain a reference to the initial message sender with sender().

    Definition Classes
    EventsourcedView
  78. implicit final val self: ActorRef

    Permalink
    Definition Classes
    Actor
  79. final def sender(): ActorRef

    Permalink
    Definition Classes
    Actor
  80. def snapshotContext: BehaviorContext

    Permalink

    Returns the snapshot BehaviorContext.

    Returns the snapshot BehaviorContext.

    Definition Classes
    EventsourcedView
  81. def stash(): Unit

    Permalink

    Adds the current command to the user's command stash.

    Adds the current command to the user's command stash. Must not be used in the event handler.

    Definition Classes
    EventsourcedView → StashSupport
  82. def supervisorStrategy: SupervisorStrategy

    Permalink
    Definition Classes
    Actor
  83. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  84. val targetEventLog: ActorRef

    Permalink

    This processor's target event log.

    This processor's target event log.

    Definition Classes
    AbstractEventsourcedProcessorEventsourcedProcessor
  85. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  86. def unhandled(message: Any): Unit

    Permalink
    Definition Classes
    Actor
  87. def unstashAll(): Unit

    Permalink

    Prepends all stashed commands to the actor's mailbox and then clears the command stash.

    Prepends all stashed commands to the actor's mailbox and then clears the command stash. Has no effect if the actor is recovering i.e. if recovering returns true.

    Definition Classes
    EventsourcedView → StashSupport
  88. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  89. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  90. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  91. final def write(): Future[Long]

    Permalink

    Asynchronously writes processed events that have been collected since the last write together with the current processing progress.

    Asynchronously writes processed events that have been collected since the last write together with the current processing progress. If the number of processed events since the last write is greater than the configured eventuate.log.write-batch-size multiple batches with a size less than or equal to eventuate.log.write-batch-size will be written sequentially. When splitting into multiple batches it is guaranteed that the processing result of a single event is part of the same batch i.e. it is guaranteed that the processing result of a single event is written atomically. If the processing result of a single event is larger than eventuate.log.write-batch-size, write write does not split that batch into smaller batches.

    Definition Classes
    EventsourcedProcessorEventsourcedWriter
  92. final def writeFailure(cause: Throwable): Unit

    Permalink
    Definition Classes
    EventsourcedWriterFailureHandlerAdapter → EventsourcedWriterFailureHandlers
  93. final def writeSuccess(result: Long): Unit

    Permalink
    Definition Classes
    EventsourcedProcessorWriteSuccessHandlerAdapter → EventsourcedWriterSuccessHandlers
  94. def writeTimeout: FiniteDuration

    Permalink

    The default write timeout configured with the eventuate.log.write-timeout parameter.

    The default write timeout configured with the eventuate.log.write-timeout parameter. Can be overridden.

    Definition Classes
    EventsourcedProcessor

Inherited from EventsourcedProcessorWriteSuccessHandlerAdapter

Inherited from EventSourcedProcessorAdapter

Inherited from EventsourcedWriterFailureHandlerAdapter

Inherited from EventsourcedProcessorHandlers

Inherited from EventsourcedProcessor

Inherited from ActorLogging

Inherited from EventsourcedWriter[Long, Long]

Inherited from EventsourcedWriterFailureHandlers

Inherited from EventsourcedWriterSuccessHandlers[Long, Long]

Inherited from AbstractEventsourcedComponent

Inherited from ConditionalRequests

Inherited from EventsourcedVersion

Inherited from EventsourcedView

Inherited from Stash

Inherited from RequiresMessageQueue[DequeBasedMessageQueueSemantics]

Inherited from UnrestrictedStash

Inherited from StashSupport

Inherited from Actor

Inherited from AnyRef

Inherited from Any

Ungrouped