| Package | Description | 
|---|---|
| org.axonframework.commandhandling | 
 Classes that implement the concept of command handling using explicit command objects. 
 | 
| org.axonframework.commandhandling.callbacks | |
| org.axonframework.commandhandling.disruptor | |
| org.axonframework.commandhandling.distributed | |
| org.axonframework.commandhandling.distributed.commandfilter | |
| org.axonframework.commandhandling.gateway | |
| org.axonframework.commandhandling.model | |
| org.axonframework.commandhandling.model.inspection | |
| org.axonframework.jgroups.commandhandling | |
| org.axonframework.metrics | |
| org.axonframework.spring.commandhandling.distributed.jgroups | |
| org.axonframework.spring.commandhandling.gateway | |
| org.axonframework.springcloud.commandhandling | |
| 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  | 
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 | 
|---|---|
default <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,R> callback)  | 
<C,R> void | 
CommandBus.dispatch(CommandMessage<C> command,
        CommandCallback<? super C,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,R> callback)
Performs the actual dispatching logic. 
 | 
Object | 
AnnotationCommandHandlerAdapter.handle(CommandMessage<?> command)
Invokes the @CommandHandler annotated method that accepts the given  
command. | 
Object | 
AggregateAnnotationCommandHandler.handle(CommandMessage<?> commandMessage)  | 
protected <C,R> void | 
SimpleCommandBus.handle(CommandMessage<C> command,
      MessageHandler<? super CommandMessage<?>> handler,
      CommandCallback<? super C,R> callback)
Performs the actual handling logic. 
 | 
protected <C,R> void | 
AsynchronousCommandBus.handle(CommandMessage<C> command,
      MessageHandler<? super CommandMessage<?>> handler,
      CommandCallback<? super C,R> callback)  | 
protected <C> CommandMessage<C> | 
SimpleCommandBus.intercept(CommandMessage<C> command)
Invokes all the dispatch interceptors. 
 | 
void | 
MonitorAwareCallback.onFailure(CommandMessage<? extends C> commandMessage,
         Throwable cause)  | 
void | 
CommandCallback.onFailure(CommandMessage<? extends C> commandMessage,
         Throwable cause)
Invoked when command handling execution resulted in an error. 
 | 
void | 
MonitorAwareCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         R result)  | 
void | 
CommandCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         R result)
Invoked when command handling execution was successful. 
 | 
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 | 
CommandTargetResolver.resolveTarget(CommandMessage<?> command)
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given  
command should be executed. | 
VersionedAggregateIdentifier | 
AnnotationCommandTargetResolver.resolveTarget(CommandMessage<?> command)  | 
| Modifier and Type | Method and Description | 
|---|---|
protected <C,R> void | 
SimpleCommandBus.handle(CommandMessage<C> command,
      MessageHandler<? super CommandMessage<?>> handler,
      CommandCallback<? super C,R> callback)
Performs the actual handling logic. 
 | 
protected <C,R> void | 
AsynchronousCommandBus.handle(CommandMessage<C> command,
      MessageHandler<? super CommandMessage<?>> handler,
      CommandCallback<? super C,R> callback)  | 
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. 
 | 
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 | 
|---|
AsynchronousCommandBus(Executor executor,
                      TransactionManager transactionManager,
                      MessageMonitor<? super CommandMessage<?>> messageMonitor)
Initialize the AsynchronousCommandBus using the given  
executor, transactionManager and
 messageMonitor. | 
SimpleCommandBus(TransactionManager transactionManager,
                MessageMonitor<? super CommandMessage<?>> messageMonitor)
Initializes the SimpleCommandBus with the given  
transactionManager and messageMonitor | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
NoOpCallback.onFailure(CommandMessage<?> commandMessage,
         Throwable cause)
Invoked when command handling execution resulted in an error. 
 | 
void | 
LoggingCallback.onFailure(CommandMessage<?> message,
         Throwable cause)  | 
void | 
FailureLoggingCallback.onFailure(CommandMessage<? extends C> commandMessage,
         Throwable cause)  | 
void | 
FutureCallback.onFailure(CommandMessage commandMessage,
         Throwable cause)  | 
void | 
NoOpCallback.onSuccess(CommandMessage<?> commandMessage,
         Object result)
Invoked when command handling execution was successful. 
 | 
protected abstract void | 
VoidCallback.onSuccess(CommandMessage<? extends C> commandMessage)
Invoked when command handling execution was successful. 
 | 
void | 
VoidCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         Object result)
Invoked when command handling execution was successful. 
 | 
