Uses of Interface
org.axonframework.domain.EventMessage

Packages that use EventMessage
org.axonframework.auditing   
org.axonframework.commandhandling.disruptor   
org.axonframework.domain The domain components of the Axon Framework, mainly the Aggregates and Events. 
org.axonframework.eventhandling Classes related to event handling and dispatching, such as Event Listeners and the Event Bus
org.axonframework.eventhandling.amqp   
org.axonframework.eventhandling.amqp.spring   
org.axonframework.eventhandling.annotation Classes in support of the configuration of Event Handlers using annotations. 
org.axonframework.eventhandling.async   
org.axonframework.eventhandling.io   
org.axonframework.eventhandling.replay   
org.axonframework.eventhandling.scheduling.quartz   
org.axonframework.gae.commandhandling   
org.axonframework.integration.adapter Utility classes used to connect an Event Bus to a Spring Integration Channel. 
org.axonframework.integration.eventbus Contains the Event Bus implementation using Spring Integration 
org.axonframework.quickstart   
org.axonframework.quickstart.handler   
org.axonframework.saga   
org.axonframework.saga.annotation   
org.axonframework.serializer   
org.axonframework.springmessaging.adapter Utility classes used to connect an Event Bus to a Spring Messaging Channel. 
org.axonframework.springmessaging.eventbus Contains the Event Bus implementation using Spring Messaging 
org.axonframework.test Classes in support of testing Axon based applications. 
org.axonframework.test.eventscheduler   
org.axonframework.test.saga   
org.axonframework.unitofwork Classes in support of the UnitOfWork pattern in Axon Framework. 
 

Uses of EventMessage in org.axonframework.auditing
 

Methods in org.axonframework.auditing that return EventMessage
<T> EventMessage<T>
AuditingUnitOfWorkListener.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
           
 

Methods in org.axonframework.auditing with parameters of type EventMessage
<T> EventMessage<T>
AuditingUnitOfWorkListener.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
           
 

Method parameters in org.axonframework.auditing with type arguments of type EventMessage
 void NullAuditLogger.logFailed(CommandMessage<?> command, Throwable failureCause, List<EventMessage> events)
          Writes a failure entry to the audit logs.
 void AuditLogger.logFailed(CommandMessage<?> command, Throwable failureCause, List<EventMessage> events)
          Writes a failure entry to the audit logs.
 void NullAuditLogger.logSuccessful(CommandMessage<?> command, Object returnValue, List<EventMessage> events)
          Writes a success entry to the audit logs.
 void AuditLogger.logSuccessful(CommandMessage<?> command, Object returnValue, List<EventMessage> events)
          Writes a success entry to the audit logs.
 

Uses of EventMessage in org.axonframework.commandhandling.disruptor
 

Methods in org.axonframework.commandhandling.disruptor that return types with arguments of type EventMessage
 List<EventMessage> DisruptorUnitOfWork.getEventsToPublish()
          Returns the events that need to be published as part of this Unit of Work.
 

Methods in org.axonframework.commandhandling.disruptor with parameters of type EventMessage
 void DisruptorUnitOfWork.publishEvent(EventMessage event, EventBus eventBus)
           
 

Uses of EventMessage in org.axonframework.domain
 

Subinterfaces of EventMessage in org.axonframework.domain
 interface DomainEventMessage<T>
          Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain.
 

Classes in org.axonframework.domain that implement EventMessage
 class GenericDomainEventMessage<T>
          Generic implementation of the DomainEventMessage interface.
 class GenericEventMessage<T>
          Generic implementation of the EventMessage interface.
 

Methods in org.axonframework.domain that return EventMessage
 EventMessage<T> EventMessage.andMetaData(Map<String,?> metaData)
          Returns a copy of this EventMessage with it MetaData merged with the given metaData.
static
<T> EventMessage<T>
GenericEventMessage.asEventMessage(Object event)
          Returns the given event as an EventMessage.
 EventMessage<T> EventMessage.withMetaData(Map<String,?> metaData)
          Returns a copy of this EventMessage with the given metaData.
 

