Uses of Interface
org.axonframework.messaging.eventhandling.EventMessage
Packages that use EventMessage
Package
Description
Classes related to event sourcing.
Definitions and implementations of the Event store, the mechanism that can load event streams and append events to
them.
JPA Implementation of the EventStore.
Utility classes used to connect Axon Event publishing mechanisms to a Spring Messaging Channel.
Classes related to message processing in Axon Framework.
Classes related to event handling and dispatching, such as
and the
invalid reference
Event Listeners
Event Bus.-
Uses of EventMessage in org.axonframework.axonserver.connector.event
Methods in org.axonframework.axonserver.connector.event that return EventMessageModifier and TypeMethodDescriptionTaggedEventConverter.convertEvent(io.axoniq.axonserver.grpc.event.dcb.Event event) Convert the giveneventto anEventMessage.Methods in org.axonframework.axonserver.connector.event that return types with arguments of type EventMessageModifier and TypeMethodDescriptionSourcingEventMessageStream.next()StreamingEventMessageStream.next()SourcingEventMessageStream.peek()StreamingEventMessageStream.peek()AggregateBasedAxonServerEventStorageEngine.source(SourcingCondition condition) AxonServerEventStorageEngine.source(SourcingCondition condition) AggregateBasedAxonServerEventStorageEngine.stream(StreamingCondition condition) AxonServerEventStorageEngine.stream(StreamingCondition condition) -
Uses of EventMessage in org.axonframework.eventsourcing
Methods in org.axonframework.eventsourcing with parameters of type EventMessageModifier and TypeMethodDescriptionEventSourcedEntityFactory.create(ID id, EventMessage firstEventMessage, ProcessingContext context) Creates an entity of typeEwith the given identifier.Method parameters in org.axonframework.eventsourcing with type arguments of type EventMessageModifier and TypeMethodDescriptionstatic <ID,E> EventSourcedEntityFactory <ID, E> EventSourcedEntityFactory.fromEventMessage(BiFunction<ID, EventMessage, E> creator) Creates a factory for an entity of typeEventSourcedEntityFactoryusing a specified constructor with the identifier and the event message as parameters. -
Uses of EventMessage in org.axonframework.eventsourcing.annotation.reflection
Methods in org.axonframework.eventsourcing.annotation.reflection with parameters of type EventMessageModifier and TypeMethodDescriptionAnnotationBasedEventSourcedEntityFactory.create(ID id, EventMessage firstEventMessage, ProcessingContext context) -
Uses of EventMessage in org.axonframework.eventsourcing.eventstore
Classes in org.axonframework.eventsourcing.eventstore with type parameters of type EventMessageModifier and TypeClassDescriptionfinal recordGenericTaggedEventMessage<E extends EventMessage>interfaceTaggedEventMessage<E extends EventMessage>A wrapper of anEventMessageand itsTags.Methods in org.axonframework.eventsourcing.eventstore that return EventMessageModifier and TypeMethodDescriptionTooManyTagsOnEventMessageException.eventMessage()Returns the message that was rejected by the storage engine.Methods in org.axonframework.eventsourcing.eventstore that return types with arguments of type EventMessageModifier and TypeMethodDescriptionContinuousMessageStream.next()InterceptingEventStore.open(StreamingCondition condition, ProcessingContext context) StorageEngineBackedEventStore.open(StreamingCondition condition, ProcessingContext context) ContinuousMessageStream.peek()MessageStream<? extends EventMessage> DefaultEventStoreTransaction.source(SourcingCondition condition) EventStorageEngine.source(SourcingCondition condition) MessageStream<? extends EventMessage> EventStoreTransaction.source(SourcingCondition condition) Sources aMessageStreamof typeEventMessagebased on the givenconditionthat can be used to rehydrate a model.EventStorageEngine.stream(StreamingCondition condition) Methods in org.axonframework.eventsourcing.eventstore with parameters of type EventMessageModifier and TypeMethodDescriptionvoidDefaultEventStoreTransaction.appendEvent(EventMessage eventMessage) voidEventStoreTransaction.appendEvent(EventMessage eventMessage) Appends aneventMessageto be appended to anEventStorein this transaction with the givencondition.AnnotationBasedTagResolver.resolve(EventMessage event) MetadataBasedTagResolver.resolve(EventMessage event) MultiTagResolver.resolve(EventMessage event) PayloadBasedTagResolver.resolve(EventMessage event) TagResolver.resolve(EventMessage event) Method parameters in org.axonframework.eventsourcing.eventstore with type arguments of type EventMessageModifier and TypeMethodDescriptionvoidDefaultEventStoreTransaction.onAppend(Consumer<EventMessage> callback) voidEventStoreTransaction.onAppend(Consumer<EventMessage> callback) Registers acallbackto invoke when an event isappendedto this transaction.InterceptingEventStore.publish(ProcessingContext context, List<EventMessage> events) StorageEngineBackedEventStore.publish(ProcessingContext context, List<EventMessage> events) InterceptingEventStore.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) StorageEngineBackedEventStore.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) Constructors in org.axonframework.eventsourcing.eventstore with parameters of type EventMessageModifierConstructorDescriptionTooManyTagsOnEventMessageException(String message, EventMessage eventMessage, Set<Tag> tags) Initialize the exception with given explanatorymessagefor logging, referencing the giveneventMessageandtagsfor debug purposes.Constructor parameters in org.axonframework.eventsourcing.eventstore with type arguments of type EventMessageModifierConstructorDescriptionDefaultEventStoreTransaction(EventStorageEngine eventStorageEngine, ProcessingContext processingContext, Function<EventMessage, TaggedEventMessage<?>> eventTagger) Constructs aDefaultEventStoreTransactionusing the giveneventStorageEnginetoappend eventsoriginating from the givencontext.InterceptingEventStore(EventStore delegate, List<MessageDispatchInterceptor<? super EventMessage>> interceptors) Constructs aInterceptingEventStore, delegating all operation to the givendelegate. -
Uses of EventMessage in org.axonframework.eventsourcing.eventstore.inmemory
Methods in org.axonframework.eventsourcing.eventstore.inmemory that return types with arguments of type EventMessageModifier and TypeMethodDescriptionInMemoryEventStorageEngine.source(SourcingCondition condition) InMemoryEventStorageEngine.stream(StreamingCondition condition) -
Uses of EventMessage in org.axonframework.eventsourcing.eventstore.jpa
Methods in org.axonframework.eventsourcing.eventstore.jpa that return types with arguments of type EventMessageModifier and TypeMethodDescriptionAggregateBasedJpaEventStorageEngine.source(SourcingCondition condition) AggregateBasedJpaEventStorageEngine.stream(StreamingCondition condition) -
Uses of EventMessage in org.axonframework.extension.metrics.dropwizard
Methods in org.axonframework.extension.metrics.dropwizard that return types with arguments of type EventMessageModifier and TypeMethodDescriptionMessageMonitor<? super EventMessage> GlobalMetricRegistry.registerEventBus(String eventBusName) Registers new metrics to the registry to monitor anEventBus.MessageMonitor<? super EventMessage> GlobalMetricRegistry.registerEventProcessor(String eventProcessorName) Registers new metrics to the registry to monitor anEventProcessor.Methods in org.axonframework.extension.metrics.dropwizard with parameters of type EventMessageModifier and TypeMethodDescriptionEventProcessorLatencyMonitor.onMessageIngested(EventMessage message) -
Uses of EventMessage in org.axonframework.extension.metrics.micrometer
Methods in org.axonframework.extension.metrics.micrometer that return types with arguments of type EventMessageModifier and TypeMethodDescriptionMessageMonitor<? super EventMessage> GlobalMetricRegistry.registerEventBus(String eventBusName) Registers new metrics to the registry to monitor anEventBus.MessageMonitor<? super EventMessage> GlobalMetricRegistry.registerEventBus(String eventBusName, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Registers new metrics to the registry to monitor anEventBususingTags through the giventagsBuilder.MessageMonitor<? super EventMessage> GlobalMetricRegistry.registerEventProcessor(String eventProcessorName) Registers new metrics to the registry to monitor anEventProcessor.MessageMonitor<? super EventMessage> GlobalMetricRegistry.registerEventProcessor(String eventProcessorName, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> latencyTagsBuilder) Registers new metrics to the registry to monitor anEventProcessorusingTags through the giventagsBuilder.Methods in org.axonframework.extension.metrics.micrometer with parameters of type EventMessageModifier and TypeMethodDescriptionEventProcessorLatencyMonitor.onMessageIngested(EventMessage message) -
Uses of EventMessage in org.axonframework.extension.spring.messaging
Methods in org.axonframework.extension.spring.messaging that return EventMessageModifier and TypeMethodDescription<T> EventMessageDefaultEventMessageConverter.convertFromInboundMessage(org.springframework.messaging.Message message) <T> EventMessageEventMessageConverter.convertFromInboundMessage(org.springframework.messaging.Message message) Converts a Spring inboundmessageinto an Axon event Messageprotected EventMessageInboundEventMessageChannelAdapter.transformMessage(org.springframework.messaging.Message message) Transforms the given incoming Spring Messagingmessageto an Axon EventMessage.Methods in org.axonframework.extension.spring.messaging with parameters of type EventMessageModifier and TypeMethodDescriptionprotected org.springframework.context.ApplicationEventApplicationContextEventPublisher.convert(EventMessage eventMessage) Converts the given AxoneventMessageto a Spring ApplicationEvent.<T> org.springframework.messaging.MessageDefaultEventMessageConverter.convertToOutboundMessage(EventMessage event) <T> org.springframework.messaging.MessageEventMessageConverter.convertToOutboundMessage(EventMessage event) Converts Axoneventinto Spring message.protected org.springframework.messaging.MessageOutboundEventMessageChannelAdapter.transform(EventMessage event) Transforms the given Axoneventinto a Spring Messaging Message.Method parameters in org.axonframework.extension.spring.messaging with type arguments of type EventMessageModifier and TypeMethodDescriptionprotected voidOutboundEventMessageChannelAdapter.handle(List<? extends EventMessage> events, ProcessingContext context) If allows by the filter, wraps the giveneventin aGenericMessageands sends it to the configuredMessageChannel.InboundEventMessageChannelAdapter.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) Constructor parameters in org.axonframework.extension.spring.messaging with type arguments of type EventMessageModifierConstructorDescriptionInboundEventMessageChannelAdapter(List<BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>>> processors, EventMessageConverter eventMessageConverter) Initialize the adapter to publish all incoming events to the subscribed processors.OutboundEventMessageChannelAdapter(SubscribableEventSource eventSource, org.springframework.messaging.MessageChannel channel, Predicate<? super EventMessage> filter) Initialize an adapter to forward messages from the giveneventSourceto the givenchannel.OutboundEventMessageChannelAdapter(SubscribableEventSource eventSource, org.springframework.messaging.MessageChannel channel, Predicate<? super EventMessage> filter, EventMessageConverter eventMessageConverter) Initialize an adapter to forward messages from the giveneventSourceto the givenchannel. -
Uses of EventMessage in org.axonframework.messaging.core
Method parameters in org.axonframework.messaging.core with type arguments of type EventMessageModifier and TypeMethodDescriptionSubscribableEventSource.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) Subscribe the giveneventsBatchConsumerto this event source. -
Uses of EventMessage in org.axonframework.messaging.core.configuration
Method parameters in org.axonframework.messaging.core.configuration with type arguments of type EventMessageModifier and TypeMethodDescriptionMessagingConfigurer.registerEventDispatchInterceptor(ComponentBuilder<MessageDispatchInterceptor<? super EventMessage>> interceptorBuilder) MessagingConfigurer.registerEventHandlerInterceptor(ComponentBuilder<MessageHandlerInterceptor<? super EventMessage>> interceptorBuilder) MessagingConfigurer.registerEventMonitor(ComponentBuilder<MessageMonitor<? super EventMessage>> messageMonitorBuilder) Registers a component builder to configure theMessageMonitorused for monitoringEventMessage. -
Uses of EventMessage in org.axonframework.messaging.core.interception
Methods in org.axonframework.messaging.core.interception that return types with arguments of type EventMessageModifier and TypeMethodDescriptionList<MessageDispatchInterceptor<? super EventMessage>> DefaultDispatchInterceptorRegistry.eventInterceptors(Configuration config) List<MessageHandlerInterceptor<? super EventMessage>> DefaultHandlerInterceptorRegistry.eventInterceptors(Configuration config) List<MessageDispatchInterceptor<? super EventMessage>> DispatchInterceptorRegistry.eventInterceptors(Configuration config) Returns the list ofEventMessage-specificMessageDispatchInterceptorsregistered in this registry.List<MessageHandlerInterceptor<? super EventMessage>> HandlerInterceptorRegistry.eventInterceptors(Configuration config) Returns the list ofEventMessage-specificMessageHandlerInterceptorsregistered in this registry.Method parameters in org.axonframework.messaging.core.interception with type arguments of type EventMessageModifier and TypeMethodDescriptionDefaultDispatchInterceptorRegistry.registerEventInterceptor(ComponentBuilder<MessageDispatchInterceptor<? super EventMessage>> interceptorBuilder) DefaultHandlerInterceptorRegistry.registerEventInterceptor(ComponentBuilder<MessageHandlerInterceptor<? super EventMessage>> interceptorBuilder) DispatchInterceptorRegistry.registerEventInterceptor(ComponentBuilder<MessageDispatchInterceptor<? super EventMessage>> interceptorBuilder) HandlerInterceptorRegistry.registerEventInterceptor(ComponentBuilder<MessageHandlerInterceptor<? super EventMessage>> interceptorBuilder) Registers the giveninterceptorBuilderfor aEventMessageMessageHandlerInterceptorfor all event handling infrastructure components -
Uses of EventMessage in org.axonframework.messaging.core.timeout
Methods in org.axonframework.messaging.core.timeout that return types with arguments of type EventMessageModifier and TypeMethodDescriptionUnitOfWorkTimeoutInterceptorBuilder.buildEventInterceptor()Constructs aEventMessagehandler interceptor, to be registered on (e.g.) theEventProcessorConfiguration. -
Uses of EventMessage in org.axonframework.messaging.eventhandling
Classes in org.axonframework.messaging.eventhandling that implement EventMessageModifier and TypeClassDescriptionclassGeneric implementation of theEventMessageinterface.classEmptyEventMessageimplementation without anypayload, used as the terminal message of aMessageStream.Methods in org.axonframework.messaging.eventhandling that return EventMessageModifier and TypeMethodDescriptionEventMessage.andMetadata(Map<String, String> metadata) GenericEventMessage.andMetadata(Map<String, String> metadata) default EventMessageEventMessage.withConvertedPayload(Class<?> type, Converter converter) EventMessage.withConvertedPayload(Type type, Converter converter) default EventMessageEventMessage.withConvertedPayload(TypeReference<?> type, Converter converter) GenericEventMessage.withConvertedPayload(Type type, Converter converter) EventMessage.withMetadata(Map<String, String> metadata) GenericEventMessage.withMetadata(Map<String, String> metadata) Methods in org.axonframework.messaging.eventhandling with parameters of type EventMessageModifier and TypeMethodDescriptionDelegatingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) EventHandler.handle(EventMessage event, ProcessingContext context) Handles the giveneventwithin the givencontext.SimpleEventHandlingComponent.handle(EventMessage event, ProcessingContext context) default CompletableFuture<Void> EventSink.publish(ProcessingContext context, EventMessage... events) Publishes the giveneventswithin the givencontext, when present.DelegatingEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) EventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent.SimpleEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent.Method parameters in org.axonframework.messaging.eventhandling with type arguments of type EventMessageModifier and TypeMethodDescriptionDelegatingEventBus.publish(ProcessingContext context, List<EventMessage> events) EventSink.publish(ProcessingContext context, List<EventMessage> events) Publishes the giveneventswithin the givencontext, when present.InterceptingEventBus.publish(ProcessingContext context, List<EventMessage> events) InterceptingEventSink.publish(ProcessingContext context, List<EventMessage> events) SimpleEventBus.publish(ProcessingContext context, List<EventMessage> events) DelegatingEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) InterceptingEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) SimpleEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) Constructor parameters in org.axonframework.messaging.eventhandling with type arguments of type EventMessageModifierConstructorDescriptionInterceptingEventBus(EventBus delegate, List<MessageDispatchInterceptor<? super EventMessage>> interceptors) Constructs aInterceptingEventBus, delegating all operations to the givendelegate.InterceptingEventSink(EventSink delegate, List<MessageDispatchInterceptor<? super EventMessage>> interceptors) Constructs aInterceptingEventSink, delegating publishing to the givendelegate. -
Uses of EventMessage in org.axonframework.messaging.eventhandling.annotation
Methods in org.axonframework.messaging.eventhandling.annotation with parameters of type EventMessageModifier and TypeMethodDescriptionAnnotatedEventHandlingComponent.handle(EventMessage event, ProcessingContext context) AnnotatedEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) -
Uses of EventMessage in org.axonframework.messaging.eventhandling.configuration
Fields in org.axonframework.messaging.eventhandling.configuration with type parameters of type EventMessageModifier and TypeFieldDescriptionprotected List<MessageHandlerInterceptor<? super EventMessage>> EventProcessorConfiguration.interceptorsprotected MessageMonitor<? super EventMessage> EventProcessorConfiguration.messageMonitorMethods in org.axonframework.messaging.eventhandling.configuration that return types with arguments of type EventMessageModifier and TypeMethodDescriptionList<MessageHandlerInterceptor<? super EventMessage>> EventProcessorConfiguration.interceptors()Returns the list ofEventMessage-specificMessageHandlerInterceptorsto add to theEventProcessorunder construction with this configuration implementation. -
Uses of EventMessage in org.axonframework.messaging.eventhandling.conversion
Methods in org.axonframework.messaging.eventhandling.conversion with type parameters of type EventMessageModifier and TypeMethodDescription<E extends EventMessage>
EDelegatingEventConverter.convertEvent(E event, Type targetType) default <E extends EventMessage,T>
EEventConverter.convertEvent(E event, Class<T> targetType) Converts the givenevent'spayloadto the giventargetType, returning a newEventMessagewith the converted payload.<E extends EventMessage>
EEventConverter.convertEvent(E event, Type targetType) Converts the givenevent'spayloadto the giventargetType, returning a newEventMessagewith the converted payload.<E extends EventMessage,T>
TDelegatingEventConverter.convertPayload(E event, Type targetType) default <E extends EventMessage,T>
TEventConverter.convertPayload(E event, Class<T> targetType) <E extends EventMessage,T>
TEventConverter.convertPayload(E event, Type targetType) -
Uses of EventMessage in org.axonframework.messaging.eventhandling.interception
Methods in org.axonframework.messaging.eventhandling.interception with parameters of type EventMessageModifier and TypeMethodDescriptionInterceptingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) EventMessageHandlerInterceptorChain.proceed(EventMessage event, ProcessingContext context) Constructor parameters in org.axonframework.messaging.eventhandling.interception with type arguments of type EventMessageModifierConstructorDescriptionEventMessageHandlerInterceptorChain(List<MessageHandlerInterceptor<? super EventMessage>> interceptors, EventHandler eventHandler) Constructs a newEventMessageHandlerInterceptorChainwith a list ofinterceptionand aneventHandler.InterceptingEventHandlingComponent(List<MessageHandlerInterceptor<? super EventMessage>> messageHandlerInterceptors, EventHandlingComponent delegate) Constructs the component with the given delegate and interceptors. -
Uses of EventMessage in org.axonframework.messaging.eventhandling.processing
Methods in org.axonframework.messaging.eventhandling.processing with parameters of type EventMessageModifier and TypeMethodDescriptionProcessorEventHandlingComponents.sequenceIdentifiersFor(EventMessage event, ProcessingContext context) Retrieves a set of sequence identifiers for the given event message and processing context.Method parameters in org.axonframework.messaging.eventhandling.processing with type arguments of type EventMessageModifier and TypeMethodDescriptionProcessorEventHandlingComponents.handle(List<? extends EventMessage> events, ProcessingContext context) Processes a batch of events in the processing context. -
Uses of EventMessage in org.axonframework.messaging.eventhandling.processing.errorhandling
Methods in org.axonframework.messaging.eventhandling.processing.errorhandling that return types with arguments of type EventMessageModifier and TypeMethodDescriptionList<? extends EventMessage> ErrorContext.failedEvents()Returns the value of thefailedEventsrecord component.Constructor parameters in org.axonframework.messaging.eventhandling.processing.errorhandling with type arguments of type EventMessageModifierConstructorDescriptionErrorContext(String eventProcessor, Throwable error, List<? extends EventMessage> failedEvents, Context context) Compact constructor of theErrorContextto validate theeventProcessor,error,failedEvents, andcontextare not null. -
Uses of EventMessage in org.axonframework.messaging.eventhandling.processing.streaming.pooled
Methods in org.axonframework.messaging.eventhandling.processing.streaming.pooled that return types with arguments of type EventMessageModifier and TypeMethodDescriptionConsumer<? super EventMessage> PooledStreamingEventProcessorConfiguration.ignoredMessageHandler()Returns the handler for ignored messages.Method parameters in org.axonframework.messaging.eventhandling.processing.streaming.pooled with type arguments of type EventMessageModifier and TypeMethodDescriptionPooledStreamingEventProcessorConfiguration.ignoredMessageHandler(Consumer<? super EventMessage> ignoredMessageHandler) Sets the handler, that is invoked when the event is ignored by allWorkPackages thisCoordinatorcontrols.PooledStreamingEventProcessorConfiguration.withInterceptor(MessageHandlerInterceptor<? super EventMessage> interceptor) Registers the givenEventMessage-specificMessageHandlerInterceptorfor thePooledStreamingEventProcessorunder construction. -
Uses of EventMessage in org.axonframework.messaging.eventhandling.processing.streaming.segmenting
Methods in org.axonframework.messaging.eventhandling.processing.streaming.segmenting with parameters of type EventMessageModifier and TypeMethodDescriptionSequenceOverridingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) SequencingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) booleanSegmentMatcher.matches(Segment segment, EventMessage event, ProcessingContext context) Checks whether the givensegmentmatches the givenevent, based on the configured sequencing policy.SegmentMatcher.sequenceIdentifier(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent, as defined by the configured sequencing policy.SequenceCachingEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) SequenceOverridingEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) -
Uses of EventMessage in org.axonframework.messaging.eventhandling.processing.subscribing
Methods in org.axonframework.messaging.eventhandling.processing.subscribing that return types with arguments of type EventMessageModifier and TypeMethodDescriptionConsumer<? super EventMessage> SubscribingEventProcessorConfiguration.ignoredMessageHandler()Returns the handler for ignored messages.Method parameters in org.axonframework.messaging.eventhandling.processing.subscribing with type arguments of type EventMessageModifier and TypeMethodDescriptionSubscribingEventProcessorConfiguration.ignoredMessageHandler(Consumer<? super EventMessage> ignoredMessageHandler) Sets the handler, that is invoked when the event is ignored by allEventHandlingComponentsthisSubscribingEventProcessorcontrols.protected voidSubscribingEventProcessor.process(List<EventMessage> eventMessages, ProcessingContext context) Process the given messages.SubscribingEventProcessorConfiguration.withInterceptor(MessageHandlerInterceptor<? super EventMessage> interceptor) Registers the givenEventMessage-specificMessageHandlerInterceptorfor theSubscribingEventProcessorunder construction. -
Uses of EventMessage in org.axonframework.messaging.eventhandling.sequencing
Methods in org.axonframework.messaging.eventhandling.sequencing with parameters of type EventMessageModifier and TypeMethodDescriptionExtractionSequencingPolicy.getSequenceIdentifierFor(EventMessage eventMessage, ProcessingContext context) FallbackSequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) FullConcurrencyPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) HierarchicalSequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) MetadataSequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) SequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent.SequentialPerAggregatePolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) SequentialPolicy.getSequenceIdentifierFor(EventMessage task, ProcessingContext context) -
Uses of EventMessage in org.axonframework.messaging.eventhandling.tracing
Methods in org.axonframework.messaging.eventhandling.tracing that return EventMessageModifier and TypeMethodDescriptionDefaultEventBusSpanFactory.propagateContext(EventMessage eventMessage) EventBusSpanFactory.propagateContext(EventMessage eventMessage) Propagates the context of the current span to the given event message.Methods in org.axonframework.messaging.eventhandling.tracing with parameters of type EventMessageModifier and TypeMethodDescriptionDefaultEventProcessorSpanFactory.createProcessEventSpan(boolean streaming, EventMessage eventMessage) EventProcessorSpanFactory.createProcessEventSpan(boolean streaming, EventMessage eventMessage) Creates a span for the handling of an event.DefaultEventBusSpanFactory.createPublishEventSpan(EventMessage eventMessage) EventBusSpanFactory.createPublishEventSpan(EventMessage eventMessage) Creates a span for the publishing of an event.TracingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) DefaultEventBusSpanFactory.propagateContext(EventMessage eventMessage) EventBusSpanFactory.propagateContext(EventMessage eventMessage) Propagates the context of the current span to the given event message.Method parameters in org.axonframework.messaging.eventhandling.tracing with type arguments of type EventMessageModifier and TypeMethodDescriptionDefaultEventProcessorSpanFactory.createBatchSpan(boolean streaming, List<? extends EventMessage> eventMessages) EventProcessorSpanFactory.createBatchSpan(boolean streaming, List<? extends EventMessage> eventMessages) Creates a span for the batch of events that are handled by the event processor.Constructor parameters in org.axonframework.messaging.eventhandling.tracing with type arguments of type EventMessageModifierConstructorDescriptionTracingEventHandlingComponent(Function<EventMessage, Span> spanProvider, EventHandlingComponent delegate) Constructs the component with givendelegateto receive calls. -
Uses of EventMessage in org.axonframework.messaging.eventstreaming
Methods in org.axonframework.messaging.eventstreaming that return types with arguments of type EventMessageModifier and TypeMethodDescriptionStreamableEventSource.open(StreamingCondition condition, ProcessingContext context) -
Uses of EventMessage in org.axonframework.messaging.monitoring.configuration
Methods in org.axonframework.messaging.monitoring.configuration that return types with arguments of type EventMessageModifier and TypeMethodDescriptionMessageMonitor<? super EventMessage> DefaultMessageMonitorRegistry.eventMonitor(Configuration config) MessageMonitor<? super EventMessage> MessageMonitorRegistry.eventMonitor(Configuration config) Retrieves aMessageMonitorspecifically designed to monitor the processing ofEventMessageinstances.Method parameters in org.axonframework.messaging.monitoring.configuration with type arguments of type EventMessageModifier and TypeMethodDescriptionDefaultMessageMonitorRegistry.registerEventMonitor(ComponentBuilder<MessageMonitor<? super EventMessage>> monitorBuilder) MessageMonitorRegistry.registerEventMonitor(ComponentBuilder<MessageMonitor<? super EventMessage>> monitorBuilder) Registers aMessageMonitorspecific forEventMessagetypes using the supplied monitor builder. -
Uses of EventMessage in org.axonframework.messaging.monitoring.interception
Methods in org.axonframework.messaging.monitoring.interception with parameters of type EventMessageModifier and TypeMethodDescriptionMonitoringEventDispatchInterceptor.interceptOnDispatch(EventMessage message, ProcessingContext context, MessageDispatchInterceptorChain<EventMessage> interceptorChain) MonitoringEventHandlerInterceptor.interceptOnHandle(EventMessage message, ProcessingContext context, MessageHandlerInterceptorChain<EventMessage> interceptorChain) Method parameters in org.axonframework.messaging.monitoring.interception with type arguments of type EventMessageModifier and TypeMethodDescriptionMonitoringEventDispatchInterceptor.interceptOnDispatch(EventMessage message, ProcessingContext context, MessageDispatchInterceptorChain<EventMessage> interceptorChain) MonitoringEventHandlerInterceptor.interceptOnHandle(EventMessage message, ProcessingContext context, MessageHandlerInterceptorChain<EventMessage> interceptorChain) Constructor parameters in org.axonframework.messaging.monitoring.interception with type arguments of type EventMessageModifierConstructorDescriptionMonitoringEventDispatchInterceptor(MessageMonitor<? super EventMessage> messageMonitor) Constructs a new MonitoringEventDispatchInterceptor using the givenMessageMonitor.MonitoringEventHandlerInterceptor(MessageMonitor<? super EventMessage> messageMonitor) Constructs a new MonitoringEventHandlerInterceptor using the givenMessageMonitor. -
Uses of EventMessage in org.axonframework.modelling
Methods in org.axonframework.modelling with parameters of type EventMessageModifier and TypeMethodDescriptionEntityEvolver.evolve(E entity, EventMessage event, ProcessingContext context) Evolve the givenentityby applying the giveneventto it.PayloadBasedEntityEvolver.evolve(E entity, EventMessage event, ProcessingContext context) SimpleEntityEvolvingComponent.evolve(E entity, EventMessage event, ProcessingContext context) -
Uses of EventMessage in org.axonframework.modelling.annotation
Methods in org.axonframework.modelling.annotation with parameters of type EventMessageModifier and TypeMethodDescriptionAnnotationBasedEntityEvolvingComponent.evolve(E entity, EventMessage event, ProcessingContext context) -
Uses of EventMessage in org.axonframework.modelling.entity
Methods in org.axonframework.modelling.entity with parameters of type EventMessageModifier and TypeMethodDescriptionConcreteEntityMetamodel.evolve(E entity, EventMessage event, ProcessingContext context) PolymorphicEntityMetamodel.evolve(E entity, EventMessage event, ProcessingContext context) -
Uses of EventMessage in org.axonframework.modelling.entity.annotation
Methods in org.axonframework.modelling.entity.annotation with parameters of type EventMessageModifier and TypeMethodDescriptionAnnotatedEntityMetamodel.evolve(E entity, EventMessage event, ProcessingContext context) booleanRoutingKeyEventTargetMatcher.matches(E childEntity, EventMessage message, ProcessingContext processingContext) -
Uses of EventMessage in org.axonframework.modelling.entity.child
Methods in org.axonframework.modelling.entity.child with parameters of type EventMessageModifier and TypeMethodDescriptionAbstractEntityChildMetamodel.evolve(P entity, EventMessage event, ProcessingContext context) booleanEventTargetMatcher.matches(E targetEntity, EventMessage message, ProcessingContext processingContext) -
Uses of EventMessage in org.axonframework.test.fixture
Methods in org.axonframework.test.fixture that return types with arguments of type EventMessageModifier and TypeMethodDescriptionRecordingEventStore.open(StreamingCondition condition, ProcessingContext context) RecordingEventSink.recorded()Returns a copied list of all theEventMessagespublished.Methods in org.axonframework.test.fixture with parameters of type EventMessageModifier and TypeMethodDescriptionAxonTestPhase.Given.events(EventMessage... messages) Configures the givenmessagesas events in the "given" state.AxonTestPhase.Then.MessageAssertions.events(EventMessage... expectedEvents) Expect the given set of event messages to have been published during theAxonTestPhase.Whenphase.AxonTestPhase.When.events(EventMessage... messages) Publishes the given Event Messages to the appropriate event handlers and records all activity for result validation.Method parameters in org.axonframework.test.fixture with type arguments of type EventMessageModifier and TypeMethodDescriptionAxonTestPhase.Then.MessageAssertions.eventsMatch(Predicate<List<EventMessage>> predicate) Allow to check if the set of event messages which have been published during the When phase match givenpredicate.AxonTestPhase.Then.MessageAssertions.eventsSatisfy(Consumer<List<EventMessage>> consumer) Invokes the givenconsumerof the set of event messages that have been published during the When phase, allowing for any form of assertion.RecordingEventSink.publish(ProcessingContext context, List<EventMessage> events) RecordingEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) RecordingEventStore.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) -
Uses of EventMessage in org.axonframework.test.matchers
Methods in org.axonframework.test.matchers that return types with arguments of type EventMessageModifier and TypeMethodDescriptionstatic org.hamcrest.Matcher<List<EventMessage>> Matchers.noEvents()