Package | Description |
---|---|
org.axonframework.axonserver.connector.command | |
org.axonframework.commandhandling |
Classes that implement the concept of command handling using explicit command objects.
|
org.axonframework.commandhandling.callbacks | |
org.axonframework.commandhandling.distributed | |
org.axonframework.commandhandling.distributed.commandfilter | |
org.axonframework.commandhandling.gateway | |
org.axonframework.disruptor.commandhandling | |
org.axonframework.metrics | |
org.axonframework.micrometer | |
org.axonframework.modelling.command | |
org.axonframework.modelling.command.inspection | |
org.axonframework.springboot.autoconfig | |
org.axonframework.test.aggregate | |
org.axonframework.test.matchers | |
org.axonframework.test.saga | |
org.axonframework.test.utils |
A collection of classes which may prove useful when testing Axon-based classes.
|
Modifier and Type | Class and Description |
---|---|
class |
GrpcBackedCommandMessage<C>
Wrapper that allows clients to access a gRPC
Command as a CommandMessage . |
Modifier and Type | Method and Description |
---|---|
CommandMessage<?> |
CommandSerializer.deserialize(Command command)
Convert a
Command into a CommandMessage . |
Modifier and Type | Method and Description |
---|---|
int |
CommandPriorityCalculator.determinePriority(CommandMessage<?> command)
Determines the priority of the given
command . |
<C> void |
AxonServerCommandBus.dispatch(CommandMessage<C> command) |
<C,R> void |
AxonServerCommandBus.dispatch(CommandMessage<C> commandMessage,
CommandCallback<? super C,? super R> commandCallback) |
Command |
CommandSerializer.serialize(CommandMessage<?> commandMessage,
String routingKey,
int priority)
Convert a
CommandMessage into a Command . |
Modifier and Type | Method and Description |
---|---|
Registration |
AxonServerCommandBus.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> dispatchInterceptor) |
Registration |
AxonServerCommandBus.registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>> handlerInterceptor) |
Registration |
AxonServerCommandBus.subscribe(String commandName,
MessageHandler<? super CommandMessage<?>> messageHandler) |
AxonServerCommandBus.Builder |
AxonServerCommandBus.Builder.targetContextResolver(TargetContextResolver<? super CommandMessage<?>> targetContextResolver)
Sets the
TargetContextResolver used to resolve the target (bounded) context of an ingested
CommandMessage . |
Constructor and Description |
---|
AxonServerCommandBus(AxonServerConnectionManager axonServerConnectionManager,
AxonServerConfiguration configuration,
CommandBus localSegment,
Serializer serializer,
RoutingStrategy routingStrategy,
CommandPriorityCalculator priorityCalculator,
TargetContextResolver<? super CommandMessage<?>> targetContextResolver)
Deprecated.
in favor of using the
AxonServerCommandBus.Builder (with the convenience AxonServerCommandBus.builder() method) to instantiate
an Axon Server Command Bus |
Modifier and Type | Class and Description |
---|---|
class |
GenericCommandMessage<T>
Implementation of the CommandMessage that takes all properties as constructor parameters.
|
Modifier and Type | Method and Description |
---|---|
CommandMessage<T> |
CommandMessage.andMetaData(Map<String,?> metaData)
Returns a copy of this CommandMessage with it MetaData merged with the given
metaData . |
static <C> CommandMessage<C> |
GenericCommandMessage.asCommandMessage(Object command)
Returns the given command as a CommandMessage.
|
protected <C> CommandMessage<C> |
SimpleCommandBus.intercept(CommandMessage<C> command)
Invokes all the dispatch interceptors.
|
CommandMessage<T> |
CommandMessage.withMetaData(Map<String,?> metaData)
Returns a copy of this CommandMessage with the given
metaData . |
Modifier and Type | Method and Description |
---|---|
MessageHandler<? super CommandMessage<?>> |
DuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler)
Chooses what to do when a duplicate handler is registered, returning the handler that should be selected for
command handling, or otherwise throwing an exception to reject registration altogether.
|
MessageHandler<? super CommandMessage<?>> |
FailingDuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler) |
MessageHandler<? super CommandMessage<?>> |
LoggingDuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler) |
Modifier and Type | Method and Description |
---|---|
boolean |
AnnotationCommandHandlerAdapter.canHandle(CommandMessage<?> message) |
<C> void |
SimpleCommandBus.dispatch(CommandMessage<C> command) |
<C> void |
CommandBus.dispatch(CommandMessage<C> command)
Dispatch the given
command to the CommandHandler subscribed to the given command 's name. |
<C,R> void |
SimpleCommandBus.dispatch(CommandMessage<C> command,
CommandCallback<? super C,? super R> callback) |
<C,R> void |
CommandBus.dispatch(CommandMessage<C> command,
CommandCallback<? super C,? super R> callback)
Dispatch the given
command to the CommandHandler subscribed to the given command 's name. |
protected <C,R> void |
SimpleCommandBus.doDispatch(CommandMessage<C> command,
CommandCallback<? super C,? super R> callback)
Performs the actual dispatching logic.
|
Object |
AnnotationCommandHandlerAdapter.handle(CommandMessage<?> command)
Invokes the @CommandHandler annotated method that accepts the given
command . |
protected <C,R> void |
AsynchronousCommandBus.handle(CommandMessage<C> command,
MessageHandler<? super CommandMessage<?>> handler,
CommandCallback<? super C,? super R> callback) |
protected <C,R> void |
SimpleCommandBus.handle(CommandMessage<C> command,
MessageHandler<? super CommandMessage<?>> handler,
CommandCallback<? super C,? super R> callback)
Performs the actual handling logic.
|
protected <C> CommandMessage<C> |
SimpleCommandBus.intercept(CommandMessage<C> command)
Invokes all the dispatch interceptors.
|
void |
MonitorAwareCallback.onResult(CommandMessage<? extends C> commandMessage,
CommandResultMessage<? extends R> commandResultMessage) |
void |
CommandCallback.onResult(CommandMessage<? extends C> commandMessage,
CommandResultMessage<? extends R> commandResultMessage)
Invoked when command handling execution is completed.
|
Modifier and Type | Method and Description |
---|---|
protected <C,R> void |
AsynchronousCommandBus.handle(CommandMessage<C> command,
MessageHandler<? super CommandMessage<?>> handler,
CommandCallback<? super C,? super R> callback) |
protected <C,R> void |
SimpleCommandBus.handle(CommandMessage<C> command,
MessageHandler<? super CommandMessage<?>> handler,
CommandCallback<? super C,? super R> callback)
Performs the actual handling logic.
|
AsynchronousCommandBus.Builder |
AsynchronousCommandBus.Builder.messageMonitor(MessageMonitor<? super CommandMessage<?>> messageMonitor) |
SimpleCommandBus.Builder |
SimpleCommandBus.Builder.messageMonitor(MessageMonitor<? super CommandMessage<?>> messageMonitor)
Sets the
MessageMonitor of generic type CommandMessage used the to monitor the command bus. |
Registration |
SimpleCommandBus.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> dispatchInterceptor)
Registers the given list of dispatch interceptors to the command bus.
|
Registration |
SimpleCommandBus.registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>> handlerInterceptor)
Registers the given interceptor to the command bus.
|
MessageHandler<? super CommandMessage<?>> |
DuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler)
Chooses what to do when a duplicate handler is registered, returning the handler that should be selected for
command handling, or otherwise throwing an exception to reject registration altogether.
|
MessageHandler<? super CommandMessage<?>> |
DuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler)
Chooses what to do when a duplicate handler is registered, returning the handler that should be selected for
command handling, or otherwise throwing an exception to reject registration altogether.
|
MessageHandler<? super CommandMessage<?>> |
FailingDuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler) |
MessageHandler<? super CommandMessage<?>> |
FailingDuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler) |
MessageHandler<? super CommandMessage<?>> |
LoggingDuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler) |
MessageHandler<? super CommandMessage<?>> |
LoggingDuplicateCommandHandlerResolver.resolve(String commandName,
MessageHandler<? super CommandMessage<?>> registeredHandler,
MessageHandler<? super CommandMessage<?>> candidateHandler) |
Registration |
SimpleCommandBus.subscribe(String commandName,
MessageHandler<? super CommandMessage<?>> handler)
Subscribe the given
handler to commands with given commandName . |
Registration |
CommandBus.subscribe(String commandName,
MessageHandler<? super CommandMessage<?>> handler)
Subscribe the given
handler to commands with the given commandName . |
Constructor and Description |
---|
NoHandlerForCommandException(CommandMessage<?> commandMessage)
Initialize a NoHandlerForCommandException with a message describing the given
CommandMessage . |
Constructor and Description |
---|
DuplicateCommandHandlerSubscriptionException(String commandName,
MessageHandler<? super CommandMessage<?>> initialHandler,
MessageHandler<? super CommandMessage<?>> duplicateHandler)
Initialize a duplicate command handler subscription exception using the given
initialHandler and duplicateHandler to form a specific message. |
DuplicateCommandHandlerSubscriptionException(String commandName,
MessageHandler<? super CommandMessage<?>> initialHandler,
MessageHandler<? super CommandMessage<?>> duplicateHandler)
Initialize a duplicate command handler subscription exception using the given
initialHandler and duplicateHandler to form a specific message. |
Modifier and Type | Method and Description |
---|---|
void |
NoOpCallback.onResult(CommandMessage<?> commandMessage,
CommandResultMessage<?> commandResultMessage)
Invoked when command handling execution is completed.
|
void |
FailureLoggingCallback.onResult(CommandMessage<? extends C> commandMessage,
CommandResultMessage<? extends R> commandResultMessage) |
void |
FutureCallback.onResult(CommandMessage<? extends C> commandMessage,
CommandResultMessage<? extends R> commandResultMessage) |
void |
LoggingCallback.onResult(CommandMessage message,
CommandResultMessage commandResultMessage) |
Modifier and Type | Method and Description |
---|---|
CommandMessage<?> |
DispatchMessage.getCommandMessage(Serializer serializer)
Returns the CommandMessage wrapped in this Message.
|
CommandMessage<C> |
CommandCallbackWrapper.getMessage()
Returns the command message that was sent.
|
Modifier and Type | Method and Description |
---|---|
<C> void |
DistributedCommandBus.dispatch(CommandMessage<C> command) |
<C,R> void |
DistributedCommandBus.dispatch(CommandMessage<C> command,
CommandCallback<? super C,? super R> callback)
Dispatch the given
command to the CommandHandler subscribed to the given command 's name. |
protected String |
AnnotationRoutingStrategy.doResolveRoutingKey(CommandMessage<?> command) |
protected String |
MetaDataRoutingStrategy.doResolveRoutingKey(CommandMessage<?> command) |
protected abstract String |
AbstractRoutingStrategy.doResolveRoutingKey(CommandMessage<?> command)
Resolve the Routing Key for the given
command . |
Optional<Member> |
CommandRouter.findDestination(CommandMessage<?> message)
Returns the member instance to which the given
message should be routed. |
Optional<Member> |
ConsistentHash.getMember(String routingKey,
CommandMessage<?> commandMessage)
Returns the member instance to which the given
message should be routed. |
String |
RoutingStrategy.getRoutingKey(CommandMessage<?> command)
Generates a routing key for the given
command . |
String |
AbstractRoutingStrategy.getRoutingKey(CommandMessage<?> command) |
boolean |
CommandMessageFilter.matches(CommandMessage<?> commandMessage)
Indicates whether the given
commandMessage matches this filter. |
void |
CommandCallbackWrapper.onResult(CommandMessage<? extends C> message,
CommandResultMessage<? extends R> commandResultMessage) |
<C> void |
CommandBusConnector.send(Member destination,
CommandMessage<? extends C> command)
Sends the given
command to the node assigned to handle messages with the given routingKey . |
<C,R> void |
CommandBusConnector.send(Member destination,
CommandMessage<C> command,
CommandCallback<? super C,R> callback)
Sends the given
command to the node assigned to handle messages with the given routingKey . |
Modifier and Type | Method and Description |
---|---|
DistributedCommandBus.Builder |
DistributedCommandBus.Builder.messageMonitor(MessageMonitor<? super CommandMessage<?>> messageMonitor)
Sets the
MessageMonitor for generic types implementing CommandMessage , which is used to
monitor incoming messages and their execution result. |
Registration |
DistributedCommandBus.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> dispatchInterceptor)
Registers the given list of dispatch interceptors to the command bus.
|
Registration |
DistributedCommandBus.registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>> handlerInterceptor) |
Registration |
CommandBusConnector.subscribe(String commandName,
MessageHandler<? super CommandMessage<?>> handler)
Subscribes a command message handler for commands with given
commandName . |
Registration |
DistributedCommandBus.subscribe(String commandName,
MessageHandler<? super CommandMessage<?>> handler)
Subscribe the given
handler to commands with the given commandName . |
Constructor and Description |
---|
CommandCallbackWrapper(A channelId,
CommandMessage<C> message,
CommandCallback<? super C,? super R> callback)
Initializes a
CommandCallbackWrapper which wraps the original callback and holds on to the
command message and channelId of the channel on which the message is sent. |
DispatchMessage(CommandMessage<?> commandMessage,
Serializer serializer,
boolean expectReply)
Initialized a DispatchMessage for the given
commandMessage , which uses the given
serializer to deserialize its contents. |
Modifier and Type | Method and Description |
---|---|
boolean |
DenyCommandNameFilter.matches(CommandMessage commandMessage) |
boolean |
NegateCommandMessageFilter.matches(CommandMessage<?> commandMessage) |
boolean |
DenyAll.matches(CommandMessage<?> message) |
boolean |
AndCommandMessageFilter.matches(CommandMessage<?> commandMessage) |
boolean |
CommandNameFilter.matches(CommandMessage<?> commandMessage) |
boolean |
AcceptAll.matches(CommandMessage<?> message) |
boolean |
OrCommandMessageFilter.matches(CommandMessage<?> commandMessage) |
Modifier and Type | Method and Description |
---|---|
protected <C> CommandMessage<? extends C> |
AbstractCommandGateway.processInterceptors(CommandMessage<C> commandMessage)
Invokes all the dispatch interceptors and returns the CommandMessage instance that should be dispatched.
|
Modifier and Type | Method and Description |
---|---|
protected long |
ExponentialBackOffIntervalRetryScheduler.computeRetryInterval(CommandMessage commandMessage,
RuntimeException lastFailure,
List<Class<? extends Throwable>[]> failures) |
protected long |
IntervalRetryScheduler.computeRetryInterval(CommandMessage commandMessage,
RuntimeException lastFailure,
List<Class<? extends Throwable>[]> failures) |
protected abstract long |
AbstractRetryScheduler.computeRetryInterval(CommandMessage commandMessage,
RuntimeException lastFailure,
List<Class<? extends Throwable>[]> failures)
Compute the amount of milliseconds delay until the next retry, given the information passed.
|
void |
RetryingCallback.onResult(CommandMessage<? extends C> commandMessage,
CommandResultMessage<? extends R> commandResultMessage) |
protected <C> CommandMessage<? extends C> |
AbstractCommandGateway.processInterceptors(CommandMessage<C> commandMessage)
Invokes all the dispatch interceptors and returns the CommandMessage instance that should be dispatched.
|
boolean |
AbstractRetryScheduler.scheduleRetry(CommandMessage commandMessage,
RuntimeException lastFailure,
List<Class<? extends Throwable>[]> failures,
Runnable dispatchTask)
This is the entrypoint of the
RetryScheduler . |
boolean |
RetryScheduler.scheduleRetry(CommandMessage commandMessage,
RuntimeException lastFailure,
List<Class<? extends Throwable>[]> failures,
Runnable commandDispatch)
Inspect the given
commandMessage that failed with given lastFailure . |
Modifier and Type | Method and Description |
---|---|
DefaultCommandGateway.Builder |
DefaultCommandGateway.Builder.dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>> dispatchInterceptors) |
CommandGatewayFactory.Builder |
CommandGatewayFactory.Builder.dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>> dispatchInterceptors)
Sets the
MessageDispatchInterceptor s which are invoked before dispatching a CommandMessage on
the CommandBus . |
AbstractCommandGateway.Builder |
AbstractCommandGateway.Builder.dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>> dispatchInterceptors)
|
Registration |
DefaultCommandGateway.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> dispatchInterceptor) |
protected Registration |
AbstractCommandGateway.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> interceptor)
Registers a command dispatch interceptor within a
CommandGateway . |
CommandGatewayFactory |
CommandGatewayFactory.registerDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>> dispatchInterceptor)
Registers the given
dispatchInterceptor which is invoked for each Command dispatched through the
Command Gateways created by this factory. |
Modifier and Type | Method and Description |
---|---|
<C> void |
DisruptorCommandBus.dispatch(CommandMessage<C> command) |
<C,R> void |
DisruptorCommandBus.dispatch(CommandMessage<C> command,
CommandCallback<? super C,? super R> callback) |
void |
BlacklistDetectingCallback.onResult(CommandMessage<? extends C> commandMessage,
CommandResultMessage<? extends R> commandResultMessage) |
void |
CommandHandlingEntry.reset(CommandMessage<?> newCommand,
MessageHandler<? super CommandMessage<?>> newCommandHandler,
int newInvokerSegmentId,
int newPublisherSegmentId,
BlacklistDetectingCallback newCallback,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> invokerInterceptors,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> publisherInterceptors)
Resets this entry, preparing it for use for another command.
|
Modifier and Type | Method and Description |
---|---|
DisruptorCommandBus.Builder |
DisruptorCommandBus.Builder.dispatchInterceptors(List<MessageDispatchInterceptor<CommandMessage<?>>> dispatchInterceptors)
Configures
MessageDispatchInterceptor of generic type CommandMessage to use with the
DisruptorCommandBus when commands are dispatched. |
DisruptorCommandBus.Builder |
DisruptorCommandBus.Builder.invokerInterceptors(List<MessageHandlerInterceptor<? super CommandMessage<?>>> invokerInterceptors)
Set the
MessageHandlerInterceptor of generic type CommandMessage to use with the
DisruptorCommandBus during in the invocation thread. |
DisruptorCommandBus.Builder |
DisruptorCommandBus.Builder.messageMonitor(MessageMonitor<? super CommandMessage<?>> messageMonitor)
Sets the
MessageMonitor of generic type CommandMessage used the to monitor the command bus. |
DisruptorCommandBus.Builder |
DisruptorCommandBus.Builder.publisherInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>> publisherInterceptors)
Configures the
MessageHandlerInterceptor of generic type CommandMessage to use with the
DisruptorCommandBus during the publication of changes. |
Registration |
DisruptorCommandBus.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> dispatchInterceptor) |
Registration |
DisruptorCommandBus.registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>> handlerInterceptor) |
void |
CommandHandlingEntry.reset(CommandMessage<?> newCommand,
MessageHandler<? super CommandMessage<?>> newCommandHandler,
int newInvokerSegmentId,
int newPublisherSegmentId,
BlacklistDetectingCallback newCallback,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> invokerInterceptors,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> publisherInterceptors)
Resets this entry, preparing it for use for another command.
|
void |
CommandHandlingEntry.reset(CommandMessage<?> newCommand,
MessageHandler<? super CommandMessage<?>> newCommandHandler,
int newInvokerSegmentId,
int newPublisherSegmentId,
BlacklistDetectingCallback newCallback,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> invokerInterceptors,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> publisherInterceptors)
Resets this entry, preparing it for use for another command.
|
void |
CommandHandlingEntry.reset(CommandMessage<?> newCommand,
MessageHandler<? super CommandMessage<?>> newCommandHandler,
int newInvokerSegmentId,
int newPublisherSegmentId,
BlacklistDetectingCallback newCallback,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> invokerInterceptors,
List<MessageHandlerInterceptor<? super CommandMessage<?>>> publisherInterceptors)
Resets this entry, preparing it for use for another command.
|
Registration |
DisruptorCommandBus.subscribe(String commandName,
MessageHandler<? super CommandMessage<?>> handler) |
Constructor and Description |
---|
BlacklistDetectingCallback(CommandCallback<? super C,R> delegate,
com.lmax.disruptor.RingBuffer<CommandHandlingEntry> ringBuffer,
BiConsumer<CommandMessage<? extends C>,CommandCallback<? super C,R>> retryMethod,
boolean rescheduleOnCorruptState)
Initializes the callback which allows the given
command to be rescheduled on the given
ringBuffer if it failed due to a corrupt state. |
Modifier and Type | Method and Description |
---|---|
MessageMonitor<? super CommandMessage<?>> |
GlobalMetricRegistry.registerCommandBus(String name)
Registers new metrics to the registry to monitor a
CommandBus . |
Modifier and Type | Method and Description |
---|---|
MessageMonitor<? super CommandMessage<?>> |
GlobalMetricRegistry.registerCommandBus(String name)
Registers new metrics to the registry to monitor a
CommandBus . |
Modifier and Type | Method and Description |
---|---|
boolean |
AggregateAnnotationCommandHandler.canHandle(CommandMessage<?> message) |
Object |
AggregateAnnotationCommandHandler.handle(CommandMessage<?> commandMessage) |
protected Object |
AggregateAnnotationCommandHandler.resolveReturnValue(CommandMessage<?> command,
Aggregate<T> createdAggregate)
Resolves the value to return when the given
command has created the given aggregate . |
VersionedAggregateIdentifier |
MetaDataCommandTargetResolver.resolveTarget(CommandMessage<?> command) |
VersionedAggregateIdentifier |
AnnotationCommandTargetResolver.resolveTarget(CommandMessage<?> command)
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given
command should be executed. |
VersionedAggregateIdentifier |
CommandTargetResolver.resolveTarget(CommandMessage<?> command)
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given
command should be executed. |
Modifier and Type | Method and Description |
---|---|
protected abstract <T> Object |
AbstractChildEntityDefinition.resolveCommandTarget(CommandMessage<?> msg,
T parent,
Field field,
EntityModel<Object> childEntityModel)
Resolve the target of an incoming
CommandMessage to the right Child
Entity. |
protected <T> Object |
AggregateMemberAnnotatedChildEntityDefinition.resolveCommandTarget(CommandMessage<?> msg,
T parent,
Field field,
EntityModel<Object> childEntityModel) |
protected <T> Object |
AggregateMemberAnnotatedChildEntityCollectionDefinition.resolveCommandTarget(CommandMessage<?> msg,
T parent,
Field field,
EntityModel<Object> childEntityModel) |
protected <T> Object |
AggregateMemberAnnotatedChildEntityMapDefinition.resolveCommandTarget(CommandMessage<?> msg,
T parent,
Field field,
EntityModel<Object> childEntityModel) |
Modifier and Type | Method and Description |
---|---|
Object |
AnnotatedCommandHandlerInterceptor.handle(UnitOfWork<? extends CommandMessage<?>> unitOfWork,
InterceptorChain interceptorChain) |
Constructor and Description |
---|
AnnotatedChildEntity(EntityModel<C> entityModel,
boolean forwardCommands,
BiFunction<CommandMessage<?>,P,C> commandTargetResolver,
BiFunction<EventMessage<?>,P,Stream<C>> eventTargetResolver)
Initiates a new AnnotatedChildEntity instance that uses the provided
entityModel to delegate command
and event handling to an annotated child entity. |
ChildForwardingCommandMessageHandlingMember(List<MessageHandlingMember<? super C>> childHandlerInterceptors,
MessageHandlingMember<? super C> childHandler,
BiFunction<CommandMessage<?>,P,C> childEntityResolver)
Initializes a
ChildForwardingCommandMessageHandlingMember that routes commands to a compatible child
entity. |
Modifier and Type | Method and Description |
---|---|
AxonServerCommandBus |
AxonServerAutoConfiguration.axonServerCommandBus(AxonServerConnectionManager axonServerConnectionManager,
AxonServerConfiguration axonServerConfiguration,
CommandBus localSegment,
Serializer messageSerializer,
RoutingStrategy routingStrategy,
CommandPriorityCalculator priorityCalculator,
CommandLoadFactorProvider loadFactorProvider,
TargetContextResolver<? super CommandMessage<?>> targetContextResolver) |
Modifier and Type | Method and Description |
---|---|
void |
ResultValidatorImpl.onResult(CommandMessage<?> commandMessage,
CommandResultMessage<?> commandResultMessage) |
Modifier and Type | Method and Description |
---|---|
FixtureConfiguration<T> |
FixtureConfiguration.registerCommandDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> commandDispatchInterceptor)
Register a command dispatch interceptor which will always be invoked before a command is dispatched on the
command bus to perform a task specified in the interceptor.
|
FixtureConfiguration<T> |
AggregateTestFixture.registerCommandDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> commandDispatchInterceptor) |
FixtureConfiguration<T> |
FixtureConfiguration.registerCommandHandler(Class<?> payloadType,
MessageHandler<CommandMessage<?>> commandHandler)
Registers a
commandHandler to handle commands of the given commandType with the
command bus used by this fixture. |
FixtureConfiguration<T> |
AggregateTestFixture.registerCommandHandler(Class<?> payloadType,
MessageHandler<CommandMessage<?>> commandHandler) |
FixtureConfiguration<T> |
FixtureConfiguration.registerCommandHandler(String commandName,
MessageHandler<CommandMessage<?>> commandHandler)
Registers a
commandHandler to handle commands of the given commandType with the
command bus used by this fixture. |
FixtureConfiguration<T> |
AggregateTestFixture.registerCommandHandler(String commandName,
MessageHandler<CommandMessage<?>> commandHandler) |
FixtureConfiguration<T> |
FixtureConfiguration.registerCommandHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>> commandHandlerInterceptor)
Register a command handler interceptor which may be invoked before or after the command has been dispatched on
the command bus to perform a task specified in the interceptor.
|
FixtureConfiguration<T> |
AggregateTestFixture.registerCommandHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>> commandHandlerInterceptor) |
Modifier and Type | Method and Description |
---|---|
static org.hamcrest.Matcher<List<CommandMessage<?>>> |
Matchers.noCommands()
Matches an empty List of Commands.
|
Modifier and Type | Method and Description |
---|---|
FixtureExecutionResult |
FixtureExecutionResult.expectDispatchedCommandsMatching(org.hamcrest.Matcher<? extends List<? super CommandMessage<?>>> matcher)
Asserts that the sagas dispatched commands as defined by the given
matcher . |
FixtureExecutionResult |
FixtureExecutionResultImpl.expectDispatchedCommandsMatching(org.hamcrest.Matcher<? extends List<? super CommandMessage<?>>> matcher) |
Modifier and Type | Method and Description |
---|---|
List<CommandMessage<?>> |
RecordingCommandBus.getDispatchedCommands()
Returns a list with all commands that have been dispatched by this command bus.
|
Map<String,MessageHandler<? super CommandMessage<?>>> |
RecordingCommandBus.getSubscriptions()
Returns a Map will all Command Names and their Command Handler that have been subscribed to this command bus.
|
Modifier and Type | Method and Description |
---|---|
<C> void |
RecordingCommandBus.dispatch(CommandMessage<C> command) |
<C,R> void |
RecordingCommandBus.dispatch(CommandMessage<C> command,
CommandCallback<? super C,? super R> callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
RecordingCommandBus.isSubscribed(MessageHandler<? super CommandMessage<?>> commandHandler)
Indicates whether the given
commandHandler is subscribed to this command bus. |
<C> boolean |
RecordingCommandBus.isSubscribed(String commandName,
MessageHandler<? super CommandMessage<?>> commandHandler)
Indicates whether the given
commandHandler is subscribed to commands of the given
commandType on this command bus. |
Registration |
RecordingCommandBus.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> dispatchInterceptor) |
Registration |
RecordingCommandBus.registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>> handlerInterceptor) |
Registration |
RecordingCommandBus.subscribe(String commandName,
MessageHandler<? super CommandMessage<?>> handler) |
Copyright © 2010–2020. All rights reserved.