Uses of EventMessage in org.axonframework.eventhandling
 

Methods in org.axonframework.eventhandling with parameters of type EventMessage
 void EventListener.handle(EventMessage event)
          Process the given event.
 void MultiplexingEventProcessingMonitor.prepare(EventMessage eventMessage)
          Prepare the monitor for processing the given message.
 void MultiplexingEventProcessingMonitor.prepareForInvocation(EventMessage eventMessage, EventListener member)
          Prepare the monitor for the invocation of the given message to the given member.
 void SimpleEventBus.publish(EventMessage... events)
          Publish a collection of events on this bus (one, or multiple).
 void EventBusTerminal.publish(EventMessage... events)
          Publishes the given events to all clusters on the Event Bus.
 void EventBus.publish(EventMessage... events)
          Publish a collection of events on this bus (one, or multiple).
 void ClusteringEventBus.publish(EventMessage... events)
           
 void Cluster.publish(EventMessage... events)
          Publishes the given Events to the members of this cluster.
 void AbstractCluster.publish(EventMessage... events)
           
 

Method parameters in org.axonframework.eventhandling with type arguments of type EventMessage
 void SimpleCluster.doPublish(List<EventMessage> events, Set<EventListener> eventListeners, MultiplexingEventProcessingMonitor monitor)
           
protected abstract  void AbstractCluster.doPublish(List<EventMessage> events, Set<EventListener> eventListeners, MultiplexingEventProcessingMonitor eventProcessingMonitor)
          Publish the given list of events to the given set of eventListeners, and notify the given eventProcessingMonitor after completion.
 void MultiplexingEventProcessingMonitor.onEventProcessingCompleted(List<? extends EventMessage> eventMessages)
           
 void EventProcessingMonitorCollection.onEventProcessingCompleted(List<? extends EventMessage> eventMessages)
           
 void EventProcessingMonitor.onEventProcessingCompleted(List<? extends EventMessage> eventMessages)
          Invoked when one or more events have been successfully processed by the instance it was subscribed to.
 void MultiplexingEventProcessingMonitor.onEventProcessingFailed(List<? extends EventMessage> eventMessages, Throwable cause)
           
 void EventProcessingMonitorCollection.onEventProcessingFailed(List<? extends EventMessage> eventMessages, Throwable cause)
           
 void EventProcessingMonitor.onEventProcessingFailed(List<? extends EventMessage> eventMessages, Throwable cause)
          Invoked when one or more events have failed processing by the instance it was subscribed to.
 

Uses of EventMessage in org.axonframework.eventhandling.amqp
 

Methods in org.axonframework.eventhandling.amqp that return EventMessage
 EventMessage DefaultAMQPMessageConverter.readAMQPMessage(byte[] messageBody, Map<String,Object> headers)
           
 EventMessage AMQPMessageConverter.readAMQPMessage(byte[] messageBody, Map<String,Object> headers)
          Reconstruct an EventMessage from the given messageBody and headers.
 

Methods in org.axonframework.eventhandling.amqp with parameters of type EventMessage
 AMQPMessage DefaultAMQPMessageConverter.createAMQPMessage(EventMessage eventMessage)
           
 AMQPMessage AMQPMessageConverter.createAMQPMessage(EventMessage eventMessage)
          Creates an AMQPMessage from given eventMessage.
 String RoutingKeyResolver.resolveRoutingKey(EventMessage eventMessage)
          Returns the Routing Key to use when sending the given eventMessage to the Message Broker.
 String PackageRoutingKeyResolver.resolveRoutingKey(EventMessage event)
           
 

Uses of EventMessage in org.axonframework.eventhandling.amqp.spring
 

Methods in org.axonframework.eventhandling.amqp.spring with parameters of type EventMessage
 void SpringAMQPTerminal.publish(EventMessage... events)
           
 

Uses of EventMessage in org.axonframework.eventhandling.annotation
 

Methods in org.axonframework.eventhandling.annotation with parameters of type EventMessage
 void AnnotationEventListenerAdapter.handle(EventMessage event)
          Process the given event.
 

