Modifier and Type | Class and Description |
---|---|
class |
DispatchInterceptors<M extends Message<?>>
Composite of
MessageDispatchInterceptor s that apply all interceptors in the order of registration. |
interface |
TargetContextResolver<T extends Message<?>>
Interface towards a mechanism that is capable of resolving the context name to which a
Message should be
routed. |
Modifier and Type | Method and Description |
---|---|
static TargetContextResolver<Message<?>> |
TargetContextResolver.noOp()
Returns a no-op TargetContextResolver.
|
Modifier and Type | Class and Description |
---|---|
class |
GrpcBackedCommandMessage<C>
Wrapper that allows clients to access a gRPC
Command as a CommandMessage . |
Modifier and Type | Class and Description |
---|---|
class |
GrpcBackedQueryMessage<Q,R>
Wrapper that allows clients to access a gRPC
QueryRequest as a QueryMessage . |
class |
GrpcBackedResponseMessage<R>
Wrapper that allows clients to access a gRPC
QueryResponse as a QueryResponseMessage . |
Modifier and Type | Class and Description |
---|---|
class |
GrpcBackedSubscriptionQueryMessage<Q,I,U>
Wrapper that allows clients to access a gRPC
SubscriptionQuery message as a SubscriptionQueryMessage . |
Modifier and Type | Method and Description |
---|---|
SerializedObject |
GrpcPayloadSerializer.apply(Message message) |
Modifier and Type | Interface and Description |
---|---|
interface |
CommandMessage<T>
Represents a Message carrying a command as its payload.
|
interface |
CommandResultMessage<R>
Message that represents a result from handling a
CommandMessage . |
Modifier and Type | Class and Description |
---|---|
class |
GenericCommandMessage<T>
Implementation of the CommandMessage that takes all properties as constructor parameters.
|
class |
GenericCommandResultMessage<R>
Generic implementation of
CommandResultMessage . |
Modifier and Type | Method and Description |
---|---|
boolean |
CurrentUnitOfWorkParameterResolverFactory.matches(Message message) |
boolean |
InterceptorChainParameterResolverFactory.matches(Message<?> message) |
Object |
CurrentUnitOfWorkParameterResolverFactory.resolveParameterValue(Message message) |
InterceptorChain |
InterceptorChainParameterResolverFactory.resolveParameterValue(Message<?> message) |
Constructor and Description |
---|
GenericCommandMessage(Message<T> delegate,
String commandName)
Create a CommandMessage from the given
delegate message containing payload, metadata and message
identifier, and the given commandName . |
GenericCommandResultMessage(Message<R> delegate)
Creates a new Command Result Message with given
delegate message. |
GenericCommandResultMessage(Message<R> delegate,
Throwable exception)
Creates a Command Result Message with given
delegate message and exception . |
Modifier and Type | Method and Description |
---|---|
<M extends Message<?>> |
Configuration.messageMonitor(Class<?> componentType,
String componentName)
Returns the message monitor configured for a component of given
componentType and componentName . |
Modifier and Type | Method and Description |
---|---|
MessageMonitor<Message<?>> |
MessageMonitorFactory.create(Configuration configuration,
Class<?> componentType,
String componentName)
Function to create a Message Monitor based on the given configuration, component type and component name.
|
MessageMonitor<? super Message<?>> |
EventProcessingModule.messageMonitor(Class<?> componentType,
String eventProcessorName) |
MessageMonitor<? super Message<?>> |
EventProcessingConfiguration.messageMonitor(Class<?> componentType,
String componentName)
Returns the
MessageMonitor set to the given componentType and componentName registered
within this configuration. |
Modifier and Type | Method and Description |
---|---|
default Configurer |
Configurer.configureMessageMonitor(Class<?> componentType,
Function<Configuration,MessageMonitor<Message<?>>> messageMonitorBuilder)
Configures the builder function to create the Message Monitor for the Message processing components in this
configuration that match the given componentType, unless more specific configuration based on both type and name
is available.
|
default Configurer |
Configurer.configureMessageMonitor(Class<?> componentType,
String componentName,
Function<Configuration,MessageMonitor<Message<?>>> messageMonitorBuilder)
Configures the builder function to create the Message Monitor for the Message processing components in this
configuration that match the given class and name.
|
Configurer |
DefaultConfigurer.configureMessageMonitor(Function<Configuration,BiFunction<Class<?>,String,MessageMonitor<Message<?>>>> builder) |
Configurer |
Configurer.configureMessageMonitor(Function<Configuration,BiFunction<Class<?>,String,MessageMonitor<Message<?>>>> messageMonitorFactoryBuilder)
Configures the Message Monitor to use for the Message processing components in this configuration, unless more
specific configuration based on the component's type, or type and name is available.
|
default EventProcessingConfigurer |
EventProcessingConfigurer.registerMessageMonitor(String eventProcessorName,
Function<Configuration,MessageMonitor<Message<?>>> messageMonitorBuilder)
|
Modifier and Type | Interface and Description |
---|---|
interface |
DeadlineMessage<T>
Represents a Message for a Deadline, specified by its deadline name and optionally containing a deadline payload.
|
Modifier and Type | Class and Description |
---|---|
class |
GenericDeadlineMessage<T>
Generic implementation of the
DeadlineMessage . |
Constructor and Description |
---|
GenericDeadlineMessage(String deadlineName,
Message<T> delegate,
Supplier<Instant> timestampSupplier)
Constructor to reconstruct a DeadlineMessage using existing data.
|
Modifier and Type | Class and Description |
---|---|
class |
DisruptorUnitOfWork<T extends Message<?>>
Specialized UnitOfWork instance for the
DisruptorCommandBus . |
Modifier and Type | Method and Description |
---|---|
UnitOfWork<T> |
DisruptorUnitOfWork.transformMessage(Function<T,? extends Message<?>> transformOperator) |
Modifier and Type | Interface and Description |
---|---|
interface |
DomainEventMessage<T>
Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain.
|
interface |
EventMessage<T>
Represents a Message wrapping an Event, which is represented by its payload.
|
interface |
TrackedEventMessage<T>
Represents an
EventMessage containing a TrackingToken . |
Modifier and Type | Class and Description |
---|---|
class |
GenericDomainEventMessage<T>
Generic implementation of a
DomainEventMessage . |
class |
GenericEventMessage<T>
Generic implementation of the EventMessage interface.
|
class |
GenericTrackedDomainEventMessage<T>
Generic implementation of a
DomainEventMessage that is also a TrackedEventMessage . |
class |
GenericTrackedEventMessage<T>
Generic implementation of a
TrackedEventMessage . |
Modifier and Type | Method and Description |
---|---|
static boolean |
ReplayToken.isReplay(Message<?> message)
Indicates whether the given message is "redelivered", as a result of a previous reset.
|
boolean |
SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver.matches(Message message) |
boolean |
ConcludesBatchParameterResolverFactory.matches(Message<?> message) |
Long |
SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver.resolveParameterValue(Message message) |
Boolean |
ConcludesBatchParameterResolverFactory.resolveParameterValue(Message<?> message) |
Constructor and Description |
---|
GenericDomainEventMessage(String type,
String aggregateIdentifier,
long sequenceNumber,
Message<T> delegate,
Instant timestamp)
Initialize a DomainEventMessage originating from an Aggregate with the given
aggregateIdentifier ,
with given sequenceNumber and payload , metaData and timestamp . |
GenericDomainEventMessage(String type,
String aggregateIdentifier,
long sequenceNumber,
Message<T> delegate,
Supplier<Instant> timestamp)
Initialize a DomainEventMessage originating from an Aggregate using existing data.
|
GenericEventMessage(Message<T> delegate,
Instant timestamp)
Initializes a
GenericEventMessage with given message as delegate and given timestamp . |
GenericEventMessage(Message<T> delegate,
Supplier<Instant> timestampSupplier)
Constructor to reconstruct an EventMessage using existing data.
|
GenericTrackedDomainEventMessage(TrackingToken trackingToken,
String type,
String aggregateIdentifier,
long sequenceNumber,
Message<T> delegate,
Instant timestamp)
Initialize a DomainEventMessage originating from an aggregate.
|
GenericTrackedDomainEventMessage(TrackingToken trackingToken,
String type,
String aggregateIdentifier,
long sequenceNumber,
Message<T> delegate,
Supplier<Instant> timestamp)
Initialize a DomainEventMessage originating from an Aggregate using existing data.
|
GenericTrackedEventMessage(TrackingToken trackingToken,
Message<T> delegate,
Instant timestamp)
Initializes a
GenericTrackedEventMessage with given message as delegate and given timestamp . |
GenericTrackedEventMessage(TrackingToken trackingToken,
Message<T> delegate,
Supplier<Instant> timestamp)
Creates a GenericTrackedEventMessage with given
trackingToken and delegate event message. |
Modifier and Type | Method and Description |
---|---|
boolean |
ConflictResolution.matches(Message<?> message) |
ConflictResolver |
ConflictResolution.resolveParameterValue(Message<?> message) |
Modifier and Type | Class and Description |
---|---|
class |
DefaultInterceptorChain<T extends Message<?>>
Mechanism that takes care of interceptor and handler execution.
|
interface |
MessageDispatchInterceptor<T extends Message<?>>
Interceptor that allows messages to be intercepted and modified before they are dispatched.
|
interface |
MessageDispatchInterceptorSupport<T extends Message<?>>
Interface marking components capable of registering Dispatch Interceptors.
|
interface |
MessageHandler<T extends Message<?>>
Interface for a component that processes Messages.
|
interface |
MessageHandlerInterceptor<T extends Message<?>>
Workflow interface that allows for customized message handler invocation chains.
|
interface |
MessageHandlerInterceptorSupport<T extends Message<?>>
Interface marking components capable of registering Handler Interceptors.
|
interface |
StreamableMessageSource<M extends Message<?>>
Interface for a source of
messages that processors can track. |
interface |
SubscribableMessageSource<M extends Message<?>>
Interface for a source of
messages to which message processors can subscribe. |
Modifier and Type | Interface and Description |
---|---|
interface |
ResultMessage<R>
Message that represents a result of handling some form of request message.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMessage<T>
Abstract base class for Messages.
|
class |
GenericMessage<T>
Generic implementation of a
Message that contains the payload and metadata as unserialized values. |
class |
GenericResultMessage<R>
Generic implementation of
ResultMessage . |
class |
MessageDecorator<T>
Abstract implementation of a
Message that delegates to an existing message. |
Modifier and Type | Method and Description |
---|---|
Message<T> |
Message.andMetaData(Map<String,?> metaData)
Returns a copy of this Message with it MetaData merged with the given
metaData . |
Message<T> |
AbstractMessage.andMetaData(Map<String,?> metaData) |
static Message<?> |
GenericMessage.asMessage(Object payloadOrMessage)
Returns a Message representing the given
payloadOrMessage , either by wrapping it or by returning it
as-is. |
protected Message<T> |
MessageDecorator.getDelegate()
Returns the wrapped message delegate.
|
Message<T> |
Message.withMetaData(Map<String,?> metaData)
Returns a copy of this Message with the given
metaData . |
Message<T> |
AbstractMessage.withMetaData(Map<String,?> metaData) |
protected Message<T> |
GenericMessage.withMetaData(MetaData metaData) |
protected abstract Message<T> |
AbstractMessage.withMetaData(MetaData metaData)
Returns a new message instance with the same payload and properties as this message but given
metaData . |
Modifier and Type | Method and Description |
---|---|
void |
ScopeAware.send(Message<?> message,
ScopeDescriptor scopeDescription)
|
Constructor and Description |
---|
GenericResultMessage(Message<R> delegate)
Creates a new ResultMessage with given
delegate message. |
GenericResultMessage(Message<R> delegate,
Throwable exception)
Creates a ResultMessage with given
delegate message and exception . |
MessageDecorator(Message<T> delegate)
Initializes a new decorator with given
delegate message. |
Modifier and Type | Method and Description |
---|---|
boolean |
AnnotatedMessageHandlingMember.canHandle(Message<?> message) |
boolean |
MessageHandlingMember.canHandle(Message<?> message)
Checks if this handler is capable of handling the given
message . |
boolean |
WrappedMessageHandlingMember.canHandle(Message<?> message) |
Object |
AnnotatedMessageHandlingMember.handle(Message<?> message,
T target) |
Object |
MessageHandlingMember.handle(Message<?> message,
T target)
Handles the given
message by invoking the appropriate method on given target . |
Object |
WrappedMessageHandlingMember.handle(Message<?> message,
T target) |
boolean |
FixedValueParameterResolver.matches(Message message) |
boolean |
PayloadParameterResolver.matches(Message message) |
boolean |
ParameterResolver.matches(Message<?> message)
Indicates whether this resolver is capable of providing a value for the given
message . |
protected boolean |
AnnotatedMessageHandlingMember.parametersMatch(Message<?> message)
Checks if the parameter resolvers of this member are compatible with the given
message . |
T |
FixedValueParameterResolver.resolveParameterValue(Message message) |
Object |
PayloadParameterResolver.resolveParameterValue(Message message) |
T |
ParameterResolver.resolveParameterValue(Message<?> message)
Resolves the parameter value to use for the given
message , or null if no suitable
parameter value can be resolved. |
protected boolean |
AnnotatedMessageHandlingMember.typeMatches(Message<?> message)
Checks if this member can handle the type of the given
message . |
Constructor and Description |
---|
AnnotatedMessageHandlingMember(Executable executable,
Class<? extends Message> messageType,
Class<?> explicitPayloadType,
ParameterResolverFactory parameterResolverFactory)
Initializes a new instance that will invoke the given
executable (method) on a target to handle a message
of the given messageType . |
Modifier and Type | Class and Description |
---|---|
class |
MultiCorrelationDataProvider<T extends Message>
CorrelationDataProvider that combines the data of multiple other correlation providers.
|
Modifier and Type | Method and Description |
---|---|
Map<String,?> |
SimpleCorrelationDataProvider.correlationDataFor(Message<?> message) |
Map<String,?> |
MultiCorrelationDataProvider.correlationDataFor(Message<?> message) |
Map<String,?> |
MessageOriginProvider.correlationDataFor(Message<?> message) |
Map<String,?> |
CorrelationDataProvider.correlationDataFor(Message<?> message)
Provides a map with the entries to attach as correlation data to generated messages while processing given
message . |
Modifier and Type | Class and Description |
---|---|
class |
BeanValidationInterceptor<T extends Message<?>>
Interceptor that applies JSR303 bean validation on incoming messages.
|
class |
CorrelationDataInterceptor<T extends Message<?>>
Message interceptor that registers
CorrelationDataProviders with the Unit of Work. |
class |
LoggingInterceptor<T extends Message<?>>
MessageDispatchInterceptor and MessageHandlerInterceptor implementation that logs dispatched and
incoming messages, and their result, to a SLF4J logger. |
class |
TransactionManagingInterceptor<T extends Message<?>>
Interceptor that uses a
TransactionManager to start a new transaction before a Message is handled. |
Modifier and Type | Class and Description |
---|---|
class |
ConvertingResponseMessage<R>
Implementation of a QueryResponseMessage that is aware of the requested response type and performs a just-in-time
conversion to ensure the response is formatted as requested.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractUnitOfWork<T extends Message<?>>
Abstract implementation of the Unit of Work.
|
class |
BatchingUnitOfWork<T extends Message<?>>
Unit of Work implementation that is able to process a batch of Messages instead of just a single Message.
|
class |
DefaultUnitOfWork<T extends Message<?>>
Implementation of the UnitOfWork that processes a single message.
|
class |
MessageProcessingContext<T extends Message<?>>
Maintains the context around the processing of a single Message.
|
interface |
UnitOfWork<T extends Message<?>>
This class represents a Unit of Work that monitors the processing of a
Message . |
Modifier and Type | Method and Description |
---|---|
static <T extends Message<?>> |
DefaultUnitOfWork.startAndGet(T message)
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork.
|
Modifier and Type | Method and Description |
---|---|
Map<Message<?>,ExecutionResult> |
BatchingUnitOfWork.getExecutionResults()
Returns a Map of
ExecutionResult per Message. |
Modifier and Type | Method and Description |
---|---|
boolean |
BatchingUnitOfWork.isFirstMessage(Message<?> message)
Checks if the given
message is the first of the batch being processed in this unit of work. |
boolean |
BatchingUnitOfWork.isLastMessage(Message<?> message)
Checks if the given
message is the last of the batch being processed in this unit of work. |
Modifier and Type | Method and Description |
---|---|
UnitOfWork<T> |
UnitOfWork.transformMessage(Function<T,? extends Message<?>> transformOperator)
Transform the Message being processed using the given operator and stores the result.
|
UnitOfWork<T> |
DefaultUnitOfWork.transformMessage(Function<T,? extends Message<?>> transformOperator) |
void |
MessageProcessingContext.transformMessage(Function<T,? extends Message<?>> transformOperator)
Transform the Message being processed using the given operator.
|
UnitOfWork<T> |
BatchingUnitOfWork.transformMessage(Function<T,? extends Message<?>> transformOperator) |
Constructor and Description |
---|
BatchingUnitOfWork(T... messages)
Initializes a BatchingUnitOfWork for processing the given batch of
messages . |
Modifier and Type | Class and Description |
---|---|
class |
PayloadTypeMessageMonitorWrapper<T extends MessageMonitor<Message<?>> & com.codahale.metrics.MetricSet>
A
MessageMonitor implementation which creates a new MessageMonitor for every Message payload type
ingested by it. |
Modifier and Type | Method and Description |
---|---|
MessageMonitor<? extends Message<?>> |
GlobalMetricRegistry.registerComponent(Class<?> componentType,
String componentName)
Registers new metrics to the registry to monitor a component of given
type . |
Modifier and Type | Method and Description |
---|---|
MessageMonitor.MonitorCallback |
MessageTimerMonitor.onMessageIngested(Message<?> message) |
MessageMonitor.MonitorCallback |
MessageCountingMonitor.onMessageIngested(Message<?> message) |
MessageMonitor.MonitorCallback |
CapacityMonitor.onMessageIngested(Message<?> message) |
MessageMonitor.MonitorCallback |
PayloadTypeMessageMonitorWrapper.onMessageIngested(Message<?> message) |
Modifier and Type | Class and Description |
---|---|
class |
PayloadTypeMessageMonitorWrapper<T extends MessageMonitor<Message<?>>>
A
MessageMonitor implementation which creates a new MessageMonitor for every Message payload type
ingested by it. |
Modifier and Type | Method and Description |
---|---|
MessageMonitor<? extends Message<?>> |
GlobalMetricRegistry.registerComponent(Class<?> componentType,
String componentName)
Registers new metrics to the registry to monitor a component of given
type . |
Modifier and Type | Method and Description |
---|---|
MessageMonitor.MonitorCallback |
MessageTimerMonitor.onMessageIngested(Message<?> message) |
MessageMonitor.MonitorCallback |
MessageCountingMonitor.onMessageIngested(Message<?> message) |
MessageMonitor.MonitorCallback |
CapacityMonitor.onMessageIngested(Message<?> message) |
MessageMonitor.MonitorCallback |
PayloadTypeMessageMonitorWrapper.onMessageIngested(Message<?> message) |
Modifier and Type | Interface and Description |
---|---|
interface |
ForwardingMode<T extends Message<?>>
Interface describing the required functionality to forward a message.
|
class |
ForwardMatchingInstances<T extends Message<?>>
Only forward messages of type
T if the routing key of the message matches that of the entity. |
class |
ForwardNone<T extends Message<?>>
Forward no messages
T regardless of their set up. |
class |
ForwardToAll<T extends Message<?>>
Forward all messages
T regardless of their set up. |
Modifier and Type | Method and Description |
---|---|
Object |
LockAwareAggregate.handle(Message<?> message) |
Object |
Aggregate.handle(Message<?> message)
Handle the given
message on the aggregate root or one of its child entities. |
void |
AbstractRepository.send(Message<?> message,
ScopeDescriptor scopeDescription) |
Modifier and Type | Method and Description |
---|---|
boolean |
ChildForwardingCommandMessageHandlingMember.canHandle(Message<?> message) |
Object |
AnnotatedAggregate.handle(Message<?> message) |
Object |
ChildForwardingCommandMessageHandlingMember.handle(Message<?> message,
P target) |
Modifier and Type | Method and Description |
---|---|
Object |
SagaMethodMessageHandlingMember.handle(Message<?> message,
T target) |
void |
AbstractSagaManager.send(Message<?> message,
ScopeDescriptor scopeDescription) |
Modifier and Type | Interface and Description |
---|---|
interface |
MessageMonitor<T extends Message<?>>
Specifies a mechanism to monitor message processing.
|
class |
MultiMessageMonitor<T extends Message<?>>
Delegates messages and callbacks to the given list of message monitors
|
Modifier and Type | Method and Description |
---|---|
MessageMonitor.MonitorCallback |
NoOpMessageMonitor.onMessageIngested(Message<?> message) |
Modifier and Type | Interface and Description |
---|---|
interface |
QueryMessage<T,R>
Message type that carries a Query: a request for information.
|
interface |
QueryResponseMessage<T>
Message that contains the results of a Query.
|
interface |
SubscriptionQueryMessage<Q,I,U>
Message type that carries a Subscription Query: a request for information.
|
interface |
SubscriptionQueryUpdateMessage<U>
Message which holds incremental update of an subscription query.
|
Modifier and Type | Class and Description |
---|---|
class |
GenericQueryMessage<T,R>
Generic implementation of the QueryMessage.
|
class |
GenericQueryResponseMessage<R>
QueryResponseMessage implementation that takes all properties as constructor parameters.
|
class |
GenericSubscriptionQueryMessage<Q,I,U>
Generic implementation of the
SubscriptionQueryMessage . |
class |
GenericSubscriptionQueryUpdateMessage<U>
Generic
SubscriptionQueryUpdateMessage which holds incremental update of an subscription query. |
Constructor and Description |
---|
GenericQueryMessage(Message<T> delegate,
String queryName,
ResponseType<R> responseType)
Initialize the Query Message, using given
delegate as the carrier of payload and metadata and given
queryName and expecting the given responseType . |
GenericQueryResponseMessage(Message<R> delegate)
Copy-constructor that takes the payload, meta data and message identifier of the given
delegate for this
message. |
GenericQueryResponseMessage(Message<R> delegate,
Throwable exception)
Copy-constructor that takes the payload, meta data and message identifier of the given
delegate for this
message and given exception as a cause for the failure. |
GenericSubscriptionQueryMessage(Message<Q> delegate,
String queryName,
ResponseType<I> responseType,
ResponseType<U> updateResponseType)
Initializes the message, using given
delegate as the carrier of payload and metadata and given queryName , expected responseType and expected updateResponseType . |
GenericSubscriptionQueryUpdateMessage(Message<U> delegate)
Initializes a new decorator with given
delegate message. |
Modifier and Type | Class and Description |
---|---|
class |
SerializedMessage<T>
A message containing serialized payload data and metadata.
|
Constructor and Description |
---|
SerializedObjectHolder(Message message)
Initialize the holder for the serialized representations of the payload and meta data of given
message |
Modifier and Type | Method and Description |
---|---|
<M extends Message<?>> |
AxonConfiguration.messageMonitor(Class<?> componentType,
String componentName) |
Modifier and Type | Method and Description |
---|---|
TargetContextResolver<Message<?>> |
AxonServerAutoConfiguration.targetContextResolver() |
Modifier and Type | Class and Description |
---|---|
class |
PayloadMatcher<T extends Message>
Matcher that matches any message (e.g.
|
Modifier and Type | Method and Description |
---|---|
static org.hamcrest.Matcher<Message<?>> |
Matchers.messageWithPayload(org.hamcrest.Matcher<?> payloadMatcher)
Matches a single Message if the given
payloadMatcher matches that message's payload. |
static org.hamcrest.Matcher<List<Message<?>>> |
Matchers.payloadsMatching(org.hamcrest.Matcher<? extends List<?>> matcher)
Matches a list of Messages if a list containing their respective payloads matches the given
matcher . |
Copyright © 2010–2020. All rights reserved.