void | 
FutureCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         R executionResult)  | 
void | 
FailureLoggingCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         R result)  | 
void | 
LoggingCallback.onSuccess(CommandMessage message,
         Object result)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<MessageDispatchInterceptor<? super CommandMessage<?>>> | 
DisruptorConfiguration.getDispatchInterceptors()
Returns the dispatch interceptors for the DisruptorCommandBus. 
 | 
List<MessageHandlerInterceptor<? super CommandMessage<?>>> | 
DisruptorConfiguration.getInvokerInterceptors()
Returns the interceptors for the DisruptorCommandBus. 
 | 
MessageMonitor<? super CommandMessage<?>> | 
DisruptorConfiguration.getMessageMonitor()
Returns the message monitor to use. 
 | 
List<MessageHandlerInterceptor<? super CommandMessage<?>>> | 
DisruptorConfiguration.getPublisherInterceptors()
Returns the interceptors for the DisruptorCommandBus. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
<C> void | 
DisruptorCommandBus.dispatch(CommandMessage<C> command)  | 
<C,R> void | 
DisruptorCommandBus.dispatch(CommandMessage<C> command,
        CommandCallback<? super C,R> callback)  | 
void | 
BlacklistDetectingCallback.onFailure(CommandMessage<? extends C> command,
         Throwable cause)  | 
void | 
BlacklistDetectingCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         R result)  | 
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 | 
|---|---|
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. 
 | 
DisruptorConfiguration | 
DisruptorConfiguration.setDispatchInterceptors(List<MessageDispatchInterceptor<CommandMessage<?>>> dispatchInterceptors)
Configures the CommandDispatchInterceptor to use with the DisruptorCommandBus when commands are dispatched. 
 | 
DisruptorConfiguration | 
DisruptorConfiguration.setInvokerInterceptors(List<MessageHandlerInterceptor<? super CommandMessage<?>>> invokerInterceptors)
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during in the invocation thread. 
 | 
DisruptorConfiguration | 
DisruptorConfiguration.setMessageMonitor(MessageMonitor<? super CommandMessage<?>> messageMonitor)
Sets the message monitor to use. 
 | 
DisruptorConfiguration | 
DisruptorConfiguration.setPublisherInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>> publisherInterceptors)
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during the publication of changes. 
 | 
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 | 
|---|---|
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 | 
|---|---|
Predicate<? super CommandMessage<?>> | 
ConsistentHash.ConsistentHashMember.getCommandFilter()
Returns this member's filter describing the commands it supports 
 | 
| Modifier and Type | Method and Description | 
|---|---|
<C> void | 
DistributedCommandBus.dispatch(CommandMessage<C> command)  | 
<C,R> void | 
DistributedCommandBus.dispatch(CommandMessage<C> command,
        CommandCallback<? super C,R> callback)
Dispatch the given  
command to the CommandHandler subscribed to the given command's name. | 
protected String | 
MetaDataRoutingStrategy.doResolveRoutingKey(CommandMessage<?> command)  | 
protected String | 
AnnotationRoutingStrategy.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)  | 
void | 
CommandCallbackWrapper.onFailure(CommandMessage<? extends C> message,
         Throwable cause)  | 
void | 
CommandCallbackWrapper.onSuccess(CommandMessage<? extends C> message,
         R result)  | 
<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 | 
|---|---|
Registration | 
DistributedCommandBus.registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>> dispatchInterceptor)
Registers the given list of dispatch interceptors to the command bus. 
 | 
Registration | 
DistributedCommandBus.subscribe(String commandName,
         MessageHandler<? super CommandMessage<?>> handler)
Subscribe the given  
handler to commands with the given commandName. | 
Registration | 
CommandBusConnector.subscribe(String commandName,
         MessageHandler<? super CommandMessage<?>> handler)
Subscribes a command message handler for commands with given  
commandName. | 
void | 
CommandRouter.updateMembership(int loadFactor,
                Predicate<? super CommandMessage<?>> commandFilter)
Updates the load factor and capabilities of this member representing the current endpoint if the implementation
 allows memberships to be updated dynamically. 
 | 
ConsistentHash | 
ConsistentHash.with(Member member,
    int loadFactor,
    Predicate<? super CommandMessage<?>> commandFilter)
Registers the given  
member with given loadFactor and commandFilter if it is not
 already contained in the ConsistentHash. | 