Uses of EventMessage in org.axonframework.eventhandling.async
 

Methods in org.axonframework.eventhandling.async with parameters of type EventMessage
protected  EventProcessor.ProcessingResult EventProcessor.doHandle(EventMessage<?> event)
          Does the actual processing of the event.
 Object SequentialPerAggregatePolicy.getSequenceIdentifierFor(EventMessage event)
          Returns the sequence identifier for the given event.
 RetryPolicy ErrorHandler.handleError(Throwable exception, EventMessage<?> eventMessage, EventListener eventListener)
          Invoked when a handler or the unit of work throws an exception.
 RetryPolicy DefaultErrorHandler.handleError(Throwable exception, EventMessage<?> eventMessage, EventListener eventListener)
           
protected  void AsynchronousCluster.schedule(EventMessage<?> task, MultiplexingEventProcessingMonitor eventProcessingMonitor)
          Schedules this task for execution when all pre-conditions have been met.
 boolean EventProcessor.scheduleEvent(EventMessage<?> event)
          Schedules an event for processing.
 

Method parameters in org.axonframework.eventhandling.async with type arguments of type EventMessage
protected  void AsynchronousCluster.doPublish(List<EventMessage> events, Set<EventListener> eventListeners, MultiplexingEventProcessingMonitor eventProcessingMonitor)
           
 

Constructor parameters in org.axonframework.eventhandling.async with type arguments of type EventMessage
AsynchronousCluster(String identifier, Executor executor, SequencingPolicy<? super EventMessage<?>> sequencingPolicy)
          Creates an AsynchronousCluster implementation using the given executor and sequencingPolicy.
AsynchronousCluster(String identifier, Executor executor, TransactionManager transactionManager, SequencingPolicy<? super EventMessage<?>> sequencingPolicy)
          Creates an AsynchronousCluster implementation using the given executor, transactionManager and sequencingPolicy.
AsynchronousCluster(String identifier, Executor executor, TransactionManager transactionManager, SequencingPolicy<? super EventMessage<?>> sequencingPolicy, ErrorHandler errorHandler)
          Creates an AsynchronousCluster implementation using the given executor, transactionManager and sequencingPolicy.
AsynchronousCluster(String name, Executor executor, UnitOfWorkFactory unitOfWorkFactory, SequencingPolicy<? super EventMessage<?>> sequencingPolicy, ErrorHandler errorHandler)
          Creates an AsynchronousCluster implementation using the given executor, unitOfWorkFactory and sequencingPolicy.
AsynchronousCluster(String name, Executor executor, UnitOfWorkFactory unitOfWorkFactory, SequencingPolicy<? super EventMessage<?>> sequencingPolicy, ErrorHandler errorHandler, OrderResolver orderResolver)
          Creates an AsynchronousCluster implementation using the given executor, unitOfWorkFactory and sequencingPolicy.
 

Uses of EventMessage in org.axonframework.eventhandling.io
 

Methods in org.axonframework.eventhandling.io that return EventMessage
<T> EventMessage<T>
EventMessageReader.readEventMessage()
          Reads an EventMessage from the underlying input.
 

Methods in org.axonframework.eventhandling.io with parameters of type EventMessage
static EventMessageType EventMessageType.forMessage(EventMessage message)
          Returns the most specific EventMessageType for the given message.
 void EventMessageWriter.writeEventMessage(EventMessage eventMessage)
          Writes the given eventMessage to the underling output.
 

Uses of EventMessage in org.axonframework.eventhandling.replay
 

