Uses of Interface
org.axonframework.messaging.core.Message
Packages that use Message
Package
Description
Classes that implement the concept of command handling using explicit command objects.
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.A collection of classes which may prove useful when testing Axon-based classes.
-
Uses of Message in org.axonframework.axonserver.connector
Classes in org.axonframework.axonserver.connector with type parameters of type MessageModifier and TypeInterfaceDescriptioninterfaceTargetContextResolver<T extends Message>Interface towards a mechanism that is capable of resolving the context name to which aMessageshould be routed.Methods in org.axonframework.axonserver.connector that return types with arguments of type MessageModifier and TypeMethodDescriptionstatic TargetContextResolver<Message> TargetContextResolver.noOp()Returns a no-op TargetContextResolver. -
Uses of Message in org.axonframework.extension.metrics.dropwizard
Classes in org.axonframework.extension.metrics.dropwizard with type parameters of type MessageModifier and TypeClassDescriptionclassPayloadTypeMessageMonitorWrapper<T extends MessageMonitor<Message> & com.codahale.metrics.MetricSet>AMessageMonitorimplementation which creates a new MessageMonitor for everyMessagepayload type ingested by it.Methods in org.axonframework.extension.metrics.dropwizard that return types with arguments of type MessageModifier and TypeMethodDescriptionMessageMonitor<? extends Message> GlobalMetricRegistry.registerComponent(Class<?> componentType, String componentName) Registers new metrics to theMetricRegistryto monitor a component of givencomponentType.Methods in org.axonframework.extension.metrics.dropwizard with parameters of type MessageModifier and TypeMethodDescriptionCapacityMonitor.onMessageIngested(Message message) MessageCountingMonitor.onMessageIngested(Message message) MessageTimerMonitor.onMessageIngested(Message message) PayloadTypeMessageMonitorWrapper.onMessageIngested(Message message) -
Uses of Message in org.axonframework.extension.metrics.micrometer
Fields in org.axonframework.extension.metrics.micrometer with type parameters of type MessageModifier and TypeFieldDescriptionTagsUtil.METADATA_TAGGER_FUNCTIONThe function for creating the MicrometerTags based on the message metadata.TagsUtil.PAYLOAD_TYPE_TAGGER_FUNCTIONThe function for creating the MicrometerTags based on the message payload type.Methods in org.axonframework.extension.metrics.micrometer that return types with arguments of type MessageModifier and TypeMethodDescriptionMessageMonitor<? extends Message> GlobalMetricRegistry.registerComponent(Class<?> componentType, String componentName) Registers new metrics to the registry to monitor a component of the givencomponentType.MessageMonitor<? extends Message> GlobalMetricRegistry.registerComponentWithDefaultTags(Class<?> componentType, String componentName) Registers new metrics to the registry to monitor a component of the givencomponentType.Methods in org.axonframework.extension.metrics.micrometer with parameters of type MessageModifier and TypeMethodDescriptionCapacityMonitor.onMessageIngested(Message message) MessageCountingMonitor.onMessageIngested(Message message) MessageTimerMonitor.onMessageIngested(Message message) Method parameters in org.axonframework.extension.metrics.micrometer with type arguments of type MessageModifier and TypeMethodDescriptionstatic CapacityMonitorCapacityMonitor.buildMonitor(String meterNamePrefix, io.micrometer.core.instrument.MeterRegistry meterRegistry, long window, TimeUnit timeUnit, io.micrometer.core.instrument.Clock clock, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Creates a capacity monitor with the given time window.static CapacityMonitorCapacityMonitor.buildMonitor(String meterNamePrefix, io.micrometer.core.instrument.MeterRegistry meterRegistry, long window, TimeUnit timeUnit, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Creates a capacity monitor with the default system clock.static CapacityMonitorCapacityMonitor.buildMonitor(String meterNamePrefix, io.micrometer.core.instrument.MeterRegistry meterRegistry, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Creates a capacity monitor with the default time window 10 minutesstatic MessageCountingMonitorMessageCountingMonitor.buildMonitor(String meterNamePrefix, io.micrometer.core.instrument.MeterRegistry meterRegistry, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Creates a message counting monitorMessageMonitor<? super CommandMessage> GlobalMetricRegistry.registerCommandBus(String commandBusName, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Registers new metrics to the registry to monitor aCommandBususingTags through the giventagsBuilder.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, 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.MessageMonitor<? super QueryMessage> GlobalMetricRegistry.registerQueryBus(String queryBusName, Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Registers new metrics to the registry to monitor aQueryBususingTags through the giventagsBuilder.EventProcessorLatencyMonitor.Builder.tagsBuilder(Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Configures theFunctionused to deduce what theTags should be for a message being monitored.MessageTimerMonitor.Builder.tagsBuilder(Function<Message, Iterable<io.micrometer.core.instrument.Tag>> tagsBuilder) Configures theFunctionused to deduce what theTags should be for a message being monitored. -
Uses of Message in org.axonframework.extension.spring.authorization
Classes in org.axonframework.extension.spring.authorization with type parameters of type MessageModifier and TypeClassDescriptionclassMessageAuthorizationDispatchInterceptor<T extends Message>AMessageDispatchInterceptorthat adds the {$code username} and {$code authorities} from the authorized principle.classMessageAuthorizationHandlerInterceptor<M extends Message>AMessageHandlerInterceptorthat verifies authorization based onSecuredannotations on the payload ofMessages. -
Uses of Message in org.axonframework.extension.spring.config
Methods in org.axonframework.extension.spring.config that return types with arguments of type MessageModifier and TypeMethodDescriptionMessageHandlerConfigurer.Type.getMessageType()Returns the supportedMessageimplementation.Method parameters in org.axonframework.extension.spring.config with type arguments of type MessageModifier and TypeMethodDescriptionMessageHandlerLookup.messageHandlerBeans(Class<? extends Message> messageType, org.springframework.beans.factory.config.ConfigurableListableBeanFactory registry) Returns a list of beans found in the givenregisterthat contain a handler for the givenmessageType.MessageHandlerLookup.messageHandlerBeans(Class<? extends Message> messageType, org.springframework.beans.factory.config.ConfigurableListableBeanFactory registry, boolean includePrototypeBeans) Returns a list of beans found in the givenregisterthat contain a handler for the givenmessageType. -
Uses of Message in org.axonframework.extension.springboot.autoconfig
Method parameters in org.axonframework.extension.springboot.autoconfig with type arguments of type MessageModifier and TypeMethodDescriptionInterceptorAutoConfiguration.handlerInterceptorEnhancer(Optional<List<MessageHandlerInterceptor<Message>>> interceptors, Optional<List<MessageHandlerInterceptor<CommandMessage>>> commandInterceptors, Optional<List<MessageHandlerInterceptor<EventMessage>>> eventInterceptors, Optional<List<MessageHandlerInterceptor<QueryMessage>>> queryInterceptors) Bean creation method for aDecoratorDefinitionthat registersMessage-specificMessageHandlerInterceptorswith theHandlerInterceptorRegistry. -
Uses of Message in org.axonframework.extension.tracing.opentelemetry
Methods in org.axonframework.extension.tracing.opentelemetry with type parameters of type MessageModifier and TypeMethodDescription<M extends Message>
MOpenTelemetrySpanFactory.propagateContext(M message) Methods in org.axonframework.extension.tracing.opentelemetry with parameters of type MessageModifier and TypeMethodDescriptionOpenTelemetrySpanFactory.createDispatchSpan(Supplier<String> operationNameSupplier, Message parentMessage, Message... linkedSiblings) OpenTelemetrySpanFactory.createHandlerSpan(Supplier<String> operationNameSupplier, Message parentMessage, boolean isChildTrace, Message... linkedParents) OpenTelemetrySpanFactory.createInternalSpan(Supplier<String> operationNameSupplier, Message message) Method parameters in org.axonframework.extension.tracing.opentelemetry with type arguments of type MessageModifier and TypeMethodDescriptionOpenTelemetrySpanFactory.Builder.textMapGetter(io.opentelemetry.context.propagation.TextMapGetter<Message> textMapGetter) Defines theTextMapGetterto use, which is used for extracting the propagated context from another thread or service. -
Uses of Message in org.axonframework.messaging.commandhandling
Subinterfaces of Message in org.axonframework.messaging.commandhandlingModifier and TypeInterfaceDescriptioninterfaceAMessagecarrying a command as its payload.interfaceAResultMessagethat represents a result from handling aCommandMessage.Classes in org.axonframework.messaging.commandhandling that implement MessageModifier and TypeClassDescriptionclassGeneric implementation of theCommandMessageinterface.classGeneric implementation of theCommandResultMessageinterface.Constructors in org.axonframework.messaging.commandhandling with parameters of type MessageModifierConstructorDescriptionGenericCommandMessage(Message delegate) Constructs aGenericCommandMessagewith givendelegate.GenericCommandMessage(Message delegate, String routingKey, Integer priority) Constructs aGenericCommandMessagewith givendelegate,routingKey, andpriority.GenericCommandResultMessage(Message delegate) Constructs aGenericCommandResultMessagefor the givendelegate, intended to reconstruct anotherCommandResultMessage. -
Uses of Message in org.axonframework.messaging.commandhandling.gateway
Methods in org.axonframework.messaging.commandhandling.gateway that return types with arguments of type MessageModifier and TypeMethodDescriptionCompletableFuture<? extends Message> CommandResult.getResultMessage()Returns the resultMessagewithin aCompletableFutureof command handling.CompletableFuture<? extends Message> FutureCommandResult.getResultMessage()Method parameters in org.axonframework.messaging.commandhandling.gateway with type arguments of type MessageModifier and TypeMethodDescriptiondefault <R> CommandResultCommandResult.onSuccess(Class<R> resultType, BiConsumer<R, Message> successHandler) Attaches the givensuccessHandlertothiscommand result, expecting the givenresultType.default CommandResultAttaches the givensuccessHandlertothiscommand result.Constructor parameters in org.axonframework.messaging.commandhandling.gateway with type arguments of type MessageModifierConstructorDescriptionFutureCommandResult(CompletableFuture<? extends Message> result) Initializes the CommandResult based on the givenresultthe completes when the resultMessagebecomes available -
Uses of Message in org.axonframework.messaging.core
Classes in org.axonframework.messaging.core with type parameters of type MessageModifier and TypeClassDescriptionclassCloseCallbackMessageStream<M extends Message>MessageStream implementation that invokes the givencloseHandleronce the stream is closed.classDefaultMessageDispatchInterceptorChain<M extends Message>Default implementation for aMessageDispatchInterceptorChain.classDelayedMessageStream<M extends Message>An implementation of theMessageStreamthat wraps a stream that will become available asynchronously.classDelegatingMessageStream<DM extends Message,RM extends Message> Abstract implementation of an MessageStream that delegates calls to a given delegate.classDelegatingMessageStream<DM extends Message,RM extends Message> Abstract implementation of an MessageStream that delegates calls to a given delegate.interfaceMessageDispatchInterceptor<M extends Message>Interceptor that allowsmessagesto be intercepted and modified before they are dispatched.interfaceMessageDispatchInterceptorChain<M extends Message>interfaceMessageHandlerInterceptor<M extends Message>Workflow interface that allows for customized message handler invocation chains.interfaceMessageHandlerInterceptorChain<M extends Message>An interceptor chain that manages the flow of aMessageof typeMthrough a chain ofinterceptors, and ultimately to a message handler.interfaceMessageStream<M extends Message>static interfaceMessageStream.Empty<M extends Message>AMessageStreamimplementation that completes normally or with an error without returning any elements.static interfaceMessageStream.Entry<M extends Message>AMessageStream-specific container ofMessageimplementations.static interfaceMessageStream.Single<M extends Message>AMessageStreamimplementation that returns at most a single result before completing.classQueueMessageStream<M extends Message>MessageStream implementation that uses a Queue to make elements available to a consumer.final recordSimpleEntry<M extends Message>Simple implementation of theMessageStream.Entrycontaining a singleMessageimplementation of typeMand aContext.Subinterfaces of Message in org.axonframework.messaging.coreModifier and TypeInterfaceDescriptioninterfaceAMessagethat represents a result of handling some form of a request message.Classes in org.axonframework.messaging.core that implement MessageModifier and TypeClassDescriptionclassAbstract base class forMessages.classclassGeneric implementation ofResultMessageinterface.classAbstract implementation of aMessagethat delegates to an existing message.Fields in org.axonframework.messaging.core with type parameters of type MessageMethods in org.axonframework.messaging.core with type parameters of type MessageModifier and TypeMethodDescriptionstatic <M extends Message>
CompletableFuture<MessageStream.Entry<M>> MessageStreamUtils.asCompletableFuture(MessageStream<M> source) static <M extends Message>
MessageStream<M> FluxUtils.asMessageStream(reactor.core.publisher.Flux<M> flux) Create a stream that provides theMessagesreturned by the givenflux, automatically wrapped in anMessageStream.Entry.static <M extends Message>
MessageStream<M> FluxUtils.asMessageStream(reactor.core.publisher.Flux<M> flux, Function<M, Context> contextSupplier) Create a stream that provides theMessagesreturned by the givenflux, automatically wrapped in anMessageStream.Entrywith the resultingContextfrom thecontextSupplier.static <M extends Message>
MessageStream.Single<M> MonoUtils.asSingle(reactor.core.publisher.Mono<M> mono) Create a stream that returns a singlewrapping theinvalid reference
entryMessagefrom the givenmono, once the givenmonocompletes.static <M extends Message>
MessageStream.Single<M> Create a stream that returns a singlewrapping theinvalid reference
entryMessagefrom the givenmono, once the givenmonocompletes.default <T extends Message>
MessageStream<T> MessageStream.cast()Casts this stream to the given type.default <T extends Message>
MessageStream.Empty<T> MessageStream.Empty.cast()default <R extends Message>
MessageStream.Single<R> MessageStream.Single.cast()static <M extends Message>
MessageStream<M> DelayedMessageStream.create(CompletableFuture<? extends MessageStream<M>> delegate) Creates astreamthat delays actions to itsdelegatewhen it becomes available.static <M extends Message>
MessageStream.Single<M> DelayedMessageStream.createSingle(CompletableFuture<MessageStream.Single<M>> delegate) Creates asingle streamthat delays actions to itsdelegatewhen it becomes available.static <M extends Message>
MessageStream.Empty<M> Create a stream that completed with givenfailure.static <M extends Message>
MessageStream.Single<M> MessageStream.fromFuture(CompletableFuture<M> future) static <M extends Message>
MessageStream.Single<M> MessageStream.fromFuture(CompletableFuture<M> future, Function<M, Context> contextSupplier) static <M extends Message>
MessageStream<M> MessageStream.fromItems(M... items) Creates a MessageStream that provides the givenitemsand then completes.static <M extends Message>
MessageStream<M> MessageStream.fromIterable(Iterable<M> iterable) Create a stream that provides theMessagesreturned by the giveniterable, automatically wrapped in anMessageStream.Entry.static <M extends Message>
MessageStream<M> MessageStream.fromIterable(Iterable<M> iterable, Function<M, Context> contextSupplier) Create a stream that provides theMessagesreturned by the giveniterable, automatically wrapped in anMessageStream.Entrywith the resultingContextfrom thecontextSupplier.static <M extends Message>
MessageStream<M> MessageStream.fromStream(Stream<M> stream) Create a stream that provides theMessagesreturned by the givenstream, automatically wrapped in anMessageStream.Entry.static <M extends Message>
MessageStream<M> MessageStream.fromStream(Stream<M> stream, Function<M, Context> contextSupplier) Create a stream that provides theMessagesreturned by the givenstream, automatically wrapped in anMessageStream.Entrywith the resultingContextfrom thecontextSupplier.static <T,M extends Message>
MessageStream<M> MessageStream.fromStream(Stream<T> stream, Function<T, M> messageSupplier, Function<T, Context> contextSupplier) Create a stream that provides the items of typeTreturned by the givenstream, automatically wrapped in anMessageStream.Entrywith the resultingMessageandContextfrom themessageSupplierand thecontextSupplierrespectively.static <M extends Message>
MessageStream.Single<M> MessageStream.just(M message) Create a stream containing the single givenmessage, automatically wrapped in anMessageStream.Entry.static <M extends Message>
MessageStream.Single<M> Create a stream containing the single givenmessage, automatically wrapped in anMessageStream.Entry.default <RM extends Message>
MessageStream.Empty<RM> MessageStream.Empty.map(Function<MessageStream.Entry<M>, MessageStream.Entry<RM>> mapper) <RM extends Message>
MessageStream.Entry<RM> Maps theMessageStream.Entry.message()by running it through the givenmapper.default <RM extends Message>
MessageStream<RM> MessageStream.map(Function<MessageStream.Entry<M>, MessageStream.Entry<RM>> mapper) default <RM extends Message>
MessageStream.Single<RM> MessageStream.Single.map(Function<MessageStream.Entry<M>, MessageStream.Entry<RM>> mapper) <RM extends Message>
MessageStream.Entry<RM> default <RM extends Message>
MessageStream.Empty<RM> MessageStream.Empty.mapMessage(Function<M, RM> mapper) default <RM extends Message>
MessageStream<RM> MessageStream.mapMessage(Function<M, RM> mapper) default <RM extends Message>
MessageStream.Single<RM> MessageStream.Single.mapMessage(Function<M, RM> mapper) static <M extends Message>
reactor.core.publisher.Flux<MessageStream.Entry<M>> FluxUtils.of(MessageStream<M> source) Creates a Flux containing theentriesprovided by the givensource.static <M extends Message,R>
CompletableFuture<R> MessageStreamUtils.reduce(MessageStream<M> source, R identity, BiFunction<R, MessageStream.Entry<M>, R> accumulator) Returns aCompletableFuturethat completes with the given reduction of messages read from thesource.static <M extends Message>
org.reactivestreams.Publisher<M> FluxUtils.streamToPublisher(Supplier<MessageStream<M>> stream) Methods in org.axonframework.messaging.core that return MessageModifier and TypeMethodDescriptionAbstractMessage.andMetadata(Map<String, String> metadata) Message.andMetadata(Map<String, String> metadata) protected MessageMessageDecorator.delegate()Returns the wrappedMessagedelegated by this decorator.static MessageGenericMessage.emptyMessage()Construct an empty message.static MessageMessage.fromContext(ProcessingContext context) GenericMessage.withConvertedPayload(Type type, Converter converter) default MessageMessage.withConvertedPayload(Class<?> type, Converter converter) Returns a newMessageimplementation with itspayload()converted to the giventypeby the givenconverter.Message.withConvertedPayload(Type type, Converter converter) Returns a newMessageimplementation with itspayload()converted to the giventypeby the givenconverter.default MessageMessage.withConvertedPayload(TypeReference<?> type, Converter converter) Returns a newMessageimplementation with itspayload()converted to the giventypeby the givenconverter.MessageDecorator.withConvertedPayload(Type type, Converter converter) AbstractMessage.withMetadata(Map<String, String> metadata) protected abstract MessageAbstractMessage.withMetadata(Metadata metadata) Returns a new message instance with the same payload and properties as this message but givenmetadata.protected MessageGenericMessage.withMetadata(Metadata metadata) Message.withMetadata(Map<String, String> metadata) Returns a copy of thisMessage(implementation) with the givenmetadata.Methods in org.axonframework.messaging.core that return types with arguments of type MessageModifier and TypeMethodDescriptionstatic MessageStream.Empty<Message> MessageStream.empty()Create a stream that carries noMessageStream.Entryand is considered to be successfully completed.Methods in org.axonframework.messaging.core with parameters of type MessageModifier and TypeMethodDescriptionstatic ProcessingContextMessage.addToContext(ProcessingContext context, Message message) static <M extends Message>
MessageStream<M> MessageStream.fromItems(M... items) Creates a MessageStream that provides the givenitemsand then completes.Constructors in org.axonframework.messaging.core with parameters of type MessageModifierConstructorDescriptionGenericResultMessage(Message delegate) Constructs aGenericResultMessagefor the givendelegate, intended to reconstruct anotherResultMessage.protectedMessageDecorator(Message delegate) Initializes a new decorator with givendelegateMessage. -
Uses of Message in org.axonframework.messaging.core.annotation
Methods in org.axonframework.messaging.core.annotation with type parameters of type MessageModifier and TypeMethodDescriptionstatic <M extends Message>
MessageStream<?> InterceptorChainParameterResolverFactory.callWithInterceptorChain(ProcessingContext processingContext, MessageHandlerInterceptorChain<M> interceptorChain, Function<ProcessingContext, MessageStream<?>> action) Invoke the givenactionwith the giveninterceptorChainbeing available for parameter injection.static <M extends Message>
MessageHandlerInterceptorChain<M> InterceptorChainParameterResolverFactory.currentInterceptorChain(ProcessingContext processingContext) Methods in org.axonframework.messaging.core.annotation with parameters of type MessageModifier and TypeMethodDescriptionbooleanMessageHandlingMember.canHandle(Message message, ProcessingContext context) Checks if this handler is capable of handling the givenmessage.booleanMethodInvokingMessageHandlingMember.canHandle(Message message, ProcessingContext context) booleanWrappedMessageHandlingMember.canHandle(Message message, ProcessingContext context) ChainedMessageHandlerInterceptorMember.handle(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) MessageHandlingMember.handle(Message message, ProcessingContext context, T target) Handles the givenmessagewithin the givencontextby invoking the appropriate method on giventarget.MethodInvokingMessageHandlingMember.handle(Message message, ProcessingContext context, T target) WrappedMessageHandlingMember.handle(Message message, ProcessingContext context, T target) ChainedMessageHandlerInterceptorMember.handleSync(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) MessageHandlingMember.handleSync(Message message, ProcessingContext context, T target) Deprecated, for removal: This API element is subject to removal in a future version.MethodInvokingMessageHandlingMember.handleSync(Message message, ProcessingContext context, T target) WrappedMessageHandlingMember.handleSync(Message message, ProcessingContext context, T target) protected booleanMethodInvokingMessageHandlingMember.parametersMatch(Message message, ProcessingContext processingContext) Checks if the parameter resolvers of this member are compatible with the givenmessage.protected booleanMethodInvokingMessageHandlingMember.typeMatches(Message message) Checks if this member can handle the type of the givenmessage.Method parameters in org.axonframework.messaging.core.annotation with type arguments of type MessageModifier and TypeMethodDescriptionbooleanMessageHandlingMember.canHandleMessageType(Class<? extends Message> messageType) Checks if this handler is capable of handlingMessageimplementations of the givenmessageType.booleanMethodInvokingMessageHandlingMember.canHandleMessageType(Class<? extends Message> messageType) booleanWrappedMessageHandlingMember.canHandleMessageType(Class<? extends Message> messageType) Constructor parameters in org.axonframework.messaging.core.annotation with type arguments of type MessageModifierConstructorDescriptionMethodInvokingMessageHandlingMember(Method method, Class<? extends Message> messageType, Class<?> explicitPayloadType, ParameterResolverFactory parameterResolverFactory, Function<Object, MessageStream<?>> returnTypeConverter) Initializes a new instance that will invoke the givenexecutable(method) on a target to handle a message of the givenmessageType. -
Uses of Message in org.axonframework.messaging.core.configuration
Method parameters in org.axonframework.messaging.core.configuration with type arguments of type MessageModifier and TypeMethodDescriptionMessagingConfigurer.registerDispatchInterceptor(ComponentBuilder<MessageDispatchInterceptor<Message>> interceptorBuilder) MessagingConfigurer.registerMessageHandlerInterceptor(ComponentBuilder<MessageHandlerInterceptor<Message>> interceptorBuilder) MessagingConfigurer.registerMessageMonitor(ComponentBuilder<MessageMonitor<Message>> messageMonitorBuilder) Registers a message monitor for the messaging components in the configuration. -
Uses of Message in org.axonframework.messaging.core.conversion
Methods in org.axonframework.messaging.core.conversion with type parameters of type MessageModifier and TypeMethodDescription<M extends Message>
MDelegatingMessageConverter.convertMessage(M message, Type targetType) default <M extends Message,T>
MMessageConverter.convertMessage(M message, Class<T> targetType) Converts the givenmessage'spayloadto the giventargetType, returning a newMessagewith the converted payload.<M extends Message>
MMessageConverter.convertMessage(M message, Type targetType) Converts the givenmessage'spayloadto the giventargetType, returning a newMessagewith the converted payload.<M extends Message,T>
TDelegatingMessageConverter.convertPayload(M message, Type targetType) default <M extends Message,T>
TMessageConverter.convertPayload(M message, Class<T> targetType) <M extends Message,T>
TMessageConverter.convertPayload(M message, Type targetType) -
Uses of Message in org.axonframework.messaging.core.correlation
Methods in org.axonframework.messaging.core.correlation with parameters of type MessageModifier and TypeMethodDescriptionCorrelationDataProvider.correlationDataFor(Message message) Provides a map with the entries to attach as correlation data to generated messages while processing givenmessage.MessageOriginProvider.correlationDataFor(Message message) MultiCorrelationDataProvider.correlationDataFor(Message message) SimpleCorrelationDataProvider.correlationDataFor(Message message) -
Uses of Message in org.axonframework.messaging.core.interception
Classes in org.axonframework.messaging.core.interception with type parameters of type MessageModifier and TypeClassDescriptionclassBeanValidationInterceptor<M extends Message>Interceptor that applies JSR303 bean validation on incomingMessages.classCorrelationDataInterceptor<M extends Message>AMessageDispatchInterceptorandMessageHandlerInterceptorimplementation usingCorrelationDataProvidersto collect and set a collection of correlation data.classLoggingInterceptor<M extends Message>AMessageDispatchInterceptorandMessageHandlerInterceptorimplementation that logs dispatched and incoming messages, and their result, to aLogger.Method parameters in org.axonframework.messaging.core.interception with type arguments of type MessageModifier and TypeMethodDescriptionDefaultDispatchInterceptorRegistry.registerInterceptor(ComponentBuilder<MessageDispatchInterceptor<Message>> interceptorBuilder) DefaultHandlerInterceptorRegistry.registerInterceptor(ComponentBuilder<MessageHandlerInterceptor<Message>> interceptorBuilder) DispatchInterceptorRegistry.registerInterceptor(ComponentBuilder<MessageDispatchInterceptor<Message>> interceptorBuilder) HandlerInterceptorRegistry.registerInterceptor(ComponentBuilder<MessageHandlerInterceptor<Message>> interceptorBuilder) Registers the giveninterceptorBuilderconstructing a genericMessageMessageHandlerInterceptorfor all handling infrastructure components. -
Uses of Message in org.axonframework.messaging.core.interception.annotation
Methods in org.axonframework.messaging.core.interception.annotation with parameters of type MessageModifier and TypeMethodDescriptiondefault MessageStream<?> MessageHandlerInterceptorMemberChain.handle(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) NoMoreInterceptors.handle(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) MessageHandlerInterceptorMemberChain.handleSync(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) Deprecated, for removal: This API element is subject to removal in a future version.default ObjectMessageHandlerInterceptorMemberChain.handleSync(Message message, T target, MessageHandlingMember<? super T> handler) Deprecated, for removal: This API element is subject to removal in a future version.NoMoreInterceptors.handleSync(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) Deprecated. -
Uses of Message in org.axonframework.messaging.core.retry
Classes in org.axonframework.messaging.core.retry with type parameters of type MessageModifier and TypeInterfaceDescriptionstatic interfaceRetryScheduler.Dispatcher<M extends Message,R extends Message> Represents the logic to dispatch a message and attempt to retrieve the resultstatic interfaceRetryScheduler.Dispatcher<M extends Message,R extends Message> Represents the logic to dispatch a message and attempt to retrieve the resultMethods in org.axonframework.messaging.core.retry with type parameters of type MessageModifier and TypeMethodDescription<M extends Message,R extends Message>
MessageStream<R> AsyncRetryScheduler.scheduleRetry(M message, ProcessingContext processingContext, Throwable cause, RetryScheduler.Dispatcher<M, R> dispatcher) <M extends Message,R extends Message>
MessageStream<R> AsyncRetryScheduler.scheduleRetry(M message, ProcessingContext processingContext, Throwable cause, RetryScheduler.Dispatcher<M, R> dispatcher) <M extends Message,R extends Message>
MessageStream<R> RetryScheduler.scheduleRetry(M message, ProcessingContext processingContext, Throwable cause, RetryScheduler.Dispatcher<M, R> dispatcher) Schedules the givenmessageto retry dispatching using the givendispatchingfunction.<M extends Message,R extends Message>
MessageStream<R> RetryScheduler.scheduleRetry(M message, ProcessingContext processingContext, Throwable cause, RetryScheduler.Dispatcher<M, R> dispatcher) Schedules the givenmessageto retry dispatching using the givendispatchingfunction.Methods in org.axonframework.messaging.core.retry with parameters of type MessageModifier and TypeMethodDescriptionExponentialBackOffRetryPolicy.defineFor(Message message, Throwable failure, List<Class<? extends Throwable>[]> previousFailures) FilteringRetryPolicy.defineFor(Message message, Throwable cause, List<Class<? extends Throwable>[]> previousFailures) MaxAttemptsPolicy.defineFor(Message message, Throwable cause, List<Class<? extends Throwable>[]> previousFailures) RetryPolicy.defineFor(Message message, Throwable failure, List<Class<? extends Throwable>[]> previousFailures) Provides the outcome for the policy given the failedmessagethat was dispatched and resulted in givenfailure. -
Uses of Message in org.axonframework.messaging.core.unitofwork
Constructors in org.axonframework.messaging.core.unitofwork with parameters of type MessageModifierConstructorDescriptionLegacyMessageSupportingContext(Message message) Deprecated.Initialize theProcessingContextwith the givenmessageas the only resource. -
Uses of Message in org.axonframework.messaging.eventhandling
Subinterfaces of Message in org.axonframework.messaging.eventhandlingModifier and TypeInterfaceDescriptioninterfaceClasses in org.axonframework.messaging.eventhandling that implement MessageModifier and TypeClassDescriptionclassGeneric implementation of theEventMessageinterface.classEmptyEventMessageimplementation without anypayload, used as the terminal message of aMessageStream.Methods in org.axonframework.messaging.eventhandling that return types with arguments of type MessageModifier and TypeMethodDescriptionDelegatingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) EventHandler.handle(EventMessage event, ProcessingContext context) Handles the giveneventwithin the givencontext.SimpleEventHandlingComponent.handle(EventMessage event, ProcessingContext context) Constructors in org.axonframework.messaging.eventhandling with parameters of type MessageModifierConstructorDescriptionprotectedGenericEventMessage(Message delegate, Instant timestamp) Constructs aGenericEventMessagewith givendelegateandtimestamp.GenericEventMessage(Message delegate, Supplier<Instant> timestampSupplier) Constructs aGenericEventMessagefor the givendelegateandtimestampSupplier, intended to reconstruct anotherEventMessage. -
Uses of Message in org.axonframework.messaging.eventhandling.annotation
Methods in org.axonframework.messaging.eventhandling.annotation that return types with arguments of type MessageModifier and TypeMethodDescriptionAnnotatedEventHandlingComponent.handle(EventMessage event, ProcessingContext context) -
Uses of Message in org.axonframework.messaging.eventhandling.interception
Methods in org.axonframework.messaging.eventhandling.interception that return types with arguments of type MessageModifier and TypeMethodDescriptionInterceptingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) -
Uses of Message in org.axonframework.messaging.eventhandling.processing
Methods in org.axonframework.messaging.eventhandling.processing that return types with arguments of type MessageModifier and TypeMethodDescriptionProcessorEventHandlingComponents.handle(List<? extends EventMessage> events, ProcessingContext context) Processes a batch of events in the processing context. -
Uses of Message in org.axonframework.messaging.eventhandling.processing.streaming.segmenting
Methods in org.axonframework.messaging.eventhandling.processing.streaming.segmenting that return types with arguments of type MessageModifier and TypeMethodDescriptionSequenceOverridingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) SequencingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) -
Uses of Message in org.axonframework.messaging.eventhandling.replay
Subinterfaces of Message in org.axonframework.messaging.eventhandling.replayModifier and TypeInterfaceDescriptioninterfaceAMessageinitiating the reset of an Event Handling Component.Classes in org.axonframework.messaging.eventhandling.replay that implement MessageConstructors in org.axonframework.messaging.eventhandling.replay with parameters of type MessageModifierConstructorDescriptionGenericResetContext(Message delegate) Constructs aGenericResetContextfor the givendelegate, intended to reconstruct anotherResetContext. -
Uses of Message in org.axonframework.messaging.eventhandling.tracing
Methods in org.axonframework.messaging.eventhandling.tracing that return types with arguments of type MessageModifier and TypeMethodDescriptionTracingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) -
Uses of Message in org.axonframework.messaging.monitoring
Classes in org.axonframework.messaging.monitoring with type parameters of type MessageModifier and TypeInterfaceDescriptioninterfaceMessageMonitor<T extends Message>Specifies a mechanism to monitor message processing.classMultiMessageMonitor<T extends Message>Delegates messages and callbacks to the given list of message monitorsMethods in org.axonframework.messaging.monitoring with parameters of type Message -
Uses of Message in org.axonframework.messaging.monitoring.configuration
Method parameters in org.axonframework.messaging.monitoring.configuration with type arguments of type MessageModifier and TypeMethodDescriptionDefaultMessageMonitorRegistry.registerMonitor(ComponentBuilder<MessageMonitor<Message>> monitorBuilder) MessageMonitorRegistry.registerMonitor(ComponentBuilder<MessageMonitor<Message>> monitorBuilder) Registers aMessageMonitorfor genericMessagetypes using the supplied monitor builder. -
Uses of Message in org.axonframework.messaging.queryhandling
Subinterfaces of Message in org.axonframework.messaging.queryhandlingModifier and TypeInterfaceDescriptioninterfaceAMessagetype that carries a Query: a request for information.interfaceAResultMessageimplementation that contains the result of query handling.interfaceAResultMessageimplementation that holds incremental update of a subscription query.Classes in org.axonframework.messaging.queryhandling that implement MessageModifier and TypeClassDescriptionclassGeneric implementation of theQueryMessageinterface.classGeneric implementation of theQueryResponseMessageinterface.classGeneric implementation of theSubscriptionQueryUpdateMessageinterface holding incremental update of a subscription query.Constructors in org.axonframework.messaging.queryhandling with parameters of type MessageModifierConstructorDescriptionGenericQueryMessage(Message delegate) Constructs aGenericQueryMessagewith givendelegateandresponseType.GenericQueryMessage(Message delegate, Integer priority) Constructs aGenericQueryMessagewith givendelegate,responseTypeandpriority.GenericQueryResponseMessage(Message delegate) Constructs aGenericQueryResponseMessagefor the givendelegate, intended to reconstruct anotherQueryResponseMessage.GenericSubscriptionQueryUpdateMessage(Message delegate) Initializes a new decorator with givendelegatemessage. -
Uses of Message in org.axonframework.messaging.tracing
Methods in org.axonframework.messaging.tracing with type parameters of type MessageModifier and TypeMethodDescription<M extends Message>
MMultiSpanFactory.propagateContext(M message) <M extends Message>
MNoOpSpanFactory.propagateContext(M message) <M extends Message>
MSpanFactory.propagateContext(M message) Propagates the currently active trace and span to the message.Methods in org.axonframework.messaging.tracing with parameters of type MessageModifier and TypeMethodDescriptiondefault SpanSpanFactory.createChildHandlerSpan(Supplier<String> operationNameSupplier, Message parentMessage, Message... linkedParents) Creates a newSpanwhich is part of the current trace.MultiSpanFactory.createDispatchSpan(Supplier<String> operationNameSupplier, Message parentMessage, Message... linkedSiblings) NoOpSpanFactory.createDispatchSpan(Supplier<String> operationNameSupplier, Message parentMessage, Message... linkedSiblings) SpanFactory.createDispatchSpan(Supplier<String> operationNameSupplier, Message parentMessage, Message... linkedSiblings) MultiSpanFactory.createHandlerSpan(Supplier<String> operationNameSupplier, Message parentMessage, boolean isChildTrace, Message... linkedParents) NoOpSpanFactory.createHandlerSpan(Supplier<String> operationNameSupplier, Message parentMessage, boolean isChildTrace, Message... linkedParents) SpanFactory.createHandlerSpan(Supplier<String> operationNameSupplier, Message parentMessage, boolean isChildTrace, Message... linkedParents) MultiSpanFactory.createInternalSpan(Supplier<String> operationNameSupplier, Message message) NoOpSpanFactory.createInternalSpan(Supplier<String> operationNameSupplier, Message message) SpanFactory.createInternalSpan(Supplier<String> operationNameSupplier, Message message) Creates a newSpanlinked to the currently active span.default SpanSpanFactory.createLinkedHandlerSpan(Supplier<String> operationNameSupplier, Message parentMessage, Message... linkedParents) Creates a newSpanwhich becomes its own separate trace, linked to the previous span.static StringSpanUtils.determineMessageName(Message message) Creates a human-readable name for a message based on itstype().SpanAttributesProvider.provideForMessage(Message message) -
Uses of Message in org.axonframework.messaging.tracing.attributes
Methods in org.axonframework.messaging.tracing.attributes with parameters of type MessageModifier and TypeMethodDescriptionAggregateIdentifierSpanAttributesProvider.provideForMessage(Message message) MessageIdSpanAttributesProvider.provideForMessage(Message message) MessageNameSpanAttributesProvider.provideForMessage(Message message) MessageTypeSpanAttributesProvider.provideForMessage(Message message) MetadataSpanAttributesProvider.provideForMessage(Message message) PayloadTypeSpanAttributesProvider.provideForMessage(Message message) -
Uses of Message in org.axonframework.modelling
Methods in org.axonframework.modelling with parameters of type MessageModifier and TypeMethodDescriptionEntityIdResolver.resolve(Message message, ProcessingContext context) Resolve the id of the entity from the givenmessageandcontext.PropertyBasedEntityIdResolver.resolve(Message message, ProcessingContext context) -
Uses of Message in org.axonframework.modelling.annotation
Methods in org.axonframework.modelling.annotation with parameters of type MessageModifier and TypeMethodDescriptionAnnotationBasedEntityIdResolver.resolve(Message message, ProcessingContext context) -
Uses of Message in org.axonframework.modelling.entity.annotation
Methods in org.axonframework.modelling.entity.annotation with parameters of type Message -
Uses of Message in org.axonframework.test.fixture
Methods in org.axonframework.test.fixture that return MessageModifier and TypeMethodDescriptionRecordingCommandBus.resultOf(CommandMessage command) Returns the result of the givencommand.Methods in org.axonframework.test.fixture that return types with arguments of type MessageModifier and TypeMethodDescriptionRecordingCommandBus.recorded()Returns map of all theCommandMessagesdispatched, and their corresponding results. -
Uses of Message in org.axonframework.test.matchers
Classes in org.axonframework.test.matchers with type parameters of type MessageModifier and TypeClassDescriptionclassPayloadMatcher<T extends Message>Matcher that matches any message (e.g.Methods in org.axonframework.test.matchers with type parameters of type MessageModifier and TypeMethodDescriptionstatic <T extends Message>
org.hamcrest.Matcher<T> Matchers.messageWithPayload(org.hamcrest.Matcher<?> payloadMatcher) Returns aMatcherthat matches a singleMessageif the givenpayloadMatchermatches that message's payload.Methods in org.axonframework.test.matchers that return types with arguments of type MessageModifier and TypeMethodDescriptionMatchers.payloadsMatching(org.hamcrest.Matcher<? extends List<?>> matcher) Returns aMatcherthat matches a list ofMessageif a list containing their respective payloads matches the givenmatcher. -
Uses of Message in org.axonframework.test.util
Methods in org.axonframework.test.util that return MessageModifier and TypeMethodDescriptionMessageMonitorReport.Report.Failure.message()Returns the value of themessagerecord component.MessageMonitorReport.Report.Ignored.message()Returns the value of themessagerecord component.MessageMonitorReport.Report.message()Retrieves the message associated with the report.MessageMonitorReport.Report.Success.message()Returns the value of themessagerecord component.Methods in org.axonframework.test.util with parameters of type MessageModifier and TypeMethodDescriptionCreates a new instance ofMessageMonitorReport.Report.Failurewith the specified message and cause.Creates a new instance ofMessageMonitorReport.Report.Ignoredwith the specified message.RecordingMessageMonitor.onMessageIngested(@NotNull Message message) protected voidRecordingMessageMonitor.onReportFailure(Message message, Throwable cause) Hook for subclasses to perform additional actions when a message is reported as failed.protected voidRecordingMessageMonitor.onReportIgnored(Message message) Hook for subclasses to perform additional actions when a message is reported as ignored.protected voidRecordingMessageMonitor.onReportSuccess(Message message) Hook for subclasses to perform additional actions when a message is reported as successful.Creates a new instance ofMessageMonitorReport.Report.Successwith the specified message.Constructors in org.axonframework.test.util with parameters of type Message
MessageHandlingMember.handle(Message, ProcessingContext, Object).