| Constructor and Description | 
|---|
CommandCallbackWrapper(A channelId,
                      CommandMessage<C> message,
                      CommandCallback<? super C,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. | 
| Constructor and Description | 
|---|
DistributedCommandBus(CommandRouter commandRouter,
                     CommandBusConnector connector,
                     MessageMonitor<? super CommandMessage<?>> messageMonitor)
Initializes the command bus with the given  
commandRouter, connector and messageMonitor. | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
DenyCommandNameFilter.test(CommandMessage commandMessage)  | 
boolean | 
DenyAll.test(CommandMessage commandMessage)  | 
boolean | 
CommandNameFilter.test(CommandMessage commandMessage)  | 
boolean | 
AcceptAll.test(CommandMessage commandMessage)  | 
| Modifier and Type | Method and Description | 
|---|---|
Predicate<CommandMessage<?>> | 
DenyCommandNameFilter.and(Predicate<? super CommandMessage<?>> other)  | 
Predicate<CommandMessage<?>> | 
DenyAll.and(Predicate<? super CommandMessage<?>> other)  | 
Predicate<CommandMessage<?>> | 
CommandNameFilter.and(Predicate<? super CommandMessage<?>> other)  | 
Predicate<CommandMessage<?>> | 
AcceptAll.and(Predicate<? super CommandMessage<?>> other)  | 
Predicate<CommandMessage<?>> | 
DenyCommandNameFilter.or(Predicate<? super CommandMessage<?>> other)  | 
Predicate<CommandMessage<?>> | 
DenyAll.or(Predicate<? super CommandMessage<?>> other)  | 
Predicate<CommandMessage<?>> | 
CommandNameFilter.or(Predicate<? super CommandMessage<?>> other)  | 
Predicate<CommandMessage<?>> | 
AcceptAll.or(Predicate<? super CommandMessage<?>> other)  | 
| 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 | 
|---|---|
void | 
RetryingCallback.onFailure(CommandMessage<? extends C> commandMessage,
         Throwable cause)  | 
void | 
RetryingCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         R result)  | 
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 | 
RetryScheduler.scheduleRetry(CommandMessage commandMessage,
             RuntimeException lastFailure,
             List<Class<? extends Throwable>[]> failures,
             Runnable commandDispatch)
Inspect the given  
commandMessage that failed with given lastFailure. | 
boolean | 
IntervalRetryScheduler.scheduleRetry(CommandMessage commandMessage,
             RuntimeException lastFailure,
             List<Class<? extends Throwable>[]> failures,
             Runnable dispatchTask)  | 
| Modifier and Type | Method and Description | 
|---|---|
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. | 
| Constructor and Description | 
|---|
AbstractCommandGateway(CommandBus commandBus,
                      RetryScheduler retryScheduler,
                      List<MessageDispatchInterceptor<? super CommandMessage<?>>> messageDispatchInterceptors)
Initialize the AbstractCommandGateway with given  
commandBus, retryScheduler and
 commandDispatchInterceptors. | 
CommandGatewayFactory(CommandBus commandBus,
                     RetryScheduler retryScheduler,
                     List<MessageDispatchInterceptor<CommandMessage<?>>> messageDispatchInterceptors)
Initialize the factory sending Commands to the given  
commandBus, optionally intercepting them with
 given dispatchInterceptors. | 
DefaultCommandGateway(CommandBus commandBus,
                     RetryScheduler retryScheduler,
                     List<MessageDispatchInterceptor<? super CommandMessage<?>>> messageDispatchInterceptors)
Initializes a command gateway that dispatches commands to the given  
commandBus after they have been
 handles by the given commandDispatchInterceptors. | 
| Modifier and Type | Method and Description | 
|---|---|
Object | 
LockAwareAggregate.handle(CommandMessage<?> commandMessage)  | 
Object | 
Aggregate.handle(CommandMessage<?> commandMessage)
Handle the given  
commandMessage on the aggregate root or one of its child entities. | 
| Modifier and Type | Method and Description | 
|---|---|
Object | 
AnnotatedAggregate.handle(CommandMessage<?> msg)  | 
protected <T> Object | 
AggregateMemberAnnotatedChildEntityMapDefinition.resolveCommandTarget(CommandMessage<?> msg,
                    T parent,
                    Field field,
                    EntityModel<Object> childEntityModel)  | 
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 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. | 
| 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(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 | 
|---|---|
Predicate<? super CommandMessage<?>> | 
JoinMessage.messageFilter()
Returns the command message filter used by the member. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
Optional<Member> | 
JGroupsConnector.findDestination(CommandMessage<?> message)  | 
<C> void | 
JGroupsConnector.send(Member destination,
    CommandMessage<? extends C> command)  | 
<C,R> void | 
JGroupsConnector.send(Member destination,
    CommandMessage<C> command,
    CommandCallback<? super C,R> callback)  | 
| Modifier and Type | Method and Description | 
|---|---|
Registration | 
JGroupsConnector.subscribe(String commandName,
         MessageHandler<? super CommandMessage<?>> handler)  | 
void | 
JGroupsConnector.updateMembership(int loadFactor,
                Predicate<? super CommandMessage<?>> commandFilter)  | 
| Constructor and Description | 
|---|
JGroupsDispatchMessage(CommandMessage<?> commandMessage,
                      Serializer serializer,
                      boolean expectReply)
Initialize a JGroupsDispatchMessage for the given  
commandMessage, to be serialized using given
 serializer. | 
| Constructor and Description | 
|---|
JoinMessage(int loadFactor,
           Predicate<? super CommandMessage<?>> messageFilter,
           int order,
           boolean expectReply)
Initializes a JoinMessage with the given  
loadFactor. | 
| 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 | 
|---|---|
void | 
JGroupsConnectorFactoryBean.setInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>> interceptors)
Sets the interceptor to use in the default local segment (a SimpleCommandBus). 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
CommandGatewayFactoryBean.addCommandDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>> messageDispatchInterceptor)
Add an interceptor that should be invoked before a command is dispatched the the Command Bus. 
 | 