Methods in org.axonframework.eventhandling.replay that return types with arguments of type EventMessage
 List<EventMessage> IncomingMessageHandler.onIncomingMessages(Cluster destination, EventMessage... messages)
          Invoked while the ReplayingCluster is in replay mode and an Event is being dispatched to the Cluster.
 List<EventMessage> DiscardingIncomingMessageHandler.onIncomingMessages(Cluster destination, EventMessage... messages)
           
 List<EventMessage> BackloggingIncomingMessageHandler.onIncomingMessages(Cluster destination, EventMessage... messages)
           
 List<EventMessage> IncomingMessageHandler.releaseMessage(Cluster destination, DomainEventMessage message)
          Invoked when a message has been replayed from the event store.
 List<EventMessage> DiscardingIncomingMessageHandler.releaseMessage(Cluster destination, DomainEventMessage message)
           
 List<EventMessage> BackloggingIncomingMessageHandler.releaseMessage(Cluster destination, DomainEventMessage message)
           
 

Methods in org.axonframework.eventhandling.replay with parameters of type EventMessage
 List<EventMessage> IncomingMessageHandler.onIncomingMessages(Cluster destination, EventMessage... messages)
          Invoked while the ReplayingCluster is in replay mode and an Event is being dispatched to the Cluster.
 List<EventMessage> DiscardingIncomingMessageHandler.onIncomingMessages(Cluster destination, EventMessage... messages)
           
 List<EventMessage> BackloggingIncomingMessageHandler.onIncomingMessages(Cluster destination, EventMessage... messages)
           
 void ReplayingCluster.publish(EventMessage... events)
           
 

Constructor parameters in org.axonframework.eventhandling.replay with type arguments of type EventMessage
BackloggingIncomingMessageHandler(org.joda.time.Duration backlogThresholdMargin, Queue<EventMessage> backlog)
          Creates a new BackloggingIncomingMessageHandler.
 

Uses of EventMessage in org.axonframework.eventhandling.scheduling.quartz
 

Methods in org.axonframework.eventhandling.scheduling.quartz with parameters of type EventMessage
protected  org.quartz.JobDetail QuartzEventScheduler.buildJobDetail(EventMessage event, org.quartz.JobKey jobKey)
          Builds the JobDetail instance for Quartz, which defines the Job that needs to be executed when the trigger fires.
 

Uses of EventMessage in org.axonframework.gae.commandhandling
 

Methods in org.axonframework.gae.commandhandling with parameters of type EventMessage
 void SimpleEventBusWithoutStatistics.publish(EventMessage... events)
           
 

Uses of EventMessage in org.axonframework.integration.adapter
 

Methods in org.axonframework.integration.adapter with parameters of type EventMessage
 void EventListeningMessageChannelAdapter.handle(EventMessage event)
          If allows by the filter, wraps the given event in a GenericMessage ands sends it to the configured MessageChannel.
 

Uses of EventMessage in org.axonframework.integration.eventbus
 

Methods in org.axonframework.integration.eventbus with parameters of type EventMessage
 void SpringIntegrationEventBus.publish(EventMessage... events)
           
 

Uses of EventMessage in org.axonframework.quickstart
 

Methods in org.axonframework.quickstart with parameters of type EventMessage
 void RunEventReplay.ThreadPrintingEventListener.onEvent(EventMessage event)
           
 void RunClusteringEventBusWithSpring.ThreadPrintingEventListener.onEvent(EventMessage event)
           
 

Uses of EventMessage in org.axonframework.quickstart.handler
 

Methods in org.axonframework.quickstart.handler with parameters of type EventMessage
 void ToDoEventListener.handle(EventMessage eventMessage)
           
 

Uses of EventMessage in org.axonframework.saga
 

Methods in org.axonframework.saga with parameters of type EventMessage
protected  Set<AssociationValue> SimpleSagaManager.extractAssociationValues(Class<? extends Saga> type, EventMessage event)
           
protected abstract  Set<AssociationValue> AbstractSagaManager.extractAssociationValues(Class<? extends Saga> sagaType, EventMessage event)
          Extracts the AssociationValues from the given event as relevant for a Saga of given sagaType.
 Set<AssociationValue> AssociationValueResolver.extractAssociationValues(EventMessage event)
          Extracts an Association Value from the given event.
protected  SagaInitializationPolicy SimpleSagaManager.getSagaCreationPolicy(Class<? extends Saga> type, EventMessage event)
           
protected abstract  SagaInitializationPolicy AbstractSagaManager.getSagaCreationPolicy(Class<? extends Saga> sagaType, EventMessage event)
          Returns the Saga Initialization Policy for a Saga of the given sagaType and event.
 void SagaManager.handle(EventMessage event)
          Handles the event by passing it to all Saga instances that have an Association Value found in the given event.
 void Saga.handle(EventMessage event)
          Handle the given event.
 void AbstractSagaManager.handle(EventMessage event)
           
protected  AssociationValue SimpleSagaManager.initialAssociationValue(EventMessage event)
          Returns the association value to assign to a Saga when the given event triggers the creation of a new instance.
 

Method parameters in org.axonframework.saga with type arguments of type EventMessage
 void AbstractSagaManager.setCorrelationDataProvider(CorrelationDataProvider<? super EventMessage> correlationDataProvider)
          Sets the correlation data provider for this SagaManager.
 void AbstractSagaManager.setCorrelationDataProviders(List<? extends CorrelationDataProvider<? super EventMessage>> correlationDataProviders)
          Sets the given correlationDataProviders.
 

Uses of EventMessage in org.axonframework.saga.annotation
 

Methods in org.axonframework.saga.annotation that return EventMessage
 EventMessage AsyncSagaProcessingEvent.getPublishedEvent()
          Returns the event that has been published on the EventBus.
 

Methods in org.axonframework.saga.annotation with parameters of type EventMessage
protected  Set<AssociationValue> AnnotatedSagaManager.extractAssociationValues(Class<? extends Saga> sagaType, EventMessage event)
           
 SagaMethodMessageHandler SagaMethodMessageHandlerInspector.findHandlerMethod(AbstractAnnotatedSaga target, EventMessage event)
          Finds the handler method on given target for the given event.
 AssociationValue SagaMethodMessageHandler.getAssociationValue(EventMessage eventMessage)
          The AssociationValue to find the saga instance with, or null if no AssociationValue can be found on the given eventMessage.
 List<SagaMethodMessageHandler> SagaMethodMessageHandlerInspector.getMessageHandlers(EventMessage event)
          Find the configuration for the handlers for the given event.
protected  SagaInitializationPolicy AnnotatedSagaManager.getSagaCreationPolicy(Class<? extends Saga> sagaType, EventMessage event)
           
 void AsyncAnnotatedSagaManager.handle(EventMessage event)
           
 void AbstractAnnotatedSaga.handle(EventMessage event)
           
 void SagaMethodMessageHandler.invoke(Object target, EventMessage message)
          Invoke a handler on given target for given message.
 boolean SagaMethodMessageHandler.matches(EventMessage message)
          Indicates whether this Handler is suitable for the given message.
 RetryPolicy RetryingErrorHandler.onErrorInvoking(Saga saga, EventMessage publishedEvent, int invocationCount, Exception e)
           
 RetryPolicy ProceedingErrorHandler.onErrorInvoking(Saga saga, EventMessage publishedEvent, int invocationCount, Exception e)
           
 RetryPolicy ErrorHandler.onErrorInvoking(Saga saga, EventMessage publishedEvent, int invocationCount, Exception exception)
          Invoked when an error occurs when a Saga instance is invoked.
 RetryPolicy RetryingErrorHandler.onErrorPreparing(Class<? extends Saga> sagaType, EventMessage<?> publishedEvent, int invocationCount, Exception e)
           
 RetryPolicy ProceedingErrorHandler.onErrorPreparing(Class<? extends Saga> sagaType, EventMessage<?> publishedEvent, int invocationCount, Exception e)
           
 RetryPolicy ErrorHandler.onErrorPreparing(Class<? extends Saga> sagaType, EventMessage<?> publishedEvent, int invocationCount, Exception exception)
          Invoked when an error occurs preparing Sagas.
 void AsyncSagaProcessingEvent.reset(EventMessage nextEvent, Class<? extends AbstractAnnotatedSaga> nextSagaType, List<SagaMethodMessageHandler> nextHandlers, AbstractAnnotatedSaga nextSagaInstance)
          Reset this entry for processing a new EventMessage
 