void | 
CommandGatewayFactoryBean.setCommandDispatchInterceptors(List<MessageDispatchInterceptor<CommandMessage<?>>> messageDispatchInterceptors)
Sets the interceptors that should be invoked before a command is dispatched the the Command Bus. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
CommandMessage<C> | 
SpringHttpDispatchMessage.getCommandMessage(Serializer serializer)  | 
| Modifier and Type | Method and Description | 
|---|---|
Predicate<? super CommandMessage<?>> | 
MessageRoutingInformation.getCommandFilter(Serializer serializer)  | 
| Modifier and Type | Method and Description | 
|---|---|
Optional<Member> | 
SpringCloudCommandRouter.findDestination(CommandMessage<?> commandMessage)  | 
void | 
SpringHttpCommandBusConnector.SpringHttpReplyFutureCallback.onFailure(CommandMessage commandMessage,
         Throwable cause)  | 
void | 
SpringHttpCommandBusConnector.SpringHttpReplyFutureCallback.onSuccess(CommandMessage<? extends C> commandMessage,
         R result)  | 
<C> void | 
SpringHttpCommandBusConnector.send(Member destination,
    CommandMessage<? extends C> commandMessage)  | 
<C,R> void | 
SpringHttpCommandBusConnector.send(Member destination,
    CommandMessage<C> commandMessage,
    CommandCallback<? super C,R> callback)  | 
| Modifier and Type | Method and Description | 
|---|---|
Registration | 
SpringHttpCommandBusConnector.subscribe(String commandName,
         MessageHandler<? super CommandMessage<?>> handler)  | 
void | 
SpringCloudHttpBackupCommandRouter.updateMembership(int loadFactor,
                Predicate<? super CommandMessage<?>> commandFilter)  | 
void | 
SpringCloudCommandRouter.updateMembership(int loadFactor,
                Predicate<? super CommandMessage<?>> commandFilter)  | 
| Constructor and Description | 
|---|
SpringHttpDispatchMessage(CommandMessage<?> commandMessage,
                         Serializer serializer,
                         boolean expectReply)
Initialize a SpringHttpDispatchMessage for the given  
commandMessage, to be serialized using given
 serializer. | 
| Constructor and Description | 
|---|
MessageRoutingInformation(int loadFactor,
                         Predicate<? super CommandMessage<?>> commandFilter,
                         Serializer serializer)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ResultValidatorImpl.onFailure(CommandMessage<?> commandMessage,
         Throwable cause)  | 
void | 
ResultValidatorImpl.onSuccess(CommandMessage<?> commandMessage,
         Object result)  | 
| Modifier and Type | Method and Description | 
|---|---|
FixtureConfiguration<T> | 
FixtureConfiguration.registerCommandDispatchInterceptor(MessageDispatchInterceptor<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<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<CommandMessage<?>> commandHanderInterceptor)
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<CommandMessage<?>> commandHanderInterceptor)  | 
| 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 | 
FixtureExecutionResultImpl.expectDispatchedCommandsMatching(org.hamcrest.Matcher<? extends List<? super CommandMessage<?>>> matcher)  | 
FixtureExecutionResult | 
FixtureExecutionResult.expectDispatchedCommandsMatching(org.hamcrest.Matcher<? extends List<? super CommandMessage<?>>> matcher)
Asserts that the sagas dispatched commands as defined by the given  
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,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.subscribe(String commandName,
         MessageHandler<? super CommandMessage<?>> handler)  | 
Copyright © 2010–2018. All rights reserved.