Method parameters in org.axonframework.saga.annotation with type arguments of type EventMessage
 void AsyncAnnotatedSagaManager.setCorrelationDataProvider(CorrelationDataProvider<? super EventMessage> correlationDataProvider)
          Sets the CorrelationDataProvider which provides the Meta Data to assign to messages generated by the Sagas that are managed by this SagaManager instance.
 void AsyncAnnotatedSagaManager.setCorrelationDataProviders(List<? extends CorrelationDataProvider<? super EventMessage>> correlationDataProviders)
          Sets the CorrelationDataProviders which provide the Meta Data to assign to messages generated by the Sagas that are managed by this SagaManager instance.
 

Uses of EventMessage in org.axonframework.serializer
 

Classes in org.axonframework.serializer that implement EventMessage
 class SerializationAwareDomainEventMessage<T>
          Wrapper around a DomainEventMessage that adds "Serialization Awareness" to the message it wraps.
 class SerializationAwareEventMessage<T>
          Wrapper around am EventMessage that adds "Serialization Awareness" to the message it wraps.
 class SerializedDomainEventMessage<T>
          DomainEventMessage implementation that is optimized to cope with serialized Payload and MetaData.
 class SerializedEventMessage<T>
          EventMessage implementation that is optimized to cope with serialized Payload and MetaData.
 

Methods in org.axonframework.serializer that return EventMessage
 EventMessage<T> SerializedEventMessage.andMetaData(Map<String,?> additionalMetaData)
           
 EventMessage<T> SerializationAwareEventMessage.andMetaData(Map<String,?> metaData)
           
 EventMessage<T> SerializationAwareEventMessage.withMetaData(Map<String,?> metaData)
           
static
<T> EventMessage<T>
SerializationAwareEventMessage.wrap(EventMessage<T> message)
          Wrap the given message to make it SerializationAware.
 

Methods in org.axonframework.serializer with parameters of type EventMessage
static
<T> EventMessage<T>
SerializationAwareEventMessage.wrap(EventMessage<T> message)
          Wrap the given message to make it SerializationAware.
 

Constructors in org.axonframework.serializer with parameters of type EventMessage
SerializationAwareEventMessage(EventMessage<T> eventMessage)
          Initializes a new wrapper for the given eventMessage.
 

Uses of EventMessage in org.axonframework.springmessaging.adapter
 

Methods in org.axonframework.springmessaging.adapter with parameters of type EventMessage
 void EventListeningMessageChannelAdapter.handle(EventMessage event)
          If allows by the filter, wraps the given event in a GenericMessage ands sends it to the configured MessageChannel.
 

Uses of EventMessage in org.axonframework.springmessaging.eventbus
 

Methods in org.axonframework.springmessaging.eventbus with parameters of type EventMessage
 void SpringMessagingEventBus.publish(EventMessage... events)
           
 

Uses of EventMessage in org.axonframework.test
 

Method parameters in org.axonframework.test with type arguments of type EventMessage
 void Reporter.reportDifferenceInStoredVsPublished(Collection<DomainEventMessage> storedEvents, Collection<EventMessage> publishedEvents, Throwable probableCause)
          Report a failed assertion due to a difference in the stored versus the published events.
 

Constructor parameters in org.axonframework.test with type arguments of type EventMessage
ResultValidatorImpl(Collection<DomainEventMessage> storedEvents, Collection<EventMessage> publishedEvents, FieldFilter fieldFilter)
          Initialize the ResultValidatorImpl with the given storedEvents and publishedEvents.
 

Uses of EventMessage in org.axonframework.test.eventscheduler
 

Methods in org.axonframework.test.eventscheduler that return EventMessage
 EventMessage StubEventScheduler.advanceToNextTrigger()
          Advances the "current time" of the scheduler to the next scheduled Event, and returns that event.
 EventMessage StubScheduleToken.getEvent()
           
 EventMessage ScheduledItem.getEvent()
          The Event scheduled for publication.
 

Methods in org.axonframework.test.eventscheduler that return types with arguments of type EventMessage
 List<EventMessage> StubEventScheduler.advanceTime(org.joda.time.DateTime newDateTime)
          Advance time to the given newDateTime and returns all events scheduled for publication until that time.
 List<EventMessage> StubEventScheduler.advanceTime(org.joda.time.Duration duration)
          Advance time by the given duration and returns all events scheduled for publication until that time.
 

Uses of EventMessage in org.axonframework.test.saga
 

Methods in org.axonframework.test.saga with parameters of type EventMessage
 void EventValidator.handle(EventMessage event)
           
 

Uses of EventMessage in org.axonframework.unitofwork
 

Methods in org.axonframework.unitofwork that return EventMessage
<T> EventMessage<T>
UnitOfWorkListenerCollection.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
          Invoked when an Event is registered for publication when the UnitOfWork is committed.
<T> EventMessage<T>
UnitOfWorkListenerAdapter.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
          Invoked when an Event is registered for publication when the UnitOfWork is committed.
<T> EventMessage<T>
UnitOfWorkListener.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
          Invoked when an Event is registered for publication when the UnitOfWork is committed.
<T> EventMessage<T>
MetaDataMutatingUnitOfWorkListenerAdapter.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
           
 

Methods in org.axonframework.unitofwork with parameters of type EventMessage
protected abstract  Map<String,?> MetaDataMutatingUnitOfWorkListenerAdapter.assignMetaData(EventMessage event, List<EventMessage> events, int index)
          Defines the additional meta data to assign to the given event.
<T> EventMessage<T>
UnitOfWorkListenerCollection.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
          Invoked when an Event is registered for publication when the UnitOfWork is committed.
<T> EventMessage<T>
UnitOfWorkListenerAdapter.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
          Invoked when an Event is registered for publication when the UnitOfWork is committed.
<T> EventMessage<T>
UnitOfWorkListener.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
          Invoked when an Event is registered for publication when the UnitOfWork is committed.
<T> EventMessage<T>
MetaDataMutatingUnitOfWorkListenerAdapter.onEventRegistered(UnitOfWork unitOfWork, EventMessage<T> event)
           
 void UnitOfWork.publishEvent(EventMessage<?> event, EventBus eventBus)
          Request to publish the given event on the given eventBus.
 void NestableUnitOfWork.publishEvent(EventMessage<?> event, EventBus eventBus)
           
protected abstract  void NestableUnitOfWork.registerForPublication(EventMessage<?> event, EventBus eventBus, boolean notifyRegistrationHandlers)
          Register the given event for publication on the given eventBus when the unit of work is committed.
 void DefaultUnitOfWork.registerForPublication(EventMessage<?> event, EventBus eventBus, boolean notifyRegistrationHandlers)
           
 

Method parameters in org.axonframework.unitofwork with type arguments of type EventMessage
protected abstract  Map<String,?> MetaDataMutatingUnitOfWorkListenerAdapter.assignMetaData(EventMessage event, List<EventMessage> events, int index)
          Defines the additional meta data to assign to the given event.
 void UnitOfWorkListenerCollection.onPrepareCommit(UnitOfWork unitOfWork, Set<AggregateRoot> aggregateRoots, List<EventMessage> events)
          Invoked before aggregates are committed, and before any events are published.
 void UnitOfWorkListenerAdapter.onPrepareCommit(UnitOfWork unitOfWork, Set<AggregateRoot> aggregateRoots, List<EventMessage> events)
          Invoked before aggregates are committed, and before any events are published.
 void UnitOfWorkListener.onPrepareCommit(UnitOfWork unitOfWork, Set<AggregateRoot> aggregateRoots, List<EventMessage> events)
          Invoked before aggregates are committed, and before any events are published.
 void MetaDataMutatingUnitOfWorkListenerAdapter.onPrepareCommit(UnitOfWork unitOfWork, Set<AggregateRoot> aggregateRoots, List<EventMessage> events)
           
 



Copyright © 2010-2016. All Rights Reserved.