A B C D E F G H I J K L M N O P Q R S T U V W X

A

AbstractAggregateFactory<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Abstract AggregateFactory implementation that is aware of snapshot events.
AbstractAggregateFactory() - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
 
AbstractAggregateFactory(ParameterResolverFactory) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
 
AbstractAggregateRoot<I> - Class in org.axonframework.domain
Very basic implementation of the AggregateRoot interface.
AbstractAggregateRoot() - Constructor for class org.axonframework.domain.AbstractAggregateRoot
 
AbstractAnnotatedAggregateRoot<I> - Class in org.axonframework.eventsourcing.annotation
Convenience super type for aggregate roots that have their event handler methods annotated with the EventSourcingHandler annotation (and EventHandler for backwards compatibility).
AbstractAnnotatedAggregateRoot() - Constructor for class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
 
AbstractAnnotatedEntity - Class in org.axonframework.eventsourcing.annotation
Convenience super type for entities (other than aggregate roots) that have their event handler methods annotated with the EventHandler annotation.
AbstractAnnotatedEntity() - Constructor for class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
Default constructor.
AbstractAnnotatedHandlerDefinition<T extends Annotation> - Class in org.axonframework.common.annotation
Abstract implementation of the HandlerDefinition that uses annotations to recognise handler methods or constructors.
AbstractAnnotatedHandlerDefinition(Class<T>) - Constructor for class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
Initialize the Definition, using where handlers are annotated with given annotationType.
AbstractAnnotatedParameterResolverFactory<A,P> - Class in org.axonframework.eventhandling.annotation
ParameterResolverFactory that will supply a parameter resolver when a matching parameter annotation is paired with a suitable type of parameter.
AbstractAnnotatedParameterResolverFactory(Class<A>, Class<P>) - Constructor for class org.axonframework.eventhandling.annotation.AbstractAnnotatedParameterResolverFactory
Initialize a ParameterResolverFactory instance that resolves parameters of type declaredParameterType annotated with the given annotationType.
AbstractAnnotatedSaga - Class in org.axonframework.saga.annotation
Implementation of the interface that delegates incoming events to @SagaEventHandler annotated methods.
AbstractAnnotatedSaga() - Constructor for class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Initialize the saga with a random identifier.
AbstractAnnotatedSaga(String) - Constructor for class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Initialize the saga with the given identifier.
AbstractAnnotationHandlerBeanPostProcessor<I,T extends I> - Class in org.axonframework.common.annotation
Abstract bean post processor that finds candidates for proxying.
AbstractAnnotationHandlerBeanPostProcessor() - Constructor for class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
 
AbstractCacheAdapter<L> - Class in org.axonframework.cache
Abstract implementation of the Cache interface which makes it easier to implement Adapters.
AbstractCacheAdapter() - Constructor for class org.axonframework.cache.AbstractCacheAdapter
 
AbstractCluster - Class in org.axonframework.eventhandling
Abstract Cluster implementation that keeps track of Cluster members (EventListeners).
AbstractCluster(String) - Constructor for class org.axonframework.eventhandling.AbstractCluster
Initializes the cluster with given name.
AbstractCluster(String, Comparator<EventListener>) - Constructor for class org.axonframework.eventhandling.AbstractCluster
Initializes the cluster with given name, using given comparator to order the listeners in the cluster.
AbstractClusterSelector - Class in org.axonframework.eventhandling
Abstract implementation of the ClusterSelector interface that detects proxies and passes the actual Class of the Event Listener implementation.
AbstractClusterSelector() - Constructor for class org.axonframework.eventhandling.AbstractClusterSelector
 
AbstractCommandGateway - Class in org.axonframework.commandhandling.gateway
Abstract implementation of a CommandGateway, which handles the dispatch interceptors and retrying on failure.
AbstractCommandGateway(CommandBus, RetryScheduler, List<CommandDispatchInterceptor>) - Constructor for class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Initialize the AbstractCommandGateway with given commandBus, retryScheduler and commandDispatchInterceptors.
AbstractContentTypeConverter<S,T> - Class in org.axonframework.serializer
Abstract implementation of the ContentTypeConverter for convenience purposes.
AbstractContentTypeConverter() - Constructor for class org.axonframework.serializer.AbstractContentTypeConverter
 
AbstractEventEntry - Class in org.axonframework.eventstore.jpa
Data needed by different types of event logs.
AbstractEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntry
Initialize an Event entry for the given event.
AbstractEventEntry(String, DomainEventMessage, DateTime, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntry
Initialize an Event entry for the given event.
AbstractEventEntry() - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntry
Default constructor, as required by JPA specification.
AbstractEventEntryData<T> - Class in org.axonframework.eventstore.jpa
Abstract JPA Entity, which defines all fields except for the payload and metaData field.
AbstractEventEntryData(String, String, String, long, DateTime, SerializedType) - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntryData
Initializes the fields in this entity using the values provided in the given parameters.
AbstractEventEntryData() - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntryData
Constructor required by JPA.
AbstractEventEntryData.PK - Class in org.axonframework.eventstore.jpa
Primary key definition of the AbstractEventEntry class.
AbstractEventEntryData.PK() - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntryData.PK
Constructor for JPA.
AbstractEventSourcedAggregateRoot<I> - Class in org.axonframework.eventsourcing
Abstract convenience class to be extended by all aggregate roots.
AbstractEventSourcedAggregateRoot() - Constructor for class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
 
AbstractEventSourcedEntity - Class in org.axonframework.eventsourcing
Base class for Event Sourced entities that are not at the root of the aggregate.
AbstractEventSourcedEntity() - Constructor for class org.axonframework.eventsourcing.AbstractEventSourcedEntity
 
AbstractMessageHandler - Class in org.axonframework.common.annotation
Abstract superclass for annotation based Message handlers.
AbstractMessageHandler(Class<?>, Class<?>, ParameterResolver...) - Constructor for class org.axonframework.common.annotation.AbstractMessageHandler
Initializes the MessageHandler to handle messages with the given payloadType, declared in the given declaringClass and using the given parameterValueResolvers.
AbstractMessageHandler(AbstractMessageHandler) - Constructor for class org.axonframework.common.annotation.AbstractMessageHandler
Constructor used for implementations that delegate activity to another handler.
AbstractMethodPropertyAccessStrategy - Class in org.axonframework.common.property
Abstract implementation of the PropertyAccessStrategy that uses a no-arg, public method to access the property value.
AbstractMethodPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
 
AbstractMongoTemplate - Class in org.axonframework.mongo3.common
Abstract implementation for Mongo templates.
AbstractMongoTemplate(MongoClient) - Constructor for class org.axonframework.mongo3.common.AbstractMongoTemplate
Initializes the MongoTemplate to connect using the given mongo instance and a database with default name "axonframework".
AbstractMongoTemplate(MongoClient, String) - Constructor for class org.axonframework.mongo3.common.AbstractMongoTemplate
Initializes the MongoTemplate to connect using the given mongo instance and the database with given databaseName.
AbstractReplayAwareSagaManager - Class in org.axonframework.saga
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager implementations.
AbstractReplayAwareSagaManager() - Constructor for class org.axonframework.saga.AbstractReplayAwareSagaManager
 
AbstractRepository<T extends AggregateRoot> - Class in org.axonframework.repository
Abstract implementation of the Repository that takes care of the dispatching of events when an aggregate is persisted.
AbstractRepository(Class<T>) - Constructor for class org.axonframework.repository.AbstractRepository
Initializes a repository that stores aggregate of the given aggregateType.
AbstractRoutingStrategy - Class in org.axonframework.commandhandling.distributed
Abstract implementation of the RoutingStrategy interface that uses a policy to prescribe what happens when a routing cannot be resolved.
AbstractRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
Initializes the strategy using given unresolvedRoutingKeyPolicy prescribing what happens when a routing key cannot be resolved.
AbstractSagaManager - Class in org.axonframework.saga
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager implementations.
AbstractSagaManager(EventBus, SagaRepository, SagaFactory, Class<? extends Saga>...) - Constructor for class org.axonframework.saga.AbstractSagaManager
Deprecated. use AbstractSagaManager.AbstractSagaManager(SagaRepository, SagaFactory, Class[]) and register using EventBus.subscribe(org.axonframework.eventhandling.EventListener)
AbstractSagaManager(SagaRepository, SagaFactory, Class<? extends Saga>...) - Constructor for class org.axonframework.saga.AbstractSagaManager
Initializes the SagaManager with the given sagaRepository.
AbstractSagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
Abstract SagaManager parser that parses common properties for all SagaManager implementations.
AbstractSagaManagerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
 
AbstractSagaRepository - Class in org.axonframework.saga.repository
Abstract implementation for saga repositories.
AbstractSagaRepository() - Constructor for class org.axonframework.saga.repository.AbstractSagaRepository
 
AbstractSingleEntryUpcaster<T> - Class in org.axonframework.upcasting
Abstract implementation of an upcaster that only needs to convert one serialized object to another using the same representation.
AbstractSingleEntryUpcaster() - Constructor for class org.axonframework.upcasting.AbstractSingleEntryUpcaster
 
AbstractSnapshotter - Class in org.axonframework.eventsourcing
Abstract implementation of the Snapshotter that uses a task executor to creates snapshots.
AbstractSnapshotter() - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
 
AbstractUpcasterChain - Class in org.axonframework.upcasting
Abstract implementation of the UpcasterChain interface.
AbstractUpcasterChain(List<Upcaster>) - Constructor for class org.axonframework.upcasting.AbstractUpcasterChain
Initializes the UpcasterChain with given upcasters and a ChainingConverterFactory to convert between content types.
AbstractUpcasterChain(ConverterFactory, List<Upcaster>) - Constructor for class org.axonframework.upcasting.AbstractUpcasterChain
Initializes the UpcasterChain with given converterFactory and upcasters.
AbstractXStreamSerializer - Class in org.axonframework.serializer
Abstract implementation for XStream based serializers.
AbstractXStreamSerializer(XStream) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
AbstractXStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
AbstractXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
AbstractXStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
AbstractXStreamSerializer(Charset, XStream, RevisionResolver, ConverterFactory) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
Initialize the serializer using the given charset, xStream instance, revisionResolver and converterFactory.
accept(Class<?>) - Method in interface org.axonframework.integration.adapter.EventFilter
Whether or not this filter allows an event of the given type to pass through or not.
accept(Class<?>) - Method in class org.axonframework.integration.adapter.NoFilter
Whether or not this filter allows an event of the given type to pass through or not.
accept(Class<?>) - Method in interface org.axonframework.springmessaging.adapter.EventFilter
Whether or not this filter allows an event of the given type to pass through or not.
accept(Class<?>) - Method in class org.axonframework.springmessaging.adapter.NoFilter
Whether or not this filter allows an event of the given type to pass through or not.
accept(Field) - Method in class org.axonframework.test.matchers.AllFieldsFilter
 
accept(Field) - Method in interface org.axonframework.test.matchers.FieldFilter
Indicates whether the given field should be accepted for processing, or skipped/ignored.
accept(Field) - Method in class org.axonframework.test.matchers.IgnoreField
 
accept(Field) - Method in class org.axonframework.test.matchers.MatchAllFieldFilter
 
accept(Field) - Method in class org.axonframework.test.matchers.NonTransientFieldsFilter
 
AcceptAllConflictResolver - Class in org.axonframework.eventsourcing.conflictresolvers
Implementation of the conflict resolver that will accept all changes made to an aggregate, even if the aggregate contains changes that were not expected by the command handler.
AcceptAllConflictResolver() - Constructor for class org.axonframework.eventsourcing.conflictresolvers.AcceptAllConflictResolver
 
add(T) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
add(T) - Method in class org.axonframework.repository.AbstractRepository
Adds the given aggregate to the repository.
add(T) - Method in class org.axonframework.repository.LockingRepository
 
add(T) - Method in interface org.axonframework.repository.Repository
Adds the given aggregate to the repository.
add(AssociationValue) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
add(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues
Adds the given associationValue, if it has not been previously added.
add(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
 
add(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AssociationValueMap
Adds an association between the given associationValue and sagaIdentifier.
add(Saga) - Method in class org.axonframework.saga.repository.CachingSagaRepository
 
add(Saga) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
add(Saga) - Method in interface org.axonframework.saga.SagaRepository
Registers a newly created Saga with the Repository.
add(UnitOfWorkListener) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
Adds a listener to the collection.
addAlias(String, Class) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Adds an alias to use instead of the fully qualified class name.
addAttribute(String, String) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
addAttribute(String, String) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
addChildNode(String) - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Adds a child node to the current node.
addChildNode(String) - Method in class org.axonframework.serializer.bson.BSONNode
Adds a child node to the current node.
addCluster(Cluster) - Method in class org.axonframework.eventhandling.amqp.spring.ClusterMessageListener
Registers an additional cluster.
addedAssociations() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
addedAssociations() - Method in interface org.axonframework.saga.AssociationValues
Returns the Set of association values that have been added since the last AssociationValues.commit().
addEvent(MetaData, T) - Method in class org.axonframework.domain.EventContainer
Add an event to this container.
addEvent(DomainEventMessage<T>) - Method in class org.axonframework.domain.EventContainer
Add an event to this container.
addEventRegistrationCallback(EventRegistrationCallback) - Method in class org.axonframework.domain.AbstractAggregateRoot
 
addEventRegistrationCallback(EventRegistrationCallback) - Method in interface org.axonframework.domain.AggregateRoot
Adds an EventRegistrationCallback, which is notified when the aggregate registers an Event for publication.
addEventRegistrationCallback(EventRegistrationCallback) - Method in class org.axonframework.domain.EventContainer
Adds an EventRegistrationCallback, which is invoked when the aggregate owning this container registers an Event.
addFieldAlias(String, Class, String) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Adds an alias to use for a given field in the given class.
addPackageAlias(String, String) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Add an alias for a package.
advanceTime(DateTime) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Advance time to the given newDateTime and returns all events scheduled for publication until that time.
advanceTime(Duration) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Advance time by the given duration and returns all events scheduled for publication until that time.
advanceToNextTrigger() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Advances the "current time" of the scheduler to the next scheduled Event, and returns that event.
AFTER_REPLAY_TIMEOUT - Static variable in class org.axonframework.eventhandling.replay.ReplayingCluster
The key to use in Cluster MetaData that indicates how long the replaying cluster should wait for all events to be processed, before invoking the afterReplay on all methods.
afterCommit(UnitOfWork) - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
 
afterCommit(UnitOfWork) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked when the UnitOfWork is committed.
afterCommit(UnitOfWork) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Invoked when the UnitOfWork is committed.
afterCommit(UnitOfWork) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
Invoked when the UnitOfWork is committed.
afterPropertiesSet() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
 
afterPropertiesSet() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerFactory
 
afterPropertiesSet() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
 
afterPropertiesSet() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
afterPropertiesSet() - Method in class org.axonframework.gae.eventstore.GaeSnapshotter
 
afterPropertiesSet() - Method in class org.axonframework.integration.adapter.EventListeningMessageChannelAdapter
Subscribes this event listener to the event bus.
afterPropertiesSet() - Method in class org.axonframework.springmessaging.adapter.EventListeningMessageChannelAdapter
Subscribes this event listener to the event bus.
afterReplay() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
 
afterReplay() - Method in interface org.axonframework.eventhandling.replay.ReplayAware
Invoked when a replay has finished.
afterReplay() - Method in class org.axonframework.quickstart.RunEventReplay.AnotherThreadPrintingEventListener
 
afterReplay() - Method in class org.axonframework.saga.AbstractReplayAwareSagaManager
 
afterShutdown(EventProcessor) - Method in interface org.axonframework.eventhandling.async.EventProcessor.ShutdownCallback
Called when event processing is complete.
AggregateAnnotationCommandHandler<T extends AggregateRoot> - Class in org.axonframework.commandhandling.annotation
Command handler that handles commands based on CommandHandler annotations on an aggregate.
AggregateAnnotationCommandHandler(Class<T>, Repository<T>) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType, using the given repository to add and load aggregate instances.
AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandTargetResolver) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType, using the given repository to add and load aggregate instances and the default ParameterResolverFactory.
AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandTargetResolver, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType, using the given repository to add and load aggregate instances and the given parameterResolverFactory.
AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandBus) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Deprecated. Use AggregateAnnotationCommandHandler.AggregateAnnotationCommandHandler(Class, org.axonframework.repository.Repository) and subscribe the adapter to the command bus using CommandBus.subscribe(String, org.axonframework.commandhandling.CommandHandler). Alternatively, use AggregateAnnotationCommandHandler.subscribe(Class, org.axonframework.repository.Repository, org.axonframework.commandhandling.CommandBus).
AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandBus, CommandTargetResolver) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Deprecated. Use AggregateAnnotationCommandHandler.AggregateAnnotationCommandHandler(Class, org.axonframework.repository.Repository, org.axonframework.commandhandling.CommandTargetResolver) and subscribe the handler to the command bus using CommandBus.subscribe(String, org.axonframework.commandhandling.CommandHandler). Alternatively, use AggregateAnnotationCommandHandler.subscribe(Class, org.axonframework.repository.Repository, org.axonframework.commandhandling.CommandBus, org.axonframework.commandhandling.CommandTargetResolver).
AggregateAnnotationCommandHandlerFactoryBean<T extends AggregateRoot<?>> - Class in org.axonframework.commandhandling.annotation
Spring FactoryBean that creates an AggregateAnnotationCommandHandler instance.
AggregateAnnotationCommandHandlerFactoryBean() - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
 
AggregateAnnotationInspector - Class in org.axonframework.eventsourcing.annotation
Inspects objects to find aggregate specific annotations, such as AggregateIdentifier and EventSourcedMember.
AggregateBlacklistedException - Exception in org.axonframework.commandhandling.disruptor
Exception indicating that an aggregate has been blacklisted by the DisruptorCommandBus.
AggregateBlacklistedException(Object, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateBlacklistedException
Initializes the exception with given aggregateIdentifier, given explanatory message and cause.
AggregateCommandHandlerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
Bean Definition parser that parses AggregateAnnotationCommandHandler type beans (aggregate-command-handler element).
AggregateCommandHandlerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AggregateCommandHandlerBeanDefinitionParser
 
AggregateCommandHandlerInspector<T extends AggregateRoot> - Class in org.axonframework.commandhandling.annotation
Handler inspector that finds annotated constructors and methods on a given aggregate type and provides handlers for those methods.
AggregateCommandHandlerInspector(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
Initialize an MethodMessageHandlerInspector, where the given annotationType is used to annotate the Event Handler methods.
AggregateDeletedException - Exception in org.axonframework.eventsourcing
Special case of the AggregateNotFoundException that indicates that historic information of an aggregate was found, but the aggregate has been deleted.
AggregateDeletedException(Object, String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier and given message.
AggregateDeletedException(Object) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier and a default message.
AggregateFactory<T extends EventSourcedAggregateRoot> - Interface in org.axonframework.eventsourcing
Interface describing objects capable of creating instances of aggregates to be initialized with an event stream.
AggregateIdentifier - Annotation Type in org.axonframework.eventsourcing.annotation
Field annotation that indicates the field contains the identifier of the Aggregate.
AggregateIdentifierNotInitializedException - Exception in org.axonframework.domain
Exception indicating that an AggregateRoot instance has failed to provide a valid aggregate identifier in time.
AggregateIdentifierNotInitializedException(String) - Constructor for exception org.axonframework.domain.AggregateIdentifierNotInitializedException
Initialize the exception with the given message
AggregateNotFoundException - Exception in org.axonframework.repository
Exception indicating that the an aggregate could not be found in the repository.
AggregateNotFoundException(Object, String) - Constructor for exception org.axonframework.repository.AggregateNotFoundException
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier and given message.
AggregateNotFoundException(Object, String, Throwable) - Constructor for exception org.axonframework.repository.AggregateNotFoundException
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier and with the given message and cause.
AggregateRoot<I> - Interface in org.axonframework.domain
Interface defining a contract for entities that represent the aggregate root.
AggregateSnapshotter - Class in org.axonframework.eventsourcing
Implementation of a snapshotter that uses the actual aggregate and its state to create a snapshot event.
AggregateSnapshotter() - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
 
AggregateStateCorruptedException - Exception in org.axonframework.commandhandling.disruptor
Exception indicating that the changes in an aggregate (generated events) are ignored by the DisruptorCommandBus, because it cannot guarantee that these changes have been applied to an aggregate instance with the correct state.
AggregateStateCorruptedException(Object, String) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
Initializes the exception with given aggregateIdentifier and given explanatory message.
AggregateStateCorruptedException(Object, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
Initializes the exception with given aggregateIdentifier, given explanatory message and cause.
AllFieldsFilter - Class in org.axonframework.test.matchers
FieldFilter implementation that accepts all Fields.
AMQP_CONFIG_PROPERTY - Static variable in interface org.axonframework.eventhandling.amqp.AMQPConsumerConfiguration
The key of the property in the Cluster Meta Data that reflects the AMQPConsumerConfiguration instance for that cluster
AMQPConfigurationBeanDefinitionParser - Class in org.axonframework.contextsupport.spring.amqp
BeanDefinitionParser that parses AMQP Configuration elements into SpringAMQPConsumerConfiguration Bean Definitions.
AMQPConfigurationBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.amqp.AMQPConfigurationBeanDefinitionParser
 
AMQPConsumerConfiguration - Interface in org.axonframework.eventhandling.amqp
 
AMQPMessage - Class in org.axonframework.eventhandling.amqp
Representation of an AMQP Message.
AMQPMessage(byte[], String) - Constructor for class org.axonframework.eventhandling.amqp.AMQPMessage
Creates an AMQP Message with given body and routingKey, which is not mandatory and non-immediate and has no additional properties.
AMQPMessage(byte[], String, AMQP.BasicProperties, boolean, boolean) - Constructor for class org.axonframework.eventhandling.amqp.AMQPMessage
Creates an AMQPMessage.
AMQPMessageConverter - Interface in org.axonframework.eventhandling.amqp
Interface describing a mechanism that converts AMQP Messages from an Axon Messages and vice versa.
and(Criteria) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcCriteria
 
and(Criteria) - Method in class org.axonframework.eventstore.jpa.criteria.JpaCriteria
 
and(Criteria) - Method in interface org.axonframework.eventstore.management.Criteria
Returns a criteria instance where both this and given criteria must match.
And - Class in org.axonframework.eventstore.mongo.criteria
Representation of an AND operator for Mongo selection criteria.
And(MongoCriteria, MongoCriteria) - Constructor for class org.axonframework.eventstore.mongo.criteria.And
Returns a criterium that requires both criteria1 and criteria2 to be true.
and(Criteria) - Method in class org.axonframework.eventstore.mongo.criteria.MongoCriteria
 
And - Class in org.axonframework.mongo3.eventstore.criteria
Representation of an AND operator for Mongo selection criteria.
And(MongoCriteria, MongoCriteria) - Constructor for class org.axonframework.mongo3.eventstore.criteria.And
Returns a criterium that requires both criteria1 and criteria2 to be true.
and(Criteria) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoCriteria
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandMessage
Returns a copy of this CommandMessage with it MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.DomainEventMessage
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.EventMessage
Returns a copy of this EventMessage with it MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericDomainEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.Message
Returns a copy of this Message with it MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedDomainEventMessage
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedMessage
 
andNoMore() - Static method in class org.axonframework.test.matchers.Matchers
Matches against null or void.
andThenAggregate(Object) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
andThenAggregate(Object) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Use this method to indicate that an aggregate with given identifier published certain events.
andThenAPublished(Object) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
andThenAPublished(Object) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Indicates that the given event has been published in the past.
andThenTimeAdvancesTo(DateTime) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
andThenTimeAdvancesTo(DateTime) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Simulate time shifts in the current given state.
andThenTimeElapses(Duration) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
andThenTimeElapses(Duration) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Simulate time shifts in the current given state.
AnnotatedSagaManager - Class in org.axonframework.saga.annotation
Implementation of the SagaManager that uses annotations on the Sagas to describe the lifecycle management.
AnnotatedSagaManager(SagaRepository, EventBus, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Deprecated. use AnnotatedSagaManager.AnnotatedSagaManager(org.axonframework.saga.SagaRepository, Class[]) instead and register this instance using EventBus.subscribe(org.axonframework.eventhandling.EventListener)
AnnotatedSagaManager(SagaRepository, SagaFactory, EventBus, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Deprecated. use AnnotatedSagaManager.AnnotatedSagaManager(org.axonframework.saga.SagaRepository, org.axonframework.saga.SagaFactory, Class[]) instead and register this instance using EventBus.subscribe(org.axonframework.eventhandling.EventListener)
AnnotatedSagaManager(SagaRepository, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using given repository to load sagas and supporting given annotated sagaClasses.
AnnotatedSagaManager(SagaRepository, ParameterResolverFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using given repository to load sagas and supporting given annotated sagaClasses.
AnnotatedSagaManager(SagaRepository, SagaFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using the given resources.
AnnotatedSagaManager(SagaRepository, SagaFactory, ParameterResolverFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using the given resources.
AnnotatedSagaTestFixture - Class in org.axonframework.test.saga
Fixture for testing Annotated Sagas based on events and time passing.
AnnotatedSagaTestFixture(Class<? extends AbstractAnnotatedSaga>) - Constructor for class org.axonframework.test.saga.AnnotatedSagaTestFixture
Creates an instance of the AnnotatedSagaTestFixture to test sagas of the given sagaType.
AnnotationClusterSelector - Class in org.axonframework.eventhandling
Cluster Selector implementation that selects a cluster if an Annotation is present on the Event Listener class.
AnnotationClusterSelector(Class<? extends Annotation>, Cluster) - Constructor for class org.axonframework.eventhandling.AnnotationClusterSelector
Initializes a ClusterSelector instance that selects the given cluster for Event Listeners that are annotated with the given annotationType.
AnnotationClusterSelector(Class<? extends Annotation>, Cluster, boolean) - Constructor for class org.axonframework.eventhandling.AnnotationClusterSelector
Initializes a ClusterSelector instance that selects the given cluster for Event Listeners that are annotated with the given annotationType.
AnnotationCommandHandlerAdapter - Class in org.axonframework.commandhandling.annotation
Adapter that turns any @CommandHandler annotated bean into a CommandHandler implementation.
AnnotationCommandHandlerAdapter(Object, CommandBus) - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Deprecated. Use AnnotationCommandHandlerAdapter.AnnotationCommandHandlerAdapter(Object) and subscribe the handler to the command bus using CommandBus.subscribe(String, org.axonframework.commandhandling.CommandHandler).
AnnotationCommandHandlerAdapter(Object) - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Wraps the given annotatedCommandHandler, allowing it to be subscribed to a Command Bus.
AnnotationCommandHandlerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Wraps the given annotatedCommandHandler, allowing it to be subscribed to a Command Bus.
AnnotationCommandHandlerBeanPostProcessor - Class in org.axonframework.commandhandling.annotation
Spring Bean post processor that automatically generates an adapter for each bean containing CommandHandler annotated methods.
AnnotationCommandHandlerBeanPostProcessor() - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
AnnotationCommandTargetResolver - Class in org.axonframework.commandhandling.annotation
CommandTargetResolver that uses annotations on the command to identify the methods that provide the Aggregate Identifier of the targeted Aggregate and optionally the expected version of the aggregate.
AnnotationCommandTargetResolver() - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandTargetResolver
 
AnnotationConfigurationBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
The AnnotationConfigurationBeanDefinitionParser is responsible for parsing the annotation-config element from the Axon namespace.
AnnotationConfigurationBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
 
AnnotationDriven - Annotation Type in org.axonframework.contextsupport.spring
Annotation for @Configuration that will automatically subscribe @CommandHandler and @EventHandler annotated beans with the CommandBus and EventBus, respectively.
AnnotationDrivenConfiguration - Class in org.axonframework.contextsupport.spring
Spring @Configuration related class that adds Axon Annotation PostProcessors to the BeanDefinitionRegistry.
AnnotationDrivenConfiguration() - Constructor for class org.axonframework.contextsupport.spring.AnnotationDrivenConfiguration
 
AnnotationEventListenerAdapter - Class in org.axonframework.eventhandling.annotation
Adapter that turns any bean with EventHandler annotated methods into an EventListener.
AnnotationEventListenerAdapter(Object) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Wraps the given annotatedEventListener, allowing it to be subscribed to an Event Bus.
AnnotationEventListenerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Wraps the given annotatedEventListener, allowing it to be subscribed to an Event Bus.
AnnotationEventListenerAdapter(Object, EventBus) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Deprecated. Use AnnotationEventListenerAdapter.AnnotationEventListenerAdapter(Object) and subscribe the listener to the event bus using EventBus.subscribe(org.axonframework.eventhandling.EventListener)
AnnotationEventListenerBeanPostProcessor - Class in org.axonframework.eventhandling.annotation
Spring Bean post processor that automatically generates an adapter for each bean containing EventHandler annotated methods.
AnnotationEventListenerBeanPostProcessor() - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
AnnotationRevisionResolver - Class in org.axonframework.serializer
Revision Resolver implementation that checks for the presence of an @Revision annotation.
AnnotationRevisionResolver() - Constructor for class org.axonframework.serializer.AnnotationRevisionResolver
 
AnnotationRoutingStrategy - Class in org.axonframework.commandhandling.distributed
RoutingStrategy that expects an TargetAggregateIdentifier annotation on the command message's payload.
AnnotationRoutingStrategy() - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that fails when an incoming command does not define an AggregateIdentifier to base the routing key on.
AnnotationRoutingStrategy(Class<? extends Annotation>) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier.
AnnotationRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that uses the given unresolvedRoutingKeyPolicy when an incoming command does not define an AggregateIdentifier to base the routing key on.
AnnotationRoutingStrategy(Class<? extends Annotation>, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier and the given unresolvedRoutingKeyPolicy when an incoming command does not define an AggregateIdentifier to base the routing key on.
appendErrors(ErrorWriter) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
appendErrors(ErrorWriter) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
appendEvents(String, DomainEventStream) - Method in interface org.axonframework.eventstore.EventStore
Append the events in the given stream to the event store.
appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
Append the events in the given stream to the event store.
appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
Append the events in the given stream to the event store.
appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Append the events in the given stream to the event store.
appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.supporting.SequenceEventStore
 
appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
 
appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
 
appendEvents(String, DomainEventStream) - Method in class org.axonframework.gae.eventstore.GaeEventStore
 
appendEvents(String, DomainEventStream) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
appendEvents(String, DomainEventStream) - Method in class org.axonframework.quickstart.RunEventReplay.StubEventStore
 
appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
Append the given snapshotEvent to the snapshot event log for the given type type.
appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
Append the given snapshotEvent to the snapshot event log for the given type type.
appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Append the given snapshotEvent to the snapshot event log for the given type type.
appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
appendSnapshotEvent(String, DomainEventMessage) - Method in interface org.axonframework.eventstore.SnapshotEventStore
Append the given snapshotEvent to the snapshot event log for the given type type.
appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.gae.eventstore.GaeEventStore
 
appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
ApplicationContextLookupParameterResolverFactory - Class in org.axonframework.contextsupport.spring
FactoryBean implementation that create a ParameterResolverFactory, which auto-detects beans implementing ParameterResolverFactory beans in the application context.
ApplicationContextLookupParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
Creates an instance, using the given defaultFactories.
apply(Object) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Apply the provided event.
apply(Object, MetaData) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Apply the provided event.
apply(Object) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Apply the provided event.
apply(Object, MetaData) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Apply the provided event and attaching the given metaData.
asBson() - Method in class org.axonframework.mongo3.eventstore.criteria.And
 
asBson() - Method in class org.axonframework.mongo3.eventstore.criteria.CollectionCriteria
 
asBson() - Method in class org.axonframework.mongo3.eventstore.criteria.Equals
 
asBson() - Method in class org.axonframework.mongo3.eventstore.criteria.MongoCriteria
Returns the Bson representing the criterium.
asBson() - Method in class org.axonframework.mongo3.eventstore.criteria.Or
 
asBson() - Method in class org.axonframework.mongo3.eventstore.criteria.SimpleMongoOperator
 
asCommandMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandMessage
Returns the given command as a CommandMessage.
asDBObject() - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Returns the current BSON structure as DBObject.
asDBObject() - Method in class org.axonframework.saga.repository.mongo.SagaEntry
Returns the Mongo Document representing the Saga provided in this entry.
asDBObject() - Method in class org.axonframework.serializer.bson.BSONNode
Returns the current BSON structure as DBObject.
asDocument() - Method in class org.axonframework.mongo3.saga.repository.SagaEntry
Returns the Mongo Document representing the Saga provided in this entry.
asEventMessage(Object) - Static method in class org.axonframework.domain.GenericEventMessage
Returns the given event as an EventMessage.
asMongoObject() - Method in class org.axonframework.eventstore.mongo.criteria.And
 
asMongoObject() - Method in class org.axonframework.eventstore.mongo.criteria.CollectionCriteria
 
asMongoObject() - Method in class org.axonframework.eventstore.mongo.criteria.Equals
 
asMongoObject() - Method in class org.axonframework.eventstore.mongo.criteria.MongoCriteria
Returns the DBObject representing the criterium.
asMongoObject() - Method in class org.axonframework.eventstore.mongo.criteria.Or
 
asMongoObject() - Method in class org.axonframework.eventstore.mongo.criteria.SimpleMongoOperator
 
Assert - Class in org.axonframework.common
Utility class (inspired by Springs Assert class) for doing assertions on parameters and object state.
assertActiveSagas(int) - Method in class org.axonframework.test.saga.RepositoryContentValidator
Asserts that the repsitory contains the given expected amount of active sagas.
assertAssociationPresent(String, String) - Method in class org.axonframework.test.saga.RepositoryContentValidator
Asserts that an association is present for the given associationKey and associationValue.
assertDispatchedEqualTo(Object...) - Method in class org.axonframework.test.saga.CommandValidator
Assert that the given commands have been dispatched in the exact sequence provided.
assertDispatchedMatching(Matcher<?>) - Method in class org.axonframework.test.saga.CommandValidator
Assert that commands matching the given matcher has been dispatched on the command bus.
assertNoAssociationPresent(String, String) - Method in class org.axonframework.test.saga.RepositoryContentValidator
Asserts that no association is present for the given associationKey and associationValue.
assertNoScheduledEvents() - Method in class org.axonframework.test.saga.EventSchedulerValidator
Asserts that no events are scheduled for publication.
assertPublishedEvents(Object...) - Method in class org.axonframework.test.saga.EventValidator
Assert that the given expected events have been published.
assertPublishedEventsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.saga.EventValidator
Asserts that events have been published matching the given matcher.
assertScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.saga.EventSchedulerValidator
Asserts that an event matching the given matcher is scheduled for publication after the given duration.
assertScheduledEventMatching(DateTime, Matcher<?>) - Method in class org.axonframework.test.saga.EventSchedulerValidator
Asserts that an event matching the given matcher is scheduled for publication at the given scheduledTime.
assertValidRecording() - Method in class org.axonframework.test.ResultValidatorImpl
Makes sure the execution phase has finishes without any Errors ir FixtureExecutionExceptions.
asSet() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
asSet() - Method in interface org.axonframework.saga.AssociationValues
Returns this instance as a Set of Association Values.
assignMetaData(EventMessage, List<EventMessage>, int) - Method in class org.axonframework.unitofwork.MetaDataMutatingUnitOfWorkListenerAdapter
Defines the additional meta data to assign to the given event.
associateWith(AssociationValue) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Registers a AssociationValue with the given saga.
associateWith(String, String) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Registers a AssociationValue with the given saga.
associateWith(String, Number) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Registers a AssociationValue with the given saga.
AssociationValue - Class in org.axonframework.saga
A combination of key and value by which a Saga can be found.
AssociationValue(String, String) - Constructor for class org.axonframework.saga.AssociationValue
Creates a Association Value instance with the given key and value.
AssociationValueEntry - Class in org.axonframework.saga.repository.jpa
JPA wrapper around an Association Value.
AssociationValueEntry(String, String, AssociationValue) - Constructor for class org.axonframework.saga.repository.jpa.AssociationValueEntry
Initialize a new AssociationValueEntry for a saga with given sagaIdentifier and associationValue.
AssociationValueEntry() - Constructor for class org.axonframework.saga.repository.jpa.AssociationValueEntry
Constructor required by JPA.
AssociationValueMap - Class in org.axonframework.saga.repository
In-memory storage for AssociationValue to Saga mappings.
AssociationValueMap() - Constructor for class org.axonframework.saga.repository.AssociationValueMap
Initializes a new and empty AssociationValueMap.
AssociationValueResolver - Interface in org.axonframework.saga
Interface describing the mechanism that resolves Association Values from events.
AssociationValues - Interface in org.axonframework.saga
Interface describing a container of Association Values for a single Saga instance.
AssociationValuesImpl - Class in org.axonframework.saga.annotation
Default implementation of the AssociationValues interface.
AssociationValuesImpl() - Constructor for class org.axonframework.saga.annotation.AssociationValuesImpl
 
assocValueEntryTable() - Method in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
 
AsyncAnnotatedSagaManager - Class in org.axonframework.saga.annotation
A SagaManager implementation that processes Sagas asynchronously.
AsyncAnnotatedSagaManager(EventBus, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Deprecated. use AsyncAnnotatedSagaManager.AsyncAnnotatedSagaManager(Class[]) and register with the event bus using EventBus.subscribe(org.axonframework.eventhandling.EventListener)
AsyncAnnotatedSagaManager(Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Initializes an Asynchronous Saga Manager using default values for the given sagaTypes.
AsyncAnnotatedSagaManager(ParameterResolverFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Initializes an Asynchronous Saga Manager using default values for the given sagaTypes.
AsynchronousCluster - Class in org.axonframework.eventhandling.async
Cluster implementation that publishes events to the subscribed Event Listeners asynchronously from the publishing thread.
AsynchronousCluster(String, Executor, TransactionManager, SequencingPolicy<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
Creates an AsynchronousCluster implementation using the given executor, transactionManager and sequencingPolicy.
AsynchronousCluster(String, Executor, SequencingPolicy<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
Creates an AsynchronousCluster implementation using the given executor and sequencingPolicy.
AsynchronousCluster(String, Executor, TransactionManager, SequencingPolicy<? super EventMessage<?>>, ErrorHandler) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
Creates an AsynchronousCluster implementation using the given executor, transactionManager and sequencingPolicy.
AsynchronousCluster(String, Executor, UnitOfWorkFactory, SequencingPolicy<? super EventMessage<?>>, ErrorHandler) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
Creates an AsynchronousCluster implementation using the given executor, unitOfWorkFactory and sequencingPolicy.
AsynchronousCluster(String, Executor, UnitOfWorkFactory, SequencingPolicy<? super EventMessage<?>>, ErrorHandler, OrderResolver) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
Creates an AsynchronousCluster implementation using the given executor, unitOfWorkFactory and sequencingPolicy.
AsynchronousCommandBus - Class in org.axonframework.commandhandling
Specialization of the SimpleCommandBus that processed Commands asynchronously from the calling thread.
AsynchronousCommandBus() - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
Initialize the AsynchronousCommandBus, using a Cached Thread Pool.
AsynchronousCommandBus(Executor) - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
Initialize the AsynchronousCommandBus using the given executor.
AsyncSagaCreationElector - Class in org.axonframework.saga.annotation
Manages the election of which asynchronous saga event processor is responsible for creating a new Saga instance, when necessary.
AsyncSagaCreationElector() - Constructor for class org.axonframework.saga.annotation.AsyncSagaCreationElector
 
AsyncSagaEventProcessor - Class in org.axonframework.saga.annotation
Processes events by forwarding it to Saga instances "owned" by each processor.
AsyncSagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that parses saga-manager elements in the application context.
AsyncSagaManagerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
 
AsyncSagaProcessingEvent - Class in org.axonframework.saga.annotation
Placeholder for information required by the AsyncSagaEventProcessor for processing Events.
AsyncSagaProcessingEvent() - Constructor for class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
 
attachInheritedResources(UnitOfWork) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
attachInheritedResources(UnitOfWork) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
attachInheritedResources(UnitOfWork) - Method in interface org.axonframework.unitofwork.UnitOfWork
Attach all inherited resources to the given unitOfWork.
attachResource(String, Object) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
attachResource(String, Object, boolean) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
attachResource(String, Object) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
attachResource(String, Object, boolean) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
attachResource(String, Object) - Method in interface org.axonframework.unitofwork.UnitOfWork
Attaches the given resource to this Unit of Work under the given name.
attachResource(String, Object, boolean) - Method in interface org.axonframework.unitofwork.UnitOfWork
Attaches the given resource to this Unit of Work under the given name.
attributes() - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Returns a map containing the attributes of the current node.
attributes() - Method in class org.axonframework.serializer.bson.BSONNode
Returns a map containing the attributes of the current node.
AuditDataProvider - Interface in org.axonframework.auditing
Interface describing the instance that provides the relevant information for auditing purposes.
AuditingInterceptor - Class in org.axonframework.auditing
Interceptor that keeps track of commands and the events that were dispatched as a result of handling that command.
AuditingInterceptor() - Constructor for class org.axonframework.auditing.AuditingInterceptor
 
AuditingUnitOfWorkListener - Class in org.axonframework.auditing
Listener implementation that adds auditing information to events being tracked by the unit of work this listener is registered to.
AuditingUnitOfWorkListener(CommandMessage<?>, AuditDataProvider, AuditLogger) - Constructor for class org.axonframework.auditing.AuditingUnitOfWorkListener
Initialize a listener for the given command.
AuditLogger - Interface in org.axonframework.auditing
Interface describing a component capable of writing auditing entries to a log.
AuthenticatingMongoTemplate - Class in org.axonframework.common.mongo
Abstract implementation for Mongo templates.
AuthenticatingMongoTemplate(Mongo, String, char[]) - Constructor for class org.axonframework.common.mongo.AuthenticatingMongoTemplate
Initializes the MongoTemplate to connect using the given mongo instance and a database with default name "axonframework".
AuthenticatingMongoTemplate(Mongo, String, String, char[]) - Constructor for class org.axonframework.common.mongo.AuthenticatingMongoTemplate
Initializes the MongoTemplate to connect using the given mongo instance and the database with given databaseName.
AuthenticatingMongoTemplate(Mongo, String, String, String, char[]) - Constructor for class org.axonframework.common.mongo.AuthenticatingMongoTemplate
Initializes the MongoTemplate to connect using the given mongo instance and the database with given databaseName.
AutowiredBean - Class in org.axonframework.contextsupport.spring
Special type of BeanDefinition that references can be use to explicitly define a property as being autowired.
AutowiredDependencyFactoryBean - Class in org.axonframework.contextsupport.spring
Convenience factory bean that locates a bean of a number of given types.
AutowiredDependencyFactoryBean(Class<?>...) - Constructor for class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
Creates a factory bean that automatically resolved to a bean of one of the given beanTypes.
AutowiredDependencyFactoryBean(Object, Class<?>...) - Constructor for class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
Creates a factory bean that automatically resolved to a bean of one of the given beanTypes, reverting to the given defaultBean if no candidates are found.
AutowiredResourceInjector - Class in org.axonframework.test.utils
Resource injector that uses setter methods to inject resources.
AutowiredResourceInjector(Iterable<?>) - Constructor for class org.axonframework.test.utils.AutowiredResourceInjector
Initializes the resource injector to inject to given resources.
AutowiringClusterSelector - Class in org.axonframework.eventhandling
Cluster selector implementation that uses a Spring Application Context to find all selector beans available.
AutowiringClusterSelector() - Constructor for class org.axonframework.eventhandling.AutowiringClusterSelector
 
awaitCompletion(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Wait for completion of the command, or for the timeout to expire.
awaitJoined() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
this method blocks until this member has successfully joined the other members, until the thread is interrupted, or when joining has failed.
awaitJoined(long, TimeUnit) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
this method blocks until this member has successfully joined the other members, until the thread is interrupted, when the given number of milliseconds have passed, or when joining has failed.
AxonAMQPNamespaceHandler - Class in org.axonframework.contextsupport.spring.amqp
The Axon AMQP namespace handler is responsible for parsing the elements of the Axon AMQP namespace and adjusting the Spring context configuration accordingly.
AxonAMQPNamespaceHandler() - Constructor for class org.axonframework.contextsupport.spring.amqp.AxonAMQPNamespaceHandler
 
AxonAssertionError - Error in org.axonframework.test
Error indication that an Assertion failed during a test case.
AxonAssertionError(String) - Constructor for error org.axonframework.test.AxonAssertionError
Create a new error instance using the given detailMessage.
AxonConfigurationException - Exception in org.axonframework.common
Exception indicating that a configuration error has been made in the Axon configuration.
AxonConfigurationException(String) - Constructor for exception org.axonframework.common.AxonConfigurationException
Initializes the exception using the given message.
AxonConfigurationException(String, Throwable) - Constructor for exception org.axonframework.common.AxonConfigurationException
Initializes the exception using the given message and cause.
AxonException - Exception in org.axonframework.common
Base exception of all Axon Framework related exceptions.
AxonException(String) - Constructor for exception org.axonframework.common.AxonException
Initializes the exception using the given message.
AxonException(String, Throwable) - Constructor for exception org.axonframework.common.AxonException
Initializes the exception using the given message and cause.
AxonNamespaceHandler - Class in org.axonframework.contextsupport.spring
The Axon namespace handler is responsible for parsing the elements of the Axon namespace and adjusting the Spring context configuration accordingly.
AxonNamespaceHandler() - Constructor for class org.axonframework.contextsupport.spring.AxonNamespaceHandler
 
AxonNonTransientException - Exception in org.axonframework.common
Exception indicating an error has been cause that cannot be resolved without intervention.
AxonNonTransientException(String) - Constructor for exception org.axonframework.common.AxonNonTransientException
Initializes the exception using the given message.
AxonNonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonNonTransientException
Initializes the exception using the given message and cause.
AxonThreadFactory - Class in org.axonframework.common
Thread factory that created threads in a given group.
AxonThreadFactory(String) - Constructor for class org.axonframework.common.AxonThreadFactory
Initializes a ThreadFactory instance that creates each thread in a group with given groupName with default priority.
AxonThreadFactory(ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
Initializes a ThreadFactory instance that create each thread in the given group with default priority.
AxonThreadFactory(int, ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
Initializes a ThreadFactory instance that create each thread in the given group with given priority.
AxonTransientException - Exception in org.axonframework.common
Exception indicating an error occurred that might be resolved by retrying the operation that caused the exception.
AxonTransientException(String) - Constructor for exception org.axonframework.common.AxonTransientException
Initializes the exception using the given message.
AxonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonTransientException
Initializes the exception using the given message and cause.

B

BackloggingIncomingMessageHandler - Class in org.axonframework.eventhandling.replay
IncomingMessageHandler implementation that maintains a backlog of all Events published to a cluster while it is in replay mode.
BackloggingIncomingMessageHandler() - Constructor for class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
Creates a new BackloggingIncomingMessageHandler.
BackloggingIncomingMessageHandler(Duration) - Constructor for class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
Creates a new BackloggingIncomingMessageHandler.
BackloggingIncomingMessageHandler(Duration, Queue<EventMessage>) - Constructor for class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
Creates a new BackloggingIncomingMessageHandler.
BeanPropertyAccessStrategy - Class in org.axonframework.common.property
BeanPropertyAccessStrategy implementation that uses JavaBean style property access.
BeanPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.BeanPropertyAccessStrategy
 
BeanValidationInterceptor - Class in org.axonframework.commandhandling.interceptors
Interceptor that applies JSR303 bean validation on incoming commands.
BeanValidationInterceptor() - Constructor for class org.axonframework.commandhandling.interceptors.BeanValidationInterceptor
Initializes a validation interceptor using a default ValidatorFactory (see Validation.buildDefaultValidatorFactory()).
BeanValidationInterceptor(ValidatorFactory) - Constructor for class org.axonframework.commandhandling.interceptors.BeanValidationInterceptor
Initializes a validation interceptor using the given ValidatorFactory.
beforeReplay() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
 
beforeReplay() - Method in interface org.axonframework.eventhandling.replay.ReplayAware
Invoked when a replay is started.
beforeReplay() - Method in class org.axonframework.quickstart.RunEventReplay.AnotherThreadPrintingEventListener
 
beforeReplay() - Method in class org.axonframework.saga.AbstractReplayAwareSagaManager
 
BinaryOperator - Class in org.axonframework.eventstore.jdbc.criteria
Implementation of a binary operator for the Jdbc Event Store.
BinaryOperator(JdbcCriteria, String, JdbcCriteria) - Constructor for class org.axonframework.eventstore.jdbc.criteria.BinaryOperator
Initializes a binary operator that matches against two criteria
BinaryOperator - Class in org.axonframework.eventstore.jpa.criteria
Implementation of a binary operator for the Jpa Event Store.
BinaryOperator(JpaCriteria, String, JpaCriteria) - Constructor for class org.axonframework.eventstore.jpa.criteria.BinaryOperator
Initializes a binary operator that matches against two criteria
BlacklistDetectingCallback<R> - Class in org.axonframework.commandhandling.disruptor
Wrapper for command handler Callbacks that detects blacklisted aggregates and starts a cleanup process when an aggregate is blacklisted.
BlacklistDetectingCallback(CommandCallback<R>, CommandMessage, RingBuffer<CommandHandlingEntry>, DisruptorCommandBus, boolean) - Constructor for class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
Initializes the callback which allows the given command to be rescheduled on the given ringBuffer if it failed due to a corrupt state.
BlobToInputStreamConverter - Class in org.axonframework.serializer.converters
 
BlobToInputStreamConverter() - Constructor for class org.axonframework.serializer.converters.BlobToInputStreamConverter
 
BSONNode - Class in org.axonframework.mongo3.serializer.bson
Represents a node in a BSON structure.
BSONNode(String) - Constructor for class org.axonframework.mongo3.serializer.bson.BSONNode
Creates a node with given "code" name.
BSONNode - Class in org.axonframework.serializer.bson
Represents a node in a BSON structure.
BSONNode(String) - Constructor for class org.axonframework.serializer.bson.BSONNode
Creates a node with given "code" name.
buildJobDetail(EventMessage, JobKey) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Builds the JobDetail instance for Quartz, which defines the Job that needs to be executed when the trigger fires.
buildTrigger(DateTime, JobKey) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Builds a Trigger which fires the Job identified by jobKey at (or around) the given triggerDateTime.
ByteArrayToInputStreamConverter - Class in org.axonframework.serializer.converters
ContentTypeConverter that converts byte arrays into InputStream.
ByteArrayToInputStreamConverter() - Constructor for class org.axonframework.serializer.converters.ByteArrayToInputStreamConverter
 
ByteArrayToJsonNodeConverter - Class in org.axonframework.serializer.json
ContentTypeConverter implementation that converts byte[] containing UTF8 encoded JSON string to a Jackson JsonNode.
ByteArrayToJsonNodeConverter(ObjectMapper) - Constructor for class org.axonframework.serializer.json.ByteArrayToJsonNodeConverter
Initialize the Converter, using given objectMapper to parse the binary contents
ByteArrayToStringConverter - Class in org.axonframework.serializer.converters
ContentTypeConverter that converts byte arrays into Strings.
ByteArrayToStringConverter() - Constructor for class org.axonframework.serializer.converters.ByteArrayToStringConverter
 

C

Cache - Interface in org.axonframework.cache
Abstraction for a Caching mechanism.
Cache.EntryListener - Interface in org.axonframework.cache
Interface describing callback methods, which are invoked when changes are made in the underlying cache.
Cache.EntryListenerAdapter - Class in org.axonframework.cache
Adapter implementation for the EntryListener, allowing for overriding only specific callback methods.
Cache.EntryListenerAdapter() - Constructor for class org.axonframework.cache.Cache.EntryListenerAdapter
 
CachingEventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Implementation of the event sourcing repository that uses a cache to improve loading performance.
CachingEventSourcingRepository(AggregateFactory<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Initializes a repository with a the given aggregateFactory and a pessimistic locking strategy.
CachingEventSourcingRepository(AggregateFactory<T>, EventStore, LockManager) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Initializes a repository with a the given aggregateFactory and a pessimistic locking strategy.
CachingSagaRepository - Class in org.axonframework.saga.repository
Saga Repository implementation that adds caching behavior to the repository it wraps.
CachingSagaRepository(SagaRepository, Cache, Cache) - Constructor for class org.axonframework.saga.repository.CachingSagaRepository
Initializes an instance delegating to the given delegate, storing associations in the given associationsCache and Saga instances in the given sagaCache.
calculateChain(Class<S>, Class<T>, Collection<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serializer.ChainedConverter
Returns a converter that can convert an IntermediateRepresentation from the given sourceType to the given targetType using a chain formed with given candidates.
CallbackBehavior - Interface in org.axonframework.test.utils
Interface towards a mechanism that replicates the behavior of a Command Handling component.
cancel(boolean) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Always returns false, since command execution cannot be cancelled.
cancelSchedule(ScheduleToken) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Cancel the publication of a scheduled event.
cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
cancelSchedule(ScheduleToken) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
canConvert(Class<S>, Class<T>, List<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serializer.ChainedConverter
Indicates whether this converter is capable of converting the given sourceContentType into targetContentType, using the given converters.
CannotConvertBetweenTypesException - Exception in org.axonframework.serializer
Exception indicating that a conversion is required between to upcasters, but there is no converter capable of doing the conversion.
CannotConvertBetweenTypesException(String) - Constructor for exception org.axonframework.serializer.CannotConvertBetweenTypesException
Initializes the exception with the given message.
CannotConvertBetweenTypesException(String, Throwable) - Constructor for exception org.axonframework.serializer.CannotConvertBetweenTypesException
Initializing the exception with given message and cause.
canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.JavaSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.json.JacksonSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
 
canSerializeTo(Class<T>) - Method in interface org.axonframework.serializer.Serializer
Indicates whether this Serializer is capable of serializing to the given expectedRepresentation.
canUpcast(SerializedType) - Method in class org.axonframework.quickstart.RunUpcaster.ToDoItemUpcaster
 
canUpcast(SerializedType) - Method in interface org.axonframework.upcasting.Upcaster
Indicates whether this upcaster is capable of upcasting the given type.
CapturingEventVisitor - Class in org.axonframework.eventstore.supporting
 
CapturingEventVisitor() - Constructor for class org.axonframework.eventstore.supporting.CapturingEventVisitor
 
ChainedConverter<S,T> - Class in org.axonframework.serializer
A converter that delegates to a chain of other ContentTypeConverters to convert from a source to a target for which there is not necessarily a single converter available.
ChainedConverter(List<ContentTypeConverter>) - Constructor for class org.axonframework.serializer.ChainedConverter
Creates a new instance that uses the given delegates to form a chain of converters.
ChainingConverterFactory - Class in org.axonframework.serializer
ConverterFactory implementation that will combine converters to form chains of converters to be able to convert from one type to another, for which there is no suitable single converter.
ChainingConverterFactory() - Constructor for class org.axonframework.serializer.ChainingConverterFactory
Initialize a new ChainingConverterFactory.
children() - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Returns an iterator providing access to the child nodes of the current node.
children() - Method in class org.axonframework.serializer.bson.BSONNode
Returns an iterator providing access to the child nodes of the current node.
classForType(SerializedType) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Returns the class for the given type identifier.
classForType(SerializedType) - Method in class org.axonframework.serializer.JavaSerializer
 
classForType(SerializedType) - Method in class org.axonframework.serializer.json.JacksonSerializer
 
classForType(SerializedType) - Method in class org.axonframework.serializer.MessageSerializer
 
classForType(SerializedType) - Method in interface org.axonframework.serializer.Serializer
Returns the class for the given type identifier.
ClassNamePatternClusterSelector - Class in org.axonframework.eventhandling
ClusterSelector implementation that chooses a Cluster based on whether the Listener's Class Name matches a given Pattern.
ClassNamePatternClusterSelector(Pattern, Cluster) - Constructor for class org.axonframework.eventhandling.ClassNamePatternClusterSelector
Initializes the ClassNamePrefixClusterSelector using the given mappings.
ClassNamePrefixClusterSelector - Class in org.axonframework.eventhandling
ClusterSelector implementation that chooses a Cluster based on a mapping of the Listener's Class Name.
ClassNamePrefixClusterSelector(String, Cluster) - Constructor for class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
Initializes the ClassNamePrefixClusterSelector where classes starting with the given prefix will be mapped to the given cluster.
ClassNamePrefixClusterSelector(Map<String, Cluster>) - Constructor for class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
Initializes the ClassNamePrefixClusterSelector using the given mappings.
ClassNamePrefixClusterSelector(Map<String, Cluster>, Cluster) - Constructor for class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
Initializes the ClassNamePrefixClusterSelector using the given mappings.
ClasspathParameterResolverFactory - Class in org.axonframework.common.annotation
ParameterResolverFactory instance that locates other ParameterResolverFactory instances on the class path.
ClasspathParameterResolverFactory() - Constructor for class org.axonframework.common.annotation.ClasspathParameterResolverFactory
 
clear() - Static method in class org.axonframework.correlation.CorrelationDataHolder
Clears the correlation data from the current thread.
clear() - Method in class org.axonframework.domain.MetaData
This operation is not supported.

clear() - Method in class org.axonframework.saga.annotation.AsyncSagaCreationElector
Clears the voting counts for a new round.
clear() - Method in class org.axonframework.saga.repository.AssociationValueMap
Clears all the associations.
clear() - Static method in class org.axonframework.test.FixtureResourceParameterResolverFactory
Clears the injectable resources registered to the current thread.
clear(UnitOfWork) - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Clears the UnitOfWork currently bound to the current thread, if that UnitOfWork is the given unitOfWork.
clearCache() - Static method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
Clears the cached message handlers.
clearCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
Clears all the commands recorded by this Command Bus.
clearSubscriptions() - Method in class org.axonframework.test.utils.RecordingCommandBus
Clears all subscribed handlers on this command bus.
clone() - Method in interface org.axonframework.cache.Cache.EntryListener
Clone operation used by some Cache implementations.
clone() - Method in class org.axonframework.cache.Cache.EntryListenerAdapter
 
close(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
Close the given connection, which was wrapped by the ConnectionWrapperFactory.
close(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
 
close() - Method in class org.axonframework.eventstore.fs.FileSystemBufferedReaderDomainEventStream
 
close() - Method in class org.axonframework.eventstore.fs.FileSystemEventMessageReader
 
close() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
close() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
close() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
close() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
closeIfCloseable(Object) - Static method in class org.axonframework.common.io.IOUtils
Close the given closeable if it implements the Closeable interface.
closeQuietly(Closeable) - Static method in class org.axonframework.common.io.IOUtils
Closes any Closable object, while suppressing any IOExceptions it will generate.
closeQuietly(ResultSet) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Close the given resultSet, if possible.
closeQuietly(Statement) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Close the given statement, if possible.
closeQuietly(Connection) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Close the given connection, if possible.
closeQuietlyIfCloseable(Object) - Static method in class org.axonframework.common.io.IOUtils
Closes any object if that object implements Closeable, while suppressing any IOExceptions it will generate.
Cluster - Interface in org.axonframework.eventhandling
A cluster represents a group of Event Listeners that are treated as a single group by the ClusteringEventBus.
ClusterBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser implementation that parses "cluster" elements.
ClusterBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.ClusterBeanDefinitionParser
 
ClusteringEventBus - Class in org.axonframework.eventhandling
EventBus implementation that supports clustering of Event Listeners.
ClusteringEventBus() - Constructor for class org.axonframework.eventhandling.ClusteringEventBus
Initializes a ClusteringEventBus with a SimpleEventBusTerminal and a DefaultClusterSelector.
ClusteringEventBus(EventBusTerminal) - Constructor for class org.axonframework.eventhandling.ClusteringEventBus
Initializes a ClusteringEventBus with the given terminal and a DefaultClusterSelector.
ClusteringEventBus(ClusterSelector) - Constructor for class org.axonframework.eventhandling.ClusteringEventBus
Initializes a ClusteringEventBus with the given clusterSelector and a SimpleEventBusTerminal, which dispatches all events to all local clusters synchronously.
ClusteringEventBus(ClusterSelector, EventBusTerminal) - Constructor for class org.axonframework.eventhandling.ClusteringEventBus
Initializes a ClusteringEventBus with the given clusterSelector and a terminal.
ClusterMessageListener - Class in org.axonframework.eventhandling.amqp.spring
MessageListener implementation that deserializes incoming messages and forwards them to one or more clusters.
ClusterMessageListener(Cluster, AMQPMessageConverter) - Constructor for class org.axonframework.eventhandling.amqp.spring.ClusterMessageListener
Initializes a ClusterMessageListener with given initialCluster that uses given serializer to deserialize the message's contents into an EventMessage.
ClusterMetaData - Interface in org.axonframework.eventhandling
Allows arbitrary information to be attached to a cluster.
ClusterSelector - Interface in org.axonframework.eventhandling
The ClusterSelector defines the mechanism that assigns each of the subscribed listeners to a Cluster instance.
CollectionCriteria - Class in org.axonframework.eventstore.mongo.criteria
Implementation of Collection operators for the Mongo Criteria, such as "In" and "NotIn".
CollectionCriteria(MongoProperty, String, Object) - Constructor for class org.axonframework.eventstore.mongo.criteria.CollectionCriteria
Returns a criterion that requires the given property value to be present in the given expression to evaluate to true.
CollectionCriteria - Class in org.axonframework.mongo3.eventstore.criteria
Implementation of Collection operators for the Mongo Criteria, such as "In" and "NotIn".
CollectionCriteria(MongoProperty, String, Object) - Constructor for class org.axonframework.mongo3.eventstore.criteria.CollectionCriteria
Returns a criterion that requires the given property value to be present in the given expression to evaluate to true.
CollectionOperator - Class in org.axonframework.eventstore.jdbc.criteria
Abstract implementation to use for testing whether an item is present in a collection or not.
CollectionOperator(JdbcProperty, String, Object) - Constructor for class org.axonframework.eventstore.jdbc.criteria.CollectionOperator
Initializes the operator matching given property against the given expression using the given operator.
CollectionOperator - Class in org.axonframework.eventstore.jpa.criteria
Abstract implementation to use for testing whether an item is present in a collection or not.
CollectionOperator(JpaProperty, String, Object) - Constructor for class org.axonframework.eventstore.jpa.criteria.CollectionOperator
Initializes the operator matching given property against the given expression using the given operator.
CollectionUtils - Class in org.axonframework.common
Utility methods for operations on collections.
CommandBus - Interface in org.axonframework.commandhandling
The mechanism that dispatches Command objects to their appropriate CommandHandler.
CommandBusConnector - Interface in org.axonframework.commandhandling.distributed
Interface describing the component that remotely connects multiple CommandBus instances.
CommandCallback<R> - Interface in org.axonframework.commandhandling
Interface describing a callback that is invoked when command handler execution has finished.
CommandDispatchException - Exception in org.axonframework.commandhandling.distributed
Exception indicating that an error has occurred while trying to dispatch a command to another (potentially remote) segment of the CommandBus.
CommandDispatchException(String) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
Initializes the exception using the given message.
CommandDispatchException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
Initializes the exception using the given message and cause.
CommandDispatchInterceptor - Interface in org.axonframework.commandhandling
Interceptor that allows commands to be intercepted and modified before they are dispatched by the Command Bus.
CommandExecutionException - Exception in org.axonframework.commandhandling
Indicates that an exception has occurred while handling a command.
CommandExecutionException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
Initializes the exception with given message and cause.
CommandGateway - Interface in org.axonframework.commandhandling.gateway
Interface towards the Command Handling components of an application.
CommandGatewayFactoryBean<T> - Class in org.axonframework.commandhandling.gateway
FactoryBean that creates a gateway instance for any given (compatible) interface.
CommandGatewayFactoryBean() - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
 
CommandGenerator - Class in org.axonframework.quickstart
Runner that uses the provided CommandGateway to send some commands to our application.
CommandGenerator() - Constructor for class org.axonframework.quickstart.CommandGenerator
 
CommandHandler - Annotation Type in org.axonframework.commandhandling.annotation
Marker annotation to mark any method on an object as being a CommandHandler.
CommandHandler<T> - Interface in org.axonframework.commandhandling
Marks an instance that is capable of handling commands.
CommandHandlerInterceptor - Interface in org.axonframework.commandhandling
Workflow interface that allows for customized command handler invocation chains.
CommandHandlerInvoker - Class in org.axonframework.commandhandling.disruptor
Component of the DisruptorCommandBus that invokes the command handler.
CommandHandlerInvoker(EventStore, Cache, int) - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
Create an aggregate invoker instance that uses the given eventStore and cache to retrieve aggregate instances.
CommandHandlingEntry - Class in org.axonframework.commandhandling.disruptor
DataHolder for the DisruptorCommandBus.
CommandHandlingEntry(boolean) - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Initializes the CommandHandlingEntry
CommandHandlingEntry.Factory - Class in org.axonframework.commandhandling.disruptor
Factory class for CommandHandlingEntry instances.
CommandHandlingEntry.Factory(boolean) - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlingEntry.Factory
Initialize the factory with given transactional flag
CommandHandlingMember - Annotation Type in org.axonframework.commandhandling.annotation
Marker annotation for field that contain an Entity capable of handling Commands on behalf of the aggregate.
CommandHandlingMemberCollection - Annotation Type in org.axonframework.commandhandling.annotation
Marker annotation for field that contain an Entity capable of handling Commands on behalf of the aggregate.
CommandHandlingMemberMap - Annotation Type in org.axonframework.commandhandling.annotation
Marker annotation for fields that contain a Map of Entities capable of handling Commands on behalf of the aggregate.
CommandMessage<T> - Interface in org.axonframework.commandhandling
Represents a Message carrying a command as its payload.
CommandMessageHandlerUtils - Class in org.axonframework.commandhandling.annotation
Utility class that resolves the name of a Command accepted by a given handler.
CommandMessageHandlerUtils() - Constructor for class org.axonframework.commandhandling.annotation.CommandMessageHandlerUtils
 
CommandMetaDataProvider - Class in org.axonframework.auditing
AuditDataProvider implementation that attaches a Command's MetaData to each event generated as result of that command.
CommandMetaDataProvider() - Constructor for class org.axonframework.auditing.CommandMetaDataProvider
 
CommandResponseProcessingFailedException - Exception in org.axonframework.commandhandling.distributed.jgroups
Exception indicating that a failure occurred during processing of a command response.
CommandResponseProcessingFailedException(String) - Constructor for exception org.axonframework.commandhandling.distributed.jgroups.CommandResponseProcessingFailedException
Initializes the exception using the given message.
CommandResponseProcessingFailedException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.jgroups.CommandResponseProcessingFailedException
Initializes the exception using the given message and cause.
CommandTargetResolver - Interface in org.axonframework.commandhandling
Interface towards a mechanism that is capable of extracting an Aggregate Identifier and Version form a command that identifies the aggregate instance the command should be invoked on.
CommandValidator - Class in org.axonframework.test.saga
Helper class for validation of dispatched commands.
CommandValidator(RecordingCommandBus, FieldFilter) - Constructor for class org.axonframework.test.saga.CommandValidator
Creates a validator which monitors the given commandBus.
commit() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
commit(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
Commits the underlying transaction
commit(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
 
commit() - Method in class org.axonframework.domain.EventContainer
Clears the events in this container.
commit(Saga) - Method in class org.axonframework.saga.AbstractSagaManager
Commits the given saga to the registered repository.
commit() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
commit() - Method in interface org.axonframework.saga.AssociationValues
Resets the tracked changes.
commit(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
 
commit(Saga) - Method in class org.axonframework.saga.repository.CachingSagaRepository
 
commit(Saga) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
commit(Saga) - Method in interface org.axonframework.saga.SagaRepository
Commits the changes made to the Saga instance.
commit() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Commits the current UnitOfWork.
commit() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
commit() - Method in interface org.axonframework.unitofwork.UnitOfWork
Commits the UnitOfWork.
commitEvents() - Method in class org.axonframework.domain.AbstractAggregateRoot
Clears the events currently marked as "uncommitted" and clears any known EventRegistrationCallbacks (see AggregateRoot.addEventRegistrationCallback(EventRegistrationCallback)).
commitEvents() - Method in interface org.axonframework.domain.AggregateRoot
Clears the events currently marked as "uncommitted" and clears any known EventRegistrationCallbacks (see AggregateRoot.addEventRegistrationCallback(EventRegistrationCallback)).
commitEvents() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
 
commitInnerUnitOfWork() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Commit all registered inner units of work.
commitTransaction(Object) - Method in class org.axonframework.unitofwork.NoTransactionManager
 
commitTransaction(TransactionStatus) - Method in class org.axonframework.unitofwork.SpringTransactionManager
 
commitTransaction(T) - Method in interface org.axonframework.unitofwork.TransactionManager
Commits the transaction identifier by given transactionStatus.
CompactDriver - Class in org.axonframework.serializer.xml
XStream HierarchicalStreamDriver implementation that uses a CompactWriter to write XML without newlines and indentation, while writing it using the (default) XPPReader.
CompactDriver() - Constructor for class org.axonframework.serializer.xml.CompactDriver
 
compare(T, T) - Method in class org.axonframework.common.annotation.PriorityAnnotationComparator
 
compare(EventListener, EventListener) - Method in class org.axonframework.eventhandling.EventListenerOrderComparator
 
compareTo(AbstractMessageHandler) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
 
compareTo(PropertyAccessStrategy) - Method in class org.axonframework.common.property.PropertyAccessStrategy
 
compareTo(SagaMethodMessageHandler) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
 
compareTo(StubScheduleToken) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
CompositeClusterSelector - Class in org.axonframework.eventhandling
ClusterSelector implementation that delegates the selection to a list of other ClusterSelectors.
CompositeClusterSelector(List<ClusterSelector>) - Constructor for class org.axonframework.eventhandling.CompositeClusterSelector
Initializes the CompositeClusterSelector with the given List of delegates.
CompositeEventStreamDecorator - Class in org.axonframework.eventsourcing
EventStreamDecorator implementation that delegates to several other decorator instances.
CompositeEventStreamDecorator(Collection<EventStreamDecorator>) - Constructor for class org.axonframework.eventsourcing.CompositeEventStreamDecorator
Initialize the decorator, delegating to the given eventStreamDecorators.
ConcurrencyException - Exception in org.axonframework.repository
Exception indicating that concurrent access to a repository was detected.
ConcurrencyException(String) - Constructor for exception org.axonframework.repository.ConcurrencyException
Initialize a ConcurrencyException with the given message.
ConcurrencyException(String, Throwable) - Constructor for exception org.axonframework.repository.ConcurrencyException
Initialize a ConcurrencyException with the given message and cause.
ConflictingAggregateVersionException - Exception in org.axonframework.repository
Exception indicating that the (actual) version of a loaded aggregate did not match the given expected version number.
ConflictingAggregateVersionException(Object, long, long) - Constructor for exception org.axonframework.repository.ConflictingAggregateVersionException
Initializes the exception using the given message.
ConflictingAggregateVersionException(Object, long, long, Throwable) - Constructor for exception org.axonframework.repository.ConflictingAggregateVersionException
Initializes the exception using the given message and cause.
ConflictingModificationException - Exception in org.axonframework.repository
Root of a hierarchy of exceptions indicating the detection of conflicting concurrent modifications.
ConflictingModificationException(String) - Constructor for exception org.axonframework.repository.ConflictingModificationException
Initializes the exception using the given message.
ConflictingModificationException(String, Throwable) - Constructor for exception org.axonframework.repository.ConflictingModificationException
Initializes the exception using the given message and cause.
ConflictResolver - Interface in org.axonframework.eventsourcing
Interface describing an object that is capable of detecting conflicts between changes applied to an aggregate, and unseen changes made to the aggregate.
connect(int) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
Connects this member to the cluster using the given loadFactor.
ConnectionFailedException - Exception in org.axonframework.commandhandling.distributed.jgroups
Exception indicating that a CommandBusConnector failed to connect to other instances.
ConnectionFailedException(String) - Constructor for exception org.axonframework.commandhandling.distributed.jgroups.ConnectionFailedException
Initializes the exception using the given message.
ConnectionFailedException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.jgroups.ConnectionFailedException
Initializes the exception using the given message and cause.
ConnectionProvider - Interface in org.axonframework.common.jdbc
Interface towards a mechanism that provides access to a JDBC Connection.
ConnectionWrapperFactory - Class in org.axonframework.common.jdbc
Factory for creating wrappers around a Connection, allowing one to override the behavior of the Connection.close() method.
ConnectionWrapperFactory.ConnectionCloseHandler - Interface in org.axonframework.common.jdbc
Interface defining an operation to close the wrapped connection
ConnectionWrapperFactory.NoOpCloseHandler - Class in org.axonframework.common.jdbc
Implementation of ConnectionCloseHandler that does nothing on close.
ConnectionWrapperFactory.NoOpCloseHandler() - Constructor for class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
 
ConsistentHash - Class in org.axonframework.commandhandling.distributed
Basic implementation of a Consistent Hashing algorithm, using the MD5 algorithm to build the hash values for given keys and node names.
ConsistentHash() - Constructor for class org.axonframework.commandhandling.distributed.ConsistentHash
Initializes an empty hash.
ConsistentHash.Member - Class in org.axonframework.commandhandling.distributed
Represents a member in a consistently hashed cluster.
ConsistentHash.Member(String, int, Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.ConsistentHash.Member
Constructs a new member with given nodeName, segmentCount supporting given supportedCommandTypes.
ConstructorCommandMessageHandler<T extends AggregateRoot> - Class in org.axonframework.commandhandling.annotation
Command Handler that creates a new aggregate instance by invoking that aggregate's constructor.
ContainerManagedEntityManagerProvider - Class in org.axonframework.common.jpa
EntityManagerProvider implementation that expects the container to inject the default container managed EntityManager instance.
ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
 
contains(AssociationValue) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
contains(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues
Indicates whether this instance contains the given associationValue.
containsKey(K) - Method in interface org.axonframework.cache.Cache
Indicates whether there is an item stored under given key.
containsKey(K) - Method in class org.axonframework.cache.EhCacheAdapter
 
containsKey(K) - Method in class org.axonframework.cache.JCacheAdapter
 
containsKey(Object) - Method in class org.axonframework.cache.NoCache
 
containsKey(K) - Method in class org.axonframework.cache.WeakReferenceCache
 
containsKey(Object) - Method in class org.axonframework.domain.MetaData
 
containsValue(Object) - Method in class org.axonframework.domain.MetaData
 
ContentTypeConverter<S,T> - Interface in org.axonframework.serializer
Interface describing a mechanism that converts the data type of IntermediateRepresentations of SerializedObjects for Upcasters.
ContinuedGivenState - Interface in org.axonframework.test.saga
Interface describing methods that can be executed after the first "given" state has been supplied.
convert(Set<ConstraintViolation<Object>>) - Static method in exception org.axonframework.commandhandling.interceptors.JSR303ViolationException
Convert the violations to a human readable format, sorted by class and property e.g.
convert(DBObject) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectToStringContentTypeConverter
 
convert(String) - Method in class org.axonframework.mongo3.serializer.bson.StringToDBObjectContentTypeConverter
 
convert(SerializedObject<S>) - Method in class org.axonframework.serializer.AbstractContentTypeConverter
 
convert(Class<S>, Class<T>, S) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Convert the given source, of type sourceType to the given targetType.
convert(DBObject) - Method in class org.axonframework.serializer.bson.DBObjectToStringContentTypeConverter
 
convert(String) - Method in class org.axonframework.serializer.bson.StringToDBObjectContentTypeConverter
 
convert(SerializedObject<S>) - Method in class org.axonframework.serializer.ChainedConverter
 
convert(S) - Method in class org.axonframework.serializer.ChainedConverter
 
convert(SerializedObject<S>) - Method in interface org.axonframework.serializer.ContentTypeConverter
Converts the data format of the given original IntermediateRepresentation to the target data type.
convert(S) - Method in interface org.axonframework.serializer.ContentTypeConverter
Converts the given object into another.
convert(Blob) - Method in class org.axonframework.serializer.converters.BlobToInputStreamConverter
 
convert(byte[]) - Method in class org.axonframework.serializer.converters.ByteArrayToInputStreamConverter
 
convert(byte[]) - Method in class org.axonframework.serializer.converters.ByteArrayToStringConverter
 
convert(InputStream) - Method in class org.axonframework.serializer.converters.InputStreamToByteArrayConverter
 
convert(String) - Method in class org.axonframework.serializer.converters.StringToByteArrayConverter
 
convert(byte[]) - Method in class org.axonframework.serializer.json.ByteArrayToJsonNodeConverter
 
convert(JsonNode) - Method in class org.axonframework.serializer.json.JsonNodeToByteArrayConverter
 
convert(Document) - Method in class org.axonframework.serializer.xml.Dom4JToByteArrayConverter
 
convert(InputStream) - Method in class org.axonframework.serializer.xml.InputStreamToDom4jConverter
 
convert(InputStream) - Method in class org.axonframework.serializer.xml.InputStreamToXomConverter
 
convert(Document) - Method in class org.axonframework.serializer.xml.XomToStringConverter
 
ConverterFactory - Interface in org.axonframework.serializer
Interface describing a mechanism that provides instances of ContentTypeConverter for a given source and target data type.
CorrelationAuditDataProvider - Class in org.axonframework.auditing
AuditDataProvider implementation that attaches the command identifier to each Event generated as result of that Command.
CorrelationAuditDataProvider() - Constructor for class org.axonframework.auditing.CorrelationAuditDataProvider
Initializes the CorrelationAuditDataProvider which attaches the Command Identifier to an Event's MetaData using the default key (""command-identifier"").
CorrelationAuditDataProvider(String) - Constructor for class org.axonframework.auditing.CorrelationAuditDataProvider
Initializes the CorrelationAuditDataProvider which attaches the Command Identifier to an Event's MetaData using the given correlationIdKey.
correlationDataFor(T) - Method in interface org.axonframework.correlation.CorrelationDataProvider
Provides a map with the entries to attach as correlation data to generated messages while processing given message.
correlationDataFor(T) - Method in class org.axonframework.correlation.MultiCorrelationDataProvider
 
correlationDataFor(Message) - Method in class org.axonframework.correlation.SimpleCorrelationDataProvider
 
CorrelationDataHolder - Class in org.axonframework.correlation
DataHolder for meta data entries that need to be attached to messages being generated by this thread.
CorrelationDataProvider<T extends Message> - Interface in org.axonframework.correlation
Object defining the the data from a Message that should be attached as correlation data to messages generated as result of the processing of that message.
count() - Method in class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
The number of times to apply the retryPolicy.
createAggregate(Object, DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
 
createAggregate(Object, DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.AggregateFactory
Instantiate the aggregate using the given aggregate identifier and first event.
createAMQPMessage(EventMessage) - Method in interface org.axonframework.eventhandling.amqp.AMQPMessageConverter
Creates an AMQPMessage from given eventMessage.
createAMQPMessage(EventMessage) - Method in class org.axonframework.eventhandling.amqp.DefaultAMQPMessageConverter
 
createAutowiredBean(Class<?>...) - Static method in class org.axonframework.contextsupport.spring.AutowiredBean
Creates an autowired dependency on the given autowiredTypes.
createAutowiredBeanWithFallback(Object, Class<?>...) - Static method in class org.axonframework.contextsupport.spring.AutowiredBean
Creates an autowired dependency on the given autowiredTypes.
createContainer() - Method in class org.axonframework.eventhandling.amqp.spring.DefaultRabbitMqStrategy
 
createContainer() - Method in class org.axonframework.eventhandling.amqp.spring.LegacyRabbitMqStrategy
 
createContainer(SpringAMQPConsumerConfiguration) - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerFactory
Creates a new SimpleMessageListenerContainer, initialized with the properties set on this factory.
createContainer() - Method in interface org.axonframework.eventhandling.amqp.spring.RabbitMqStrategy
Create a new instance of the container
createDocuments(String, Serializer, List<DomainEventMessage>) - Method in class org.axonframework.eventstore.mongo.DocumentPerCommitStorageStrategy
 
createDocuments(String, Serializer, List<DomainEventMessage>) - Method in class org.axonframework.eventstore.mongo.DocumentPerEventStorageStrategy
 
createDocuments(String, Serializer, List<DomainEventMessage>) - Method in interface org.axonframework.eventstore.mongo.StorageStrategy
Generates the DBObject instances that need to be stored for a commit.
createDocuments(String, Serializer, List<DomainEventMessage>) - Method in class org.axonframework.mongo3.eventstore.DocumentPerCommitStorageStrategy
 
createDocuments(String, Serializer, List<DomainEventMessage>) - Method in class org.axonframework.mongo3.eventstore.DocumentPerEventStorageStrategy
 
createDocuments(String, Serializer, List<DomainEventMessage>) - Method in interface org.axonframework.mongo3.eventstore.StorageStrategy
Generates the DBObject instances that need to be stored for a commit.
createDomainEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
 
createDomainEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
Allows for customization of the DomainEventEntry to store.
createDomainEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
Creates an entity representing a Domain Event, which contains the data provided in the parameters, which can be stored using the JPA Entity Manager configured on the JpaEventStore using this factory.
createEventHandlerInvoker(Object) - Method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
Creates a new MessageHandlerInvoker that invokes methods on the given instance.
createFor(Method, Class<?>, ParameterResolverFactory) - Static method in class org.axonframework.common.annotation.MethodMessageHandler
Creates a MethodMessageHandler for the given method, using given explicitPayloadType (if not null) defining the payload of the message it supports.
createGateway(Class<T>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Creates a gateway instance for the given gatewayInterface.
createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.commandhandling.annotation.CurrentUnitOfWorkParameterResolverFactory
 
createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.DefaultParameterResolverFactory
 
createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.MultiParameterResolverFactory
 
createInstance(Annotation[], Class<?>, Annotation[]) - Method in interface org.axonframework.common.annotation.ParameterResolverFactory
If available, creates a ParameterResolver instance that can provide a parameter of type parameterType for a given message.
createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.SimpleResourceParameterResolverFactory
 
createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.SpringBeanParameterResolverFactory
 
createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.eventhandling.annotation.AbstractAnnotatedParameterResolverFactory
 
createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.test.FixtureResourceParameterResolverFactory
 
createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.cache.AbstractCacheAdapter
Creates an adapter for the given cacheEntryListener.
createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.cache.EhCacheAdapter
 
createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.cache.JCacheAdapter
 
createMongo() - Method in class org.axonframework.eventstore.mongo.MongoFactory
Creates a mongo instance based on the provided configuration.
createMongo() - Method in class org.axonframework.mongo3.eventstore.MongoFactory
Creates a mongo instance based on the provided configuration.
createMongoOptions() - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Uses the configured parameters to create a MongoOptions instance.
createMongoOptions() - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Uses the configured parameters to create a MongoOptions instance.
createParameterResolverFactory() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
Creates (or returns) a ParameterResolverFactory which is used by this aggregate root to resolve the parameters for @EventSourcingHandler annotated methods.
createParameterResolverFactory() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
Creates (or returns) a ParameterResolverFactory which is used by this aggregate root to resolve the parameters for @EventSourcingHandler annotated methods.
createReader(Reader) - Method in class org.axonframework.serializer.xml.CompactDriver
 
createReader(InputStream) - Method in class org.axonframework.serializer.xml.CompactDriver
 
createReader(URL) - Method in class org.axonframework.serializer.xml.CompactDriver
 
createReader(File) - Method in class org.axonframework.serializer.xml.CompactDriver
 
createRepository(AggregateFactory<T>, EventStreamDecorator) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
Create a repository instance for an aggregate created by the given aggregateFactory.
createRepository(AggregateFactory<T>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate that is created by the given aggregateFactory.
createRepository(AggregateFactory<T>, EventStreamDecorator) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate that is created by the given aggregateFactory.
createRepositoryDefinition(Element, String, ParserContext, PropertyValue) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser
 
createSaga(Class<T>) - Method in class org.axonframework.saga.GenericSagaFactory
 
createSaga(Class<T>) - Method in interface org.axonframework.saga.SagaFactory
Create a new instance of a Saga of given type.
createSchema() - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
Performs the DDL queries to create the schema necessary for this EventEntryStore implementation.
createSchema() - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
Creates the SQL Schema required to store Sagas and their associations,.
createSerializedDomainEventData(ResultSet) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Reads the current entry of the ResultSet into a SerializedDomainEventData.
createSerializedDomainEventData(ResultSet) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
createSnapshot(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Creates a snapshot event for an aggregate of the given typeIdentifier of which passed events are available in the given eventStream.
createSnapshot(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
 
createSnapshot(String, String) - Method in class org.axonframework.gae.eventstore.GaeSnapshotter
 
createSnapshotEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
 
createSnapshotEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
Allows for customization of the SnapshotEventEntry to store.
createSnapshotEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
Creates an entity representing a Snapshot Event, which contains the data provided in the parameters, which can be stored using the JPA Entity Manager configured on the JpaEventStore using this factory.
createSnapshotterTask(String, Object) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Creates an instance of a task that contains the actual snapshot creation logic.
CreateToDoCommandHandler - Class in org.axonframework.quickstart.handler
 
CreateToDoCommandHandler(Repository<ToDoItem>) - Constructor for class org.axonframework.quickstart.handler.CreateToDoCommandHandler
 
CreateToDoItemCommand - Class in org.axonframework.quickstart.api
Command used to create a new ToDoItem
CreateToDoItemCommand(String, String) - Constructor for class org.axonframework.quickstart.api.CreateToDoItemCommand
 
createUnitOfWork() - Method in class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
 
createUnitOfWork() - Method in interface org.axonframework.unitofwork.UnitOfWorkFactory
Creates a new UnitOfWork instance.
createWriter(Writer) - Method in class org.axonframework.serializer.xml.CompactDriver
 
createWriter(OutputStream) - Method in class org.axonframework.serializer.xml.CompactDriver
 
Criteria - Interface in org.axonframework.eventstore.management
Interface describing the criteria that DomainEvent entries must match against.
CriteriaBuilder - Interface in org.axonframework.eventstore.management
Interface providing access to the criteria API of an Event Store.
currentTime() - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
currentTime() - Method in interface org.axonframework.test.saga.FixtureConfiguration
Returns the time as "known" by the fixture.
CurrentUnitOfWork - Class in org.axonframework.unitofwork
Default entry point to gain access to the current UnitOfWork.
CurrentUnitOfWorkParameterResolverFactory - Class in org.axonframework.commandhandling.annotation
ParameterResolverFactory that add support for the UnitOfWork parameter type in annotated handlers.
CurrentUnitOfWorkParameterResolverFactory() - Constructor for class org.axonframework.commandhandling.annotation.CurrentUnitOfWorkParameterResolverFactory
 
cutoff(DateTime) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
 

D

database() - Method in class org.axonframework.common.mongo.AuthenticatingMongoTemplate
Returns a reference to the Database with the configured database name.
database() - Method in class org.axonframework.mongo3.common.AbstractMongoTemplate
Returns a reference to the Database with the configured database name.
DataSourceConnectionProvider - Class in org.axonframework.common.jdbc
ConnectionProvider implementation that obtains a connection from a given DataSource.
DataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.common.jdbc.DataSourceConnectionProvider
Initialize the Connection Provider, using given dataSource to obtain new connections.
DBObjectHierarchicalStreamReader - Class in org.axonframework.mongo3.serializer.bson
HierarchicalStreamReader implementation that reads from a Mongo DBObject structure that has been created using the DBObjectHierarchicalStreamWriter.
DBObjectHierarchicalStreamReader(DBObject) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
Initialize the reader to read the structure of the given root DBObject.
DBObjectHierarchicalStreamReader - Class in org.axonframework.serializer.bson
HierarchicalStreamReader implementation that reads from a Mongo DBObject structure that has been created using the DBObjectHierarchicalStreamWriter.
DBObjectHierarchicalStreamReader(DBObject) - Constructor for class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
Initialize the reader to read the structure of the given root DBObject.
DBObjectHierarchicalStreamWriter - Class in org.axonframework.mongo3.serializer.bson
HierarchicalStreamWriter implementation that writes objects into a MongoDB DBObject structure.
DBObjectHierarchicalStreamWriter(DBObject) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
Initialize the writer to write the object structure to the given root DBObject.
DBObjectHierarchicalStreamWriter - Class in org.axonframework.serializer.bson
HierarchicalStreamWriter implementation that writes objects into a MongoDB DBObject structure.
DBObjectHierarchicalStreamWriter(DBObject) - Constructor for class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
Initialize the writer to write the object structure to the given root DBObject.
DBObjectToStringContentTypeConverter - Class in org.axonframework.mongo3.serializer.bson
ContentTypeConverter implementation that converts a DBObject structure into a String containing its Binary JSON representation.
DBObjectToStringContentTypeConverter() - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectToStringContentTypeConverter
 
DBObjectToStringContentTypeConverter - Class in org.axonframework.serializer.bson
ContentTypeConverter implementation that converts a DBObject structure into a String containing its Binary JSON representation.
DBObjectToStringContentTypeConverter() - Constructor for class org.axonframework.serializer.bson.DBObjectToStringContentTypeConverter
 
DBObjectXStreamSerializer - Class in org.axonframework.mongo3.serializer.bson
XStream based serializer implementation that serializes objects into a Binary JSON structure.
DBObjectXStreamSerializer() - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer with UTF-8 character set and a default XStream serializer.
DBObjectXStreamSerializer(XStream) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the UTF-8 character set.
DBObjectXStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the UTF-8 character set.
DBObjectXStreamSerializer(Charset) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset.
DBObjectXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
DBObjectXStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset, xStream and revisionResolver instance.
DBObjectXStreamSerializer(Charset, XStream, RevisionResolver, ConverterFactory) - Constructor for class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
DBObjectXStreamSerializer - Class in org.axonframework.serializer.bson
XStream based serializer implementation that serializes objects into a Binary JSON structure.
DBObjectXStreamSerializer() - Constructor for class org.axonframework.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer with UTF-8 character set and a default XStream serializer.
DBObjectXStreamSerializer(XStream) - Constructor for class org.axonframework.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the UTF-8 character set.
DBObjectXStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the UTF-8 character set.
DBObjectXStreamSerializer(Charset) - Constructor for class org.axonframework.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset.
DBObjectXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
DBObjectXStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset, xStream and revisionResolver instance.
DBObjectXStreamSerializer(Charset, XStream, RevisionResolver, ConverterFactory) - Constructor for class org.axonframework.serializer.bson.DBObjectXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
DeadlockException - Exception in org.axonframework.common.lock
Exception indicating that a deadlock has been detected while a thread was attempting to acquire a lock.
DeadlockException(String) - Constructor for exception org.axonframework.common.lock.DeadlockException
Initializes the exception with given message.
declaringClass(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
Returns the class on which the method with name "getter" and parameters of type parameterTypes is declared.
decorateForAppend(String, EventSourcedAggregateRoot, DomainEventStream) - Method in class org.axonframework.eventsourcing.CompositeEventStreamDecorator
 
decorateForAppend(String, EventSourcedAggregateRoot, DomainEventStream) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
 
decorateForAppend(String, EventSourcedAggregateRoot, DomainEventStream) - Method in interface org.axonframework.eventsourcing.EventStreamDecorator
Called when an event stream is appended to the event store.
decorateForRead(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.CompositeEventStreamDecorator
 
decorateForRead(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
 
decorateForRead(String, Object, DomainEventStream) - Method in interface org.axonframework.eventsourcing.EventStreamDecorator
Called when an event stream is read from the event store.
DEFAULT_ASSOC_VALUE_ENTRY_TABLE - Static variable in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
 
DEFAULT_BUFFER_SIZE - Static variable in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
The default size of the buffer in this configuration
DEFAULT_CORRELATION_KEY - Static variable in class org.axonframework.auditing.CorrelationAuditDataProvider
The default meta-data key, which is used when an instance is created using the default constructor
DEFAULT_DOMAINEVENT_TABLE - Static variable in class org.axonframework.eventstore.jdbc.SchemaConfiguration
 
DEFAULT_SAGA_ENTRY_TABLE - Static variable in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
 
DEFAULT_SNAPSHOTEVENT_TABLE - Static variable in class org.axonframework.eventstore.jdbc.SchemaConfiguration
 
DefaultAMQPConsumerConfiguration - Class in org.axonframework.eventhandling.amqp
Implementation of the AMQPConsumerConfiguration that allows the Queue Name to be configured.
DefaultAMQPConsumerConfiguration(String) - Constructor for class org.axonframework.eventhandling.amqp.DefaultAMQPConsumerConfiguration
Initializes the configuration with the given queueName.
DefaultAMQPMessageConverter - Class in org.axonframework.eventhandling.amqp
Default implementation of the AMQPMessageConverter interface.
DefaultAMQPMessageConverter(Serializer) - Constructor for class org.axonframework.eventhandling.amqp.DefaultAMQPMessageConverter
Initializes the AMQPMessageConverter with the given serializer, using a PackageRoutingKeyResolver and requesting durable dispatching.
DefaultAMQPMessageConverter(Serializer, RoutingKeyResolver, boolean) - Constructor for class org.axonframework.eventhandling.amqp.DefaultAMQPMessageConverter
Initializes the AMQPMessageConverter with the given serializer, routingKeyResolver and requesting durable dispatching when durable is true.
DefaultCallbackBehavior - Class in org.axonframework.test.utils
Default implementation of the CallbackBehavior interface.
DefaultCallbackBehavior() - Constructor for class org.axonframework.test.utils.DefaultCallbackBehavior
 
DefaultClusterMetaData - Class in org.axonframework.eventhandling
Default implementation of ClusterMetaData.
DefaultClusterMetaData() - Constructor for class org.axonframework.eventhandling.DefaultClusterMetaData
 
DefaultClusterSelector - Class in org.axonframework.eventhandling
ClusterSelector implementation that always selects the same cluster.
DefaultClusterSelector() - Constructor for class org.axonframework.eventhandling.DefaultClusterSelector
Initializes the DefaultClusterSelector using a SimpleCluster with identifier "default", to which this instance will assign all Event Listeners.
DefaultClusterSelector(Cluster) - Constructor for class org.axonframework.eventhandling.DefaultClusterSelector
Initializes the DefaultClusterSelector to assign the given defaultCluster to each listener.
DefaultCommandGateway - Class in org.axonframework.commandhandling.gateway
Default implementation of the CommandGateway interface.
DefaultCommandGateway(CommandBus, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Initializes a command gateway that dispatches commands to the given commandBus after they have been handles by the given commandDispatchInterceptors.
DefaultCommandGateway(CommandBus, RetryScheduler, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Initializes a command gateway that dispatches commands to the given commandBus after they have been handles by the given commandDispatchInterceptors.
DefaultCommandGateway(CommandBus, RetryScheduler, List<CommandDispatchInterceptor>) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Initializes a command gateway that dispatches commands to the given commandBus after they have been handles by the given commandDispatchInterceptors.
DefaultErrorHandler - Class in org.axonframework.eventhandling.async
An ErrorHandler implementation that returns a fixed RetryPolicy instance when an error occurs.
DefaultErrorHandler(RetryPolicy) - Constructor for class org.axonframework.eventhandling.async.DefaultErrorHandler
Initializes the ErrorHandler, making it return the given retryPolicy when an error occurs.
DefaultEventEntryFactory - Class in org.axonframework.eventstore.jpa
Implementation of the EventEntryFactory that provides the default Axon entities, which store payload and meta data of Events as byte arrays.
DefaultEventEntryFactory() - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
Creates a new instance of the factory which stores the timestamps with the original timezone of the event messages.
DefaultEventEntryFactory(boolean) - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
Creates a new instance of the factory which, when forceUtc true, stores the timestamps converted to UTC timezone.
DefaultEventEntryStore<T> - Class in org.axonframework.eventstore.jdbc
Implementation of the EventEntryStore that stores events in DomainEventEntry table and snapshot events in SnapshotEventEntry table.
DefaultEventEntryStore(DataSource, EventSqlSchema<T>) - Constructor for class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
Initialize the EventEntryStore, fetching connections from the given dataSource and executing SQL statements using given sqlSchema.
DefaultEventEntryStore(ConnectionProvider, EventSqlSchema<T>) - Constructor for class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
Initialize the EventEntryStore, fetching connections from the given connectionProvider and executing SQL statements using given sqlSchema.
DefaultEventEntryStore(ConnectionProvider) - Constructor for class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
Initialize the EventEntryStore using a Generic SQL Schema, and given connectionProvider to obtain connections.
DefaultEventEntryStore<T> - Class in org.axonframework.eventstore.jpa
Implementation of the EventEntryStore that stores events in DomainEventEntry entities and snapshot events in SnapshotEventEntry entities.
DefaultEventEntryStore() - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryStore
Initialize the Event Entry Store, storing timestamps in the system timezone and storing serialized data as byte arrays.
DefaultEventEntryStore(boolean) - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryStore
Initializes the EventEntryStore, storing serialized data as byte arrays, with the possibility to force timestamps to be stored in UTC timezone.
DefaultEventEntryStore(EventEntryFactory<T>) - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryStore
Initializes the EventEntryStore, using the given eventEntryFactory to provide instances of the JPA entities to use for persistence.
DefaultIdentifierFactory - Class in org.axonframework.domain
Default IdentifierFactory implementation that uses generates random java.util.UUID based identifiers.
DefaultIdentifierFactory() - Constructor for class org.axonframework.domain.DefaultIdentifierFactory
 
DefaultInterceptorChain - Class in org.axonframework.commandhandling
Mechanism that takes care of interceptor and event handler execution.
DefaultInterceptorChain(CommandMessage<?>, UnitOfWork, CommandHandler<?>, Iterable<? extends CommandHandlerInterceptor>) - Constructor for class org.axonframework.commandhandling.DefaultInterceptorChain
Initialize the default interceptor chain to dispatch the given command, through the chain, to the handler.
DefaultMongoTemplate - Class in org.axonframework.eventstore.mongo
Default implementation for the MongoTemplate.
DefaultMongoTemplate(Mongo) - Constructor for class org.axonframework.eventstore.mongo.DefaultMongoTemplate
Initializes the MongoTemplate using the given mongoDb for database access, using default database and collection names.
DefaultMongoTemplate(Mongo, String, String, String, String, char[]) - Constructor for class org.axonframework.eventstore.mongo.DefaultMongoTemplate
Creates a template connecting to given mongo instance, and loads events in the collection with given domainEventsCollectionName and snapshot events from snapshotEventsCollectionName, in a database with given databaseName.
DefaultMongoTemplate(Mongo, String, String, String, String, String, char[]) - Constructor for class org.axonframework.eventstore.mongo.DefaultMongoTemplate
Creates a template connecting to given mongo instance, and loads events in the collection with given domainEventsCollectionName and snapshot events from snapshotEventsCollectionName, in a database with given databaseName.
DefaultMongoTemplate - Class in org.axonframework.mongo3.eventstore
Default implementation for the MongoTemplate.
DefaultMongoTemplate(MongoClient) - Constructor for class org.axonframework.mongo3.eventstore.DefaultMongoTemplate
Initializes the MongoTemplate using the given mongo for database access, using default database and collection names.
DefaultMongoTemplate(MongoClient, String, String, String) - Constructor for class org.axonframework.mongo3.eventstore.DefaultMongoTemplate
Creates a template connecting to given mongo instance, and loads events in the collection with given domainEventsCollectionName and snapshot events from snapshotEventsCollectionName, in a database with given databaseName.
DefaultMongoTemplate - Class in org.axonframework.mongo3.saga.repository
MongoTemplate instance providing access to the MongoDB Collection containing stored Sagas.
DefaultMongoTemplate(MongoClient) - Constructor for class org.axonframework.mongo3.saga.repository.DefaultMongoTemplate
Initialize a template for the given mongoDb instance, using default database name ("axonframework") and collection name ("sagas").
DefaultMongoTemplate(MongoClient, String, String) - Constructor for class org.axonframework.mongo3.saga.repository.DefaultMongoTemplate
Creates a template connecting to given mongo instance, and loads sagas in the collection with given sagasCollectionName, in a database with given databaseName.
DefaultMongoTemplate - Class in org.axonframework.saga.repository.mongo
MongoTemplate instance providing access to the MongoDB Collection containing stored Sagas.
DefaultMongoTemplate(Mongo) - Constructor for class org.axonframework.saga.repository.mongo.DefaultMongoTemplate
Initialize a template for the given mongoDb instance, using default database name ("axonframework") and collection name ("sagas").
DefaultMongoTemplate(Mongo, String, String, String, char[]) - Constructor for class org.axonframework.saga.repository.mongo.DefaultMongoTemplate
Creates a template connecting to given mongo instance, and loads sagas in the collection with given sagasCollectionName, in a database with given databaseName.
DefaultParameterResolverFactory - Class in org.axonframework.common.annotation
Factory for the default parameter resolvers.
DefaultParameterResolverFactory() - Constructor for class org.axonframework.common.annotation.DefaultParameterResolverFactory
 
DefaultRabbitMqStrategy - Class in org.axonframework.eventhandling.amqp.spring
Strategy for creating a SimpleMessageListenerContainer instance using the Spring AMQP 1.3 API.
DefaultRabbitMqStrategy() - Constructor for class org.axonframework.eventhandling.amqp.spring.DefaultRabbitMqStrategy
 
DefaultUnitOfWork - Class in org.axonframework.unitofwork
Implementation of the UnitOfWork that buffers all published events until it is committed.
DefaultUnitOfWork() - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWork
Initializes a Unit of Work (without starting it) that is not bound to any transaction.
DefaultUnitOfWork(TransactionManager<?>) - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWork
Initializes a Unit of Work (without starting it) that is binds to the transaction created by the given transactionManager when the Unit of Work starts.
DefaultUnitOfWorkFactory - Class in org.axonframework.unitofwork
UnitOfWorkFactory implementation that creates instances of the DefaultUnitOfWork.
DefaultUnitOfWorkFactory() - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
Initializes the Unit of Work Factory to create Unit of Work that are not bound to any transaction.
DefaultUnitOfWorkFactory(TransactionManager) - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
Initializes the factory to create Unit of Work bound to transactions managed by the given transactionManager
deleteSaga(Saga) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
deleteSaga(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Remove the given saga as well as all known association values pointing to it from the repository.
deleteSaga(Saga) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
deleteSaga(Saga) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
deleteSaga(Saga) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ExactSequenceMatcher
 
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListMatcher
Describes the type of collection expected.
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListWithAllOfMatcher
 
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.SequenceMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.EmptyCollectionMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.ListMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.NullOrVoidMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.PayloadMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.PayloadsMatcher
 
DescriptionUtils - Class in org.axonframework.test.saga
Utility class for creating a description.
deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Deserializes the first object read from the given bytes.
deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.JavaSerializer
 
deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.json.JacksonSerializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.axonframework.serializer.json.JodaDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.axonframework.serializer.json.MetaDataDeserializer
 
deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.MessageSerializer
 
deserialize(SerializedObject<S>) - Method in interface org.axonframework.serializer.Serializer
Deserializes the first object read from the given bytes.
destroy() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
destroy() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
determineLoadFactor() - Static method in class org.axonframework.quickstart.RunDistributedCommandBus
 
determineNumberOfCommandLoops() - Static method in class org.axonframework.quickstart.RunDistributedCommandBus
 
Digester - Class in org.axonframework.common.digest
Utility class for generating hashes for values using several algorithms.
digestHex() - Method in class org.axonframework.common.digest.Digester
Returns the hex representation of the digest of all data that has been provided so far.
DirectExecutor - Class in org.axonframework.common
Simple executor implementation that runs a given Runnable immediately in the calling thread.
DirectExecutor() - Constructor for class org.axonframework.common.DirectExecutor
 
DiscardingIncomingMessageHandler - Class in org.axonframework.eventhandling.replay
IncomingMessageHandler implementation that simply discards all messages dispatch during a replay process.
DiscardingIncomingMessageHandler() - Constructor for class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
 
dispatch(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.CommandBus
Dispatch the given command to the CommandHandler subscribed to that type of command.
dispatch(CommandMessage<?>, CommandCallback<R>) - Method in interface org.axonframework.commandhandling.CommandBus
Dispatch the given command to the CommandHandler subscribed to that type of command.
dispatch(CommandMessage<?>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
 
dispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
 
dispatch(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Dispatch the given command to the CommandHandler subscribed to that type of command.
dispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Dispatch the given command to the CommandHandler subscribed to that type of command.
dispatch(CommandMessage<?>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
 
dispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
 
dispatch(CommandMessage<?>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
dispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
DispatchMessage - Class in org.axonframework.commandhandling.distributed.jgroups
JGroups message that contains a CommandMessage that needs to be dispatched on a remote command bus segment.
DispatchMessage() - Constructor for class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
Default constructor required by the Streamable and Externalizable interfaces.
DispatchMessage(CommandMessage<?>, Serializer, boolean) - Constructor for class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
Initialized a DispatchMessage for the given commandMessage, to be serialized using given serializer.
DisruptorCommandBus - Class in org.axonframework.commandhandling.disruptor
Asynchronous CommandBus implementation with very high performance characteristics.
DisruptorCommandBus(EventStore, EventBus) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Initialize the DisruptorCommandBus with given resources, using default configuration settings.
DisruptorCommandBus(EventStore, EventBus, DisruptorConfiguration) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Initialize the DisruptorCommandBus with given resources and settings.
DisruptorCommandBusBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that parses <disruptor-command-bus> elements in the Spring context
DisruptorCommandBusBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.DisruptorCommandBusBeanDefinitionParser
 
DisruptorConfiguration - Class in org.axonframework.commandhandling.disruptor
Configuration object for the DisruptorCommandBus.
DisruptorConfiguration() - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Initializes a configuration instance with default settings: ring-buffer size: 4096, blocking wait strategy and multi-threaded producer type.
DisruptorRepositoryBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
Bean Definition parsers that parses disruptor-repository elements.
DisruptorRepositoryBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser
 
DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean - Class in org.axonframework.contextsupport.spring
FactoryBean to create repository instances for use with the DisruptorCommandBus
DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean() - Constructor for class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
 
DisruptorUnitOfWork - Class in org.axonframework.commandhandling.disruptor
Specialized UnitOfWork instance for the DisruptorCommandBus.
DisruptorUnitOfWork(boolean) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Creates a new Unit of Work for use in the DisruptorCommandBus.
DistributedCommandBus - Class in org.axonframework.commandhandling.distributed
Implementation of a CommandBus that is aware of multiple instances of a CommandBus working together to spread load.
DistributedCommandBus(CommandBusConnector) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
Initializes the command bus with the given connector and an AnnotationRoutingStrategy.
DistributedCommandBus(CommandBusConnector, RoutingStrategy) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
Initializes the command bus with the given connector and routingStrategy.
doCommit() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
doCommit() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Executes the logic required to commit this unit of work.
doCreateAggregate(Object, DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
Create an uninitialized Aggregate instance with the given aggregateIdentifier.
doCreateAggregate(Object, DomainEventMessage) - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
Create an uninitialized Aggregate instance with the given aggregateIdentifier.
doCreateAggregate(Object, DomainEventMessage) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
DocumentPerCommitStorageStrategy - Class in org.axonframework.eventstore.mongo
Implementation of the StorageStrategy that stores each commit as a single document.
DocumentPerCommitStorageStrategy() - Constructor for class org.axonframework.eventstore.mongo.DocumentPerCommitStorageStrategy
 
DocumentPerCommitStorageStrategy - Class in org.axonframework.mongo3.eventstore
Implementation of the StorageStrategy that stores each commit as a single document.
DocumentPerCommitStorageStrategy() - Constructor for class org.axonframework.mongo3.eventstore.DocumentPerCommitStorageStrategy
 
DocumentPerEventStorageStrategy - Class in org.axonframework.eventstore.mongo
Implementation of the StorageStrategy that stores each event as a separate document.
DocumentPerEventStorageStrategy() - Constructor for class org.axonframework.eventstore.mongo.DocumentPerEventStorageStrategy
 
DocumentPerEventStorageStrategy - Class in org.axonframework.mongo3.eventstore
Implementation of the StorageStrategy that stores each event as a separate document.
DocumentPerEventStorageStrategy() - Constructor for class org.axonframework.mongo3.eventstore.DocumentPerEventStorageStrategy
 
doDelete(T) - Method in class org.axonframework.repository.AbstractRepository
Removes the aggregate from the repository.
doDelete(T) - Method in class org.axonframework.repository.LockingRepository
Verifies whether all locks are valid and delegates to LockingRepository.doDeleteWithLock(org.axonframework.domain.AggregateRoot) to perform actual deleting.
doDeleteWithLock(T) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Delegates to EventSourcingRepository.doSaveWithLock(EventSourcedAggregateRoot), as Event Sourcing generally doesn't delete aggregates (not their events).
doDeleteWithLock(T) - Method in class org.axonframework.eventsourcing.HybridJpaRepository
 
doDeleteWithLock(T) - Method in class org.axonframework.repository.GenericJpaRepository
 
doDeleteWithLock(T) - Method in class org.axonframework.repository.LockingRepository
Perform the actual deleting of the aggregate.
doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
 
doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Deserialize the given serializedObject.
doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serializer.bson.DBObjectXStreamSerializer
 
doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serializer.xml.XStreamSerializer
Deserialize the given serializedObject.
doDispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
 
doDispatch(CommandMessage, CommandCallback<R>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Forces a dispatch of a command.
doDispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Performs the actual dispatching logic.
doHandle(EventMessage<?>) - Method in class org.axonframework.eventhandling.async.EventProcessor
Does the actual processing of the event.
doInsertEventEntry(String, Connection, String, String, long, DateTime, String, String, T, T, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
Creates a statement to insert an entry with given attributes in the given tableName.
doLoad(Object, Long) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
Perform the actual loading of an aggregate.
doLoad(Object, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Perform the actual loading of an aggregate.
doLoad(Object, Long) - Method in class org.axonframework.repository.AbstractRepository
Loads and initialized the aggregate with the given aggregateIdentifier.
doLoad(Object, Long) - Method in class org.axonframework.repository.GenericJpaRepository
 
doLoad(Object, Long) - Method in class org.axonframework.repository.LockingRepository
Perform the actual loading of an aggregate.
Dom4JToByteArrayConverter - Class in org.axonframework.serializer.xml
Converter that converts Dom4j Document instances to a byte array.
Dom4JToByteArrayConverter() - Constructor for class org.axonframework.serializer.xml.Dom4JToByteArrayConverter
 
domainEventCollection() - Method in class org.axonframework.eventstore.mongo.DefaultMongoTemplate
Returns a reference to the collection containing the domain events.
domainEventCollection() - Method in interface org.axonframework.eventstore.mongo.MongoTemplate
Returns a reference to the collection containing the domain events.
domainEventCollection() - Method in class org.axonframework.mongo3.eventstore.DefaultMongoTemplate
Returns a reference to the collection containing the domain events.
domainEventCollection() - Method in interface org.axonframework.mongo3.eventstore.MongoTemplate
Returns a reference to the collection containing the domain events.
DomainEventEntry - Class in org.axonframework.eventstore.jpa
JPA compliant wrapper around a DomainEvent.
DomainEventEntry() - Constructor for class org.axonframework.eventstore.jpa.DomainEventEntry
Default constructor, as required by JPA specification.
DomainEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.DomainEventEntry
Initialize an Event entry for the given event.
DomainEventEntry(String, DomainEventMessage, DateTime, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.DomainEventEntry
Initialize an Event entry for the given event.
domainEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
The name of the DomainEventEntry entity to use when querying for domain events.
domainEventEntryTable() - Method in class org.axonframework.eventstore.jdbc.SchemaConfiguration
 
DomainEventMessage<T> - Interface in org.axonframework.domain
Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain.
DomainEventStream - Interface in org.axonframework.domain
The DomainEventStream represents a stream of historical domain events.
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.JdbcEventStoreBeanDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
doParse(Element, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.JpaRepositoryBeanDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
 
doPublish(List<EventMessage>, Set<EventListener>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.AbstractCluster
Publish the given list of events to the given set of eventListeners, and notify the given eventProcessingMonitor after completion.
doPublish(List<EventMessage>, Set<EventListener>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.async.AsynchronousCluster
 
doPublish(List<EventMessage>, Set<EventListener>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.SimpleCluster
 
doRegisterListener(L) - Method in class org.axonframework.cache.AbstractCacheAdapter
Registers the given listener with the cache implementation
doRegisterListener(CacheEventListener) - Method in class org.axonframework.cache.EhCacheAdapter
 
doRegisterListener(CacheEntryListenerConfiguration) - Method in class org.axonframework.cache.JCacheAdapter
 
doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
Resolve the Routing Key for the given command.
doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
 
doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
 
doRollback(Throwable) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
doRollback(Throwable) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Executes the logic required to commit this unit of work.
doSave(T) - Method in class org.axonframework.repository.AbstractRepository
Performs the actual saving of the aggregate.
doSave(T) - Method in class org.axonframework.repository.LockingRepository
Verifies whether all locks are valid and delegates to LockingRepository.doSaveWithLock(org.axonframework.domain.AggregateRoot) to perform actual storage.
doSaveWithLock(T) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Perform the actual saving of the aggregate.
doSaveWithLock(T) - Method in class org.axonframework.eventsourcing.HybridJpaRepository
 
doSaveWithLock(T) - Method in class org.axonframework.repository.GenericJpaRepository
 
doSaveWithLock(T) - Method in class org.axonframework.repository.LockingRepository
Perform the actual saving of the aggregate.
doSelectCluster(EventListener, Class<?>) - Method in class org.axonframework.eventhandling.AbstractClusterSelector
Select a cluster for the given eventListener, which has the actual class listenerType.
doSelectCluster(EventListener, Class<?>) - Method in class org.axonframework.eventhandling.AnnotationClusterSelector
 
doSelectCluster(EventListener, Class) - Method in class org.axonframework.eventhandling.ClassNamePatternClusterSelector
 
doSelectCluster(EventListener, Class<?>) - Method in class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
 
doSendMessage(Channel, AMQPMessage) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Does the actual publishing of the given body on the given channel.
doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
 
doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Serialize the given object to the given expectedFormat.
doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serializer.bson.DBObjectXStreamSerializer
 
doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serializer.xml.XStreamSerializer
 
doStart() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
doStart() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Performs logic required when starting this UnitOfWork instance.
doUnregisterListener(L) - Method in class org.axonframework.cache.AbstractCacheAdapter
Unregisters the given listener with the cache
doUnregisterListener(CacheEventListener) - Method in class org.axonframework.cache.EhCacheAdapter
 
doUnregisterListener(CacheEntryListenerConfiguration) - Method in class org.axonframework.cache.JCacheAdapter
 
doUpcast(SerializedObject<Document>, UpcastingContext) - Method in class org.axonframework.quickstart.RunUpcaster.ToDoItemUpcaster
 
doUpcast(SerializedType) - Method in class org.axonframework.quickstart.RunUpcaster.ToDoItemUpcaster
 
doUpcast(SerializedObject<T>, UpcastingContext) - Method in class org.axonframework.upcasting.AbstractSingleEntryUpcaster
Upcasts the given intermediateRepresentation into zero or more other representations.
doUpcast(SerializedType) - Method in class org.axonframework.upcasting.AbstractSingleEntryUpcaster
Upcast the given serializedType into its new format.
doUpcast(Upcaster<T>, SerializedObject<?>, List<SerializedType>, UpcastingContext) - Method in class org.axonframework.upcasting.AbstractUpcasterChain
Performs the actual upcasting by the given upcaster on the given sourceObject.
doUpcast(Upcaster<T>, SerializedObject<?>, List<SerializedType>, UpcastingContext) - Method in class org.axonframework.upcasting.LazyUpcasterChain
 
doUpcast(Upcaster<T>, SerializedObject<?>, List<SerializedType>, UpcastingContext) - Method in class org.axonframework.upcasting.SimpleUpcasterChain
 
doWithEvent(DomainEventMessage) - Method in interface org.axonframework.eventstore.EventVisitor
Called for each event loaded by the event store.
doWithEvent(DomainEventMessage) - Method in class org.axonframework.eventstore.supporting.CapturingEventVisitor
 

E

EhCacheAdapter - Class in org.axonframework.cache
Cache implementation that delegates all calls to an EhCache instance.
EhCacheAdapter(Ehcache) - Constructor for class org.axonframework.cache.EhCacheAdapter
Initialize the adapter to forward all call to the given ehCache instance
EMPTY - Static variable in class org.axonframework.upcasting.SimpleUpcasterChain
Represents an empty UpcasterChain.
EmptyCollectionMatcher - Class in org.axonframework.test.matchers
Matches any empty collection.
EmptyCollectionMatcher(String) - Constructor for class org.axonframework.test.matchers.EmptyCollectionMatcher
Creates a matcher of a list of empty items.
EmptyDataProvider - Class in org.axonframework.auditing
Implementation of AuditDataProvider that provides no information (empty map).
EmptyDataProvider() - Constructor for class org.axonframework.auditing.EmptyDataProvider
 
emptyInstance() - Static method in class org.axonframework.domain.MetaData
Returns an empty MetaData instance.
emptyRing() - Static method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns an instance of an empty Ring, which can be used to add members.
emptyStream() - Static method in class org.axonframework.domain.SimpleDomainEventStream
Creates an empty stream.
end() - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Marks the saga as ended.
endNode() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
endNode() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
EndSaga - Annotation Type in org.axonframework.saga.annotation
Indicates that the annotated SagaEventHandler method indicates the end of a Saga instance's lifecycle.
ensureAccessible(T) - Static method in class org.axonframework.common.ReflectionUtils
Makes the given member accessible via reflection if it is not the case already.
ensureCorrectContentType(SerializedObject<S>, Class<T>) - Method in class org.axonframework.upcasting.AbstractUpcasterChain
Converts, if necessary, the given serializedObject, and returns a SerializedObject with given expectedContentType.
ensureIndexes(DBCollection, DBCollection) - Method in class org.axonframework.eventstore.mongo.DocumentPerCommitStorageStrategy
 
ensureIndexes(DBCollection, DBCollection) - Method in class org.axonframework.eventstore.mongo.DocumentPerEventStorageStrategy
 
ensureIndexes() - Method in class org.axonframework.eventstore.mongo.MongoEventStore
Make sure an index is created on the collection that stores domain events.
ensureIndexes(DBCollection, DBCollection) - Method in interface org.axonframework.eventstore.mongo.StorageStrategy
Ensure that the correct indexes are in place.
ensureIndexes(MongoCollection, MongoCollection) - Method in class org.axonframework.mongo3.eventstore.DocumentPerCommitStorageStrategy
 
ensureIndexes(MongoCollection, MongoCollection) - Method in class org.axonframework.mongo3.eventstore.DocumentPerEventStorageStrategy
 
ensureIndexes() - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
Make sure an index is created on the collection that stores domain events.
ensureIndexes(MongoCollection<Document>, MongoCollection<Document>) - Method in interface org.axonframework.mongo3.eventstore.StorageStrategy
Ensure that the correct indexes are in place.
EntityManagerProvider - Interface in org.axonframework.common.jpa
Provides components with an EntityManager to access the persistence mechanism.
entrySet() - Method in class org.axonframework.domain.MetaData
 
EqualFieldsMatcher<T> - Class in org.axonframework.test.matchers
Matcher that will match an Object if all the fields on that Object contain values equal to the same field in the expected instance.
EqualFieldsMatcher(T) - Constructor for class org.axonframework.test.matchers.EqualFieldsMatcher
Initializes an EqualFieldsMatcher that will match an object with equal properties as the given expected object.
EqualFieldsMatcher(T, FieldFilter) - Constructor for class org.axonframework.test.matchers.EqualFieldsMatcher
Initializes an EqualFieldsMatcher that will match an object with equal properties as the given expected object.
equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.Member
 
equals(Object) - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
 
equals(Object) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
 
equals(Object) - Method in class org.axonframework.common.annotation.MethodMessageHandler
 
equals(Object) - Method in class org.axonframework.domain.MetaData
 
Equals - Class in org.axonframework.eventstore.jdbc.criteria
Implementation of the EQUALS operator for a Jdbc Event Store.
Equals(JdbcProperty, Object) - Constructor for class org.axonframework.eventstore.jdbc.criteria.Equals
Initializes an Equals operator matching the given property against the given expression.
equals(Object) - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData.PK
 
Equals - Class in org.axonframework.eventstore.jpa.criteria
Implementation of the EQUALS operator for a JPA Event Store.
Equals(JpaProperty, Object) - Constructor for class org.axonframework.eventstore.jpa.criteria.Equals
Initializes an Equals operator matching the given property against the given expression.
Equals - Class in org.axonframework.eventstore.mongo.criteria
Representation of an Equals operator for Mongo selection criteria.
Equals(MongoProperty, Object) - Constructor for class org.axonframework.eventstore.mongo.criteria.Equals
Creates an equal instance that requires the given property to equal the given expression.
Equals - Class in org.axonframework.mongo3.eventstore.criteria
Representation of an Equals operator for Mongo selection criteria.
Equals(MongoProperty, Object) - Constructor for class org.axonframework.mongo3.eventstore.criteria.Equals
Creates an equal instance that requires the given property to equal the given expression.
equals(Object) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
 
equals(Object) - Method in class org.axonframework.saga.AssociationValue
 
equals(Object) - Method in class org.axonframework.serializer.SerializedMetaData
 
equals(Object) - Method in class org.axonframework.serializer.SimpleSerializedObject
 
equals(Object) - Method in class org.axonframework.serializer.SimpleSerializedType
 
equals(Object) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
equalTo(T) - Static method in class org.axonframework.test.matchers.Matchers
Matches against each event of the same runtime type that has all field values equal to the fields in the expected event.
equalTo(T, FieldFilter) - Static method in class org.axonframework.test.matchers.Matchers
Matches against each event of the same runtime type that has all field values equal to the fields in the expected event.
ErrorHandler - Interface in org.axonframework.eventhandling.async
Interface describing a mechanism that decides what should happen when an asynchronously handled event raises an error.
ErrorHandler - Interface in org.axonframework.saga.annotation
Defines the behavior of a component when an error occurs during Event Processing in a Saga.
EVENT_BUS_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the Event Bus in the scheduler context.
EVENT_JOB_DATA_BINDER_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the EventJobDataBinder in the scheduler context.
EVENT_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
The key used to locate the event in the JobDataMap.
EventBus - Interface in org.axonframework.eventhandling
Specification of the mechanism on which the Event Listeners can subscribe for events and event publishers can publish their events.
EventBusBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
The EventBusBeanDefinitionParser is responsible for parsing the eventBus element from the Axon namespace.
EventBusBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.EventBusBeanDefinitionParser
 
EventBusTerminal - Interface in org.axonframework.eventhandling
Interface describing a mechanism that connects Event Bus clusters.
EventContainer - Class in org.axonframework.domain
Container for events related to a single aggregate.
EventContainer(Object) - Constructor for class org.axonframework.domain.EventContainer
Initialize an EventContainer for an aggregate with the given aggregateIdentifier.
EventCountSnapshotterTrigger - Class in org.axonframework.eventsourcing
Snapshotter trigger mechanism that counts the number of events to decide when to create a snapshot.
EventCountSnapshotterTrigger() - Constructor for class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
 
EventEntry - Class in org.axonframework.gae.eventstore
Class that represents an event to store in the google app engine data store.
EventEntryFactory<T> - Interface in org.axonframework.eventstore.jpa
Interface describing a factory that creates Entities for the JpaEventStore to persist.
EventEntryStore<T> - Interface in org.axonframework.eventstore.jdbc
Interface describing the mechanism that stores Events into the backing data store.
EventEntryStore<T> - Interface in org.axonframework.eventstore.jpa
Interface describing the mechanism that stores Events into the backing data store.
eventFileExists(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
Indicates whether there is a file containing (regular) events for the given aggregateIdentifier of given type.
eventFileExists(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
EventFileResolver - Interface in org.axonframework.eventstore.fs
Interface that allows basic access to InputStreams and appending OutputStreams to event logs for aggregates.
EventFilter - Interface in org.axonframework.integration.adapter
Interface describing an Event Filter.
EventFilter - Interface in org.axonframework.springmessaging.adapter
Interface describing an Event Filter.
EventHandler - Annotation Type in org.axonframework.eventhandling.annotation
Annotation to be placed on methods that can handle events.
EventJobDataBinder - Interface in org.axonframework.eventhandling.scheduling.quartz
Strategy towards reading/writing an Axon EventMessage from/to a Quartz JobDataMap.
EventListener - Interface in org.axonframework.eventhandling
Interface to be implemented by classes that can handle events.
EventListenerOrderComparator - Class in org.axonframework.eventhandling
Comparator implementation that uses an OrderResolver instance to define the expected order of two candidates.
EventListenerOrderComparator(OrderResolver) - Constructor for class org.axonframework.eventhandling.EventListenerOrderComparator
Creates a comparator using given orderResolver to resolve the "order" value.
EventListenerProxy - Interface in org.axonframework.eventhandling
Specialist interface for implementations of an event listener that redirect actual processing to another instance.
EventListenerSubscriptionFailedException - Exception in org.axonframework.eventhandling
Exception indicating that the subscription of an Event Listener has not succeeded.
EventListenerSubscriptionFailedException(String) - Constructor for exception org.axonframework.eventhandling.EventListenerSubscriptionFailedException
Initializes the exception with given descriptive message.
EventListenerSubscriptionFailedException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.EventListenerSubscriptionFailedException
Initializes the exception with given descriptive message and originating cause.
EventListeningMessageChannelAdapter - Class in org.axonframework.integration.adapter
Adapter class that sends Events from an event bus to a Spring Integration Message Channel.
EventListeningMessageChannelAdapter(EventBus, MessageChannel) - Constructor for class org.axonframework.integration.adapter.EventListeningMessageChannelAdapter
Initialize an adapter to forward messages from the given eventBus to the given channel.
EventListeningMessageChannelAdapter(EventBus, MessageChannel, EventFilter) - Constructor for class org.axonframework.integration.adapter.EventListeningMessageChannelAdapter
Initialize an adapter to forward messages from the given eventBus to the given channel.
EventListeningMessageChannelAdapter - Class in org.axonframework.springmessaging.adapter
Adapter class that sends Events from an event bus to a Spring Messaging Message Channel.
EventListeningMessageChannelAdapter(EventBus, MessageChannel) - Constructor for class org.axonframework.springmessaging.adapter.EventListeningMessageChannelAdapter
Initialize an adapter to forward messages from the given eventBus to the given channel.
EventListeningMessageChannelAdapter(EventBus, MessageChannel, EventFilter) - Constructor for class org.axonframework.springmessaging.adapter.EventListeningMessageChannelAdapter
Initialize an adapter to forward messages from the given eventBus to the given channel.
EventMessage<T> - Interface in org.axonframework.domain
Represents a Message wrapping an Event, which is represented by its payload.
EventMessageReader - Class in org.axonframework.eventhandling.io
Reader that reads EventMessage instances written to the underlying input.
EventMessageReader(DataInputStream, Serializer) - Constructor for class org.axonframework.eventhandling.io.EventMessageReader
Creates a new EventMessageReader that reads the data from the given input and deserializes payload and meta data using the given serializer.
EventMessageType - Enum in org.axonframework.eventhandling.io
Enumeration of supported Message Types by the EventMessageWriter and EventMessageReader.
EventMessageWriter - Class in org.axonframework.eventhandling.io
Writer that writes Event Messages onto a an OutputStream.
EventMessageWriter(DataOutput, Serializer) - Constructor for class org.axonframework.eventhandling.io.EventMessageWriter
Creates a new EventMessageWriter writing data to the specified underlying output.
EventProcessingMonitor - Interface in org.axonframework.eventhandling
Interface describing a mechanism that listens for the results of events being processed.
EventProcessingMonitorCollection - Class in org.axonframework.eventhandling
Implementation of the EventProcessingMonitor that delegates to all registered EventProcessingMonitor instances.
EventProcessingMonitorCollection() - Constructor for class org.axonframework.eventhandling.EventProcessingMonitorCollection
 
EventProcessingMonitorSupport - Interface in org.axonframework.eventhandling
Interface indicating that the implementing class is capable of notifying monitors when event processing completes.
EventProcessor - Class in org.axonframework.eventhandling.async
Scheduler that keeps track of (Event processing) tasks that need to be executed sequentially.
EventProcessor(Executor, EventProcessor.ShutdownCallback, ErrorHandler, UnitOfWorkFactory, Set<EventListener>, MultiplexingEventProcessingMonitor) - Constructor for class org.axonframework.eventhandling.async.EventProcessor
Initialize a scheduler using the given executor.
EventProcessor.ProcessingResult - Class in org.axonframework.eventhandling.async
Class indicating the result of Event Processing and the policy for resuming or retrying in case of errors.
EventProcessor.ProcessingResult(RetryPolicy, Throwable) - Constructor for class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
Creates an instance requiring the given retryPolicy and reporting the given (optional) error to indicate a failure.
EventProcessor.ShutdownCallback - Interface in org.axonframework.eventhandling.async
Callback that allows the SequenceManager to receive a notification when this scheduler finishes processing events.
EventPublicationFailedException - Exception in org.axonframework.eventhandling.amqp
Exception indication that an error occurred while publishing an event to an AMQP Broker
EventPublicationFailedException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.amqp.EventPublicationFailedException
Initialize the exception using given descriptive message and cause
EventPublisher - Class in org.axonframework.commandhandling.disruptor
Component of the DisruptorCommandBus that stores and publishes events generated by the command's execution.
EventPublisher(EventStore, EventBus, Executor, TransactionManager, RollbackConfiguration, int) - Constructor for class org.axonframework.commandhandling.disruptor.EventPublisher
Initializes the EventPublisher to publish Events to the given eventStore and eventBus for aggregate of given aggregateType.
EventPublishingMessageChannelAdapter - Class in org.axonframework.integration.adapter
Adapter class that publishes Events from a Spring Integration Message Channel on the Event Bus.
EventPublishingMessageChannelAdapter(EventBus) - Constructor for class org.axonframework.integration.adapter.EventPublishingMessageChannelAdapter
Initialize the adapter to publish all incoming events to the given eventBus.
EventPublishingMessageChannelAdapter(EventBus, EventFilter) - Constructor for class org.axonframework.integration.adapter.EventPublishingMessageChannelAdapter
Initialize the adapter to publish all incoming events to the given eventBus if they accepted by the given filter.
EventPublishingMessageChannelAdapter - Class in org.axonframework.springmessaging.adapter
Adapter class that publishes Events from a Spring Messaging Message Channel on the Event Bus.
EventPublishingMessageChannelAdapter(EventBus) - Constructor for class org.axonframework.springmessaging.adapter.EventPublishingMessageChannelAdapter
Initialize the adapter to publish all incoming events to the given eventBus.
EventPublishingMessageChannelAdapter(EventBus, EventFilter) - Constructor for class org.axonframework.springmessaging.adapter.EventPublishingMessageChannelAdapter
Initialize the adapter to publish all incoming events to the given eventBus if they accepted by the given filter.
EventRegistrationCallback - Interface in org.axonframework.domain
Callback that allows components to be notified of an event being registered with an Aggregate.
EventReplayUnsupportedException - Exception in org.axonframework.eventhandling.replay
Exception that indicates that event replays are not supported by a component.
EventReplayUnsupportedException(String) - Constructor for exception org.axonframework.eventhandling.replay.EventReplayUnsupportedException
Initialize the exception with the given message.
EventScheduler - Interface in org.axonframework.eventhandling.scheduling
Interface towards a mechanism capable of scheduling the publication of events.
EventSchedulerValidator - Class in org.axonframework.test.saga
Helper class for validating evets scheduled in a given event scheduler.
EventSchedulerValidator(StubEventScheduler) - Constructor for class org.axonframework.test.saga.EventSchedulerValidator
Initializes the validator to validate the state of the given eventScheduler.
EventSourcedAggregateRoot<I> - Interface in org.axonframework.eventsourcing
Aggregate that can be initialized using a DomainEventStream.
EventSourcedEntity - Interface in org.axonframework.eventsourcing
Interface towards an Event Sourced Entity that is part of an aggregate, but not its root.
EventSourcedMember - Annotation Type in org.axonframework.eventsourcing.annotation
Field-level annotation that indicates the objects referred to in the field are a child of the current entity.
EventSourcingHandler - Annotation Type in org.axonframework.eventsourcing.annotation
Annotation that marks a method in an Aggregate (either the root, or an entity) as a handler for Events generated by that aggregate.
EventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Abstract repository implementation that allows easy implementation of an Event Sourcing mechanism.
EventSourcingRepository(Class<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initializes a repository with the default locking strategy, using a GenericAggregateFactory to create new aggregate instances of given aggregateType.
EventSourcingRepository(AggregateFactory<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initializes a repository with the default locking strategy, using the given aggregateFactory to create new aggregate instances.
EventSourcingRepository(AggregateFactory<T>, EventStore, LockManager) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initialize a repository with the given locking strategy.
EventSourcingRepository(Class<T>, EventStore, LockManager) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initialize a repository with the given locking strategy, using a GenericAggregateFactory to create new aggregate instances.
EventSqlSchema<T> - Interface in org.axonframework.eventstore.jdbc
Interface describing the operations that the JDBC Event Store needs to do on a backing database.
EventStore - Interface in org.axonframework.eventstore
Abstraction of the event storage mechanism.
EventStoreException - Exception in org.axonframework.eventstore
Indicates that the given events stream could not be stored or read due to an underlying exception.
EventStoreException(String) - Constructor for exception org.axonframework.eventstore.EventStoreException
Initialize the exception with the given message.
EventStoreException(String, Throwable) - Constructor for exception org.axonframework.eventstore.EventStoreException
Initialize the exception with the given message and cause
EventStoreManagement - Interface in org.axonframework.eventstore.management
Interface describing operations useful for management purposes.
EventStreamDecorator - Interface in org.axonframework.eventsourcing
Interface describing a class that can decorates DomainEventStreams when events for aggregates are read or appended.
EventStreamNotFoundException - Exception in org.axonframework.eventstore
Exception indicating that the event store could not find an event stream for a given aggregate type and identifier.
EventStreamNotFoundException(String) - Constructor for exception org.axonframework.eventstore.EventStreamNotFoundException
Initialize the exception with the given message.
EventStreamNotFoundException(String, Object) - Constructor for exception org.axonframework.eventstore.EventStreamNotFoundException
Initialize the exception with a default message for a given aggregate identifier of given type.
EventStreamNotFoundException(String, Throwable) - Constructor for exception org.axonframework.eventstore.EventStreamNotFoundException
Initialize the exception with the given message and cause.
EventTemplate - Class in org.axonframework.eventhandling
Template class that dispatches Events to an EventBus, taking active UnitOfWork into account.
EventTemplate(EventBus) - Constructor for class org.axonframework.eventhandling.EventTemplate
Initialize the template to publish Events through the given eventBus.
EventTemplate(EventBus, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.EventTemplate
Initialize the template to publish Events through the given eventBus.
EventValidator - Class in org.axonframework.test.saga
Helper class for validating events published on a given EventBus.
EventValidator(EventBus, FieldFilter) - Constructor for class org.axonframework.test.saga.EventValidator
Initializes the event validator to monitor the given eventBus.
EventVisitor - Interface in org.axonframework.eventstore
Interface describing an instance of a visitor that receives events for processing.
ExactSequenceMatcher - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers against the event in a list at their respective index.
ExactSequenceMatcher(Matcher<?>...) - Constructor for class org.axonframework.test.matchers.ExactSequenceMatcher
Construct a matcher that will return true if all the given matchers match against the event with the same index in a given List if Events.
exactSequenceOf(Matcher<?>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a List of Events if each of the given matchers matches against the event at the respective index in the list.
execute(Runnable) - Method in class org.axonframework.common.DirectExecutor
Executes the given command immediately in the current thread.
execute(JobExecutionContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
 
expectActiveSagas(int) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Expect the given number of Sagas to be active (i.e.
expectActiveSagas(int) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectAssociationWith(String, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that at least one of the active sagas is associated with the given associationKey and associationValue.
expectAssociationWith(String, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectDispatchedCommandsEqualTo(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that the given commands have been dispatched in exactly the order given.
expectDispatchedCommandsEqualTo(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectDispatchedCommandsMatching(Matcher<? extends Iterable<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that the sagas dispatched commands as defined by the given matcher.
expectDispatchedCommandsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectedRepresentationType() - Method in class org.axonframework.quickstart.RunUpcaster.ToDoItemUpcaster
 
expectedRepresentationType() - Method in interface org.axonframework.upcasting.Upcaster
Returns the type of intermediate representation this upcaster expects.
expectedSourceType() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectToStringContentTypeConverter
 
expectedSourceType() - Method in class org.axonframework.mongo3.serializer.bson.StringToDBObjectContentTypeConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.bson.DBObjectToStringContentTypeConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.bson.StringToDBObjectContentTypeConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.ChainedConverter
 
expectedSourceType() - Method in interface org.axonframework.serializer.ContentTypeConverter
The expected type of input data.
expectedSourceType() - Method in class org.axonframework.serializer.converters.BlobToInputStreamConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.converters.ByteArrayToInputStreamConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.converters.ByteArrayToStringConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.converters.InputStreamToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.converters.StringToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.json.ByteArrayToJsonNodeConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.json.JsonNodeToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.xml.Dom4JToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.xml.InputStreamToDom4jConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.xml.InputStreamToXomConverter
 
expectedSourceType() - Method in class org.axonframework.serializer.xml.XomToStringConverter
 
expectEvents(Object...) - Method in interface org.axonframework.test.ResultValidator
Expect the given set of events to have been stored and published.
expectEvents(Object...) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectEventsMatching(Matcher<? extends Iterable<?>>) - Method in interface org.axonframework.test.ResultValidator
Expect the published events to match the given matcher.
expectEventsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectException(Class<? extends Throwable>) - Method in interface org.axonframework.test.ResultValidator
Expect the given expectedException to occur during command handler execution.
expectException(Matcher<?>) - Method in interface org.axonframework.test.ResultValidator
Expect an exception to occur during command handler execution that matches with the given matcher.
expectException(Class<? extends Throwable>) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectException(Matcher<?>) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectNoAssociationWith(String, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that at none of the active sagas is associated with the given associationKey and associationValue.
expectNoAssociationWith(String, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoDispatchedCommands() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that the sagas did not dispatch any commands.
expectNoDispatchedCommands() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEvents() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that no events are scheduled for publication.
expectNoScheduledEvents() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectPublishedEvents(Object...) - Method in interface org.axonframework.test.ResultValidator
Expect the given set of events to have been published on the events bus.
expectPublishedEvents(Object...) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectPublishedEvents(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that the saga published events on the EventBus in the exact sequence of the given expected events.
expectPublishedEvents(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectPublishedEventsMatching(Matcher<? extends Iterable<?>>) - Method in interface org.axonframework.test.ResultValidator
Expect the list of published event to match the given matcher.
expectPublishedEventsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectPublishedEventsMatching(Matcher<? extends Iterable<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that the saga published events on the EventBus as defined by the given matcher.
expectPublishedEventsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectReturnValue(Object) - Method in interface org.axonframework.test.ResultValidator
Expect the command handler to return the given expectedReturnValue after execution.
expectReturnValue(Matcher<?>) - Method in interface org.axonframework.test.ResultValidator
Expect the command handler to return a value that matches the given matcher after execution.
expectReturnValue(Object) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectReturnValue(Matcher<?>) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectScheduledEvent(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event equal to the given ApplicationEvent has been scheduled for publication after the given duration.
expectScheduledEvent(DateTime, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event equal to the given ApplicationEvent has been scheduled for publication at the given scheduledTime.
expectScheduledEvent(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEvent(DateTime, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventMatching(Duration, Matcher<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event matching the given matcher has been scheduled to be published after the given duration.
expectScheduledEventMatching(DateTime, Matcher<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event matching the given matcher has been scheduled to be published at the given scheduledTime.
expectScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventMatching(DateTime, Matcher<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event of the given eventType has been scheduled for publication after the given duration.
expectScheduledEventOfType(DateTime, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event of the given eventType has been scheduled for publication at the given scheduledTime.
expectScheduledEventOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventOfType(DateTime, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectStoredEvents(Object...) - Method in interface org.axonframework.test.ResultValidator
Expect the given set of events to have been stored in the event store.
expectStoredEvents(Object...) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectStoredEventsMatching(Matcher<? extends Iterable<?>>) - Method in interface org.axonframework.test.ResultValidator
Expect the list of stored event to match the given matcher.
expectStoredEventsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.ResultValidatorImpl
 
expectVoidReturnType() - Method in interface org.axonframework.test.ResultValidator
Explicitly expect a void return type on the given command handler.
expectVoidReturnType() - Method in class org.axonframework.test.ResultValidatorImpl
 
explicitlyUnequal(Object, Object) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the two given objects are not the same, override an equals method that indicates they are not equal, or implements Comparable which indicates the two are not equal.
ExtendedMessageListenerContainer - Class in org.axonframework.eventhandling.amqp.spring
Specialization of the SimpleMessageListenerContainer that allows consumer to be registered as exclusive on a channel.
ExtendedMessageListenerContainer() - Constructor for class org.axonframework.eventhandling.amqp.spring.ExtendedMessageListenerContainer
 
ExtendedUpcaster<T> - Interface in org.axonframework.upcasting
Extension of the Upcaster interface that allows type upcasting to be based on the contents of the serialized object.
extractAssociationValues(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.AbstractSagaManager
Extracts the AssociationValues from the given event as relevant for a Saga of given sagaType.
extractAssociationValues(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
 
extractAssociationValues(EventMessage) - Method in interface org.axonframework.saga.AssociationValueResolver
Extracts an Association Value from the given event.
extractAssociationValues(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.SimpleSagaManager
 
extractEventMessages(DBObject, Object, Serializer, UpcasterChain, boolean) - Method in class org.axonframework.eventstore.mongo.DocumentPerCommitStorageStrategy
 
extractEventMessages(DBObject, Object, Serializer, UpcasterChain, boolean) - Method in class org.axonframework.eventstore.mongo.DocumentPerEventStorageStrategy
 
extractEventMessages(DBObject, Object, Serializer, UpcasterChain, boolean) - Method in interface org.axonframework.eventstore.mongo.StorageStrategy
Extracts the individual Event Messages from the given entry.
extractEventMessages(Document, Object, Serializer, UpcasterChain, boolean) - Method in class org.axonframework.mongo3.eventstore.DocumentPerCommitStorageStrategy
 
extractEventMessages(Document, Object, Serializer, UpcasterChain, boolean) - Method in class org.axonframework.mongo3.eventstore.DocumentPerEventStorageStrategy
 
extractEventMessages(Document, Object, Serializer, UpcasterChain, boolean) - Method in interface org.axonframework.mongo3.eventstore.StorageStrategy
Extracts the individual Event Messages from the given entry.

F

failedMatcherMessage() - Method in class org.axonframework.test.matchers.ListMatcher
The message to append behind a failing matcher.
failedMatcherMessage() - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
fetchAggregateStream(String, Object, long, int) - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
 
fetchAggregateStream(String, Object, long, int) - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
Creates an iterator that iterates through the events for an aggregate of given type and given identifier starting at given firstSequenceNumber.
fetchAggregateStream(String, Object, long, int, EntityManager) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
 
fetchAggregateStream(String, Object, long, int, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Creates an iterator that iterates through the events for an aggregate of given type and given identifier starting at given firstSequenceNumber.
fetchFiltered(String, List<Object>, int) - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
 
fetchFiltered(String, List<Object>, int) - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
Creates an iterator that iterates through the Events that conform to the given sql whereClause.
fetchFiltered(String, Map<String, Object>, int, EntityManager) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
 
fetchFiltered(String, Map<String, Object>, int, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Creates an iterator that iterates through the Events that conform to the given JPA whereClause.
FieldFilter - Interface in org.axonframework.test.matchers
The FieldFilter indicates whether any given Field should be accepted for processing or not.
fieldsOf(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Returns an Iterable of all the fields declared on the given class and its super classes.
FILE_EXTENSION_EVENTS - Static variable in class org.axonframework.eventstore.fs.SimpleEventFileResolver
Describes the file extension used for files containing domain events.
FILE_EXTENSION_SNAPSHOTS - Static variable in class org.axonframework.eventstore.fs.SimpleEventFileResolver
Describes the file extension used for files containing snapshot events.
FileSystemBufferedReaderDomainEventStream - Class in org.axonframework.eventstore.fs
DomainEventStream implementation that reads DomainEvents from the filesystem using an InputStream.
FileSystemBufferedReaderDomainEventStream(InputStream, Serializer, UpcasterChain) - Constructor for class org.axonframework.eventstore.fs.FileSystemBufferedReaderDomainEventStream
Initialize a BufferedReaderDomainEventStream using the given inputStream and serializer.
FileSystemEventMessageReader - Class in org.axonframework.eventstore.fs
Reads events from the file system returns an event in a raw form as SerializedDomainEventData.
FileSystemEventMessageReader(DataInput) - Constructor for class org.axonframework.eventstore.fs.FileSystemEventMessageReader
Creates a new EventMessageReader that reads the data from the given input and deserializes payload and meta data using the given serializer.
FileSystemEventMessageWriter - Class in org.axonframework.eventstore.fs
Writes a domain event message to the given DataOutput.
FileSystemEventMessageWriter(DataOutput, Serializer) - Constructor for class org.axonframework.eventstore.fs.FileSystemEventMessageWriter
Creates a new EventMessageWriter writing data to the specified underlying output.
FileSystemEventStore - Class in org.axonframework.eventstore.fs
Implementation of the EventStore that serializes objects (by default using XStream) and writes them to files to disk.
FileSystemEventStore(EventFileResolver) - Constructor for class org.axonframework.eventstore.fs.FileSystemEventStore
Basic initialization of the event store.
FileSystemEventStore(Serializer, EventFileResolver) - Constructor for class org.axonframework.eventstore.fs.FileSystemEventStore
Initialize the FileSystemEventStore using the given serializer.
FileSystemEventStoreBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
The FileSystemEventStoreBeanDefinitionParser is responsible for parsing the eventStore element form the Axon namespace.
FileSystemEventStoreBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
 
FileSystemSnapshotEventReader - Class in org.axonframework.eventstore.fs
Reads the latest snapshot event from a given FileSystemSnapshotEventReader.snapshotEventFile and skips the correct number of bytes in the given FileSystemSnapshotEventReader.eventFile.
FileSystemSnapshotEventReader(InputStream, InputStream, Serializer) - Constructor for class org.axonframework.eventstore.fs.FileSystemSnapshotEventReader
Creates a snapshot event reader that reads the latest snapshot from the snapshotEventFile.
FileSystemSnapshotEventWriter - Class in org.axonframework.eventstore.fs
Writes snapshot events to the given FileSystemSnapshotEventWriter.snapshotEventFile.
FileSystemSnapshotEventWriter(InputStream, OutputStream, Serializer) - Constructor for class org.axonframework.eventstore.fs.FileSystemSnapshotEventWriter
Creates a snapshot event writer that writes any given snapshotEvent to the given snapshotEventFile.
filterByType(Iterable<?>, Class<T>) - Static method in class org.axonframework.common.CollectionUtils
Returns a list of objects of expectedType contained in the given collection.
find(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
 
find(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.saga.repository.CachingSagaRepository
 
find(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
find(Class<? extends Saga>, AssociationValue) - Method in interface org.axonframework.saga.SagaRepository
Find saga instances of the given type that have been associated with the given associationValue.
findAssociatedSagaIdentifiers(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
findAssociatedSagaIdentifiers(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Finds the identifiers of the sagas of given type associated with the given associationValue.
findAssociatedSagaIdentifiers(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
findAssociatedSagaIdentifiers(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
findAssociatedSagaIdentifiers(Class<? extends Saga>, AssociationValue) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 
findEvents(DBCollection, String, String, long) - Method in class org.axonframework.eventstore.mongo.DocumentPerCommitStorageStrategy
 
findEvents(DBCollection, MongoCriteria) - Method in class org.axonframework.eventstore.mongo.DocumentPerCommitStorageStrategy
 
findEvents(DBCollection, String, String, long) - Method in class org.axonframework.eventstore.mongo.DocumentPerEventStorageStrategy
 
findEvents(DBCollection, MongoCriteria) - Method in class org.axonframework.eventstore.mongo.DocumentPerEventStorageStrategy
 
findEvents(DBCollection, String, String, long) - Method in interface org.axonframework.eventstore.mongo.StorageStrategy
Provides a cursor for access to all events for an aggregate with given aggregateType and aggregateIdentifier, with a sequence number equal or higher than the given firstSequenceNumber.
findEvents(DBCollection, MongoCriteria) - Method in interface org.axonframework.eventstore.mongo.StorageStrategy
Find all events that match the given criteria in the given collection
findEvents(MongoCollection, String, String, long) - Method in class org.axonframework.mongo3.eventstore.DocumentPerCommitStorageStrategy
 
findEvents(MongoCollection<Document>, MongoCriteria) - Method in class org.axonframework.mongo3.eventstore.DocumentPerCommitStorageStrategy
 
findEvents(MongoCollection<Document>, String, String, long) - Method in class org.axonframework.mongo3.eventstore.DocumentPerEventStorageStrategy
 
findEvents(MongoCollection<Document>, MongoCriteria) - Method in class org.axonframework.mongo3.eventstore.DocumentPerEventStorageStrategy
 
findEvents(MongoCollection<Document>, String, String, long) - Method in interface org.axonframework.mongo3.eventstore.StorageStrategy
Provides a cursor for access to all events for an aggregate with given aggregateType and aggregateIdentifier, with a sequence number equal or higher than the given firstSequenceNumber.
findEvents(MongoCollection<Document>, MongoCriteria) - Method in interface org.axonframework.mongo3.eventstore.StorageStrategy
Find all events that match the given criteria in the given collection
findHandlerMethod(Message) - Method in class org.axonframework.common.annotation.MessageHandlerInvoker
Finds the handler method that can handle the given message, or null if no such handler exists.
findHandlerMethod(Message) - Method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
Returns the handler method that handles objects of the given parameterType.
findHandlerMethod(AbstractAnnotatedSaga, EventMessage) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
Finds the handler method on given target for the given event.
findLastSnapshot(DBCollection, String, String) - Method in class org.axonframework.eventstore.mongo.DocumentPerCommitStorageStrategy
 
findLastSnapshot(DBCollection, String, String) - Method in class org.axonframework.eventstore.mongo.DocumentPerEventStorageStrategy
 
findLastSnapshot(DBCollection, String, String) - Method in interface org.axonframework.eventstore.mongo.StorageStrategy
Finds the entry containing the last snapshot event for an aggregate with given aggregateType and aggregateIdentifier in the given collection.
findLastSnapshot(MongoCollection, String, String) - Method in class org.axonframework.mongo3.eventstore.DocumentPerCommitStorageStrategy
 
findLastSnapshot(MongoCollection<Document>, String, String) - Method in class org.axonframework.mongo3.eventstore.DocumentPerEventStorageStrategy
 
findLastSnapshot(MongoCollection<Document>, String, String) - Method in interface org.axonframework.mongo3.eventstore.StorageStrategy
Finds the entry containing the last snapshot event for an aggregate with given aggregateType and aggregateIdentifier in the given collection.
findResolvers(ParameterResolverFactory, Annotation[], Class<?>[], Annotation[][], boolean) - Static method in class org.axonframework.common.annotation.AbstractMessageHandler
Finds ParameterResolvers for the given Member details.
findSagas(String, AssociationValue) - Method in class org.axonframework.saga.repository.AssociationValueMap
Returns the identifiers of the Sagas that have been associated with the given associationValue.
FireEventJob - Class in org.axonframework.eventhandling.scheduling.quartz
Quartz Job that publishes an event on an Event Bus.
FireEventJob() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
 
FIRST - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should be the very first
FixedValueParameterResolver<T> - Class in org.axonframework.common.annotation
ParameterResolver implementation that injects a fixed value.
FixedValueParameterResolver(T) - Constructor for class org.axonframework.common.annotation.FixedValueParameterResolver
Initialize the ParameterResolver to inject the given value for each incoming message.
FixedValueRevisionResolver - Class in org.axonframework.serializer
RevisionResolver implementation that returns a fixed value as revision, regardless of the type of serialized object involved.
FixedValueRevisionResolver(String) - Constructor for class org.axonframework.serializer.FixedValueRevisionResolver
Initializes the FixedValueRevisionResolver to always return the given revision, when asked.
FixtureConfiguration<T extends EventSourcedAggregateRoot> - Interface in org.axonframework.test
Interface describing the operations available on a test fixture in the configuration stage.
FixtureConfiguration - Interface in org.axonframework.test.saga
Interface describing action to perform on a Saga Test Fixture during the configuration phase.
FixtureExecutionException - Exception in org.axonframework.test
Exception indicating that an error occurred that prevented successful execution of a test fixture.
FixtureExecutionException(String) - Constructor for exception org.axonframework.test.FixtureExecutionException
Construct the exception with the given message.
FixtureExecutionException(String, Throwable) - Constructor for exception org.axonframework.test.FixtureExecutionException
Construct the exception with the given message and cause.
FixtureExecutionResult - Interface in org.axonframework.test.saga
Interface towards an object that contains the results of a Fixture execution.
FixtureExecutionResultImpl - Class in org.axonframework.test.saga
Default implementation of FixtureExecutionResult.
FixtureResourceParameterResolverFactory - Class in org.axonframework.test
ParameterResolverFactory implementation that is aware of test-specific use cases.
FixtureResourceParameterResolverFactory() - Constructor for class org.axonframework.test.FixtureResourceParameterResolverFactory
 
Fixtures - Class in org.axonframework.test
Utility class providing access to fixture instances in the Axon Test module.
flush() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
flush() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
forClass(Class<?>) - Static method in class org.axonframework.common.annotation.ClasspathParameterResolverFactory
Creates an instance for the given clazz.
forClassLoader(ClassLoader) - Static method in class org.axonframework.common.annotation.ClasspathParameterResolverFactory
Creates an instance using the given classLoader.
forConstructor(Constructor<T>, ParameterResolverFactory) - Static method in class org.axonframework.commandhandling.annotation.ConstructorCommandMessageHandler
Creates a ConstructorCommandMessageHandler for the given constructor.
forMessage(EventMessage) - Static method in enum org.axonframework.eventhandling.io.EventMessageType
Returns the most specific EventMessageType for the given message.
from(Map<String, ?>) - Static method in class org.axonframework.domain.MetaData
Creates a new MetaData instance from the given metaDataEntries.
fromDBObject(DBObject) - Static method in class org.axonframework.mongo3.serializer.bson.BSONNode
Constructrs a BSONNode structure from the given DBObject structure.
fromDBObject(DBObject) - Static method in class org.axonframework.serializer.bson.BSONNode
Constructrs a BSONNode structure from the given DBObject structure.
fromJobData(JobDataMap) - Method in interface org.axonframework.eventhandling.scheduling.quartz.EventJobDataBinder
Read an EventMessage (or its payload) from a JobDataMap.
fromJobData(JobDataMap) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
 
fromTypeByte(byte) - Static method in enum org.axonframework.eventhandling.io.EventMessageType
Returns the EventMessageType identified by the given typeByte.
FullConcurrencyPolicy - Class in org.axonframework.eventhandling.async
SequencingPolicy that does not enforce any sequencing requirements on event processing.
FullConcurrencyPolicy() - Constructor for class org.axonframework.eventhandling.async.FullConcurrencyPolicy
 
FutureCallback<R> - Class in org.axonframework.commandhandling.callbacks
Command Handler Callback that allows the dispatching thread to wait for the result of the callback, using the Future mechanism.
FutureCallback() - Constructor for class org.axonframework.commandhandling.callbacks.FutureCallback
 

G

GaeEventStore - Class in org.axonframework.gae.eventstore
EventStore implementation that uses Google App Engine's DatastoreService to store Event Streams.
GaeEventStore() - Constructor for class org.axonframework.gae.eventstore.GaeEventStore
Constructs an instance using a GAE compatible instance of the XStreamSerializer.
GaeEventStore(Serializer) - Constructor for class org.axonframework.gae.eventstore.GaeEventStore
Constructs and instance using the given eventSerializer.
GaeSnapshotter - Class in org.axonframework.gae.eventstore
 
GaeSnapshotter(SnapshotEventStore) - Constructor for class org.axonframework.gae.eventstore.GaeSnapshotter
 
GaeXStream - Class in org.axonframework.gae.serializer
 
GaeXStream() - Constructor for class org.axonframework.gae.serializer.GaeXStream
 
GaeXStream(PureJavaReflectionProvider, XppDriver, ClassLoaderReference) - Constructor for class org.axonframework.gae.serializer.GaeXStream
 
GatewayProxyFactory - Class in org.axonframework.commandhandling.gateway
Factory that creates Gateway implementations from custom interface definitions.
GatewayProxyFactory(CommandBus, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Initialize the factory sending Commands to the given commandBus, optionally intercepting them with given dispatchInterceptors.
GatewayProxyFactory(CommandBus, RetryScheduler, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Initialize the factory sending Commands to the given commandBus, optionally intercepting them with given dispatchInterceptors.
GatewayProxyFactory(CommandBus, RetryScheduler, List<CommandDispatchInterceptor>) - Constructor for class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Initialize the factory sending Commands to the given commandBus, optionally intercepting them with given dispatchInterceptors.
GatewayProxyFactory.InvocationHandler<R> - Interface in org.axonframework.commandhandling.gateway
Interface towards the mechanism that handles a method call on a gateway interface method.
generateIdentifier() - Method in class org.axonframework.domain.DefaultIdentifierFactory
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
generateIdentifier() - Method in class org.axonframework.domain.IdentifierFactory
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
GenericAggregateFactory<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Aggregate factory that uses a convention to create instances of aggregates.
GenericAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
Initialize the AggregateFactory for creating instances of the given aggregateType.
GenericAggregateFactory(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
Initialize the AggregateFactory for creating instances of the given aggregateType and using the given parameterResolverFactory to resolve parameters of annotated event handler methods.
GenericCommandMessage<T> - Class in org.axonframework.commandhandling
Implementation of the CommandMessage that takes all properties as constructor parameters.
GenericCommandMessage(T) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
Create a CommandMessage with the given command as payload and empty metaData
GenericCommandMessage(T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
Create a CommandMessage with the given command as payload.
GenericCommandMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
Create a CommandMessage with the given command as payload.
GenericCommandMessage(String, String, T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
Create a CommandMessage with the given command as payload and a custom chosen identifier.
GenericCommandMessage(GenericCommandMessage<T>, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
Copy constructor that allows creation of a new GenericCommandMessage with modified metaData.
GenericDomainEventMessage<T> - Class in org.axonframework.domain
Generic implementation of the DomainEventMessage interface.
GenericDomainEventMessage(Object, long, T) - Constructor for class org.axonframework.domain.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier, with given sequenceNumber and payload.
GenericDomainEventMessage(Object, long, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier, with given sequenceNumber, metaData and payload.
GenericDomainEventMessage(String, DateTime, Object, long, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericDomainEventMessage
Constructor to reconstruct a DomainEventMessage using existing data.
GenericEventMessage<T> - Class in org.axonframework.domain
Generic implementation of the EventMessage interface.
GenericEventMessage(T) - Constructor for class org.axonframework.domain.GenericEventMessage
Creates a GenericEventMessage with given payload, and an empty MetaData.
GenericEventMessage(T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericEventMessage
Creates a GenericEventMessage with given payload and given metaData.
GenericEventMessage(String, DateTime, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericEventMessage
Constructor to reconstruct an EventMessage using existing data.
GenericEventSqlSchema<T> - Class in org.axonframework.eventstore.jdbc
 
GenericEventSqlSchema() - Constructor for class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
Initialize a GenericEventSqlSchema using default settings.
GenericEventSqlSchema(Class<T>) - Constructor for class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
Initialize a GenericEventSqlSchema.
GenericEventSqlSchema(Class<T>, SchemaConfiguration) - Constructor for class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
Initialize a GenericEventSqlSchema.
GenericJpaRepository<T extends AggregateRoot> - Class in org.axonframework.repository
Generic repository implementation that stores JPA annotated aggregates.
GenericJpaRepository(EntityManagerProvider, Class<T>) - Constructor for class org.axonframework.repository.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType.
GenericJpaRepository(EntityManager, Class<T>) - Constructor for class org.axonframework.repository.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType.
GenericJpaRepository(EntityManagerProvider, Class<T>, LockManager) - Constructor for class org.axonframework.repository.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType with an additional lockManager.
GenericJpaRepository(EntityManager, Class<T>, LockManager) - Constructor for class org.axonframework.repository.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType with an additional lockManager.
GenericMessage<T> - Class in org.axonframework.domain
Generic implementation of the Message interface.
GenericMessage(T) - Constructor for class org.axonframework.domain.GenericMessage
Constructs a Message for the given payload using empty meta data.
GenericMessage(T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericMessage
Constructs a Message for the given payload and meta data.
GenericMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericMessage
Constructor to reconstruct a Message using existing data.
GenericSagaFactory - Class in org.axonframework.saga
SagaFactory implementation that uses the default (no-arg) constructor on the saga to initialize.
GenericSagaFactory() - Constructor for class org.axonframework.saga.GenericSagaFactory
 
GenericSagaSqlSchema - Class in org.axonframework.saga.repository.jdbc
Generic SagaSqlSchema implementation, for use in most databases.
GenericSagaSqlSchema() - Constructor for class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
Initialize a GenericSagaSqlSchema using default settings.
GenericSagaSqlSchema(SchemaConfiguration) - Constructor for class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
Initialize a GenericSagaSqlSchema.
get(K) - Method in interface org.axonframework.cache.Cache
Returns an item from the cache, or null if no item was stored under that key
get(K) - Method in class org.axonframework.cache.EhCacheAdapter
 
get(K) - Method in class org.axonframework.cache.JCacheAdapter
 
get(K) - Method in class org.axonframework.cache.NoCache
 
get(K) - Method in class org.axonframework.cache.WeakReferenceCache
 
get() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Waits if necessary for the command handling to complete, and then returns its result.
get(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Waits if necessary for at most the given time for the command handling to complete, and then retrieves its result, if available.
get(Object) - Method in class org.axonframework.domain.MetaData
 
get() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Gets the UnitOfWork bound to the current thread.
getAcknowledgeMode() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the AcknowledgeMode configured in this instance, or the one provided by the default configuration if not explicitly provided.
getActualVersion() - Method in exception org.axonframework.repository.ConflictingAggregateVersionException
Returns the actual version of the aggregate, as loaded by the repository.
getAdapterInterface() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
getAdapterInterface() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Returns the interface that the adapter implements to connect the annotated method to the actual interface definition.
getAdapterInterface() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
getAdviceChain() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Advice Chain configured in this instance, or the one provided by the default configuration if not explicitly provided.
getAfterReplayTimeout() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
 
getAggregate() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Returns the identifier of the aggregate modified in this UnitOfWork.
getAggregateFactory() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Returns the factory used by this repository.
getAggregateIdentifier() - Method in exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
Returns the identifier of the blacklisted aggregate.
getAggregateIdentifier() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the identifier of the aggregate to recover.
getAggregateIdentifier() - Method in interface org.axonframework.domain.DomainEventMessage
Returns the identifier of the Aggregate that generated this DomainEvent.
getAggregateIdentifier() - Method in class org.axonframework.domain.EventContainer
Returns the aggregate identifier assigned to this container.
getAggregateIdentifier() - Method in class org.axonframework.domain.GenericDomainEventMessage
 
getAggregateIdentifier() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
Returns the Aggregate Identifier of the associated event.
getAggregateIdentifier() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
 
getAggregateIdentifier() - Method in class org.axonframework.gae.eventstore.EventEntry
 
getAggregateIdentifier() - Method in exception org.axonframework.repository.AggregateNotFoundException
Returns the identifier of the aggregate that could not be found.
getAggregateIdentifier() - Method in exception org.axonframework.repository.ConflictingAggregateVersionException
Returns the identifier of the aggregate which version is not as expected.
getAggregateIdentifier() - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
 
getAggregateIdentifier() - Method in interface org.axonframework.serializer.SerializedDomainEventData
Returns the Identifier of the Aggregate to which the Event was applied.
getAggregateIdentifier() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
getAggregateIdentifier() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
 
getAggregateIdentifier() - Method in interface org.axonframework.upcasting.UpcastingContext
Returns the Identifier of the Aggregate to which the Event owning the object to upcast, was applied.
getAggregateIdentifier() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
 
getAggregateRoot() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Returns the reference to the root of the aggregate this entity is a member of.
getAggregateType() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Returns the type identifier of the aggregate handled in this unit of work.
getAggregateType() - Method in interface org.axonframework.eventsourcing.AggregateFactory
Returns the type of aggregate this factory creates.
getAggregateType() - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
 
getAggregateType() - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
getAggregateType() - Method in class org.axonframework.repository.AbstractRepository
Returns the aggregate type stored by this repository.
getAnnotation(Class<A>) - Method in class org.axonframework.commandhandling.annotation.ConstructorCommandMessageHandler
 
getAnnotation(Class<T>) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
Returns the member-level annotation of given annotationType, or null if no such annotation is present.
getAnnotation(Class<T>) - Method in class org.axonframework.common.annotation.MethodMessageHandler
 
getAnnotation(Annotation[], Class<T>) - Static method in class org.axonframework.common.CollectionUtils
Finds an annotation of given annotationType from the given annotations.
getApplicationContext() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Returns the ApplicationContext this Bean Post Processor is registered in.
getApplicationContext() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerFactory
Returns the application context in which this bean is defined.
getAssociationValue(EventMessage) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
The AssociationValue to find the saga instance with, or null if no AssociationValue can be found on the given eventMessage.
getAssociationValue() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
Returns the association value contained in this entry.
getAssociationValues() - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
 
getAssociationValues() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Returns all association values that could potentially link a saga instance with the incoming event.
getAssociationValues() - Method in interface org.axonframework.saga.Saga
Returns a view on the Association Values for this saga instance.
getAttribute(String) - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Returns the value of the attribute with given name.
getAttribute(String) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttribute(int) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttribute(String) - Method in class org.axonframework.serializer.bson.BSONNode
Returns the value of the attribute with given name.
getAttribute(String) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttribute(int) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttributeCount() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttributeCount() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttributeName(int) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttributeName(int) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttributeNames() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
getAttributeNames() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
getBeanClass() - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Returns the type of bean to be created by this BeanDefinitionParser.
getBeanClass() - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.JdbcEventStoreBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.JpaRepositoryBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
 
getBeanClass() - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
 
getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.contextsupport.spring.SpringContextParameterResolverFactoryBuilder
Create, if necessary, a bean definition for a ParameterResolverFactory and returns the reference to bean for use in other Bean Definitions.
getBody() - Method in class org.axonframework.eventhandling.amqp.AMQPMessage
Returns the body of this message
getBufferSize() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the buffer size to use.
getCache() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the cache used to store Aggregates loaded by the DisruptorCommandBus.
getCallback() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the CommandCallback instance for the executed command.
getCharset() - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Returns the character set used to convert character to bytes and vice versa.
getChildEntities() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Returns a collection of event sourced entities directly referenced by this entity.
getChildEntities() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Returns a collection of event sourced entities directly referenced by this entity.
getChildEntities() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
 
getChildEntities() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
 
getChildEntities(Object) - Method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
Returns the child entities of given instance.
getChildEntities() - Method in class org.axonframework.quickstart.handler.ToDoItem
 
getCommand() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the CommandMessage to be executed.
getCommandBus() - Method in interface org.axonframework.test.FixtureConfiguration
Returns the command bus used by this fixture.
getCommandBus() - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
getCommandHandlerCount() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
Returns the amount of registered handlers.
getCommandHandlerCount() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
Returns the amount of registered handlers.
getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
Returns the identifier of the command carried by this instance.
getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
Returns the identifier of the command for which this message is a reply.
getCommandMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
Returns the CommandMessage wrapped in this Message.
getCommandName() - Method in interface org.axonframework.commandhandling.CommandMessage
Returns the name of the command to execute.
getCommandName() - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
getCommandNames() - Method in class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
Returns a read-only view on the Command Names supported by the joining member.
getCommandTargetResolver() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the CommandTargetResolver that is used to find out which Aggregate is to be invoked for a given Command.
getConcurrentConsumers() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Concurrent Consumers configured in this instance, or the one provided by the default configuration if not explicitly provided.
getConnection() - Method in interface org.axonframework.common.jdbc.ConnectionProvider
Returns a connection, ready for use.
getConnection() - Method in class org.axonframework.common.jdbc.DataSourceConnectionProvider
 
getConnection() - Method in class org.axonframework.common.jdbc.SpringDataSourceConnectionProvider
 
getConnection() - Method in class org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper
 
getConnectionsPerHost() - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Getter for connectionsPerHost.
getConnectionsPerHost() - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Getter for connectionsPerHost.
getConnectionTimeout() - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Connection time out in milli seconds for doing something in mongo.
getConnectionTimeout() - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Connection time out in milli seconds for doing something in mongo.
getConsistentHash() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
Returns the consistent hash on which current assignment of commands to nodes is being executed.
getConstructorHandlers() - Method in class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
Returns a list of constructor handlers on the given aggregate type.
getContentType() - Method in class org.axonframework.serializer.SerializedMetaData
 
getContentType() - Method in interface org.axonframework.serializer.SerializedObject
Returns the type of this representation's data.
getContentType() - Method in class org.axonframework.serializer.SimpleSerializedObject
 
getConverter(Class<S>, Class<T>) - Method in class org.axonframework.serializer.ChainingConverterFactory
 
getConverter(Class<S>, Class<T>) - Method in interface org.axonframework.serializer.ConverterFactory
Returns a converter that is capable of converting IntermediateRepresentation object containing the given sourceContentType to the given targetContentType.
getConverterFactory() - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Returns the ConverterFactory used by this serialized.
getConverterFactory() - Method in class org.axonframework.serializer.JavaSerializer
 
getConverterFactory() - Method in class org.axonframework.serializer.json.JacksonSerializer
 
getConverterFactory() - Method in class org.axonframework.serializer.MessageSerializer
 
getConverterFactory() - Method in interface org.axonframework.serializer.Serializer
Returns the converter factory used by this Serializer to convert between serialized representations.
getCoolingDownPeriod() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the cooling down period for the shutdown of the DisruptorCommandBus, in milliseconds.
getCorrelationData() - Static method in class org.axonframework.correlation.CorrelationDataHolder
Returns the correlation data attached to the current thread.
getCreationHandler() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Returns the event handler which is used to create a new saga instance based on the incoming event.
getCreationPolicy() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Returns the creation policy of the inspected method.
getCreationPolicy() - Method in class org.axonframework.saga.SagaInitializationPolicy
Returns the creation policy
getCurrentDateTime() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Returns the "Current Date Time" as used by the scheduler.
getData() - Method in class org.axonframework.serializer.SerializedMetaData
 
getData() - Method in interface org.axonframework.serializer.SerializedObject
The actual data of the serialized object.
getData() - Method in class org.axonframework.serializer.SimpleSerializedObject
 
getDataType() - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
 
getDataType() - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
Returns the type used to store serialized payloads.
getDataType() - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Returns the type used to store serialized payloads.
getDataType() - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
getDataType() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
 
getDataType() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
 
getDataType() - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
Returns the type used to store serialized payloads.
getDataType() - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Returns the type used to store serialized payloads.
getDeadline() - Method in class org.axonframework.quickstart.RunUpcaster.NewToDoItemWithDeadlineCreatedEvent
 
getDefinedPayload(T) - Method in class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
Returns the payload type configured on the given annotated method.
getDelegates() - Method in class org.axonframework.common.annotation.MultiParameterResolverFactory
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
getDescription() - Method in class org.axonframework.quickstart.api.CreateToDoItemCommand
 
getDescription() - Method in class org.axonframework.quickstart.api.ToDoItemCreatedEvent
 
getDescription() - Method in class org.axonframework.quickstart.RunUpcaster.NewToDoItemWithDeadlineCreatedEvent
 
getDispatchedCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
Returns a list with all commands that have been dispatched by this command bus.
getDispatchInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the dispatch interceptors for the DisruptorCommandBus.
getDomainEvent(Object, Serializer, UpcasterChain, boolean) - Method in class org.axonframework.gae.eventstore.EventEntry
Returns the actual DomainEvent from the EventEntry using the provided Serializer.
getDomainEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
 
getDomainEventEntryEntityName() - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
Returns the entity name of the Domain Event Entry provided by this factory.
getEntityManager() - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
 
getEntityManager() - Method in interface org.axonframework.common.jpa.EntityManagerProvider
Returns the EntityManager instance to use.
getEntityManager() - Method in class org.axonframework.common.jpa.SimpleEntityManagerProvider
 
getError(Serializer) - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
Returns the error of the command processing.
getError() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
Returns the exception that caused the processing to fail
getErrorHandler() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the ErrorHandler configured in this instance, or the one provided by the default configuration if not explicitly provided.
getEvent() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
The Event scheduled for publication.
getEvent() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
getEventBus() - Method in interface org.axonframework.test.FixtureConfiguration
Returns the event bus used by this fixture.
getEventBus() - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
getEventIdentifier() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
 
getEventIdentifier() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
 
getEventIdentifier() - Method in class org.axonframework.gae.eventstore.EventEntry
 
getEventIdentifier() - Method in interface org.axonframework.serializer.SerializedDomainEventData
Returns the identifier of the serialized event.
getEventIdentifier() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
 
getEventList() - Method in class org.axonframework.domain.EventContainer
Returns an unmodifiable version of the backing list of events.
getEventsToPublish() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Returns the events that need to be published as part of this Unit of Work.
getEventStore() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Returns the event store this snapshotter uses to load domain events and store snapshot events.
getEventStore() - Method in interface org.axonframework.test.FixtureConfiguration
Returns the event store used by this fixture.
getEventStore() - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
getEventsToStore() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Returns the events that need to be stored as part of this Unit of Work.
getEventStream() - Method in class org.axonframework.domain.EventContainer
Read the events inside this container using a DomainEventStream.
getExceptionResult() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the exception that occurred while processing the incoming command, or null if processing did not result in an exception or if execution is not yet finished.
getExclusive() - Method in interface org.axonframework.eventhandling.amqp.AMQPConsumerConfiguration
Indicates whether this Cluster wishes to be an exclusive consumer on a Queue.
getExclusive() - Method in class org.axonframework.eventhandling.amqp.DefaultAMQPConsumerConfiguration
 
getExclusive() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
 
getExecutor() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the Executor providing the processing resources (Threads) for the DisruptorCommandBus.
getExecutor() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Returns the executor that executes snapshot taking tasks.
getExpectedVersion() - Method in exception org.axonframework.repository.ConflictingAggregateVersionException
Returns the version expected by the component loading the aggregate.
getFailedField() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
Returns the field that failed comparison, if any.
getFailedFieldActualValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
Returns the actual value of a failed field comparison, if any.
getFailedFieldExpectedValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
Returns the expected value of a failed field comparison, if any.
getFieldValue(Field, Object) - Static method in class org.axonframework.common.ReflectionUtils
Returns the value of the given field in the given object.
getGroupIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Returns the Quartz group identifier.
getHandlers() - Method in class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
Returns the list of handlers found on target type.
getHandlers() - Method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
Returns the list of handlers found on target type.
getHandlers() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Returns the handler that can process the published Event.
getHandlerTypes() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
Returns a list with the names of the types of the registered handlers.
getHandlerTypes() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
Returns a list with names of the registered handlers.
getId() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
The unique identifier of this entry.
getIdentifier() - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
getIdentifier() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
Returns the identifier of the targeted Aggregate.
getIdentifier() - Method in interface org.axonframework.domain.AggregateRoot
Returns the identifier of this aggregate.
getIdentifier() - Method in interface org.axonframework.domain.EventMessage
Returns the identifier of this event.
getIdentifier() - Method in class org.axonframework.domain.GenericMessage
 
getIdentifier() - Method in interface org.axonframework.domain.Message
Returns the identifier of this message.
getIdentifier() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
 
getIdentifier(AbstractAnnotatedAggregateRoot<I>) - Method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
Returns the identifier of the given aggregateRoot.
getIdentifier() - Method in class org.axonframework.quickstart.handler.ToDoItem
 
getIdentifier() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
getIdentifier() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
getIdentifier() - Method in class org.axonframework.serializer.SerializedEventMessage
 
getIdentifier() - Method in class org.axonframework.serializer.SerializedMessage
 
getInitialAssociationValue() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Returns the association to assign to an event when handling an incoming event that creates a Saga.
getInitialAssociationValue() - Method in class org.axonframework.saga.SagaInitializationPolicy
Returns the initial association value for a newly created saga.
getInspector(Class<?>, ParameterResolverFactory) - Static method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
Returns (or creates) an inspector for the given entityType.
getInstance(Class<?>, Class<T>, ParameterResolverFactory, boolean) - Static method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
Returns a MethodMessageHandlerInspector for the given handlerClass that contains handler methods annotated with the given annotationType.
getInstance(Class<?>, ParameterResolverFactory, boolean, HandlerDefinition<? super Method>) - Static method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
Returns a MethodMessageHandlerInspector for the given handlerClass that contains handler methods annotated with the given annotationType.
getInstance() - Static method in class org.axonframework.common.annotation.PriorityAnnotationComparator
Returns the instance of the comparator.
getInstance() - Static method in class org.axonframework.common.IdentifierValidator
Returns the singleton instance of the IdentifierValidator.
getInstance() - Static method in class org.axonframework.domain.IdentifierFactory
Returns an instance of the IdentifierFactory discovered on the classpath.
getInstance(MethodMessageHandler) - Static method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Create a SagaMethodMessageHandler for the given methodHandler.
getInstance(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
Returns a SagaMethodMessageHandlerInspector for the given sagaType.
getInvocationInterceptorChain() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the InterceptorChain for the invocation process registered with this entry, or null if none is available.
getInvokerId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the Identifier of the invoker that is chosen to handle this entry.
getInvokerInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the interceptors for the DisruptorCommandBus.
getInvokerThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the number of threads to use for Command Handler invocation.
getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Returns the Quartz job identifier.
getKey() - Method in class org.axonframework.saga.AssociationValue
Returns the key of this association value.
getLastCommittedEventSequenceNumber() - Method in class org.axonframework.domain.AbstractAggregateRoot
Returns the sequence number of the last committed event, or null if no events have been committed before.
getLastCommittedSequenceNumber() - Method in class org.axonframework.domain.EventContainer
Returns the sequence number of the last committed event, or null if no events have been committed.
getLastSeparator() - Method in class org.axonframework.test.matchers.ListMatcher
The separator to use between the two last events.
getLastSeparator() - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
getLastSequenceNumber() - Method in class org.axonframework.domain.EventContainer
Returns the sequence number of the event last added to this container.
getListenerCount() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
Returns the amount of registered listeners.
getListenerCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
Returns the amount of registered listeners.
getListenerTypes() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
Returns the list of names of the registered listeners.
getListenerTypes() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
Returns a list of simple class names (class name without its package) of the registered listeners.
getLoadFactor() - Method in class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
Returns the loadFactor the member wishes to join with.
getLockManagerType() - Method in enum org.axonframework.contextsupport.spring.LockingStrategy
Returns the type of LockManager that belongs to this strategy.
getManagedSagaTypes() - Method in class org.axonframework.saga.AbstractSagaManager
Returns the set of Saga types managed by this instance.
getMatchers() - Method in class org.axonframework.test.matchers.ListMatcher
Returns a read-only list of Matchers, in the order they were provided in the constructor.
getMaxWaitTime() - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
get the maximum time a blocked thread that waits for a connection should wait.
getMaxWaitTime() - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
get the maximum time a blocked thread that waits for a connection should wait.
getMember(String, String) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the member for the given item, that supports given commandType.
getMembers() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the set of members part of this hash ring.
getMembers() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
Returns the set of members currently registered with the connector.
getMembers() - Method in class org.axonframework.eventhandling.AbstractCluster
Returns a read-only view on the members in the cluster.
getMembers() - Method in interface org.axonframework.eventhandling.Cluster
Returns a read-only view on the members in the cluster.
getMembers() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
 
getMessageHandlers(EventMessage) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
Find the configuration for the handlers for the given event.
getMessageIdentifier() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
 
getMessageIdentifier() - Method in interface org.axonframework.upcasting.UpcastingContext
Returns the identifier of the message wrapping the object to upcast.
getMessagePropertiesConverter() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the MessagePropertiesConverter configured in this instance, or the one provided by the default configuration if not explicitly provided.
getMetaData() - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
getMetaData() - Method in class org.axonframework.domain.GenericMessage
 
getMetaData() - Method in interface org.axonframework.domain.Message
Returns the meta data for this event.
getMetaData() - Method in class org.axonframework.eventhandling.AbstractCluster
 
getMetaData() - Method in interface org.axonframework.eventhandling.Cluster
Returns the MetaData of this Cluster.
getMetaData() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
 
getMetaData() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntry
 
getMetaData() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
 
getMetaData() - Method in class org.axonframework.gae.eventstore.EventEntry
 
getMetaData() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
getMetaData() - Method in interface org.axonframework.serializer.SerializedDomainEventData
Returns the serialized data of the MetaData of the serialized Event.
getMetaData() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
getMetaData() - Method in class org.axonframework.serializer.SerializedEventMessage
 
getMetaData() - Method in class org.axonframework.serializer.SerializedMessage
 
getMetaData() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
 
getMetaData() - Method in interface org.axonframework.upcasting.UpcastingContext
Returns the meta data of the message wrapping the object being upcast.
getMetaData() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
 
getMethod() - Method in class org.axonframework.common.annotation.MethodMessageHandler
Returns the Method backing this handler.
getMethodName() - Method in class org.axonframework.common.annotation.MethodMessageHandler
Returns the name of the method backing this handler.
getMillis() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
getName() - Method in class org.axonframework.eventhandling.AbstractCluster
 
getName() - Method in interface org.axonframework.eventhandling.Cluster
Returns the name of this cluster.
getName() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
 
getName() - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
Returns the name of the property.
getName() - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
Returns the name of the property.
getName() - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Returns the name of the current node
getName() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Returns the name of the handler.
getName() - Method in class org.axonframework.serializer.bson.BSONNode
Returns the name of the current node
getName() - Method in interface org.axonframework.serializer.SerializedType
Returns the name of the serialized type.
getName() - Method in class org.axonframework.serializer.SimpleSerializedType
 
getNewSaga() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Returns the new Saga instance that should be used when processing an Event that creates a new Saga instance
getNodeName() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
Returns the name of this node in the cluster, or null if this member is not connected.
getNodeName() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
getNodeName() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
getObject() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
 
getObject() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
getObject() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
 
getObject() - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
 
getObject() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
getObject() - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
 
getObject() - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
 
getObject() - Method in class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
 
getObject() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
getObject() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
getObject() - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
 
getObject() - Method in class org.axonframework.gae.serializer.XStreamFactory
 
getObject() - Method in class org.axonframework.serializer.LazyDeserializingObject
De-serializes the object and returns the result.
getObjectMapper() - Method in class org.axonframework.serializer.json.JacksonSerializer
Returns the ObjectMapper used by this serializer, allowing for configuration of the serialization settings.
getObjectType() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
 
getObjectType() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
getObjectType() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
 
getObjectType() - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
 
getObjectType() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
getObjectType() - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
 
getObjectType() - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
 
getObjectType() - Method in class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
 
getObjectType() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
getObjectType() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
getObjectType() - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
 
getObjectType() - Method in class org.axonframework.gae.serializer.XStreamFactory
 
getParameterResolverFactory() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
Returns the ParameterResolverFactory used by this inspector to resolve values for handler parameters
getParameters() - Method in class org.axonframework.eventstore.jdbc.criteria.ParameterRegistry
Returns a map containing the key-value pairs, where each key is the parameter name, and the value the expression to be inserted as parameter.
getParameters() - Method in class org.axonframework.eventstore.jpa.criteria.ParameterRegistry
Returns a map containing the key-value pairs, where each key is the parameter name, and the value the expression to be inserted as parameter.
getParameterValueResolvers() - Method in class org.axonframework.common.annotation.AbstractMessageHandler
Returns the parameter resolvers provided at construction time.
getPayload() - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
getPayload() - Method in class org.axonframework.domain.GenericMessage
 
getPayload() - Method in interface org.axonframework.domain.Message
Returns the payload of this Event.
getPayload() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntry
 
getPayload() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
 
getPayload() - Method in class org.axonframework.gae.eventstore.EventEntry
 
getPayload() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
getPayload() - Method in interface org.axonframework.serializer.SerializedDomainEventData
Returns the serialized data of the Event Message's payload.
getPayload() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
getPayload() - Method in class org.axonframework.serializer.SerializedEventMessage
 
getPayload() - Method in class org.axonframework.serializer.SerializedMessage
 
getPayload() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
 
getPayloadType() - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
getPayloadType() - Method in class org.axonframework.common.annotation.AbstractMessageHandler
Returns the type of payload this handler expects.
getPayloadType() - Method in class org.axonframework.domain.GenericMessage
 
getPayloadType() - Method in interface org.axonframework.domain.Message
Returns the type of the payload.
getPayloadType() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
Returns the payload type of the event message stored in this entry.
getPayloadType() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
getPayloadType() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
getPayloadType() - Method in class org.axonframework.serializer.SerializedEventMessage
 
getPayloadType() - Method in class org.axonframework.serializer.SerializedMessage
 
getPhase() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
getPhase() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
 
getPhase() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
 
getPhase() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
getPhase() - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
getPrefetchCount() - Method in interface org.axonframework.eventhandling.amqp.AMQPConsumerConfiguration
Indicates how many messages this Cluster's connector may read read from the Queue before expecting messages to be acknowledged.
getPrefetchCount() - Method in class org.axonframework.eventhandling.amqp.DefaultAMQPConsumerConfiguration
 
getPrefetchCount() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Prefetch Count configured in this instance, or the one provided by the default configuration if not explicitly provided.
getPriority() - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
 
getPriority() - Method in class org.axonframework.common.property.PropertyAccessStrategy
The priority of this strategy.
getPriority() - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
 
getProducerType() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the producer type to use.
getProperties() - Method in class org.axonframework.eventhandling.amqp.AMQPMessage
Returns the additional properties to dispatch this Message with
getProperty(Class<T>, String) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
Iterates over all known PropertyAccessStrategy implementations to create a Property instance for the given parameters.
getProperty(String) - Method in interface org.axonframework.eventhandling.ClusterMetaData
Returns the property stored using the given key.
getProperty(String) - Method in class org.axonframework.eventhandling.DefaultClusterMetaData
 
getPublishedEvent() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Returns the event that has been published on the EventBus.
getPublisherId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the Identifier of the publisher that is chosen to handle this entry.
getPublisherInterceptorChain() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the InterceptorChain for the publication process registered with this entry, or null if none is available.
getPublisherInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the interceptors for the DisruptorCommandBus.
getPublisherThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the number of threads to use for storing and publication of generated Events.
getQueueName() - Method in interface org.axonframework.eventhandling.amqp.AMQPConsumerConfiguration
Returns the Queue Name the Cluster should be connected to, or null if no explicit cluster is configured.
getQueueName() - Method in class org.axonframework.eventhandling.amqp.DefaultAMQPConsumerConfiguration
 
getQueueName() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
 
getReader(Class<?>) - Method in class org.axonframework.serializer.json.JacksonSerializer
Provides the ObjectReader, with which objects are read from the JSON form.
getReceivedCommandCount() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
Returns the amount of received commands from the beginning of starting up or after the last reset.
getReceivedCommandCount() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
Returns the amount of received commands.
getReceivedEventsCount() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
Returns the amount of received events, from the beginning or after the last reset.
getReceivedEventsCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
Returns the amount of received events.
getReceiveTimeout() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Receive Timeout configured in this instance, or the one provided by the default configuration if not explicitly provided.
getRecoveryInterval() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Recovery Interval configured in this instance, or the one provided by the default configuration if not explicitly provided.
getRepository(String) - Static method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
Returns the Repository instance for Aggregate with given typeIdentifier used by the CommandHandlerInvoker that is running on the current thread.
getRepository() - Method in interface org.axonframework.test.FixtureConfiguration
Returns the repository used by this fixture.
getRepository() - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
getRescheduleCommandsOnCorruptState() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Indicates whether commands that failed due to potentially corrupt Aggregate state should be automatically rescheduled for processing.
getResolver() - Method in class org.axonframework.eventhandling.annotation.AbstractAnnotatedParameterResolverFactory
 
getResolver() - Method in class org.axonframework.eventhandling.annotation.SequenceNumberParameterResolverFactory
 
getResolver() - Method in class org.axonframework.eventhandling.annotation.TimestampParameterResolverFactory
 
getResource(String) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
getResource(String) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
getResource(String) - Method in interface org.axonframework.unitofwork.UnitOfWork
Returns the resource previously attached under given name, or null if no such resource is available.
getResult() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Waits if necessary for the command handling to complete, and then returns its result.
getResult(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Waits if necessary for at most the given time for the command handling to complete, and then retrieves its result, if available.
getResult() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the result of the command's execution, or null if the command is not yet executed or resulted in an exception.
getReturnValue(Serializer) - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
Returns the returnValue of the command processing.
getRevision() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
Returns the revision of the serialized saga
getRevision() - Method in interface org.axonframework.serializer.SerializedType
Returns the revision identifier of the serialized object.
getRevision() - Method in class org.axonframework.serializer.SimpleSerializedType
 
getRollbackConfiguration() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the RollbackConfiguration indicating for which Exceptions the DisruptorCommandBus should perform a rollback, and which exceptions should result in a Commit.
getRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
 
getRoutingKey(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.RoutingStrategy
Generates a routing key for the given command.
getRoutingKey() - Method in class org.axonframework.eventhandling.amqp.AMQPMessage
Returns the Routing Key this message should be dispatched with
getSaga(Serializer) - Method in class org.axonframework.mongo3.saga.repository.SagaEntry
Returns the Saga instance stored in this entry.
getSaga(Serializer) - Method in class org.axonframework.saga.repository.jpa.SagaEntry
Returns the Saga instance stored in this entry.
getSaga(Serializer) - Method in class org.axonframework.saga.repository.mongo.SagaEntry
Returns the Saga instance stored in this entry.
getSagaCreationPolicy(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.AbstractSagaManager
Returns the Saga Initialization Policy for a Saga of the given sagaType and event.
getSagaCreationPolicy(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
 
getSagaCreationPolicy(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.SimpleSagaManager
 
getSagaId() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
Returns the identifier of the saga contained in this entry
getSagaIdentifier() - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
 
getSagaIdentifier() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
Returns the Saga Identifier contained in this entry.
getSagaIdentifier() - Method in interface org.axonframework.saga.Saga
Returns the unique identifier of this saga.
getSagaType() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Returns the type of Saga being processed.
getSagaType() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
Returns the type of saga this inspector handles.
getSagaType() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
Returns the type (fully qualified class name) of the Saga this association value belongs to
getSagaType() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
Returns the type identifier of the serialized saga
getScheduledItems() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Returns a view of all the scheduled Events at the time this method is called.
getScheduleTime() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
The time the event was scheduled for publication.
getScheduleTime() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.FullConcurrencyPolicy
Returns the sequence identifier for the given event.
getSequenceIdentifierFor(T) - Method in interface org.axonframework.eventhandling.async.SequencingPolicy
Returns the sequence identifier for the given event.
getSequenceIdentifierFor(EventMessage) - Method in class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
Returns the sequence identifier for the given event.
getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.SequentialPolicy
Returns the sequence identifier for the given event.
getSequenceNumber() - Method in interface org.axonframework.domain.DomainEventMessage
Returns the sequence number that allows DomainEvents originating from the same Aggregate to be placed in the order of generation.
getSequenceNumber() - Method in class org.axonframework.domain.GenericDomainEventMessage
 
getSequenceNumber() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
Returns the sequence number of the associated event.
getSequenceNumber() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
 
getSequenceNumber() - Method in class org.axonframework.gae.eventstore.EventEntry
getter for the sequence number of the event.
getSequenceNumber() - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
 
getSequenceNumber() - Method in interface org.axonframework.serializer.SerializedDomainEventData
Returns the sequence number of the event in the aggregate.
getSequenceNumber() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
getSequenceNumber() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
 
getSequenceNumber() - Method in interface org.axonframework.upcasting.UpcastingContext
Returns the sequence number of the event in the aggregate, or null if the message wrapping the object being upcast does not contain a sequence number.
getSequenceNumber() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
 
getSerializedMetaData() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
Returns the wrapper containing the serialized MetaData.
getSerializedObject() - Method in class org.axonframework.serializer.LazyDeserializingObject
Returns the serialized object to deserialize upon request
getSerializedRepresentation() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the type of data the serialized object should be represented in.
getSerializedSaga() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
Returns the serialized form of the Saga.
getSerializer() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the serializer to perform pre-serialization with, or null if no pre-serialization should be done.
getSerializer() - Method in class org.axonframework.serializer.LazyDeserializingObject
Returns the serializer to deserialize this object
getSerializerSegmentId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the Segment ID that identifies the serializer thread to process this entry
getSerializerThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the configured number of threads that should perform the pre-serialization step.
getShutdownTimeout() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Shutdown Timeout configured in this instance, or the one provided by the default configuration if not explicitly provided.
getSnapshotEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
 
getSnapshotEventEntryEntityName() - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
Returns the entity name of the Snapshot Event Entry provided by this factory.
getSocketTimeOut() - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Getter for the socket timeout.
getSocketTimeOut() - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Getter for the socket timeout.
getSubscriptions() - Method in class org.axonframework.test.utils.RecordingCommandBus
Returns a Map will all Command Names and their Command Handler that have been subscribed to this command bus.
getTargetType() - Method in class org.axonframework.common.annotation.MessageHandlerInvoker
Returns the targetType on which handler methods are invoked.
getTargetType() - Method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
Returns the targetType on which handler methods are invoked.
getTargetType() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
 
getTargetType() - Method in interface org.axonframework.eventhandling.EventListenerProxy
Returns the instance type that this proxy delegates all event handling to.
getTargetType() - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
 
getTargetType() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
 
getTargetType() - Method in class org.axonframework.saga.SimpleSagaManager
 
getTaskExecutor() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Task Executor configured in this instance, or the one provided by the default configuration if not explicitly provided.
getterName(String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
Returns the name of the method that is used to access the property.
getterName(String) - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
 
getterName(String) - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
 
getThreadsAllowedToBlockForConnectionMultiplier() - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Getter for the amount of threads that block in relation to the amount of possible connections.
getThreadsAllowedToBlockForConnectionMultiplier() - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Getter for the amount of threads that block in relation to the amount of possible connections.
getTimestamp() - Method in interface org.axonframework.domain.EventMessage
Returns the timestamp of this event.
getTimestamp() - Method in class org.axonframework.domain.GenericEventMessage
 
getTimestamp() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
Returns the time stamp of the associated event.
getTimestamp() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
 
getTimestamp() - Method in class org.axonframework.gae.eventstore.EventEntry
 
getTimestamp() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
getTimestamp() - Method in interface org.axonframework.serializer.SerializedDomainEventData
Returns the timestamp at which the event was first created.
getTimestamp() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
getTimestamp() - Method in class org.axonframework.serializer.SerializedEventMessage
 
getTimestamp() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
 
getTimestamp() - Method in interface org.axonframework.upcasting.UpcastingContext
Returns the timestamp at which the event was first created.
getTimestamp() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
 
getTodoId() - Method in class org.axonframework.quickstart.api.CreateToDoItemCommand
 
getTodoId() - Method in class org.axonframework.quickstart.api.MarkCompletedCommand
 
getTodoId() - Method in class org.axonframework.quickstart.api.MarkToDoItemOverdueCommand
 
getTodoId() - Method in class org.axonframework.quickstart.api.ToDoItemCompletedEvent
 
getTodoId() - Method in class org.axonframework.quickstart.api.ToDoItemCreatedEvent
 
getTodoId() - Method in class org.axonframework.quickstart.api.ToDoItemDeadlineExpiredEvent
 
getTodoId() - Method in class org.axonframework.quickstart.RunUpcaster.NewToDoItemWithDeadlineCreatedEvent
 
getTokenId() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
Returns the identifier of the scheduled task.
getTransactionAttribute() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the TransactionAttribute configured in this instance, or the one provided by the default configuration if not explicitly provided.
getTransactionManager() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the transaction manager to use to manage a transaction around the storage and publication of events.
getTransactionManager() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the TransactionManager configured in this instance, or the one provided by the default configuration if not explicitly provided.
getTxSize() - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Returns the Transaction Size configured in this instance, or the one provided by the default configuration if not explicitly provided.
getType() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
Returns the type identifier of the aggregate.
getType() - Method in class org.axonframework.serializer.LazyDeserializingObject
Returns the class of the serialized object.
getType() - Method in class org.axonframework.serializer.SerializedMetaData
 
getType() - Method in interface org.axonframework.serializer.SerializedObject
Returns the description of the type of object contained in the data.
getType() - Method in class org.axonframework.serializer.SimpleSerializedObject
 
getTypeByte() - Method in enum org.axonframework.eventhandling.io.EventMessageType
Returns the Type Byte for this EventMessageType.
getTypeIdentifier() - Method in interface org.axonframework.eventsourcing.AggregateFactory
Returns the type identifier for this aggregate factory.
getTypeIdentifier() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Return the type identifier belonging to the AggregateFactory of this repository.
getTypeIdentifier() - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
 
getTypeIdentifier() - Method in class org.axonframework.eventsourcing.HybridJpaRepository
Returns the type identifier to use when appending events in the event store.
getTypeIdentifier() - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
getUncommittedEventCount() - Method in class org.axonframework.domain.AbstractAggregateRoot
Returns the number of uncommitted events currently available in the aggregate.
getUncommittedEventCount() - Method in interface org.axonframework.domain.AggregateRoot
Returns the number of uncommitted events currently available in the aggregate.
getUncommittedEvents() - Method in class org.axonframework.domain.AbstractAggregateRoot
Returns a DomainEventStream to the events in the aggregate that have been raised since creation or the last commit.
getUncommittedEvents() - Method in interface org.axonframework.domain.AggregateRoot
Returns a DomainEventStream to the events in the aggregate that have been raised since creation or the last commit.
getUnitOfWork() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the UnitOfWork for the command execution.
getValue(T) - Method in class org.axonframework.common.property.MethodAccessedProperty
 
getValue(T) - Method in interface org.axonframework.common.property.Property
Returns the value of the property on given target.
getValue() - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Returns the value of the current node
getValue() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
getValue() - Method in class org.axonframework.saga.AssociationValue
Returns the value of this association.
getValue() - Method in class org.axonframework.serializer.bson.BSONNode
Returns the value of the current node
getValue() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
getVersion() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
Returns the version of the targeted Aggregate, or null if the version is irrelevant.
getVersion() - Method in class org.axonframework.domain.AbstractAggregateRoot
Returns the current version number of the aggregate, or null if the aggregate is newly created.
getVersion() - Method in interface org.axonframework.domain.AggregateRoot
Returns the current version number of the aggregate, or null if the aggregate is newly created.
getVersion() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
 
getViolatingMethod() - Method in exception org.axonframework.common.annotation.UnsupportedHandlerException
A reference to the method that violated the event handler rules.
getViolations() - Method in exception org.axonframework.commandhandling.interceptors.JSR303ViolationException
Returns the violations that were detected when this exception was thrown.
getWaitStrategy() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the WaitStrategy currently configured.
getWriter() - Method in class org.axonframework.serializer.json.JacksonSerializer
Provides the ObjectWriter, with which objects are serialized to JSON form.
getXStream() - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Returns a reference to the underlying XStream instance, that does the actual serialization.
given(Object...) - Method in interface org.axonframework.test.FixtureConfiguration
Configures the given domainEvents as the "given" events.
given(List<?>) - Method in interface org.axonframework.test.FixtureConfiguration
Configures the given domainEvents as the "given" events.
given(Object...) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
given(List<?>) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
givenAggregate(Object) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
givenAggregate(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Use this method to indicate that an aggregate with given identifier published certain events.
GivenAggregateEventPublisher - Interface in org.axonframework.test.saga
Interface to an object that publishes events on behalf of an aggregate.
givenAPublished(Object) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
givenAPublished(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Indicates that the given applicationEvent has been published in the past.
givenCommands(Object...) - Method in interface org.axonframework.test.FixtureConfiguration
Configures the given commands as the command that will provide the "given" events.
givenCommands(List<?>) - Method in interface org.axonframework.test.FixtureConfiguration
Configures the given commands as the command that will provide the "given" events.
givenCommands(Object...) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
givenCommands(List<?>) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
givenNoPriorActivity() - Method in interface org.axonframework.test.FixtureConfiguration
Indicates that no relevant activity has occurred in the past.
givenNoPriorActivity() - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
givenNoPriorActivity() - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
givenNoPriorActivity() - Method in interface org.axonframework.test.saga.FixtureConfiguration
Indicates that no relevant activity has occurred in the past.
GivenWhenThenTestFixture<T extends EventSourcedAggregateRoot> - Class in org.axonframework.test
A test fixture that allows the execution of given-when-then style test cases.
GivenWhenThenTestFixture(Class<T>) - Constructor for class org.axonframework.test.GivenWhenThenTestFixture
Initializes a new given-when-then style test fixture for the given aggregateType.
greaterThan(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
greaterThan(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
greaterThan(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must be "greater than" the given expression.
greaterThan(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
greaterThan(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 
greaterThanEquals(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
greaterThanEquals(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
greaterThanEquals(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must be "greater than" or "equal to" the given expression.
greaterThanEquals(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
greaterThanEquals(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 

H

handle(CommandMessage<?>, UnitOfWork, InterceptorChain) - Method in class org.axonframework.auditing.AuditingInterceptor
 
handle(CommandMessage<Object>, UnitOfWork) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
 
handle(CommandMessage<Object>, UnitOfWork) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Invokes the @CommandHandler annotated method that accepts the given command.
handle(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.CommandDispatchInterceptor
Invoked each time a command is about to be dispatched on a Command Bus.
handle(CommandMessage<T>, UnitOfWork) - Method in interface org.axonframework.commandhandling.CommandHandler
Handles the given command.
handle(CommandMessage<?>, UnitOfWork, InterceptorChain) - Method in interface org.axonframework.commandhandling.CommandHandlerInterceptor
The handle method is invoked each time a command is dispatched through the command bus that the CommandHandlerInterceptor is declared on.
handle(CommandMessage<?>, UnitOfWork, InterceptorChain) - Method in class org.axonframework.commandhandling.interceptors.BeanValidationInterceptor
 
handle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.interceptors.BeanValidationInterceptor
 
handle(CommandMessage<?>, UnitOfWork, InterceptorChain) - Method in class org.axonframework.commandhandling.interceptors.LoggingInterceptor
 
handle(CommandMessage<?>, UnitOfWork, InterceptorChain) - Method in class org.axonframework.commandhandling.interceptors.SerializationOptimizingInterceptor
 
handle(EventMessage) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Process the given event.
handle(EventMessage) - Method in interface org.axonframework.eventhandling.EventListener
Process the given event.
handle(DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Apply state changes based on the given event.
handle(DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Apply state changes based on the given event.
handle(DomainEventMessage) - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
Calls the appropriate handler method with the provided event.
handle(DomainEventMessage) - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
Calls the appropriate handler method with the provided event.
handle(EventMessage) - Method in class org.axonframework.integration.adapter.EventListeningMessageChannelAdapter
If allows by the filter, wraps the given event in a GenericMessage ands sends it to the configured MessageChannel.
handle(ToDoItemCreatedEvent, DateTime) - Method in class org.axonframework.quickstart.annotated.ToDoEventHandler
 
handle(ToDoItemCompletedEvent) - Method in class org.axonframework.quickstart.annotated.ToDoEventHandler
 
handle(CommandMessage<CreateToDoItemCommand>, UnitOfWork) - Method in class org.axonframework.quickstart.handler.CreateToDoCommandHandler
 
handle(CommandMessage<MarkCompletedCommand>, UnitOfWork) - Method in class org.axonframework.quickstart.handler.MarkCompletedCommandHandler
 
handle(EventMessage) - Method in class org.axonframework.quickstart.handler.ToDoEventListener
 
handle(DomainEventMessage) - Method in class org.axonframework.quickstart.handler.ToDoItem
 
handle(CreateToDoItemCommand) - Method in class org.axonframework.quickstart.RunDistributedCommandBus.ToDoLoggingCommandHandler
 
handle(MarkCompletedCommand) - Method in class org.axonframework.quickstart.RunDistributedCommandBus.ToDoLoggingCommandHandler
 
handle(EventMessage) - Method in class org.axonframework.saga.AbstractSagaManager
 
handle(EventMessage) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
 
handle(EventMessage) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
 
handle(EventMessage) - Method in interface org.axonframework.saga.Saga
Handle the given event.
handle(EventMessage) - Method in interface org.axonframework.saga.SagaManager
Handles the event by passing it to all Saga instances that have an Association Value found in the given event.
handle(EventMessage) - Method in class org.axonframework.springmessaging.adapter.EventListeningMessageChannelAdapter
If allows by the filter, wraps the given event in a GenericMessage ands sends it to the configured MessageChannel.
handle(EventMessage) - Method in class org.axonframework.test.saga.EventValidator
 
handle(Object, MetaData) - Method in interface org.axonframework.test.utils.CallbackBehavior
Invoked when the Command Bus receives a Command that is dispatched with a Callback method.
handle(Object, MetaData) - Method in class org.axonframework.test.utils.DefaultCallbackBehavior
 
handleError(Throwable, EventMessage<?>, EventListener) - Method in class org.axonframework.eventhandling.async.DefaultErrorHandler
 
handleError(Throwable, EventMessage<?>, EventListener) - Method in interface org.axonframework.eventhandling.async.ErrorHandler
Invoked when a handler or the unit of work throws an exception.
handleMessage(Message<?>) - Method in class org.axonframework.integration.adapter.EventPublishingMessageChannelAdapter
Handles the given message.
handleMessage(Message<?>) - Method in class org.axonframework.integration.eventbus.MessageHandlerAdapter
handleMessage(Message<?>) - Method in class org.axonframework.springmessaging.adapter.EventPublishingMessageChannelAdapter
Handles the given message.
handleMessage(Message<?>) - Method in class org.axonframework.springmessaging.eventbus.MessageHandlerAdapter
HandlerDefinition<T extends AccessibleObject> - Interface in org.axonframework.common.annotation
Defines which members (methods, constructors, etc) are considered message handlers.
handleRecursively(DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
 
handleRecursively(DomainEventMessage) - Method in interface org.axonframework.eventsourcing.EventSourcedEntity
Report the given event for handling in the current instance (this), as well as all the entities referenced by this instance.
hasConverter(Class<S>, Class<T>) - Method in class org.axonframework.serializer.ChainingConverterFactory
 
hasConverter(Class<S>, Class<T>) - Method in interface org.axonframework.serializer.ConverterFactory
Indicates whether this factory contains a converter capable of converting the given sourceContentType into the targetContentType.
hasDelegate() - Method in class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
Indicates whether this callback has a delegate that needs to be notified of the command handling result
hasEqualsMethod(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the given class implements a customized equals method.
hashChanged(ConsistentHash) - Method in interface org.axonframework.commandhandling.distributed.jgroups.HashChangeListener
Invoked when the memberships of a consistent hash have changed.
HashChangeListener - Interface in org.axonframework.commandhandling.distributed.jgroups
Receive updates from the JGroupsConnector when the consistent hash changes.
hashCode() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.Member
 
hashCode() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
 
hashCode() - Method in class org.axonframework.common.annotation.AbstractMessageHandler
 
hashCode() - Method in class org.axonframework.common.annotation.MethodMessageHandler
 
hashCode() - Method in class org.axonframework.domain.MetaData
 
hashCode() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData.PK
 
hashCode() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
 
hashCode() - Method in class org.axonframework.saga.AssociationValue
 
hashCode() - Method in class org.axonframework.serializer.SerializedMetaData
 
hashCode() - Method in class org.axonframework.serializer.SimpleSerializedObject
 
hashCode() - Method in class org.axonframework.serializer.SimpleSerializedType
 
hashCode() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
hashes() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.Member
Returns the hash values assigned to this member.
hasLock(String) - Method in class org.axonframework.common.lock.IdentifierBasedLock
Indicates whether the current thread hold a lock for the given identifier.
hasMoreChildren() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
hasMoreChildren() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
hasNext() - Method in interface org.axonframework.domain.DomainEventStream
Returns true if the stream has more events, meaning that a call to next() will not result in an exception.
hasNext() - Method in class org.axonframework.domain.SimpleDomainEventStream
Returns true if the stream has more events, meaning that a call to next() will not result in an exception.
hasNext() - Method in class org.axonframework.eventstore.fs.FileSystemBufferedReaderDomainEventStream
 
HIGH - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should have high priority, effectively placing it "in the first half".
HsqlSagaSqlSchema - Class in org.axonframework.saga.repository.jdbc
Specialization of the GenericSagaSqlSchema for use in the HSQL database.
HsqlSagaSqlSchema() - Constructor for class org.axonframework.saga.repository.jdbc.HsqlSagaSqlSchema
 
HybridJpaRepository<T extends AggregateRoot> - Class in org.axonframework.eventsourcing
Repository that stores both a (JPA based) relational model of the current state of an aggregate and the events produced by that aggregate.
HybridJpaRepository(EntityManagerProvider, Class<T>) - Constructor for class org.axonframework.eventsourcing.HybridJpaRepository
Initializes a Hybrid Repository that stored entities of the given aggregateType and the locking mechanism provided by the backend storage.
HybridJpaRepository(EntityManagerProvider, Class<T>, String) - Constructor for class org.axonframework.eventsourcing.HybridJpaRepository
Initializes a Hybrid Repository that stored entities of the given aggregateType without locking.
HybridJpaRepository(EntityManagerProvider, Class<T>, LockManager) - Constructor for class org.axonframework.eventsourcing.HybridJpaRepository
Initializes a Hybrid Repository that stored entities of the given aggregateType and a locking mechanism based on the given lockManager.
HybridJpaRepository(EntityManager, Class<T>, LockManager) - Constructor for class org.axonframework.eventsourcing.HybridJpaRepository
Initializes a Hybrid Repository that stored entities of the given aggregateType and a locking mechanism based on the given lockManager.
HybridJpaRepository(EntityManagerProvider, Class<T>, String, LockManager) - Constructor for class org.axonframework.eventsourcing.HybridJpaRepository
Initializes a Hybrid Repository that stored entities of the given aggregateType and a locking mechanism based on the given lockManager.
HybridJpaRepository(EntityManager, Class<T>, String, LockManager) - Constructor for class org.axonframework.eventsourcing.HybridJpaRepository
Initializes a Hybrid Repository that stored entities of the given aggregateType and a locking mechanism based on the given lockManager.

I

IdentifierBasedLock - Class in org.axonframework.common.lock
Locking mechanism that allows multiple threads to hold a lock, as long as the identifier of the lock they hold is not equal.
IdentifierBasedLock() - Constructor for class org.axonframework.common.lock.IdentifierBasedLock
Creates a new IdentifierBasedLock instance.
IdentifierFactory - Class in org.axonframework.domain
Abstract Factory class that provides access to an IdentifierFactory implementation.
IdentifierFactory() - Constructor for class org.axonframework.domain.IdentifierFactory
 
IdentifierValidator - Class in org.axonframework.common
Validates the structure of an object passed as Aggregate Identifier.
IgnoreField - Class in org.axonframework.test.matchers
FieldFilter implementation that rejects a given Field
IgnoreField(Field) - Constructor for class org.axonframework.test.matchers.IgnoreField
Initialize an instance that ignores the given field
IgnoreField(Class<?>, String) - Constructor for class org.axonframework.test.matchers.IgnoreField
Initialize an instance that ignores the a field with given fieldName, which is declared on the given clazz.
IllegalLockUsageException - Exception in org.axonframework.common.lock
Exception indicating that an illegal use of a lock was detect (e.g.
IllegalLockUsageException(String, Throwable) - Constructor for exception org.axonframework.common.lock.IllegalLockUsageException
Initialize the exception with given message and cause
IllegalLockUsageException(String) - Constructor for exception org.axonframework.common.lock.IllegalLockUsageException
Initialize the exception with given message.
in(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
in(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
in(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must be "in" the given expression.
in(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
in(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 
IncomingMessageHandler - Interface in org.axonframework.eventhandling.replay
Interface of a mechanism that receives Messages dispatched to a Cluster that is in Replay mode.
IncompatibleAggregateException - Exception in org.axonframework.eventsourcing
Exception indicating that an aggregate was not compatible with the requirements of the GenericAggregateFactory.
IncompatibleAggregateException(String, Exception) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
Initialize the exception with given message and cause.
IncompatibleAggregateException(String) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
Initialize the exception with given message.
init() - Method in class org.axonframework.contextsupport.spring.amqp.AxonAMQPNamespaceHandler
init() - Method in class org.axonframework.contextsupport.spring.AxonNamespaceHandler
initialAssociationValue(EventMessage) - Method in class org.axonframework.saga.SimpleSagaManager
Returns the association value to assign to a Saga when the given event triggers the creation of a new instance.
initialize() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Initializes the QuartzEventScheduler.
initializeAdapterFor(Object, ParameterResolverFactory) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
initializeAdapterFor(Object, ParameterResolverFactory) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Create an AnnotationEventListenerAdapter instance of the given bean.
initializeAdapterFor(Object, ParameterResolverFactory) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
initializeEventStream(long) - Method in class org.axonframework.domain.AbstractAggregateRoot
Initialize the event stream using the given sequence number of the last known event.
initializeSequenceNumber(Long) - Method in class org.axonframework.domain.EventContainer
Sets the first sequence number that should be assigned to an incoming event.
initializeState(DomainEventStream) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Initialize the state of this aggregate using the events in the provided DomainEventStream.
initializeState(DomainEventStream) - Method in interface org.axonframework.eventsourcing.EventSourcedAggregateRoot
Initialize the state of this aggregate using the events in the provided DomainEventStream.
injectResources(Saga) - Method in interface org.axonframework.saga.ResourceInjector
Inject required resources into the given saga.
injectResources(Saga) - Method in class org.axonframework.saga.SimpleResourceInjector
 
injectResources(Saga) - Method in class org.axonframework.saga.spring.SpringResourceInjector
 
injectResources(Saga) - Method in class org.axonframework.test.utils.AutowiredResourceInjector
 
InMemorySagaRepository - Class in org.axonframework.saga.repository.inmemory
SagaRepository implementation that stores all Saga instances in memory.
InMemorySagaRepository() - Constructor for class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
InputStreamToByteArrayConverter - Class in org.axonframework.serializer.converters
Converter that converts an InputStream to a byte array.
InputStreamToByteArrayConverter() - Constructor for class org.axonframework.serializer.converters.InputStreamToByteArrayConverter
 
InputStreamToDom4jConverter - Class in org.axonframework.serializer.xml
Converter that converts an input stream to a Dom4J document.
InputStreamToDom4jConverter() - Constructor for class org.axonframework.serializer.xml.InputStreamToDom4jConverter
 
InputStreamToXomConverter - Class in org.axonframework.serializer.xml
Converter that converts an input stream to a XOM document.
InputStreamToXomConverter() - Constructor for class org.axonframework.serializer.xml.InputStreamToXomConverter
 
INSTANCE - Static variable in class org.axonframework.auditing.EmptyDataProvider
Returns a singleton instance to this data provider.
INSTANCE - Static variable in class org.axonframework.auditing.NullAuditLogger
Returns a singleton instance to this logger.
INSTANCE - Static variable in class org.axonframework.cache.NoCache
Creates a singleton reference the the NoCache implementation.
INSTANCE - Static variable in class org.axonframework.commandhandling.callbacks.NoOpCallback
A statically available instance of the NoOpCallback.
INSTANCE - Static variable in class org.axonframework.common.DirectExecutor
Returns a singleton instance of the DirectExecutor.
instance() - Static method in class org.axonframework.test.matchers.AllFieldsFilter
Returns the (singleton) instance of the AllFieldsFilter
instance() - Static method in class org.axonframework.test.matchers.NonTransientFieldsFilter
Returns the (singleton) instance of the AllFieldsFilter
intercept(CommandMessage<?>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Invokes all the dispatch interceptors.
InterceptorChain - Interface in org.axonframework.commandhandling
The interceptor chain manages the flow of a command through a chain of interceptors and ultimately to the command handler.
IntervalRetryScheduler - Class in org.axonframework.commandhandling.gateway
RetryScheduler implementation that retries commands at regular intervals when they fail because of an exception that is not explicitly non-transient.
IntervalRetryScheduler(ScheduledExecutorService, int, int) - Constructor for class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
Initializes the retry scheduler to schedule retries on the given executor using the given interval and allowing maxRetryCount retries before giving up permanently.
invoke(Object, Message) - Method in class org.axonframework.commandhandling.annotation.ConstructorCommandMessageHandler
 
invoke(Object, Method, Object[]) - Method in interface org.axonframework.commandhandling.gateway.GatewayProxyFactory.InvocationHandler
Handle the invocation of the given invokedMethod, invoked on given proxy with given args.
invoke(Object, Message) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
Invokes this handler for the given target instance, using the given message as source object to provide parameter values.
invoke(Object, Message) - Method in class org.axonframework.common.annotation.MethodMessageHandler
 
invoke(Object, EventMessage) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Invoke a handler on given target for given message.
invokeHandlerMethod(Message) - Method in class org.axonframework.common.annotation.MessageHandlerInvoker
Invoke the handler demarcated with the given annotationClass on the target for the given event.
IOUtils - Class in org.axonframework.common.io
Utility methods for IO operations.
is(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
is(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
is(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must "equal" the given expression.
is(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
is(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 
isAccessible(AccessibleObject) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the given member is accessible.
isActive() - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
 
isActive() - Method in interface org.axonframework.saga.Saga
Indicates whether or not this saga is active.
isAutoConnectRetry() - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Getter for the AutoConnectRetry property.
isAutoStartup() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
isAutoStartup() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
 
isAutoStartup() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
 
isAutoStartup() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
isAutoStartup() - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
isCancelled() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Always returns false, since command execution cannot be cancelled.
isCauseOf(Throwable) - Static method in exception org.axonframework.common.AxonNonTransientException
Indicates whether the given throwable is a AxonNonTransientException exception or indicates to be caused by one.
isDeleted() - Method in class org.axonframework.domain.AbstractAggregateRoot
 
isDeleted() - Method in interface org.axonframework.domain.AggregateRoot
Indicates whether this aggregate has been marked as deleted.
isDeserialized() - Method in class org.axonframework.serializer.LazyDeserializingObject
Indicates whether this object has already been deserialized.
isDone() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Indicates whether command handler execution has finished.
isDuplicateKeyViolation(Exception) - Method in interface org.axonframework.common.jdbc.PersistenceExceptionResolver
Indicates whether the given exception represents a duplicate key violation.
isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventstore.jdbc.JdbcSQLErrorCodesResolver
 
isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
 
isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventstore.jpa.SQLStateResolver
 
isEmpty() - Method in class org.axonframework.domain.MetaData
 
isEmpty() - Method in class org.axonframework.saga.repository.AssociationValueMap
Indicates whether any elements are contained within this map.
isEndingHandler() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Indicates whether this handler is one that ends the Saga lifecycle
isExpectReply() - Method in class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
Indicates whether the sender of this message requests a reply.
isExplicitlyNonTransient(Throwable) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
Indicates whether the given failure is clearly non-transient.
isFailure() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
Indicates whether processing failed
isFalse(boolean, String) - Static method in class org.axonframework.common.Assert
Asserts that the given expression is false.
isHandlerAvailable() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Indicates whether the inspected method is an Event Handler.
isImmediate() - Method in class org.axonframework.eventhandling.amqp.AMQPMessage
Whether to dispatch this message using the "immediate" flag
isInReplayMode() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Indicates whether this cluster is in replay mode.
isLive() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Indicates whether this aggregate is in "live" mode.
isMandatory() - Method in class org.axonframework.eventhandling.amqp.AMQPMessage
Whether to dispatch this message using the "mandatory" flag
isMemberLive(View) - Method in class org.axonframework.commandhandling.distributed.jgroups.support.callbacks.MemberAwareCommandCallback
Indicates whether the node responsible for providing the value to invoke the callback with is still alive in the given currentView.
isMessageHandler(AccessibleObject) - Method in class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
 
isMessageHandler(T) - Method in interface org.axonframework.common.annotation.HandlerDefinition
Indicates whether the given member is to be considered a message handler
isNonFinalPublicMember(Member) - Static method in class org.axonframework.common.ReflectionUtils
Checks whether the given member is public and non-final.
isNot(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
isNot(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
isNot(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must be "not equal to" the given expression.
isNot(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
isNot(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 
isPayloadDeserialized() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
Indicates whether the payload of this message has already been deserialized.
isPayloadDeserialized() - Method in class org.axonframework.serializer.SerializedEventMessage
Indicates whether the payload of this message has already been deserialized.
isPayloadDeserialized() - Method in class org.axonframework.serializer.SerializedMessage
Indicates whether the payload of this message has already been deserialized.
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Indicates whether an object of the given targetClass should be post processed.
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
isPreSerializationConfigured() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Indicates whether pre-serialization is configured.
isPropertySet(String) - Method in interface org.axonframework.eventhandling.ClusterMetaData
Indicates whether a value is stored under the given key.
isPropertySet(String) - Method in class org.axonframework.eventhandling.DefaultClusterMetaData
 
isRecoverEntry() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Indicates whether this entry is a recovery entry.
isRunning() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
isRunning() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
 
isRunning() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
 
isRunning() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
isRunning() - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
isSerializedMetaData(SerializedObject<?>) - Static method in class org.axonframework.serializer.SerializedMetaData
Indicates whether the given serializedObject represents a serialized form of a MetaData object, such as the ones created by this class (see SerializedMetaData.SerializedMetaData(Object, Class).
isSingleton() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
 
isSingleton() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
isSingleton() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
 
isSingleton() - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
 
isSingleton() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
isSingleton() - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
 
isSingleton() - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
 
isSingleton() - Method in class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
 
isSingleton() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
isSingleton() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
isSingleton() - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
 
isSingleton() - Method in class org.axonframework.gae.serializer.XStreamFactory
 
isStarted() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
isStarted() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Indicates whether a unit of work has already been started.
isStarted() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
isStarted() - Method in interface org.axonframework.unitofwork.UnitOfWork
Indicates whether this UnitOfWork is started.
isSubscribed(CommandHandler<?>) - Method in class org.axonframework.test.utils.RecordingCommandBus
Indicates whether the given commandHandler is subscribed to this command bus.
isSubscribed(String, CommandHandler<? super C>) - Method in class org.axonframework.test.utils.RecordingCommandBus
Indicates whether the given commandHandler is subscribed to commands of the given commandType on this command bus.
isSuccess() - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
Whether the reply message represents a successfully executed command.
isTransactional() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
isTransactional() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
isTransactional() - Method in interface org.axonframework.unitofwork.UnitOfWork
Indicates whether this UnitOfWork is bound to a transaction.
isTransient(Field) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the given field has the "transient" modifier
isTransient(Throwable) - Method in class org.axonframework.saga.annotation.RetryingErrorHandler
Indicates whether the given exception is transient (i.e.
isTrue(boolean, String) - Static method in class org.axonframework.common.Assert
Asserts that the given expression is true.
isValidIdentifier(Class<?>) - Method in class org.axonframework.common.IdentifierValidator
Indicates whether or not the given identifierType is safe to use as aggregate identifier
iterator() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 

J

JacksonSerializer - Class in org.axonframework.serializer.json
Serializer implementation that uses Jackson to serialize objects into a JSON format.
JacksonSerializer() - Constructor for class org.axonframework.serializer.json.JacksonSerializer
Initialize the serializer with a default ObjectMapper instance.
JacksonSerializer(ObjectMapper) - Constructor for class org.axonframework.serializer.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JacksonSerializer(RevisionResolver, ConverterFactory) - Constructor for class org.axonframework.serializer.json.JacksonSerializer
Initialize the serializer using a default ObjectMapper instance, using the given revisionResolver to define revision for each object to serialize, and given converterFactory to be used by upcasters.
JacksonSerializer(ObjectMapper, RevisionResolver) - Constructor for class org.axonframework.serializer.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JacksonSerializer(ObjectMapper, RevisionResolver, ConverterFactory) - Constructor for class org.axonframework.serializer.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JacksonSerializer(ObjectMapper, RevisionResolver, ConverterFactory, ClassLoader) - Constructor for class org.axonframework.serializer.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JavaSerializer - Class in org.axonframework.serializer
Serializer implementation that uses Java serialization to serialize and deserialize object instances.
JavaSerializer() - Constructor for class org.axonframework.serializer.JavaSerializer
Initialize the serializer using a SerialVersionUIDRevisionResolver, which uses the SerialVersionUID field of the serializable object as the Revision.
JavaSerializer(RevisionResolver) - Constructor for class org.axonframework.serializer.JavaSerializer
Initialize the serializer using a SerialVersionUIDRevisionResolver.
JCacheAdapter - Class in org.axonframework.cache
Cache adapter implementation that allows providers implementing the JCache abstraction to be used.
JCacheAdapter(Cache) - Constructor for class org.axonframework.cache.JCacheAdapter
Initialize the adapter to forward call to the given jCache instance
JdbcCriteria - Class in org.axonframework.eventstore.jdbc.criteria
Abstract implementation of the Criteria interface for a Jdbc Event Store.
JdbcCriteria() - Constructor for class org.axonframework.eventstore.jdbc.criteria.JdbcCriteria
 
JdbcCriteriaBuilder - Class in org.axonframework.eventstore.jdbc.criteria
CriteriaBuilder implementation for the Jdbc Event Store
JdbcCriteriaBuilder() - Constructor for class org.axonframework.eventstore.jdbc.criteria.JdbcCriteriaBuilder
 
JdbcEventStore - Class in org.axonframework.eventstore.jdbc
An EventStore implementation that uses JPA to store DomainEvents in a database.
JdbcEventStore(EventEntryStore, Serializer) - Constructor for class org.axonframework.eventstore.jdbc.JdbcEventStore
Initializes a JdbcEventStore using the given eventEntryStore and serializer.
JdbcEventStore(EventEntryStore) - Constructor for class org.axonframework.eventstore.jdbc.JdbcEventStore
Initialize a JdbcEventStore using the given eventEntryStore and an XStreamSerializer, which serializes events as XML.
JdbcEventStore(ConnectionProvider) - Constructor for class org.axonframework.eventstore.jdbc.JdbcEventStore
Initialize a JdbcEventStore using the default EntryStore and an XStreamSerializer, which serializes events as XML.
JdbcEventStore(DataSource) - Constructor for class org.axonframework.eventstore.jdbc.JdbcEventStore
Initialize a JdbcEventStore using the given eventEntryStore and an XStreamSerializer, which serializes events as XML.
JdbcEventStoreBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that provides Spring namespace support for defining JDBC Event Stores.
JdbcEventStoreBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.JdbcEventStoreBeanDefinitionParser
 
JdbcProperty - Class in org.axonframework.eventstore.jdbc.criteria
Property implementation for Jdbc Event Store.
JdbcProperty(String) - Constructor for class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
Initializes a property for the given propertyName.
JdbcSagaRepository - Class in org.axonframework.saga.repository.jdbc
Jdbc implementation of the Saga Repository.
JdbcSagaRepository(ConnectionProvider) - Constructor for class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
Initializes a Saga Repository, using given connectionProvider to obtain connections to the database, using a Generic SQL Schema.
JdbcSagaRepository(DataSource, SagaSqlSchema) - Constructor for class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
Initializes a Saga Repository, using given dataSource to obtain connections to the database, and given sqldef to execute SQL statements.
JdbcSagaRepository(ConnectionProvider, SagaSqlSchema) - Constructor for class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
Initializes a Saga Repository, using given connectionProvider to obtain connections to the database, and given sqldef to execute SQL statements.
JdbcSagaRepository(ConnectionProvider, SagaSqlSchema, Serializer) - Constructor for class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
Initializes a Saga Repository, using given connectionProvider to obtain connections to the database, and given sqldef to execute SQL statements and serializer to serialize Sagas.
JdbcSagaRepositoryBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that provides Spring namespace support for defining JDBC Saga Repositories.
JdbcSagaRepositoryBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.JdbcSagaRepositoryBeanDefinitionParser
 
JdbcSQLErrorCodesResolver - Class in org.axonframework.eventstore.jdbc
SQLErrorCodesResolver is an implementation of PersistenceExceptionResolver used to resolve sql error codes to see if it is an duplicate key constraint violation.
JdbcSQLErrorCodesResolver() - Constructor for class org.axonframework.eventstore.jdbc.JdbcSQLErrorCodesResolver
 
JdbcTransactionException - Exception in org.axonframework.common.jdbc
Exception indicating an error occurred while interacting with a JDBC resource.
JdbcTransactionException(String, Throwable) - Constructor for exception org.axonframework.common.jdbc.JdbcTransactionException
Initialize the exception with given message and cause
JdbcUtils - Class in org.axonframework.common.jdbc
Utility class for silently closing JDBC resources
JdbcUtils() - Constructor for class org.axonframework.common.jdbc.JdbcUtils
 
JGroupsConnector - Class in org.axonframework.commandhandling.distributed.jgroups
A CommandBusConnector that uses JGroups to discover and connect to other JGroupsConnectors in the network.
JGroupsConnector(JChannel, String, CommandBus, Serializer) - Constructor for class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
Initializes the Connector using given resources.
JGroupsConnector(JChannel, String, CommandBus, Serializer, HashChangeListener) - Constructor for class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
Initializes the Connector using given resources.
JGroupsConnectorFactoryBean - Class in org.axonframework.commandhandling.distributed.jgroups
Spring Factory bean that creates a JGroupsConnector and starts it when the application context is started.
JGroupsConnectorFactoryBean() - Constructor for class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
JmxMonitorRegistry - Class in org.axonframework.monitoring.jmx
Utility class that allows Axon-related components to be configured with an MBeanServer.
JmxMonitorRegistry() - Constructor for class org.axonframework.monitoring.jmx.JmxMonitorRegistry
 
JodaDeserializer<T> - Class in org.axonframework.serializer.json
Jackson Serializer used to serialize and deserialize Joda DateTime classes.
JodaDeserializer(Class<T>) - Constructor for class org.axonframework.serializer.json.JodaDeserializer
 
JoinMessage - Class in org.axonframework.commandhandling.distributed.jgroups
This message represents a notification of a Member joining the DistributedCommandBus with a given loadFactor.
JoinMessage() - Constructor for class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
Default constructor required by the Streamable and Externalizable interfaces.
JoinMessage(int, Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
Initializes a JoinMessage with the given loadFactor.
JpaCriteria - Class in org.axonframework.eventstore.jpa.criteria
Abstract implementation of the Criteria interface for a JPA Event Store.
JpaCriteria() - Constructor for class org.axonframework.eventstore.jpa.criteria.JpaCriteria
 
JpaCriteriaBuilder - Class in org.axonframework.eventstore.jpa.criteria
CriteriaBuilder implementation for the Jpa Event Store
JpaCriteriaBuilder() - Constructor for class org.axonframework.eventstore.jpa.criteria.JpaCriteriaBuilder
 
JpaEventStore - Class in org.axonframework.eventstore.jpa
An EventStore implementation that uses JPA to store DomainEvents in a database.
JpaEventStore(EntityManagerProvider) - Constructor for class org.axonframework.eventstore.jpa.JpaEventStore
Initialize a JpaEventStore using an XStreamSerializer, which serializes events as XML and the default Event Entry store.
JpaEventStore(EntityManagerProvider, EventEntryStore) - Constructor for class org.axonframework.eventstore.jpa.JpaEventStore
Initialize a JpaEventStore using the given eventEntryStore and an XStreamSerializer, which serializes events as XML.
JpaEventStore(EntityManagerProvider, Serializer) - Constructor for class org.axonframework.eventstore.jpa.JpaEventStore
Initialize a JpaEventStore which serializes events using the given eventSerializer and stores the events in the database using the default EventEntryStore.
JpaEventStore(EntityManagerProvider, Serializer, EventEntryStore) - Constructor for class org.axonframework.eventstore.jpa.JpaEventStore
Initialize a JpaEventStore which serializes events using the given eventSerializer and stores the events in the database using the given eventEntryStore.
JpaEventStoreBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
The JpaEventStoreBeanDefinitionParser is responsible for parsing the eventStore element form the Axon namespace.
JpaEventStoreBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
 
JpaProperty - Class in org.axonframework.eventstore.jpa.criteria
Property implementation for JPA Event Store.
JpaProperty(String) - Constructor for class org.axonframework.eventstore.jpa.criteria.JpaProperty
Initializes a property for the given propertyName.
JpaRepositoryBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser for the jpa-repository elements in a Spring context.
JpaRepositoryBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.JpaRepositoryBeanDefinitionParser
 
JpaSagaRepository - Class in org.axonframework.saga.repository.jpa
JPA implementation of the Saga Repository.
JpaSagaRepository(EntityManagerProvider) - Constructor for class org.axonframework.saga.repository.jpa.JpaSagaRepository
Initializes a Saga Repository with a JavaSerializer.
JpaSagaRepositoryBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
Bean definition parser that parses <jpa-saga-repository> elements into Spring bean definitions.
JpaSagaRepositoryBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.JpaSagaRepositoryBeanDefinitionParser
 
JsonNodeToByteArrayConverter - Class in org.axonframework.serializer.json
ContentTypeConverter implementation that converts a JsonNode object into a byte[].
JsonNodeToByteArrayConverter(ObjectMapper) - Constructor for class org.axonframework.serializer.json.JsonNodeToByteArrayConverter
Initialize the converter, using given objectMapper to convert the JSonNode into bytes.
JSR303ViolationException - Exception in org.axonframework.commandhandling.interceptors
Specialized version of the StructuralCommandValidationFailedException that provides a set of JSR303 constraint violations that provide details about the exact failure of the command.
JSR303ViolationException(Set<ConstraintViolation<Object>>) - Constructor for exception org.axonframework.commandhandling.interceptors.JSR303ViolationException
Initializes an exception with the given message and violations.

K

keySet() - Method in class org.axonframework.domain.MetaData
 

L

LAST - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should come last.
LazyDeserializingObject<T> - Class in org.axonframework.serializer
Represents a serialized object that can be deserializedObjects upon request.
LazyDeserializingObject(T) - Constructor for class org.axonframework.serializer.LazyDeserializingObject
Creates an instance with the given deserializedObject object instance.
LazyDeserializingObject(SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serializer.LazyDeserializingObject
 
LazyUpcasterChain - Class in org.axonframework.upcasting
UpcasterChain implementation that delays the actual upcasting until the data inside the returned SerializedObject is actually fetched.
LazyUpcasterChain(List<Upcaster>) - Constructor for class org.axonframework.upcasting.LazyUpcasterChain
Initializes the UpcasterChain with given upcasters and a ChainingConverterFactory to convert between content types.
LazyUpcasterChain(Serializer, List<Upcaster>) - Constructor for class org.axonframework.upcasting.LazyUpcasterChain
Initializes the UpcasterChain with given serializer and upcasters.
LazyUpcasterChain(ConverterFactory, List<Upcaster>) - Constructor for class org.axonframework.upcasting.LazyUpcasterChain
Initializes the UpcasterChain with given converterFactory and upcasters.
LegacyRabbitMqStrategy - Class in org.axonframework.eventhandling.amqp.spring
Strategy for creating a SimpleMessageListenerContainer instance using the Spring AMQP 1.2 API.
LegacyRabbitMqStrategy() - Constructor for class org.axonframework.eventhandling.amqp.spring.LegacyRabbitMqStrategy
 
lessThan(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
lessThan(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
lessThan(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must be "less than" the given expression.
lessThan(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
lessThan(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 
lessThanEquals(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
lessThanEquals(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
lessThanEquals(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must be "less than" or "equal to" the given expression.
lessThanEquals(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
lessThanEquals(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 
ListenerContainerFactory - Class in org.axonframework.eventhandling.amqp.spring
Factory for SimpleMessageListenerContainer beans.
ListenerContainerFactory() - Constructor for class org.axonframework.eventhandling.amqp.spring.ListenerContainerFactory
 
ListenerContainerLifecycleManager - Class in org.axonframework.eventhandling.amqp.spring
Manages the lifecycle of the SimpleMessageListenerContainers that have been created to receive messages for Clusters.
ListenerContainerLifecycleManager() - Constructor for class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
ListMatcher - Class in org.axonframework.test.matchers
Abstract implementation for matchers that use event-specific matchers to match against a list of items.
ListMatcher(Matcher<?>...) - Constructor for class org.axonframework.test.matchers.ListMatcher
Creates an abstract matcher to match a number of Matchers against Events contained inside a Collection.
listWithAllOf(Matcher<?>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a List where all the given matchers must match with at least one of the items in that list.
ListWithAllOfMatcher - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers match against at least one item in a given List.
ListWithAllOfMatcher(Matcher...) - Constructor for class org.axonframework.test.matchers.ListWithAllOfMatcher
Construct a matcher that will return true if all the given matchers match against at least one item in any given List.
listWithAnyOf(Matcher<?>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a List of Events where at least one of the given matchers matches any of the Events in that list.
ListWithAnyOfMatcher - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers match against at least one item in a given List.
ListWithAnyOfMatcher(Matcher...) - Constructor for class org.axonframework.test.matchers.ListWithAnyOfMatcher
Construct a matcher that will return true if any of the given matchers matches against at least one item in a given List.
load(String) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
load(Object, Long) - Method in class org.axonframework.repository.AbstractRepository
Load the aggregate with the given unique aggregateIdentifier, expecting the version of the aggregate to be equal to the given expectedVersion.
load(Object) - Method in class org.axonframework.repository.AbstractRepository
Load the aggregate with the given unique identifier.
load(Object, Long) - Method in class org.axonframework.repository.LockingRepository
Load the aggregate with the given unique aggregateIdentifier, expecting the version of the aggregate to be equal to the given expectedVersion.
load(Object, Long) - Method in interface org.axonframework.repository.Repository
Load the aggregate with the given unique aggregateIdentifier, expecting the version of the aggregate to be equal to the given expectedVersion.
load(Object) - Method in interface org.axonframework.repository.Repository
Load the aggregate with the given unique identifier.
load(String) - Method in class org.axonframework.saga.repository.CachingSagaRepository
 
load(String) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
load(String) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
load(String) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
load(String) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 
load(String) - Method in interface org.axonframework.saga.SagaRepository
Loads a known Saga instance by its unique identifier.
loadLastSnapshotEvent(String, Object) - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
 
loadLastSnapshotEvent(String, Object) - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
Load the last known snapshot event for aggregate of given type with given identifier.
loadLastSnapshotEvent(String, Object, EntityManager) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
 
loadLastSnapshotEvent(String, Object, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Load the last known snapshot event for aggregate of given type with given identifier using given entityManager.
LockAcquisitionFailedException - Exception in org.axonframework.common.lock
Exception indicating that a lock could not be obtained.
LockAcquisitionFailedException(String, Throwable) - Constructor for exception org.axonframework.common.lock.LockAcquisitionFailedException
Initialize the exception with given message and cause
LockAcquisitionFailedException(String) - Constructor for exception org.axonframework.common.lock.LockAcquisitionFailedException
Initialize the exception with given message.
LockingRepository<T extends AggregateRoot> - Class in org.axonframework.repository
Implementation of the Repository interface that takes provides a locking mechanism to prevent concurrent modifications of persisted aggregates.
LockingRepository(Class<T>) - Constructor for class org.axonframework.repository.LockingRepository
Initialize a repository with a pessimistic locking strategy.
LockingRepository(Class<T>, LockManager) - Constructor for class org.axonframework.repository.LockingRepository
Initialize the repository with the given lockManager.
LockingStrategy - Enum in org.axonframework.contextsupport.spring
Enum indicating possible locking strategies for repositories.
LockManager - Interface in org.axonframework.repository
Interface to the lock manager.
logFailed(CommandMessage<?>, Throwable, List<EventMessage>) - Method in interface org.axonframework.auditing.AuditLogger
Writes a failure entry to the audit logs.
logFailed(CommandMessage<?>, Throwable, List<EventMessage>) - Method in class org.axonframework.auditing.NullAuditLogger
Writes a failure entry to the audit logs.
LoggingCallback - Class in org.axonframework.commandhandling.callbacks
CommandCallback implementation that simply logs the results of a command.
LoggingCallback(CommandMessage<?>) - Constructor for class org.axonframework.commandhandling.callbacks.LoggingCallback
Initialize a LoggingCallback for the given message.
LoggingInterceptor - Class in org.axonframework.commandhandling.interceptors
Command Handler Interceptor that logs incoming commands and their result to a SLF4J logger.
LoggingInterceptor(String) - Constructor for class org.axonframework.commandhandling.interceptors.LoggingInterceptor
Initialize the LoggingInterceptor with the given loggerName.
LoggingInterceptor() - Constructor for class org.axonframework.commandhandling.interceptors.LoggingInterceptor
Initialize the LoggingInterceptor with the default logger name, which is the fully qualified class name of this logger.
logSuccessful(CommandMessage<?>, Object, List<EventMessage>) - Method in interface org.axonframework.auditing.AuditLogger
Writes a success entry to the audit logs.
logSuccessful(CommandMessage<?>, Object, List<EventMessage>) - Method in class org.axonframework.auditing.NullAuditLogger
Writes a success entry to the audit logs.
LOW - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should be placed at the "lower half".

M

main(String[]) - Static method in class org.axonframework.quickstart.RunAnnotatedAggregate
 
main(String[]) - Static method in class org.axonframework.quickstart.RunAnnotatedAggregateWithSpring
 
main(String[]) - Static method in class org.axonframework.quickstart.RunBasicCommandHandling
 
main(String[]) - Static method in class org.axonframework.quickstart.RunClusteringEventBus
 
main(String[]) - Static method in class org.axonframework.quickstart.RunClusteringEventBusWithSpring
 
main(String[]) - Static method in class org.axonframework.quickstart.RunDisruptorCommandBus
 
main(String[]) - Static method in class org.axonframework.quickstart.RunDisruptorCommandBusWithSpring
 
main(String[]) - Static method in class org.axonframework.quickstart.RunDistributedCommandBus
 
main(String[]) - Static method in class org.axonframework.quickstart.RunDistributedCommandBusWithSpring
 
main(String[]) - Static method in class org.axonframework.quickstart.RunEventReplay
 
main(String[]) - Static method in class org.axonframework.quickstart.RunEventReplayWithSpring
 
main(String[]) - Static method in class org.axonframework.quickstart.RunSaga
 
main(String[]) - Static method in class org.axonframework.quickstart.RunSagaWithSpring
 
main(String[]) - Static method in class org.axonframework.quickstart.RunUpcaster
 
main(String[]) - Static method in class org.axonframework.quickstart.RunUpcasterWithSpring
 
markCompleted(MarkCompletedCommand) - Method in class org.axonframework.quickstart.annotated.ToDoItem
 
markCompleted() - Method in class org.axonframework.quickstart.handler.ToDoItem
 
MarkCompletedCommand - Class in org.axonframework.quickstart.api
Command used to mark an existing ToDoItem as completed.
MarkCompletedCommand(String) - Constructor for class org.axonframework.quickstart.api.MarkCompletedCommand
 
MarkCompletedCommandHandler - Class in org.axonframework.quickstart.handler
 
MarkCompletedCommandHandler(Repository<ToDoItem>) - Constructor for class org.axonframework.quickstart.handler.MarkCompletedCommandHandler
 
markDeleted() - Method in class org.axonframework.domain.AbstractAggregateRoot
Marks this aggregate as deleted, instructing a Repository to remove that aggregate at an appropriate time.
MarkToDoItemOverdueCommand - Class in org.axonframework.quickstart.api
 
MarkToDoItemOverdueCommand(String) - Constructor for class org.axonframework.quickstart.api.MarkToDoItemOverdueCommand
 
MatchAllFieldFilter - Class in org.axonframework.test.matchers
FieldFilter that delegates to an arbitrary number of other filters.
MatchAllFieldFilter(Collection<FieldFilter>) - Constructor for class org.axonframework.test.matchers.MatchAllFieldFilter
Initializes a filter that accepts any field that is accepted by all given filters
MatcherExecutionException - Exception in org.axonframework.test.matchers
Exception indicating that an error occurred that prevented successful execution of a matcher.
MatcherExecutionException(String) - Constructor for exception org.axonframework.test.matchers.MatcherExecutionException
Construct the exception with the given message.
MatcherExecutionException(String, Throwable) - Constructor for exception org.axonframework.test.matchers.MatcherExecutionException
Construct the exception with the given message and cause.
Matchers - Class in org.axonframework.test.matchers
Utility class containing static methods to obtain instances of (List) Matchers.
matches(Message) - Method in class org.axonframework.commandhandling.annotation.CurrentUnitOfWorkParameterResolverFactory
 
matches(Message) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
Indicates whether this Handler is suitable for the given message.
matches(Message) - Method in class org.axonframework.common.annotation.FixedValueParameterResolver
 
matches(Message) - Method in interface org.axonframework.common.annotation.ParameterResolver
Indicates whether this resolver is capable of providing a value for the given message.
matches(EventMessage) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Indicates whether this Handler is suitable for the given message.
matches(Object) - Method in class org.axonframework.test.matchers.EmptyCollectionMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.ListMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.NullOrVoidMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.PayloadMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.PayloadsMatcher
 
matchesList(List<?>) - Method in class org.axonframework.test.matchers.ExactSequenceMatcher
 
matchesList(List<?>) - Method in class org.axonframework.test.matchers.ListMatcher
Evaluates the matcher for argument item.
matchesList(List<?>) - Method in class org.axonframework.test.matchers.ListWithAllOfMatcher
 
matchesList(List<?>) - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
matchesList(List<?>) - Method in class org.axonframework.test.matchers.SequenceMatcher
 
matchRemainder(Iterator<Matcher<?>>) - Method in class org.axonframework.test.matchers.ListMatcher
Matches all the remaining Matchers in the given matcherIterator against null.
MavenArtifactRevisionResolver - Class in org.axonframework.serializer
RevisionResolver that uses Maven meta data to retrieve the application version.
MavenArtifactRevisionResolver(String, String) - Constructor for class org.axonframework.serializer.MavenArtifactRevisionResolver
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given groupId and artifactId.
MavenArtifactRevisionResolver(String, String, ClassLoader) - Constructor for class org.axonframework.serializer.MavenArtifactRevisionResolver
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given groupId and artifactId.
md5Hex(String) - Static method in class org.axonframework.common.digest.Digester
Utility method that creates a hex string of the MD5 hash of the given input
MemberAccessibilityCallback - Class in org.axonframework.common
PrivilegedAction that makes the given method accessible for reflection.
MemberAccessibilityCallback(AccessibleObject) - Constructor for class org.axonframework.common.MemberAccessibilityCallback
Initialize the callback to make the given method accessible for reflection.
MemberAwareCommandCallback<R> - Class in org.axonframework.commandhandling.distributed.jgroups.support.callbacks
Callback implementation which wraps another callback, and is aware of the JGroups node responsible for providing the value to invoke the wrapped callback with.
MemberAwareCommandCallback(Address, CommandCallback<R>) - Constructor for class org.axonframework.commandhandling.distributed.jgroups.support.callbacks.MemberAwareCommandCallback
Initialize the callback, where the given dest is responsible for providing the value to invoke the given callback with.
MembershipUpdateFailedException - Exception in org.axonframework.commandhandling.distributed.jgroups
Exception indicating that a node has failed to update its membership details with the other nodes.
MembershipUpdateFailedException(String) - Constructor for exception org.axonframework.commandhandling.distributed.jgroups.MembershipUpdateFailedException
Initializes the exception using the given message.
MembershipUpdateFailedException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.jgroups.MembershipUpdateFailedException
Initializes the exception using the given message and cause.
mergedWith(Map<String, ?>) - Method in class org.axonframework.domain.MetaData
Returns a MetaData instance containing values of this, combined with the given additionalEntries.
Message<T> - Interface in org.axonframework.domain
Representation of a Message, containing a Payload and MetaData.
MessageHandlerAdapter - Class in org.axonframework.integration.eventbus
Adapter that allows an EventListener to be registered as a Spring Integration MessageHandler.
MessageHandlerAdapter(EventListener) - Constructor for class org.axonframework.integration.eventbus.MessageHandlerAdapter
Initialize an adapter for the given eventListener.
MessageHandlerAdapter - Class in org.axonframework.springmessaging.eventbus
Adapter that allows an EventListener to be registered as a Spring Messaging MessageHandler.
MessageHandlerAdapter(EventListener) - Constructor for class org.axonframework.springmessaging.eventbus.MessageHandlerAdapter
Initialize an adapter for the given eventListener.
MessageHandlerInvocationException - Exception in org.axonframework.common.annotation
MessageHandlerInvocationException is a runtime exception that wraps an exception thrown by an invoked message handler.
MessageHandlerInvocationException(String, Throwable) - Constructor for exception org.axonframework.common.annotation.MessageHandlerInvocationException
Initialize the MessageHandlerInvocationException using given message and cause.
MessageHandlerInvoker - Class in org.axonframework.common.annotation
Abstract class to support implementations that need to invoke methods based on an annotation.
MessageHandlerInvoker(Object, ParameterResolverFactory, boolean, HandlerDefinition<? super Method>) - Constructor for class org.axonframework.common.annotation.MessageHandlerInvoker
Initialize a handler invoker for the given target object that has handler method annotated with given annotationType.
MessageSerializer - Class in org.axonframework.serializer
Wrapper around a serializer that provides SerializationAware support.
MessageSerializer(Serializer) - Constructor for class org.axonframework.serializer.MessageSerializer
Initializes the MessageSerializer as a wrapper around the given serializer.
messageWithPayload(Matcher<?>) - Static method in class org.axonframework.test.matchers.Matchers
Matches a single Message if the given payloadMatcher matches that message's payload.
MetaData - Annotation Type in org.axonframework.common.annotation
Annotation that indicates the parameter needs to be resolved to the value of the Message MetaData stored under the given key.
MetaData - Class in org.axonframework.domain
Represents MetaData that is passed along with a payload in a Message.
MetaData(Map<String, ?>) - Constructor for class org.axonframework.domain.MetaData
Initializes a MetaData instance with the given items as content.
MetaDataCommandTargetResolver - Class in org.axonframework.commandhandling
CommandTargetResolver implementation that uses MetaData entries to extract the identifier and optionally the version of the aggregate that the command targets.
MetaDataCommandTargetResolver(String) - Constructor for class org.axonframework.commandhandling.MetaDataCommandTargetResolver
Initializes the MetaDataCommandTargetResolver to use the given identifierKey as the MetaData key to the aggregate identifier, and a null (ignored) version.
MetaDataCommandTargetResolver(String, String) - Constructor for class org.axonframework.commandhandling.MetaDataCommandTargetResolver
Initializes the MetaDataCommandTargetResolver to use the given identifierKey as the MetaData key to the aggregate identifier, and the given versionKey as key to the (optional) version entry.
MetaDataDeserializer - Class in org.axonframework.serializer.json
JsonDeserializer implementation that deserializes MetaData instances.
MetaDataDeserializer() - Constructor for class org.axonframework.serializer.json.MetaDataDeserializer
 
MetaDataMutatingUnitOfWorkListenerAdapter - Class in org.axonframework.unitofwork
Specialist UnitOfWorkListenerAdapter that allows modification of Meta Data of Events during the "beforeCommit" phase of a Unit of Work.
MetaDataMutatingUnitOfWorkListenerAdapter() - Constructor for class org.axonframework.unitofwork.MetaDataMutatingUnitOfWorkListenerAdapter
 
MetaDataRoutingStrategy - Class in org.axonframework.commandhandling.distributed
RoutingStrategy implementation that uses the value in the MetaData of a CommandMessage assigned to a given key.
MetaDataRoutingStrategy(String) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Initializes the MetaDataRoutingStrategy where the given metaDataKey is used to get the Meta Data value.
MetaDataRoutingStrategy(String, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Initializes the MetaDataRoutingStrategy where the given metaDataKey is used to get the Meta Data value.
MethodAccessedProperty<T> - Class in org.axonframework.common.property
Property implementation that invokes a method to obtain a value of a property for a given instance.
MethodAccessedProperty(Method, String) - Constructor for class org.axonframework.common.property.MethodAccessedProperty
Initialize a reader that uses given accessorMethod to access a property with given propertyName.
MethodMessageHandler - Class in org.axonframework.common.annotation
Represents a method recognized as a handler by the handler inspector (see MethodMessageHandlerInspector).
MethodMessageHandlerInspector - Class in org.axonframework.common.annotation
Utility class that inspects handler methods for a given class and handler definition.
methodsOf(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Returns an Iterable of all the methods declared on the given class and its super classes.
MongoCriteria - Class in org.axonframework.eventstore.mongo.criteria
Abstract class for Mongo-based criteria.
MongoCriteria() - Constructor for class org.axonframework.eventstore.mongo.criteria.MongoCriteria
 
MongoCriteria - Class in org.axonframework.mongo3.eventstore.criteria
Abstract class for Mongo-based criteria.
MongoCriteria() - Constructor for class org.axonframework.mongo3.eventstore.criteria.MongoCriteria
 
MongoCriteriaBuilder - Class in org.axonframework.eventstore.mongo.criteria
The CriteriaBuilder implementation for use with the Mongo event store.
MongoCriteriaBuilder() - Constructor for class org.axonframework.eventstore.mongo.criteria.MongoCriteriaBuilder
 
MongoCriteriaBuilder - Class in org.axonframework.mongo3.eventstore.criteria
The CriteriaBuilder implementation for use with the Mongo event store.
MongoCriteriaBuilder() - Constructor for class org.axonframework.mongo3.eventstore.criteria.MongoCriteriaBuilder
 
MongoEventStore - Class in org.axonframework.eventstore.mongo
Implementation of the EventStore based on a MongoDB instance or replica set.
MongoEventStore(Serializer, MongoTemplate) - Constructor for class org.axonframework.eventstore.mongo.MongoEventStore
Constructor that accepts a Serializer and the MongoTemplate.
MongoEventStore(MongoTemplate) - Constructor for class org.axonframework.eventstore.mongo.MongoEventStore
Constructor that uses the default Serializer.
MongoEventStore(MongoTemplate, StorageStrategy) - Constructor for class org.axonframework.eventstore.mongo.MongoEventStore
Constructor that accepts a MongoTemplate and a custom StorageStrategy.
MongoEventStore(MongoTemplate, Serializer, StorageStrategy) - Constructor for class org.axonframework.eventstore.mongo.MongoEventStore
Initialize the mongo event store with given mongoTemplate, eventSerializer and storageStrategy.
MongoEventStore - Class in org.axonframework.mongo3.eventstore
Implementation of the EventStore based on a MongoDB instance or replica set.
MongoEventStore(Serializer, MongoTemplate) - Constructor for class org.axonframework.mongo3.eventstore.MongoEventStore
Constructor that accepts a Serializer and the MongoTemplate.
MongoEventStore(MongoTemplate) - Constructor for class org.axonframework.mongo3.eventstore.MongoEventStore
Constructor that uses the default Serializer.
MongoEventStore(MongoTemplate, StorageStrategy) - Constructor for class org.axonframework.mongo3.eventstore.MongoEventStore
Constructor that accepts a MongoTemplate and a custom StorageStrategy.
MongoEventStore(MongoTemplate, Serializer, StorageStrategy) - Constructor for class org.axonframework.mongo3.eventstore.MongoEventStore
Initialize the mongo event store with given mongoTemplate, eventSerializer and storageStrategy.
MongoFactory - Class in org.axonframework.eventstore.mongo
Convenience class for creating Mongo instances.
MongoFactory() - Constructor for class org.axonframework.eventstore.mongo.MongoFactory
 
MongoFactory - Class in org.axonframework.mongo3.eventstore
Convenience class for creating Mongo instances.
MongoFactory() - Constructor for class org.axonframework.mongo3.eventstore.MongoFactory
 
MongoOptionsFactory - Class in org.axonframework.eventstore.mongo
Factory class used to create a MongoOptions instance.
MongoOptionsFactory() - Constructor for class org.axonframework.eventstore.mongo.MongoOptionsFactory
Default constructor for the factory that initializes the defaults.
MongoOptionsFactory - Class in org.axonframework.mongo3.eventstore
Factory class used to create a MongoOptions instance.
MongoOptionsFactory() - Constructor for class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Default constructor for the factory that initializes the defaults.
MongoProperty - Class in org.axonframework.eventstore.mongo.criteria
Property implementation for use by the Mongo Event Store.
MongoProperty(String) - Constructor for class org.axonframework.eventstore.mongo.criteria.MongoProperty
Initialize a property for the given propertyName.
MongoProperty - Class in org.axonframework.mongo3.eventstore.criteria
Property implementation for use by the Mongo Event Store.
MongoProperty(String) - Constructor for class org.axonframework.mongo3.eventstore.criteria.MongoProperty
Initialize a property for the given propertyName.
MongoSagaRepository - Class in org.axonframework.mongo3.saga.repository
Implementations of the SagaRepository that stores Sagas and their associations in a Mongo Database.
MongoSagaRepository(MongoTemplate) - Constructor for class org.axonframework.mongo3.saga.repository.MongoSagaRepository
Initializes the Repository, using given mongoTemplate to access the collections containing the stored Saga instances.
MongoSagaRepository - Class in org.axonframework.saga.repository.mongo
Implementations of the SagaRepository that stores Sagas and their associations in a Mongo Database.
MongoSagaRepository(MongoTemplate) - Constructor for class org.axonframework.saga.repository.mongo.MongoSagaRepository
Initializes the Repository, using given mongoTemplate to access the collections containing the stored Saga instances.
MongoTemplate - Interface in org.axonframework.eventstore.mongo
Interface describing a mechanism that provides access to the Database and Collections required by the MongoEventStore.
MongoTemplate - Interface in org.axonframework.mongo3.eventstore
Interface describing a mechanism that provides access to the Database and Collections required by the MongoEventStore.
MongoTemplate - Interface in org.axonframework.mongo3.saga.repository
Generic template for accessing Mongo for the axon sagas.
MongoTemplate - Interface in org.axonframework.saga.repository.mongo
Generic template for accessing Mongo for the axon sagas.
MonitorRegistry - Class in org.axonframework.monitoring
Abstract Factory providing access to the MonitorRegistry implementations available at runtime.
MonitorRegistry() - Constructor for class org.axonframework.monitoring.MonitorRegistry
 
moveDown() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
moveDown() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
moveUp() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
moveUp() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
MultiCorrelationDataProvider<T extends Message> - Class in org.axonframework.correlation
CorrelationDataProvider that combines the data of multiple other correlation providers.
MultiCorrelationDataProvider(List<? extends CorrelationDataProvider<? super T>>) - Constructor for class org.axonframework.correlation.MultiCorrelationDataProvider
Initialize the correlation data provider, delegating to given correlationDataProviders.
MultiParameterResolverFactory - Class in org.axonframework.common.annotation
ParameterResolverFactory instance that delegates to multiple other instances, in the order provided.
MultiParameterResolverFactory(ParameterResolverFactory...) - Constructor for class org.axonframework.common.annotation.MultiParameterResolverFactory
Initializes an instance that delegates to the given delegates, in the order provided.
MultiParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.common.annotation.MultiParameterResolverFactory
Initializes an instance that delegates to the given delegates, in the order provided.
MultiplexingEventProcessingMonitor - Class in org.axonframework.eventhandling
Implementation of the EventProcessingMonitor that receives multiple invocations of downstream monitors and translates that to a single invocation to a target monitor.
MultiplexingEventProcessingMonitor(EventProcessingMonitor) - Constructor for class org.axonframework.eventhandling.MultiplexingEventProcessingMonitor
Creates an instance with the given targetMonitor as the monitor to eventually forward calls to.

N

name() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.Member
Returns the name of this member.
NestableUnitOfWork - Class in org.axonframework.unitofwork
Abstract implementation of the UnitOfWork interface.
NestableUnitOfWork() - Constructor for class org.axonframework.unitofwork.NestableUnitOfWork
 
NEUTRAL - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should have medium priority, effectively placing it "in the middle".
newCriteriaBuilder() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Returns a CriteriaBuilder that allows the construction of criteria for this EventStore implementation
newCriteriaBuilder() - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
 
newCriteriaBuilder() - Method in class org.axonframework.eventstore.jpa.JpaEventStore
 
newCriteriaBuilder() - Method in interface org.axonframework.eventstore.management.EventStoreManagement
Returns a CriteriaBuilder that allows the construction of criteria for this EventStore implementation
newCriteriaBuilder() - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
newCriteriaBuilder() - Method in class org.axonframework.eventstore.supporting.SequenceEventStore
 
newCriteriaBuilder() - Method in class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
 
newCriteriaBuilder() - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
 
newCriteriaBuilder() - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
newCriteriaBuilder() - Method in class org.axonframework.quickstart.RunEventReplay.StubEventStore
 
newGivenWhenThenFixture(Class<T>) - Static method in class org.axonframework.test.Fixtures
Returns a new given-when-then style test fixture in configuration mode.
newInstance() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry.Factory
 
newInstance(String) - Static method in class org.axonframework.common.digest.Digester
Creates a new Digester instance for the given algorithm.
newMD5Instance() - Static method in class org.axonframework.common.digest.Digester
Creates a new Digester instance for the MD5 Algorithm
newProcessingScheduler(EventProcessor.ShutdownCallback, Set<EventListener>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.async.AsynchronousCluster
Creates a new scheduler instance that schedules tasks on the executor service for the managed EventListener.
newThread(Runnable) - Method in class org.axonframework.common.AxonThreadFactory
 
next() - Method in interface org.axonframework.domain.DomainEventStream
Returns the next events in the stream, if available.
next() - Method in class org.axonframework.domain.SimpleDomainEventStream
Returns the next events in the stream, if available.
next() - Method in class org.axonframework.eventstore.fs.FileSystemBufferedReaderDomainEventStream
 
NoCache - Class in org.axonframework.cache
Cache implementation that does absolutely nothing.
noCommands() - Static method in class org.axonframework.test.matchers.Matchers
Matches an empty List of Commands.
noEvents() - Static method in class org.axonframework.test.matchers.Matchers
Matches an empty List of Events.
NoFilter - Class in org.axonframework.integration.adapter
 
NoFilter() - Constructor for class org.axonframework.integration.adapter.NoFilter
 
NoFilter - Class in org.axonframework.springmessaging.adapter
 
NoFilter() - Constructor for class org.axonframework.springmessaging.adapter.NoFilter
 
noHandler() - Static method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
Returns a SagaMethodMessageHandler indicating that a inspected method is *not* a SagaEventHandler.
NoHandlerForCommandException - Exception in org.axonframework.commandhandling
Exception indicating that no suitable handler could be found for the given command.
NoHandlerForCommandException(String) - Constructor for exception org.axonframework.commandhandling.NoHandlerForCommandException
Initialize a NoHandlerForCommandException with the given message.
NONE - Static variable in class org.axonframework.saga.SagaInitializationPolicy
Value indicating there is no Initialization required
NonTransientFieldsFilter - Class in org.axonframework.test.matchers
FieldFilter implementation that only accepts non-transient Fields.
NoOpCallback - Class in org.axonframework.commandhandling.callbacks
Callback that does absolutely nothing when invoked.
NoOpCallback() - Constructor for class org.axonframework.commandhandling.callbacks.NoOpCallback
 
notEmpty(String, String) - Static method in class org.axonframework.common.Assert
Assert that the given value is not null or empty.
NotEquals - Class in org.axonframework.eventstore.jdbc.criteria
Implementations of the NOT EQUALS operator for a Jdbc Event Store.
NotEquals(JdbcProperty, Object) - Constructor for class org.axonframework.eventstore.jdbc.criteria.NotEquals
Initializes a NOT EQUALS operator where the given property must not be equal to the given expression.
NotEquals - Class in org.axonframework.eventstore.jpa.criteria
Implementations of the NOT EQUALS operator for a JPA Event Store.
NotEquals(JpaProperty, Object) - Constructor for class org.axonframework.eventstore.jpa.criteria.NotEquals
Initializes a NOT EQUALS operator where the given property must not be equal to the given expression.
nothing() - Static method in class org.axonframework.test.matchers.Matchers
Matches against null or void.
notifyListenersAfterCommit() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
Send a UnitOfWorkListener.afterCommit(UnitOfWork) notification to all registered listeners.
notifyListenersCleanup() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
notifyListenersCleanup() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Send a UnitOfWorkListener.onCleanup(UnitOfWork) notification to all registered listeners.
notifyListenersPrepareCommit() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
notifyListenersPrepareCommit() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Send a UnitOfWorkListener.onPrepareCommit(UnitOfWork, java.util.Set, java.util.List) notification to all registered listeners.
notifyListenersPrepareTransactionCommit(Object) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
Send a UnitOfWorkListener.afterCommit(UnitOfWork) notification to all registered listeners.
notifyListenersRollback(Throwable) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
notifyListenersRollback(Throwable) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Send a UnitOfWorkListener.onRollback(UnitOfWork, Throwable) notification to all registered listeners.
notIn(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
 
notIn(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
 
notIn(Object) - Method in interface org.axonframework.eventstore.management.Property
Returns a criteria instance where the property must be "not in" the given expression.
notIn(Object) - Method in class org.axonframework.eventstore.mongo.criteria.MongoProperty
 
notIn(Object) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoProperty
 
notNull(Object, String) - Static method in class org.axonframework.common.Assert
Assert that the given value is not null.
NoTransactionManager - Class in org.axonframework.unitofwork
TransactionManager implementation that does nothing.
NoTransactionManager() - Constructor for class org.axonframework.unitofwork.NoTransactionManager
 
NullAuditLogger - Class in org.axonframework.auditing
An implementation of AuditLogger that does nothing.
NullAuditLogger() - Constructor for class org.axonframework.auditing.NullAuditLogger
 
NullLockManager - Class in org.axonframework.repository
LockManager implementation that does nothing.
NullLockManager() - Constructor for class org.axonframework.repository.NullLockManager
 
NullOrVoidMatcher<T> - Class in org.axonframework.test.matchers
Matcher that matches against a null or void value.
NullOrVoidMatcher() - Constructor for class org.axonframework.test.matchers.NullOrVoidMatcher
 

O

obtainLock(String) - Method in class org.axonframework.common.lock.IdentifierBasedLock
Obtain a lock on the given identifier.
obtainLock(Object) - Method in interface org.axonframework.repository.LockManager
Obtain a lock for an aggregate with the given aggregateIdentifier.
obtainLock(Object) - Method in class org.axonframework.repository.NullLockManager
Obtain a lock for an aggregate with the given aggregateIdentifier.
obtainLock(Object) - Method in class org.axonframework.repository.OptimisticLockManager
Obtain a lock for an aggregate with the given aggregateIdentifier.
obtainLock(Object) - Method in class org.axonframework.repository.PessimisticLockManager
Obtain a lock for an aggregate.
on(ToDoItemCreatedEvent) - Method in class org.axonframework.quickstart.annotated.ToDoItem
 
onAfterCommit() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Invokes this UnitOfWork's on-after-commit cycle.
onCleanup() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Invokes this UnitOfWork's on-cleanup cycle.
onCleanup(UnitOfWork) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Notifies listeners that the UnitOfWork is being cleaned up.
onCleanup(UnitOfWork) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Notifies listeners that the UnitOfWork is being cleaned up.
onCleanup(UnitOfWork) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
Notifies listeners that the UnitOfWork is being cleaned up.
onClusterCreated(Cluster) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
 
onClusterCreated(Cluster) - Method in interface org.axonframework.eventhandling.EventBusTerminal
Invoked when an Event Listener has been assigned to a cluster that was not yet known to the Event Bus.
onDeadlineExpired(ToDoItemDeadlineExpiredEvent) - Method in class org.axonframework.quickstart.saga.ToDoSaga
 
onEntryCreated(Object, Object) - Method in interface org.axonframework.cache.Cache.EntryListener
Invoked when a new item has been added to the cache
onEntryCreated(Object, Object) - Method in class org.axonframework.cache.Cache.EntryListenerAdapter
 
onEntryExpired(Object) - Method in interface org.axonframework.cache.Cache.EntryListener
Invoked when an entry has expired.
onEntryExpired(Object) - Method in class org.axonframework.cache.Cache.EntryListenerAdapter
 
onEntryRead(Object, Object) - Method in interface org.axonframework.cache.Cache.EntryListener
Invoked when an item was retrieved from the Cache
onEntryRead(Object, Object) - Method in class org.axonframework.cache.Cache.EntryListenerAdapter
 
onEntryRemoved(Object) - Method in interface org.axonframework.cache.Cache.EntryListener
Invoked when an item was removed from the cache, either following an expiry, or by explicitly calling Cache.remove(Object).
onEntryRemoved(Object) - Method in class org.axonframework.cache.Cache.EntryListenerAdapter
 
onEntryUpdated(Object, Object) - Method in interface org.axonframework.cache.Cache.EntryListener
Invoked when an item has been updated.
onEntryUpdated(Object, Object) - Method in class org.axonframework.cache.Cache.EntryListenerAdapter
 
onErrorInvoking(Saga, EventMessage, int, Exception) - Method in interface org.axonframework.saga.annotation.ErrorHandler
Invoked when an error occurs when a Saga instance is invoked.
onErrorInvoking(Saga, EventMessage, int, Exception) - Method in class org.axonframework.saga.annotation.ProceedingErrorHandler
 
onErrorInvoking(Saga, EventMessage, int, Exception) - Method in class org.axonframework.saga.annotation.RetryingErrorHandler
 
onErrorPreparing(Class<? extends Saga>, EventMessage<?>, int, Exception) - Method in interface org.axonframework.saga.annotation.ErrorHandler
Invoked when an error occurs preparing Sagas.
onErrorPreparing(Class<? extends Saga>, EventMessage<?>, int, Exception) - Method in class org.axonframework.saga.annotation.ProceedingErrorHandler
 
onErrorPreparing(Class<? extends Saga>, EventMessage<?>, int, Exception) - Method in class org.axonframework.saga.annotation.RetryingErrorHandler
 
onEvent(CommandHandlingEntry, long, boolean) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
 
onEvent(CommandHandlingEntry, long, boolean) - Method in class org.axonframework.commandhandling.disruptor.EventPublisher
 
onEvent(CommandHandlingEntry, long, boolean) - Method in class org.axonframework.commandhandling.disruptor.SerializerHandler
 
onEvent(EventMessage) - Method in class org.axonframework.quickstart.RunClusteringEventBusWithSpring.ThreadPrintingEventListener
 
onEvent(EventMessage) - Method in class org.axonframework.quickstart.RunEventReplay.ThreadPrintingEventListener
 
onEvent(AsyncSagaProcessingEvent, long, boolean) - Method in class org.axonframework.saga.annotation.AsyncSagaEventProcessor
 
onEventProcessingCompleted(List<? extends EventMessage>) - Method in interface org.axonframework.eventhandling.EventProcessingMonitor
Invoked when one or more events have been successfully processed by the instance it was subscribed to.
onEventProcessingCompleted(List<? extends EventMessage>) - Method in class org.axonframework.eventhandling.EventProcessingMonitorCollection
 
onEventProcessingCompleted(List<? extends EventMessage>) - Method in class org.axonframework.eventhandling.MultiplexingEventProcessingMonitor
 
onEventProcessingFailed(List<? extends EventMessage>, Throwable) - Method in interface org.axonframework.eventhandling.EventProcessingMonitor
Invoked when one or more events have failed processing by the instance it was subscribed to.
onEventProcessingFailed(List<? extends EventMessage>, Throwable) - Method in class org.axonframework.eventhandling.EventProcessingMonitorCollection
 
onEventProcessingFailed(List<? extends EventMessage>, Throwable) - Method in class org.axonframework.eventhandling.MultiplexingEventProcessingMonitor
 
onEventRegistered(UnitOfWork, EventMessage<T>) - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
 
onEventRegistered(UnitOfWork, EventMessage<T>) - Method in class org.axonframework.unitofwork.MetaDataMutatingUnitOfWorkListenerAdapter
 
onEventRegistered(UnitOfWork, EventMessage<T>) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked when an Event is registered for publication when the UnitOfWork is committed.
onEventRegistered(UnitOfWork, EventMessage<T>) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Invoked when an Event is registered for publication when the UnitOfWork is committed.
onEventRegistered(UnitOfWork, EventMessage<T>) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
Invoked when an Event is registered for publication when the UnitOfWork is committed.
onFailure(Throwable) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
 
onFailure(Throwable) - Method in class org.axonframework.commandhandling.callbacks.LoggingCallback
 
onFailure(Throwable) - Method in class org.axonframework.commandhandling.callbacks.NoOpCallback
Invoked when command handling execution resulted in an error.
onFailure(Throwable) - Method in interface org.axonframework.commandhandling.CommandCallback
Invoked when command handling execution resulted in an error.
onFailure(Throwable) - Method in class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
 
onFailure(Throwable) - Method in class org.axonframework.commandhandling.distributed.jgroups.support.callbacks.MemberAwareCommandCallback
 
onFailure(Throwable) - Method in class org.axonframework.commandhandling.distributed.jgroups.support.callbacks.ReplyingCallback
 
onFailure(Throwable) - Method in class org.axonframework.commandhandling.gateway.RetryingCallback
 
onFailure(Throwable) - Method in class org.axonframework.test.ResultValidatorImpl
 
onIncomingMessages(Cluster, EventMessage...) - Method in class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
 
onIncomingMessages(Cluster, EventMessage...) - Method in class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
 
onIncomingMessages(Cluster, EventMessage...) - Method in interface org.axonframework.eventhandling.replay.IncomingMessageHandler
Invoked while the ReplayingCluster is in replay mode and an Event is being dispatched to the Cluster.
onMessage(Message) - Method in class org.axonframework.eventhandling.amqp.spring.ClusterMessageListener
 
onPrepareCommit() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Invokes this UnitOfWork's on-prepare-commit cycle.
onPrepareCommit(UnitOfWork, Set<AggregateRoot>, List<EventMessage>) - Method in class org.axonframework.unitofwork.MetaDataMutatingUnitOfWorkListenerAdapter
 
onPrepareCommit(UnitOfWork, Set<AggregateRoot>, List<EventMessage>) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked before aggregates are committed, and before any events are published.
onPrepareCommit(UnitOfWork, Set<AggregateRoot>, List<EventMessage>) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Invoked before aggregates are committed, and before any events are published.
onPrepareCommit(UnitOfWork, Set<AggregateRoot>, List<EventMessage>) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
Invoked before aggregates are committed, and before any events are published.
onPrepareTransactionCommit(Object) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Invokes this UnitOfWork's on-prepare-transaction-commit cycle.
onPrepareTransactionCommit(UnitOfWork, Object) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked before the transaction bound to this Unit of Work is committed, but after all other commit activities (publication of events and saving of aggregates) are performed.
onPrepareTransactionCommit(UnitOfWork, Object) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
 
onPrepareTransactionCommit(UnitOfWork, Object) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
 
onRegisteredEvent(DomainEventMessage<T>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
onRegisteredEvent(DomainEventMessage<T>) - Method in interface org.axonframework.domain.EventRegistrationCallback
Invoked when an Aggregate registers an Event for publication.
onReplayFailed(Throwable) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
 
onReplayFailed(Cluster, Throwable) - Method in class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
 
onReplayFailed(Cluster, Throwable) - Method in class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
 
onReplayFailed(Cluster, Throwable) - Method in interface org.axonframework.eventhandling.replay.IncomingMessageHandler
Invoked when a replay has failed.
onReplayFailed(Throwable) - Method in interface org.axonframework.eventhandling.replay.ReplayAware
Invoked when a replay has failed due to an exception.
onReplayFailed(Throwable) - Method in class org.axonframework.quickstart.RunEventReplay.AnotherThreadPrintingEventListener
 
onReplayFailed(Throwable) - Method in class org.axonframework.saga.AbstractReplayAwareSagaManager
 
onRollback(UnitOfWork, Throwable) - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
 
onRollback(Throwable) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Invokes this UnitOfWork's on-rollback cycle.
onRollback(UnitOfWork, Throwable) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked when the UnitOfWork is rolled back.
onRollback(UnitOfWork, Throwable) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Invoked when the UnitOfWork is rolled back.
onRollback(UnitOfWork, Throwable) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
Invoked when the UnitOfWork is rolled back.
onShutdown() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
 
onShutdown() - Method in class org.axonframework.saga.annotation.AsyncSagaEventProcessor
 
onStart() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
 
onStart() - Method in class org.axonframework.saga.annotation.AsyncSagaEventProcessor
 
onSuccess(R) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
 
onSuccess(Object) - Method in class org.axonframework.commandhandling.callbacks.LoggingCallback
 
onSuccess(Object) - Method in class org.axonframework.commandhandling.callbacks.NoOpCallback
Invoked when command handling execution was successful.
onSuccess(Object) - Method in class org.axonframework.commandhandling.callbacks.VoidCallback
Invoked when command handling execution was successful.
onSuccess() - Method in class org.axonframework.commandhandling.callbacks.VoidCallback
Invoked when command handling execution was successful.
onSuccess(R) - Method in interface org.axonframework.commandhandling.CommandCallback
Invoked when command handling execution was successful.
onSuccess(R) - Method in class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
 
onSuccess(R) - Method in class org.axonframework.commandhandling.distributed.jgroups.support.callbacks.MemberAwareCommandCallback
 
onSuccess(Object) - Method in class org.axonframework.commandhandling.distributed.jgroups.support.callbacks.ReplyingCallback
 
onSuccess(R) - Method in class org.axonframework.commandhandling.gateway.RetryingCallback
 
onSuccess(Object) - Method in class org.axonframework.test.ResultValidatorImpl
 
onToDoItemCompleted(ToDoItemCompletedEvent) - Method in class org.axonframework.quickstart.saga.ToDoSaga
 
onToDoItemCreated(ToDoItemCreatedEvent) - Method in class org.axonframework.quickstart.saga.ToDoSaga
 
openEventFileForReading(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
Provides an input stream to the (regular) events file for the aggregate with the given aggregateIdentifier and of given type.
openEventFileForReading(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
openEventFileForWriting(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
Provides an output stream to the (regular) events file for the aggregate with the given aggregateIdentifier and of given type.
openEventFileForWriting(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
openSnapshotFileForReading(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
Provides an input stream to the snapshot events file for the aggregate with the given aggregateIdentifier and of given type.
openSnapshotFileForReading(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
openSnapshotFileForWriting(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
Provides an output stream to the snapshot events file for the aggregate with the given aggregateIdentifier and of given type.
openSnapshotFileForWriting(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
OptimisticLockManager - Class in org.axonframework.repository
Implementation of the LockManager that uses an optimistic locking strategy.
OptimisticLockManager() - Constructor for class org.axonframework.repository.OptimisticLockManager
 
or(Criteria) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcCriteria
 
or(Criteria) - Method in class org.axonframework.eventstore.jpa.criteria.JpaCriteria
 
or(Criteria) - Method in interface org.axonframework.eventstore.management.Criteria
Returns a criteria instance where either this or the given criteria must match.
or(Criteria) - Method in class org.axonframework.eventstore.mongo.criteria.MongoCriteria
 
Or - Class in org.axonframework.eventstore.mongo.criteria
Represents the OR operator for use by the Mongo Event Store.
Or(MongoCriteria, MongoCriteria) - Constructor for class org.axonframework.eventstore.mongo.criteria.Or
Initializes an OR operator where one of the given criteria must evaluate to true.
or(Criteria) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoCriteria
 
Or - Class in org.axonframework.mongo3.eventstore.criteria
Represents the OR operator for use by the Mongo Event Store.
Or(MongoCriteria, MongoCriteria) - Constructor for class org.axonframework.mongo3.eventstore.criteria.Or
Initializes an OR operator where one of the given criteria must evaluate to true.
ordered(ParameterResolverFactory...) - Static method in class org.axonframework.common.annotation.MultiParameterResolverFactory
Creates a MultiParameterResolverFactory instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
ordered(List<ParameterResolverFactory>) - Static method in class org.axonframework.common.annotation.MultiParameterResolverFactory
Creates a MultiParameterResolverFactory instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
orderOf(EventListener) - Method in interface org.axonframework.eventhandling.OrderResolver
Returns the order for the given listener.
orderOf(EventListener) - Method in class org.axonframework.eventhandling.SpringAnnotationOrderResolver
 
OrderResolver - Interface in org.axonframework.eventhandling
Interface describing a mechanism that provides the order for any given Event Listener.
org.axonframework.auditing - package org.axonframework.auditing
 
org.axonframework.cache - package org.axonframework.cache
Package containing a Caching abstraction, while waiting for the JSR 107 to be fully specified and implemented.
org.axonframework.commandhandling - package org.axonframework.commandhandling
Classes that implement the concept of command handling using explicit command objects.
org.axonframework.commandhandling.annotation - package org.axonframework.commandhandling.annotation
Classes that provide annotation support for command handling.
org.axonframework.commandhandling.callbacks - package org.axonframework.commandhandling.callbacks
 
org.axonframework.commandhandling.disruptor - package org.axonframework.commandhandling.disruptor
 
org.axonframework.commandhandling.distributed - package org.axonframework.commandhandling.distributed
 
org.axonframework.commandhandling.distributed.jgroups - package org.axonframework.commandhandling.distributed.jgroups
 
org.axonframework.commandhandling.distributed.jgroups.support.callbacks - package org.axonframework.commandhandling.distributed.jgroups.support.callbacks
 
org.axonframework.commandhandling.gateway - package org.axonframework.commandhandling.gateway
 
org.axonframework.commandhandling.interceptors - package org.axonframework.commandhandling.interceptors
Contains some useful implementations of interceptors that many application can benefit from.
org.axonframework.common - package org.axonframework.common
Contains common utility classes needed in different components of the framework.
org.axonframework.common.annotation - package org.axonframework.common.annotation
Contains the main classes for annotation support in Axon Framework.
org.axonframework.common.digest - package org.axonframework.common.digest
 
org.axonframework.common.io - package org.axonframework.common.io
 
org.axonframework.common.jdbc - package org.axonframework.common.jdbc
 
org.axonframework.common.jpa - package org.axonframework.common.jpa
 
org.axonframework.common.lock - package org.axonframework.common.lock
 
org.axonframework.common.mongo - package org.axonframework.common.mongo
 
org.axonframework.common.property - package org.axonframework.common.property
 
org.axonframework.contextsupport.spring - package org.axonframework.contextsupport.spring
 
org.axonframework.contextsupport.spring.amqp - package org.axonframework.contextsupport.spring.amqp
 
org.axonframework.correlation - package org.axonframework.correlation
 
org.axonframework.domain - package org.axonframework.domain
The domain components of the Axon Framework, mainly the Aggregates and Events.
org.axonframework.eventhandling - package org.axonframework.eventhandling
Classes related to event handling and dispatching, such as Event Listeners and the Event Bus.
org.axonframework.eventhandling.amqp - package org.axonframework.eventhandling.amqp
 
org.axonframework.eventhandling.amqp.spring - package org.axonframework.eventhandling.amqp.spring
 
org.axonframework.eventhandling.annotation - package org.axonframework.eventhandling.annotation
Classes in support of the configuration of Event Handlers using annotations.
org.axonframework.eventhandling.async - package org.axonframework.eventhandling.async
 
org.axonframework.eventhandling.io - package org.axonframework.eventhandling.io
 
org.axonframework.eventhandling.replay - package org.axonframework.eventhandling.replay
 
org.axonframework.eventhandling.scheduling - package org.axonframework.eventhandling.scheduling
 
org.axonframework.eventhandling.scheduling.java - package org.axonframework.eventhandling.scheduling.java
 
org.axonframework.eventhandling.scheduling.quartz - package org.axonframework.eventhandling.scheduling.quartz
 
org.axonframework.eventsourcing - package org.axonframework.eventsourcing
Classes related to event sourcing.
org.axonframework.eventsourcing.annotation - package org.axonframework.eventsourcing.annotation
 
org.axonframework.eventsourcing.conflictresolvers - package org.axonframework.eventsourcing.conflictresolvers
 
org.axonframework.eventstore - package org.axonframework.eventstore
Definitions and implementations of the Event store, the mechanism that can load event streams and append events to them.
org.axonframework.eventstore.fs - package org.axonframework.eventstore.fs
Package containing classes necessary to implement a FileSystem based implementation of the EventStore
org.axonframework.eventstore.jdbc - package org.axonframework.eventstore.jdbc
JDBC Implementation of the EventStore.
org.axonframework.eventstore.jdbc.criteria - package org.axonframework.eventstore.jdbc.criteria
 
org.axonframework.eventstore.jpa - package org.axonframework.eventstore.jpa
JPA Implementation of the EventStore.
org.axonframework.eventstore.jpa.criteria - package org.axonframework.eventstore.jpa.criteria
 
org.axonframework.eventstore.management - package org.axonframework.eventstore.management
 
org.axonframework.eventstore.mongo - package org.axonframework.eventstore.mongo
 
org.axonframework.eventstore.mongo.criteria - package org.axonframework.eventstore.mongo.criteria
 
org.axonframework.eventstore.supporting - package org.axonframework.eventstore.supporting
 
org.axonframework.gae.commandhandling - package org.axonframework.gae.commandhandling
 
org.axonframework.gae.eventstore - package org.axonframework.gae.eventstore
 
org.axonframework.gae.serializer - package org.axonframework.gae.serializer
 
org.axonframework.integration.adapter - package org.axonframework.integration.adapter
Utility classes used to connect an Event Bus to a Spring Integration Channel.
org.axonframework.integration.eventbus - package org.axonframework.integration.eventbus
Contains the Event Bus implementation using Spring Integration
org.axonframework.mongo3.common - package org.axonframework.mongo3.common
 
org.axonframework.mongo3.eventstore - package org.axonframework.mongo3.eventstore
 
org.axonframework.mongo3.eventstore.criteria - package org.axonframework.mongo3.eventstore.criteria
 
org.axonframework.mongo3.saga.repository - package org.axonframework.mongo3.saga.repository
 
org.axonframework.mongo3.serializer.bson - package org.axonframework.mongo3.serializer.bson
 
org.axonframework.monitoring - package org.axonframework.monitoring
 
org.axonframework.monitoring.jmx - package org.axonframework.monitoring.jmx
 
org.axonframework.quickstart - package org.axonframework.quickstart
 
org.axonframework.quickstart.annotated - package org.axonframework.quickstart.annotated
 
org.axonframework.quickstart.api - package org.axonframework.quickstart.api
 
org.axonframework.quickstart.handler - package org.axonframework.quickstart.handler
 
org.axonframework.quickstart.saga - package org.axonframework.quickstart.saga
 
org.axonframework.repository - package org.axonframework.repository
Classes related to the repository interface and implementations.
org.axonframework.saga - package org.axonframework.saga
 
org.axonframework.saga.annotation - package org.axonframework.saga.annotation
 
org.axonframework.saga.repository - package org.axonframework.saga.repository
 
org.axonframework.saga.repository.inmemory - package org.axonframework.saga.repository.inmemory
 
org.axonframework.saga.repository.jdbc - package org.axonframework.saga.repository.jdbc
 
org.axonframework.saga.repository.jpa - package org.axonframework.saga.repository.jpa
 
org.axonframework.saga.repository.mongo - package org.axonframework.saga.repository.mongo
 
org.axonframework.saga.spring - package org.axonframework.saga.spring
 
org.axonframework.serializer - package org.axonframework.serializer
 
org.axonframework.serializer.bson - package org.axonframework.serializer.bson
 
org.axonframework.serializer.converters - package org.axonframework.serializer.converters
 
org.axonframework.serializer.json - package org.axonframework.serializer.json
 
org.axonframework.serializer.xml - package org.axonframework.serializer.xml
 
org.axonframework.springmessaging.adapter - package org.axonframework.springmessaging.adapter
Utility classes used to connect an Event Bus to a Spring Messaging Channel.
org.axonframework.springmessaging.eventbus - package org.axonframework.springmessaging.eventbus
Contains the Event Bus implementation using Spring Messaging
org.axonframework.test - package org.axonframework.test
Classes in support of testing Axon based applications.
org.axonframework.test.eventscheduler - package org.axonframework.test.eventscheduler
 
org.axonframework.test.matchers - package org.axonframework.test.matchers
 
org.axonframework.test.saga - package org.axonframework.test.saga
 
org.axonframework.test.utils - package org.axonframework.test.utils
A collection of classes which may prove useful when testing Axon-based classes.
org.axonframework.unitofwork - package org.axonframework.unitofwork
Classes in support of the UnitOfWork pattern in Axon Framework.
org.axonframework.upcasting - package org.axonframework.upcasting
 

P

PackageRoutingKeyResolver - Class in org.axonframework.eventhandling.amqp
RoutingKeyResolver implementation that uses the package name of the Message's payload as routing key.
PackageRoutingKeyResolver() - Constructor for class org.axonframework.eventhandling.amqp.PackageRoutingKeyResolver
 
ParameterRegistry - Class in org.axonframework.eventstore.jdbc.criteria
The registry that keeps track of parameterized values.
ParameterRegistry() - Constructor for class org.axonframework.eventstore.jdbc.criteria.ParameterRegistry
 
ParameterRegistry - Class in org.axonframework.eventstore.jpa.criteria
The registry that keeps track of parameterized values.
ParameterRegistry() - Constructor for class org.axonframework.eventstore.jpa.criteria.ParameterRegistry
 
ParameterResolver<T> - Interface in org.axonframework.common.annotation
Interface for a mechanism that resolves handler method parameter values from a given Message.
ParameterResolverFactory - Interface in org.axonframework.common.annotation
Interface for objects capable of creating Parameter Resolver instances for annotated handler methods.
parse(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.UpcasterChainBeanDefinitionParser
Parses the given element representing an UpcasterChain definition and returns the corresponding BeanDefinition.
parse(Element, ParserContext, Object) - Method in class org.axonframework.contextsupport.spring.UpcasterChainBeanDefinitionParser
Parses the given element, using the given defaultSerializer if none is explicitly configured.
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jdbc.criteria.BinaryOperator
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jdbc.criteria.CollectionOperator
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jdbc.criteria.Equals
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcCriteria
Parses the criteria to a JPA compatible where clause and parameter values.
parse(String, StringBuilder) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
Parse the property value to a valid EJQL expression.
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jdbc.criteria.NotEquals
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jdbc.criteria.SimpleOperator
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jpa.criteria.BinaryOperator
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jpa.criteria.CollectionOperator
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jpa.criteria.Equals
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jpa.criteria.JpaCriteria
Parses the criteria to a JPA compatible where clause and parameter values.
parse(String, StringBuilder) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
Parse the property value to a valid EJQL expression.
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jpa.criteria.NotEquals
 
parse(String, StringBuilder, ParameterRegistry) - Method in class org.axonframework.eventstore.jpa.criteria.SimpleOperator
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Parses elements for shared SagaManager logic.
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.AggregateCommandHandlerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.amqp.AMQPConfigurationBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.amqp.TerminalBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.ClusterBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.DisruptorCommandBusBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.EventBusBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.JdbcSagaRepositoryBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.JpaSagaRepositoryBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.RepositoryBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.SimpleCommandBusBeanDefinitionParser
parseReplayableAttribute(Element, MutablePropertyValues) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Process the "replayable" setting on the given element.
parseSuppressExceptionsAttribute(Element, MutablePropertyValues) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Process the "suppress-exceptions" setting on the given element.
parseSuppressExceptionsAttribute(Element, MutablePropertyValues) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
 
parseSuppressExceptionsAttribute(Element, MutablePropertyValues) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
 
PartialStreamSupport - Interface in org.axonframework.eventstore
Interface implemented by Event Stores that support reading partial event streams.
PayloadMatcher<T extends Message> - Class in org.axonframework.test.matchers
Matcher that matches any message (e.g.
PayloadMatcher(Matcher<?>) - Constructor for class org.axonframework.test.matchers.PayloadMatcher
Constructs an instance with the given payloadMatcher.
PayloadsMatcher - Class in org.axonframework.test.matchers
Matches a list of Messages if the list of their payloads matches the given matcher..
PayloadsMatcher(Matcher<? extends Iterable<?>>) - Constructor for class org.axonframework.test.matchers.PayloadsMatcher
Constructs an instance that uses the given matcher to match the payloads.
payloadsMatching(Matcher<? extends Iterable<?>>) - Static method in class org.axonframework.test.matchers.Matchers
Matches a list of Messages if a list containing their respective payloads matches the given matcher.
peek() - Method in interface org.axonframework.domain.DomainEventStream
Returns the next events in the stream, if available, without moving the pointer forward.
peek() - Method in class org.axonframework.domain.SimpleDomainEventStream
Returns the next events in the stream, if available, without moving the pointer forward.
peek() - Method in class org.axonframework.eventstore.fs.FileSystemBufferedReaderDomainEventStream
 
PersistenceExceptionResolver - Interface in org.axonframework.common.jdbc
The PersistenceExceptionResolver is used to find out if an exception is caused by duplicate keys.
PersistenceExceptionResolver - Interface in org.axonframework.eventstore.jpa
Deprecated. Implement PersistenceExceptionResolver instead.
persistEvent(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
 
persistEvent(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
Stores the given event (serialized as serializedPayload and serializedMetaData in the Event Store.
persistEvent(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>, EntityManager) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
 
persistEvent(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Persists the given event which has been serialized into serializedEvent in the backing data store using given entityManager.
persistSnapshot(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
 
persistSnapshot(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
Persists the given event which has been serialized into serializedEvent.
persistSnapshot(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>, EntityManager) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
 
persistSnapshot(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Persists the given event which has been serialized into serializedEvent in the backing data store using given entityManager.
PessimisticLockManager - Class in org.axonframework.repository
Implementation of the LockManager that uses a pessimistic locking strategy.
PessimisticLockManager() - Constructor for class org.axonframework.repository.PessimisticLockManager
 
postDelete(T) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
postDelete(T) - Method in class org.axonframework.repository.AbstractRepository
Perform action that needs to be done directly after deleting an aggregate and committing the aggregate's uncommitted events.
PostgresEventSqlSchema<T> - Class in org.axonframework.eventstore.jdbc
SQL schema supporting postgres databases.
PostgresEventSqlSchema() - Constructor for class org.axonframework.eventstore.jdbc.PostgresEventSqlSchema
 
PostgresEventSqlSchema(Class<T>) - Constructor for class org.axonframework.eventstore.jdbc.PostgresEventSqlSchema
 
PostgresEventSqlSchema(Class<T>, SchemaConfiguration) - Constructor for class org.axonframework.eventstore.jdbc.PostgresEventSqlSchema
 
PostgresSagaSqlSchema - Class in org.axonframework.saga.repository.jdbc
SQL schema supporting postgres databases.
PostgresSagaSqlSchema() - Constructor for class org.axonframework.saga.repository.jdbc.PostgresSagaSqlSchema
 
PostgresSagaSqlSchema(SchemaConfiguration) - Constructor for class org.axonframework.saga.repository.jdbc.PostgresSagaSqlSchema
 
postProcessAfterInitialization(Object, String) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
postProcessBeforeDestruction(Object, String) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
postProcessBeforeInitialization(Object, String) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
postProcessInstance(T) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
Perform any processing that must be done on an aggregate instance that was reconstructed from a Snapshot Event.
postProcessInstance(T) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
postSave(T) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
postSave(T) - Method in class org.axonframework.repository.AbstractRepository
Perform action that needs to be done directly after updating an aggregate and committing the aggregate's uncommitted events.
prepare(EventMessage) - Method in class org.axonframework.eventhandling.MultiplexingEventProcessingMonitor
Prepare the monitor for processing the given message.
prepareForInvocation(EventMessage, EventListener) - Method in class org.axonframework.eventhandling.MultiplexingEventProcessingMonitor
Prepare the monitor for the invocation of the given message to the given member.
prepareForReplay(Cluster) - Method in class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
 
prepareForReplay(Cluster) - Method in class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
 
prepareForReplay(Cluster) - Method in interface org.axonframework.eventhandling.replay.IncomingMessageHandler
Invoked just before replay mode is activated.
preProcessSaga(Saga) - Method in class org.axonframework.saga.AbstractSagaManager
Perform pre-processing of sagas that have been newly created or have been loaded from the repository.
preProcessSaga(Saga) - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
 
Priority - Annotation Type in org.axonframework.common
Indicates the relative priority of the annotated component.
PriorityAnnotationComparator<T> - Class in org.axonframework.common.annotation
Comparator that compares objects based on the value on an @Priority annotation.
proceed(CommandMessage<?>) - Method in class org.axonframework.commandhandling.DefaultInterceptorChain
Signals the Interceptor Chain to continue processing the given command.
proceed() - Method in class org.axonframework.commandhandling.DefaultInterceptorChain
 
proceed() - Method in interface org.axonframework.commandhandling.InterceptorChain
Signals the Interceptor Chain to continue processing the incoming (original) command.
proceed(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.InterceptorChain
Signals the Interceptor Chain to continue processing the given command.
proceed() - Static method in class org.axonframework.eventhandling.async.RetryPolicy
Tells the scheduler to ignore the failure continue processing.
ProceedingErrorHandler - Class in org.axonframework.saga.annotation
ErrorHandler implementation that logs the error and proceeds with the next event.
ProceedingErrorHandler() - Constructor for class org.axonframework.saga.annotation.ProceedingErrorHandler
 
processBacklog(Cluster) - Method in class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
 
processBacklog(Cluster) - Method in class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
 
processBacklog(Cluster) - Method in interface org.axonframework.eventhandling.replay.IncomingMessageHandler
Invoked when all events from the Event Store have been processed.
processInterceptors(CommandMessage) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Invokes all the dispatch interceptors and returns the CommandMessage instance that should be dispatched.
Property<T> - Interface in org.axonframework.common.property
Interface describing a mechanism that can read a predefined property from a given instance.
property(String) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcCriteriaBuilder
 
property(String) - Method in class org.axonframework.eventstore.jpa.criteria.JpaCriteriaBuilder
 
property(String) - Method in interface org.axonframework.eventstore.management.CriteriaBuilder
Returns a property instance that can be used to build criteria.
Property - Interface in org.axonframework.eventstore.management
Represents a property of the Domain Event entry stored by an Event Store.
property(String) - Method in class org.axonframework.eventstore.mongo.criteria.MongoCriteriaBuilder
 
property(String) - Method in class org.axonframework.mongo3.eventstore.criteria.MongoCriteriaBuilder
 
PropertyAccessException - Exception in org.axonframework.common.property
Exception indicating that a predefined property is not accessible.
PropertyAccessException(String, Throwable) - Constructor for exception org.axonframework.common.property.PropertyAccessException
Initializes the PropertyAccessException with given message and cause.
PropertyAccessStrategy - Class in org.axonframework.common.property
Abstract Strategy that provides access to all PropertyAccessStrategy implementations.
PropertyAccessStrategy() - Constructor for class org.axonframework.common.property.PropertyAccessStrategy
 
propertyFor(Class<T>, String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
 
propertyFor(Class<T>, String) - Method in class org.axonframework.common.property.PropertyAccessStrategy
Returns a Property instance for the given property, defined in given targetClass, or null if no such property is found on the class.
provideAuditDataFor(CommandMessage<?>) - Method in interface org.axonframework.auditing.AuditDataProvider
Return the relevant auditing information for the given command.
provideAuditDataFor(CommandMessage<?>) - Method in class org.axonframework.auditing.CommandMetaDataProvider
 
provideAuditDataFor(CommandMessage<?>) - Method in class org.axonframework.auditing.CorrelationAuditDataProvider
 
provideAuditDataFor(CommandMessage<?>) - Method in class org.axonframework.auditing.EmptyDataProvider
Return the relevant auditing information for the given command.
pruneSnapshots(String, DomainEventMessage, int) - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
 
pruneSnapshots(String, DomainEventMessage, int) - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
Removes old snapshots from the storage for an aggregate of given type that generated the given mostRecentSnapshotEvent.
pruneSnapshots(String, DomainEventMessage, int, EntityManager) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
 
pruneSnapshots(String, DomainEventMessage, int, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Removes old snapshots from the storage for an aggregate of given type that generated the given mostRecentSnapshotEvent.
publish(EventMessage...) - Method in class org.axonframework.eventhandling.AbstractCluster
 
publish(EventMessage...) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
 
publish(EventMessage...) - Method in interface org.axonframework.eventhandling.Cluster
Publishes the given Events to the members of this cluster.
publish(EventMessage...) - Method in class org.axonframework.eventhandling.ClusteringEventBus
 
publish(EventMessage...) - Method in interface org.axonframework.eventhandling.EventBus
Publish a collection of events on this bus (one, or multiple).
publish(EventMessage...) - Method in interface org.axonframework.eventhandling.EventBusTerminal
Publishes the given events to all clusters on the Event Bus.
publish(EventMessage...) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
 
publish(EventMessage...) - Method in class org.axonframework.eventhandling.SimpleEventBus
Publish a collection of events on this bus (one, or multiple).
publish(EventMessage...) - Method in class org.axonframework.gae.commandhandling.SimpleEventBusWithoutStatistics
 
publish(EventMessage...) - Method in class org.axonframework.integration.eventbus.SpringIntegrationEventBus
 
publish(EventMessage...) - Method in class org.axonframework.springmessaging.eventbus.SpringMessagingEventBus
 
published(Object...) - Method in interface org.axonframework.test.saga.GivenAggregateEventPublisher
Register the given events as being published somewhere in the past.
publishes(Object) - Method in interface org.axonframework.test.saga.WhenAggregateEventPublisher
Register the given event to be published on behalf of an aggregate.
publishEvent(EventMessage, EventBus) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
publishEvent(Object) - Method in class org.axonframework.eventhandling.EventTemplate
Publishes an event with given payload on the configured Event Bus.
publishEvent(Object, Map<String, ?>) - Method in class org.axonframework.eventhandling.EventTemplate
Publishes an event with given payload on the configured Event Bus, with given metaData attached.
publishEvent(EventMessage<?>, EventBus) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
publishEvent(EventMessage<?>, EventBus) - Method in interface org.axonframework.unitofwork.UnitOfWork
Request to publish the given event on the given eventBus.
publishEvents() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
Publishes all registered events to their respective event bus.
put(K, V) - Method in interface org.axonframework.cache.Cache
Stores the given value in the cache, under given key.
put(K, V) - Method in class org.axonframework.cache.EhCacheAdapter
 
put(K, V) - Method in class org.axonframework.cache.JCacheAdapter
 
put(Object, Object) - Method in class org.axonframework.cache.NoCache
 
put(K, V) - Method in class org.axonframework.cache.WeakReferenceCache
 
put(String, Object) - Method in class org.axonframework.domain.MetaData
This operation is not supported.

putAll(Map<? extends String, ?>) - Method in class org.axonframework.domain.MetaData
This operation is not supported.

putIfAbsent(K, V) - Method in interface org.axonframework.cache.Cache
Stores the given value in the cache, under given key, if no element is yet available under that key.
putIfAbsent(K, V) - Method in class org.axonframework.cache.EhCacheAdapter
 
putIfAbsent(K, V) - Method in class org.axonframework.cache.JCacheAdapter
 
putIfAbsent(Object, Object) - Method in class org.axonframework.cache.NoCache
 
putIfAbsent(K, V) - Method in class org.axonframework.cache.WeakReferenceCache
 

Q

QuartzEventScheduler - Class in org.axonframework.eventhandling.scheduling.quartz
EventScheduler implementation that delegates scheduling and triggering to a Quartz Scheduler.
QuartzEventScheduler() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
QuartzEventScheduler.DirectEventJobDataBinder - Class in org.axonframework.eventhandling.scheduling.quartz
Binds the EventMessage as is to JobDataMap under QuartzEventScheduler.DirectEventJobDataBinder.EVENT_KEY.
QuartzEventScheduler.DirectEventJobDataBinder() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
 
QuartzEventSchedulerFactoryBean - Class in org.axonframework.eventhandling.scheduling.quartz
Spring FactoryBean that creates a QuartzEventScheduler instance using resources found in the Spring Application Context.
QuartzEventSchedulerFactoryBean() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
QuartzScheduleToken - Class in org.axonframework.eventhandling.scheduling.quartz
ScheduleToken implementation representing a scheduled Quartz Job.
QuartzScheduleToken(String, String) - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Initialize a token for the given jobIdentifier and groupIdentifier.
queryByIdentifier(String) - Static method in class org.axonframework.mongo3.saga.repository.SagaEntry
Returns the Mongo Query to find a Saga based on its identifier.
queryByIdentifier(String) - Static method in class org.axonframework.saga.repository.mongo.SagaEntry
Returns the Mongo Query to find a Saga based on its identifier.

R

RabbitMqStrategy - Interface in org.axonframework.eventhandling.amqp.spring
Interface describing a strategy for creating a SimpleMessageListenerContainer class and setting the exclusive mode on the underlying subscriptions.
readAMQPMessage(byte[], Map<String, Object>) - Method in interface org.axonframework.eventhandling.amqp.AMQPMessageConverter
Reconstruct an EventMessage from the given messageBody and headers.
readAMQPMessage(byte[], Map<String, Object>) - Method in class org.axonframework.eventhandling.amqp.DefaultAMQPMessageConverter
 
readEventMessage() - Method in class org.axonframework.eventhandling.io.EventMessageReader
Reads an EventMessage from the underlying input.
readEventMessage() - Method in class org.axonframework.eventstore.fs.FileSystemEventMessageReader
Reads the next event from the input.
readEvents(String, Object) - Method in interface org.axonframework.eventstore.EventStore
Read the events of the aggregate identified by the given type and identifier that allow the current aggregate state to be rebuilt.
readEvents(String, Object) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
 
readEvents(String, Object) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
Read the events of the aggregate identified by the given type and identifier that allow the current aggregate state to be rebuilt.
readEvents(String, Object, long) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
 
readEvents(String, Object, long, long) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
 
readEvents(String, Object) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Read the events of the aggregate identified by the given type and identifier that allow the current aggregate state to be rebuilt.
readEvents(String, Object, long) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
 
readEvents(String, Object, long, long) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
 
readEvents(String, Object) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
readEvents(String, Object, long) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
readEvents(String, Object, long, long) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
readEvents(String, Object, long) - Method in interface org.axonframework.eventstore.PartialStreamSupport
Returns a Stream containing events for the aggregate identified by the given type and identifier, starting at the event with the given firstSequenceNumber (included).
readEvents(String, Object, long, long) - Method in interface org.axonframework.eventstore.PartialStreamSupport
Returns a Stream containing events for the aggregate identified by the given type and identifier, starting at the event with the given firstSequenceNumber (included) up to and including the event with given lastSequenceNumber.
readEvents(String, Object) - Method in class org.axonframework.eventstore.supporting.SequenceEventStore
 
readEvents(String, Object) - Method in class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
 
readEvents(String, Object) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
 
readEvents(String, Object) - Method in class org.axonframework.gae.eventstore.GaeEventStore
 
readEvents(String, Object) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
readEvents(String, Object, long) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
readEvents(String, Object, long, long) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
readEvents(String, Object) - Method in class org.axonframework.quickstart.RunEventReplay.StubEventStore
 
readExternal(ObjectInput) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
readExternal(ObjectInput) - Method in class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
 
readExternal(ObjectInput) - Method in class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
 
readExternal(ObjectInput) - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
 
readFrom(DataInput) - Method in class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
 
readFrom(DataInput) - Method in class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
 
readFrom(DataInput) - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
 
readNumberFromCommandlinePlusDefault(String, int) - Static method in class org.axonframework.quickstart.RunDistributedCommandBus
 
readPayload(ResultSet, int) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
Reads a serialized object from the given resultSet at given columnIndex.
readResolve() - Method in class org.axonframework.domain.MetaData
Java Serialization specification method that will ensure that deserialization will maintain a single instance of empty MetaData.
readSerializedSaga(ResultSet) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
readSerializedSaga(ResultSet) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Reads a SerializedObject from the given resultSet, which has been returned by executing the Statement returned from SagaSqlSchema.sql_loadSaga(java.sql.Connection, String)

Note: The implementation must not change the resultSet's cursor position

readSnapshotEvent(String, Object) - Method in class org.axonframework.eventstore.fs.FileSystemSnapshotEventReader
Reads the latest snapshot of the given aggregate identifier.
readTimeStamp(ResultSet, int) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
Reads a timestamp from the given resultSet at given columnIndex.
RecordingCommandBus - Class in org.axonframework.test.utils
CommandBus implementation that does not perform any actions on subscriptions or dispatched commands, but records them instead.
RecordingCommandBus() - Constructor for class org.axonframework.test.utils.RecordingCommandBus
 
ReflectionUtils - Class in org.axonframework.common
Utility class for working with Java Reflection API.
register(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
Registers a PropertyAccessStrategy implementation at runtime.
register(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.ParameterRegistry
Registers the given expression as parameter and returns the value to use to refer to this expression.
register(Object) - Method in class org.axonframework.eventstore.jpa.criteria.ParameterRegistry
Registers the given expression as parameter and returns the value to use to refer to this expression.
registerAggregate(T, EventBus, SaveAggregateCallback<T>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
registerAggregate(T, EventBus, SaveAggregateCallback<T>) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
registerAggregate(T, EventBus, SaveAggregateCallback<T>) - Method in interface org.axonframework.unitofwork.UnitOfWork
Register an aggregate with this UnitOfWork.
registerAggregateFactory(AggregateFactory<T>) - Method in interface org.axonframework.test.FixtureConfiguration
Registers the given aggregateFactory with the fixture.
registerAggregateFactory(AggregateFactory<T>) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerAggregateRoot(AbstractEventSourcedAggregateRoot) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
 
registerAggregateRoot(AbstractEventSourcedAggregateRoot) - Method in interface org.axonframework.eventsourcing.EventSourcedEntity
Register the aggregate root with this entity.
registerAnnotatedCommandHandler(Object) - Method in interface org.axonframework.test.FixtureConfiguration
Registers an annotatedCommandHandler with this fixture.
registerAnnotatedCommandHandler(Object) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerAnnotationCommandHandlerBeanPostProcessor(String, String, String, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
Create the BeanDefinition for the AnnotationCommandHandlerBeanPostProcessor and register it.
registerAnnotationEventListenerBeanPostProcessor(String, String, String, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
Create the BeanDefinition for the AnnotationEventListenerBeanPostProcessor and register it.
registerBean(Object, Class<?>) - Method in class org.axonframework.monitoring.jmx.JmxMonitorRegistry
Attempts to register the given mBean as an MBean with the default MBeanServer.
registerBean(Object, Class<?>) - Method in class org.axonframework.monitoring.MonitorRegistry
Registers the bean with the Registry.
registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.AnnotationDrivenConfiguration
 
registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.AbstractCacheAdapter
 
registerCacheEntryListener(Cache.EntryListener) - Method in interface org.axonframework.cache.Cache
Registers the given cacheEntryListener to listen for Cache changes.
registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.NoCache
 
registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.WeakReferenceCache
 
registerCluster(Cluster, AMQPConsumerConfiguration, AMQPMessageConverter) - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
Registers the given cluster, assigning it to a listener that listens to the given queueName.
registerCommandCallback(CommandCallback<R>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Registers the callback, which is invoked for each sent command, unless Axon is able to detect that the result of the command does not match the type accepted by the callback.
registerCommandGateway(Class<T>) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
registerCommandGateway(Class<T>, T) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
registerCommandGateway(Class<T>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Creates a Command Gateway for the given gatewayInterface and registers that as a resource.
registerCommandGateway(Class<T>, T) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Creates a Command Gateway for the given gatewayInterface and registers that as a resource.
registerCommandHandler(Class<?>, CommandHandler) - Method in interface org.axonframework.test.FixtureConfiguration
Registers a commandHandler to handle commands of the given commandType with the command bus used by this fixture.
registerCommandHandler(String, CommandHandler) - Method in interface org.axonframework.test.FixtureConfiguration
Registers a commandHandler to handle commands of the given commandType with the command bus used by this fixture.
registerCommandHandler(Class<?>, CommandHandler) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerCommandHandler(String, CommandHandler) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerConverter(ContentTypeConverter) - Method in class org.axonframework.serializer.ChainingConverterFactory
Registers the given converter with this factory.
registerConverter(Class<? extends ContentTypeConverter>) - Method in class org.axonframework.serializer.ChainingConverterFactory
Registers a convert of the given converterType with this factory, only if initialization of such a converter is possible.
registerConverters(ChainingConverterFactory) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectXStreamSerializer
 
registerConverters(ChainingConverterFactory) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Registers any converters that are specific to the type of content written by this serializer.
registerConverters(ChainingConverterFactory) - Method in class org.axonframework.serializer.bson.DBObjectXStreamSerializer
 
registerConverters(ChainingConverterFactory) - Method in class org.axonframework.serializer.json.JacksonSerializer
Registers converters with the given converterFactory which depend on the actual contents of the serialized for to represent a JSON format.
registerConverters(ChainingConverterFactory) - Method in class org.axonframework.serializer.xml.XStreamSerializer
 
registerDispatchInterceptor(CommandDispatchInterceptor) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Registers the given dispatchInterceptor which is invoked for each Command dispatched through the Command Gateways created by this factory.
registerEvent(T) - Method in class org.axonframework.domain.AbstractAggregateRoot
Registers an event to be published when the aggregate is saved, containing the given payload and no (additional) meta-data.
registerEvent(MetaData, T) - Method in class org.axonframework.domain.AbstractAggregateRoot
Registers an event to be published when the aggregate is saved.
registerEventMessage(DomainEventMessage<T>) - Method in class org.axonframework.domain.AbstractAggregateRoot
Registers an event message to be published when the aggregate is saved.
registerFieldFilter(FieldFilter) - Method in interface org.axonframework.test.FixtureConfiguration
Registers the given fieldFilter, which is used to define which Fields are used when comparing objects.
registerFieldFilter(FieldFilter) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerFieldFilter(FieldFilter) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
registerFieldFilter(FieldFilter) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers the given fieldFilter, which is used to define which Fields are used when comparing objects.
registerForPublication(EventMessage<?>, EventBus, boolean) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
registerForPublication(EventMessage<?>, EventBus, boolean) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Register the given event for publication on the given eventBus when the unit of work is committed.
registerIgnoredField(Class<?>, String) - Method in interface org.axonframework.test.FixtureConfiguration
Indicates that a field with given fieldName, which is declared in given declaringClass is ignored when performing deep equality checks.
registerIgnoredField(Class<?>, String) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerIgnoredField(Class<?>, String) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
registerIgnoredField(Class<?>, String) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Indicates that a field with given fieldName, which is declared in given declaringClass is ignored when performing deep equality checks.
registerInjectableResource(Object) - Method in interface org.axonframework.test.FixtureConfiguration
Registers a resource that is eligible for injection in handler method (e.g.
registerInjectableResource(Object) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerListener(UnitOfWorkListener) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
registerListener(UnitOfWorkListener) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
registerListener(UnitOfWorkListener) - Method in interface org.axonframework.unitofwork.UnitOfWork
Register a listener that listens to state changes in this UnitOfWork.
registerMonitoringBean(Object, Class<?>) - Static method in class org.axonframework.monitoring.MonitorRegistry
Register the given monitoringBean with the registries on the classpath.
registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
Registers the given parameterResolverFactory with this aggregate instance.
registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Sets the ParameterResolverFactory for this instance to use.
registerRepository(EventSourcingRepository<T>) - Method in interface org.axonframework.test.FixtureConfiguration
Registers an arbitrary event sourcing repository with the fixture.
registerRepository(EventSourcingRepository<T>) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
registerResource(Object) - Static method in class org.axonframework.test.FixtureResourceParameterResolverFactory
Registers an additional resource for injection
registerResource(Object) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
registerResource(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers the given resource.
registerSagaFactory(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Registers the given sagaFactoryDefinition in the given sagaManagerDefinition.
registerSagaFactory(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
 
registerSagaFactory(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
 
registerSagaRepository(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Registers the given sagaRepositoryDefinition in the given sagaManagerDefinition.
registerSagaRepository(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
 
registerSagaRepository(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
 
registerScheduledEvents(UnitOfWork) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
registerScheduledEvents(UnitOfWork) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Invokes when a child Unit of Work should register its scheduled events with the given unitOfWork.
registerSpecificProperties(Element, ParserContext, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Registers any implementation specific properties found in the given element in the given sagaManagerDefinition.
registerSpecificProperties(Element, ParserContext, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
 
registerSpecificProperties(Element, ParserContext, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
 
registerTypes(String[], GenericBeanDefinition, RuntimeBeanReference) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
Registers the given Saga types in the given sagaManagerDefinition.
registerTypes(String[], GenericBeanDefinition, RuntimeBeanReference) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
 
registerTypes(String[], GenericBeanDefinition, RuntimeBeanReference) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
 
REGULAR - Static variable in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
Instance indicating processing was successful and should proceed normally.
releaseLock(String) - Method in class org.axonframework.common.lock.IdentifierBasedLock
Release the lock held on the given identifier.
releaseLock(Object) - Method in interface org.axonframework.repository.LockManager
Release the lock held for an aggregate with the given aggregateIdentifier.
releaseLock(Object) - Method in class org.axonframework.repository.NullLockManager
Release the lock held for an aggregate with the given aggregateIdentifier.
releaseLock(Object) - Method in class org.axonframework.repository.OptimisticLockManager
Release the lock held for an aggregate with the given aggregateIdentifier.
releaseLock(Object) - Method in class org.axonframework.repository.PessimisticLockManager
Release the lock held on the aggregate.
releaseMessage(Cluster, DomainEventMessage) - Method in class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
 
releaseMessage(Cluster, DomainEventMessage) - Method in class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
 
releaseMessage(Cluster, DomainEventMessage) - Method in interface org.axonframework.eventhandling.replay.IncomingMessageHandler
Invoked when a message has been replayed from the event store.
RemoteCommandHandlingException - Exception in org.axonframework.commandhandling.distributed
Exception indicating that an error has occurred while remotely handling a command.
RemoteCommandHandlingException(String) - Constructor for exception org.axonframework.commandhandling.distributed.RemoteCommandHandlingException
Initializes the exception using the given message.
RemoteCommandHandlingException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.RemoteCommandHandlingException
Initializes the exception using the given message and cause.
remove(K) - Method in interface org.axonframework.cache.Cache
Removes the entry stored under given key.
remove(K) - Method in class org.axonframework.cache.EhCacheAdapter
 
remove(K) - Method in class org.axonframework.cache.JCacheAdapter
 
remove(Object) - Method in class org.axonframework.cache.NoCache
 
remove(K) - Method in class org.axonframework.cache.WeakReferenceCache
 
remove(Object) - Method in class org.axonframework.domain.MetaData
This operation is not supported.

remove(AssociationValue) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
remove(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues
Removes the given associationValue, if it is contained by this instance.
remove(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AssociationValueMap
Removes an association between the given associationValue and sagaIdentifier.
removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Removes the association value that has been associated with Saga, identified with the given sagaIdentifier.
removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 
removeAssociationWith(AssociationValue) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Removes the given association from this Saga.
removeAssociationWith(String, String) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Removes the given association from this Saga.
removeAssociationWith(String, Number) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Removes the given association from this Saga.
removedAssociations() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
removedAssociations() - Method in interface org.axonframework.saga.AssociationValues
Returns the Set of association values that have been removed since the last AssociationValues.commit().
removeProperty(String) - Method in interface org.axonframework.eventhandling.ClusterMetaData
Removes the value store under the given key.
removeProperty(String) - Method in class org.axonframework.eventhandling.DefaultClusterMetaData
 
ReplayAware - Interface in org.axonframework.eventhandling.replay
Interface indicating a component is aware of "replays".
ReplayFailedException - Exception in org.axonframework.eventhandling.replay
Exception indicating that a replay task has failed.
ReplayFailedException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.replay.ReplayFailedException
Initialize the exception with given message and cause
ReplayingCluster - Class in org.axonframework.eventhandling.replay
Cluster implementation that wraps another Cluster, adding the capability to replay events from an Event Store.
ReplayingCluster(Cluster, EventStoreManagement, TransactionManager, int, IncomingMessageHandler) - Constructor for class org.axonframework.eventhandling.replay.ReplayingCluster
Initializes a ReplayingCluster that wraps the given delegate, to allow it to replay event from the given eventStore.
ReplyingCallback - Class in org.axonframework.commandhandling.distributed.jgroups.support.callbacks
Callback implementation that forwards the callback invocation as a reply to an incoming message.
ReplyingCallback(JChannel, Address, CommandMessage, Serializer) - Constructor for class org.axonframework.commandhandling.distributed.jgroups.support.callbacks.ReplyingCallback
Initialize the callback to send a reply for an incoming commandMessage to given address using the given channel.
ReplyMessage - Class in org.axonframework.commandhandling.distributed.jgroups
JGroups Message representing a reply to a dispatched command.
ReplyMessage() - Constructor for class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
Default constructor required by the Streamable and Externalizable interfaces.
ReplyMessage(String, Object, Throwable, Serializer) - Constructor for class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
Constructs a message containing a reply to the command with given commandIdentifier, containing either given returnValue or error, which uses the given serializer to deserialize its contents.
reportDifferenceInStoredVsPublished(Collection<DomainEventMessage>, Collection<EventMessage>, Throwable) - Method in class org.axonframework.test.Reporter
Report a failed assertion due to a difference in the stored versus the published events.
reportDifferentEventContents(Class<?>, Field, Object, Object) - Method in class org.axonframework.test.Reporter
Report an error due to a difference in on of the fields of an event.
Reporter - Class in org.axonframework.test
The reporter generates extensive human readable reports of what the expected outcome of a test was, and what the actual results were.
Reporter() - Constructor for class org.axonframework.test.Reporter
 
reportFailed(Matcher) - Method in class org.axonframework.test.matchers.ListMatcher
Report the given matcher as a failing matcher.
reportUnexpectedException(Throwable, Description) - Method in class org.axonframework.test.Reporter
Reports an error due to an unexpected exception.
reportUnexpectedReturnValue(Object, Description) - Method in class org.axonframework.test.Reporter
Report an error due to an unexpected return value, while an exception was expected.
reportWrongEvent(Collection<?>, Collection<?>, Throwable) - Method in class org.axonframework.test.Reporter
Report an error in the ordering or count of events.
reportWrongEvent(Collection<?>, StringDescription, Throwable) - Method in class org.axonframework.test.Reporter
Report an error in the ordering or count of events.
reportWrongException(Throwable, Description) - Method in class org.axonframework.test.Reporter
Report an error due to a an exception of an unexpected type.
reportWrongResult(Object, Description) - Method in class org.axonframework.test.Reporter
Reports an error due to a wrong return value.
Repository<T> - Interface in org.axonframework.repository
The repository provides an abstraction of the storage of aggregates.
RepositoryBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
The RepositoryBeanDefinitionParser is responsible for parsing the repository element from the Axon namespace.
RepositoryBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.RepositoryBeanDefinitionParser
 
RepositoryContentValidator - Class in org.axonframework.test.saga
Helper class for the validation of Saga Repository content.
requiresRescheduleEvent() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
 
requiresRescheduleEvent() - Method in class org.axonframework.eventhandling.async.RetryPolicy
Indicates whether the scheduler should reschedule the failed event.
requiresRollback() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
 
requiresRollback() - Method in class org.axonframework.eventhandling.async.RetryPolicy
Indicates whether the scheduler should rollback the Unit of Work wrapping the event handling.
reset(CommandMessage<?>, CommandHandler, int, int, int, BlacklistDetectingCallback, List<CommandHandlerInterceptor>, List<CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Resets this entry, preparing it for use for another command.
reset(EventMessage, Class<? extends AbstractAnnotatedSaga>, List<SagaMethodMessageHandler>, AbstractAnnotatedSaga) - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Reset this entry for processing a new EventMessage
resetAsRecoverEntry(Object) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Resets this entry, preparing it for use as a recovery entry.
resetReceivedCommandsCounter() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
Resets the received command counter.
resetReceivedCommandsCounter() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
Reset the amount of commands received counter.
resetReceivedEventsCount() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
Reset the amount of events that was received.
resetReceivedEventsCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
resets the amount of events received.
resolveAcceptedCommandName(AbstractMessageHandler) - Static method in class org.axonframework.commandhandling.annotation.CommandMessageHandlerUtils
Returns the name of the Command accepted by the given handler.
resolveClassName(SerializedType) - Method in class org.axonframework.serializer.json.JacksonSerializer
Resolve the class name from the given serializedType.
resolveConflicts(List<DomainEventMessage>, List<DomainEventMessage>) - Method in interface org.axonframework.eventsourcing.ConflictResolver
Checks the given list of appliedChanges and committedChanges for any conflicting changes.
resolveConflicts(List<DomainEventMessage>, List<DomainEventMessage>) - Method in class org.axonframework.eventsourcing.conflictresolvers.AcceptAllConflictResolver
Checks the given list of appliedChanges and committedChanges for any conflicting changes.
resolveConflicts(T, DomainEventStream) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Resolve (potential) conflicts for the given aggregate, where given unseenEvents may have been concurrently applied.
resolveDateTimeValue(DateTime) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
Returns the representation used for the given dateTime in the event entry.
resolveDateTimeValue(DateTime) - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
Returns the representation used for the given dateTime in the event entry.
resolveParameterValue(Message) - Method in class org.axonframework.commandhandling.annotation.CurrentUnitOfWorkParameterResolverFactory
 
resolveParameterValue(Message) - Method in class org.axonframework.common.annotation.FixedValueParameterResolver
 
resolveParameterValue(Message) - Method in interface org.axonframework.common.annotation.ParameterResolver
Resolves the parameter value to use for the given message, or null if no suitable parameter value can be resolved.
resolvePayloadFor(AccessibleObject) - Method in class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
 
resolvePayloadFor(T) - Method in interface org.axonframework.common.annotation.HandlerDefinition
Returns the explicitly defined payload of supported messages on the given member
resolvePrimitiveWrapperType(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Returns the boxed wrapper type for the given primitiveType.
resolveReturnValue(CommandMessage<?>, T) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Resolves the value to return when the given command has created the given aggregate.
resolveRoutingKey(EventMessage) - Method in class org.axonframework.eventhandling.amqp.PackageRoutingKeyResolver
 
resolveRoutingKey(EventMessage) - Method in interface org.axonframework.eventhandling.amqp.RoutingKeyResolver
Returns the Routing Key to use when sending the given eventMessage to the Message Broker.
resolveTarget(CommandMessage<?>) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandTargetResolver
 
resolveTarget(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.CommandTargetResolver
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given command should be executed.
resolveTarget(CommandMessage<?>) - Method in class org.axonframework.commandhandling.MetaDataCommandTargetResolver
 
ResourceInjector - Interface in org.axonframework.saga
Interface describing a mechanism to inject resources into Saga instances.
ResultValidator - Interface in org.axonframework.test
Interface describing the operations available on the "validate result" (a.k.a.
ResultValidatorImpl - Class in org.axonframework.test
Implementation of the ResultValidator.
ResultValidatorImpl(Collection<DomainEventMessage>, Collection<EventMessage>, FieldFilter) - Constructor for class org.axonframework.test.ResultValidatorImpl
Initialize the ResultValidatorImpl with the given storedEvents and publishedEvents.
retryAfter(long, TimeUnit) - Static method in class org.axonframework.eventhandling.async.RetryPolicy
This policy will roll back the Unit of Work (and the transaction), if any) and reschedule the event for processing.
RetryingCallback<R> - Class in org.axonframework.commandhandling.gateway
Callback implementation that will invoke a retry scheduler if a command results in a runtime exception.
RetryingCallback(CommandCallback<R>, CommandMessage, RetryScheduler, CommandBus) - Constructor for class org.axonframework.commandhandling.gateway.RetryingCallback
Initialize the RetryingCallback with the given delegate, representing the actual callback passed as a parameter to dispatch, the given commandMessage, retryScheduler and commandBus.
RetryingErrorHandler - Class in org.axonframework.saga.annotation
ErrorHandler implementation that retries Events on non-transient exceptions.
RetryingErrorHandler() - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler
Initialize an instance of the RetryingErrorHandler that indefinitely retries each 2 seconds.
RetryingErrorHandler(RetryingErrorHandler.TimeoutConfiguration...) - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler
Initialize an instance of the RetryingErrorHandler that uses the given TimeoutConfigurations that describe which retry timeout should be used for each number of retries.
RetryingErrorHandler.TimeoutConfiguration - Class in org.axonframework.saga.annotation
Definition of a timeout to use for a specific range of retries
RetryingErrorHandler.TimeoutConfiguration(long, TimeUnit) - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
Initialize a configuration to indefinitely retry, applying the given timeout between retries.
RetryingErrorHandler.TimeoutConfiguration(int, long, TimeUnit) - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
Initialize a configuration to apply the given timeout between retries for the given count number of retries.
RetryPolicy - Class in org.axonframework.eventhandling.async
This policy tells the EventProcessor how it should deal with failed transactions.
RetryPolicy() - Constructor for class org.axonframework.eventhandling.async.RetryPolicy
 
retryPolicy() - Method in class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
The retry policy to use between retries
RetryScheduler - Interface in org.axonframework.commandhandling.gateway
Interface towards a mechanism that decides whether to schedule a command for execution when a previous attempts resulted in an exception.
Revision - Annotation Type in org.axonframework.serializer
Annotation that attaches revision information to a Serializable object.
revisionOf(Class<?>) - Method in class org.axonframework.serializer.AnnotationRevisionResolver
 
revisionOf(Class<?>) - Method in class org.axonframework.serializer.FixedValueRevisionResolver
 
revisionOf(Class<?>) - Method in class org.axonframework.serializer.MavenArtifactRevisionResolver
 
revisionOf(Class<?>) - Method in interface org.axonframework.serializer.RevisionResolver
Returns the revision for the given payloadType.
revisionOf(Class<?>) - Method in class org.axonframework.serializer.SerialVersionUIDRevisionResolver
 
RevisionResolver - Interface in org.axonframework.serializer
Interface towards a mechanism that resolves the revision of a given payload type.
rollback() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
rollback(Throwable) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
rollback() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
rollback(Throwable) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
rollback() - Method in interface org.axonframework.unitofwork.UnitOfWork
Clear the UnitOfWork of any buffered changes.
rollback(Throwable) - Method in interface org.axonframework.unitofwork.UnitOfWork
Clear the UnitOfWork of any buffered changes.
RollbackConfiguration - Interface in org.axonframework.commandhandling
The RollbackConfiguration defines when a UnitOfWork should be rolled back when the command handler or any interceptors reported a failure.
rollBackOn(Throwable) - Method in interface org.axonframework.commandhandling.RollbackConfiguration
Decides whether the given throwable should trigger a rollback.
rollBackOn(Throwable) - Method in class org.axonframework.commandhandling.RollbackOnAllExceptionsConfiguration
 
rollBackOn(Throwable) - Method in class org.axonframework.commandhandling.RollbackOnUncheckedExceptionConfiguration
 
RollbackOnAllExceptionsConfiguration - Class in org.axonframework.commandhandling
The default implementation of the RollbackConfiguration interface.
RollbackOnAllExceptionsConfiguration() - Constructor for class org.axonframework.commandhandling.RollbackOnAllExceptionsConfiguration
 
RollbackOnUncheckedExceptionConfiguration - Class in org.axonframework.commandhandling
RollbackConfiguration that indicates a rollback should be triggered for all but checked exceptions.
RollbackOnUncheckedExceptionConfiguration() - Constructor for class org.axonframework.commandhandling.RollbackOnUncheckedExceptionConfiguration
 
rollbackTransaction(Object) - Method in class org.axonframework.unitofwork.NoTransactionManager
 
rollbackTransaction(TransactionStatus) - Method in class org.axonframework.unitofwork.SpringTransactionManager
 
rollbackTransaction(T) - Method in interface org.axonframework.unitofwork.TransactionManager
Rolls back the transaction identifier by given transactionStatus.
RoutingKeyResolver - Interface in org.axonframework.eventhandling.amqp
Interface toward a mechanism that provides the AMQP Routing Key for a given EventMessage.
RoutingStrategy - Interface in org.axonframework.commandhandling.distributed
Interface describing a mechanism that generates a routing key for a given command.
run() - Method in class org.axonframework.common.MemberAccessibilityCallback
run() - Method in class org.axonframework.eventhandling.async.EventProcessor
RunAnnotatedAggregate - Class in org.axonframework.quickstart
Setting up the basic ToDoItem sample with a simple command and event bus and a file based event store.
RunAnnotatedAggregate() - Constructor for class org.axonframework.quickstart.RunAnnotatedAggregate
 
RunAnnotatedAggregateWithSpring - Class in org.axonframework.quickstart
Setting up the basic ToDoItem sample with a simple command and event bus and a file based event store.
RunAnnotatedAggregateWithSpring() - Constructor for class org.axonframework.quickstart.RunAnnotatedAggregateWithSpring
 
RunBasicCommandHandling - Class in org.axonframework.quickstart
Setting up the basic ToDoItem sample with as little as possible help from axon utilities.
RunBasicCommandHandling() - Constructor for class org.axonframework.quickstart.RunBasicCommandHandling
 
RunClusteringEventBus - Class in org.axonframework.quickstart
This example creates two clusters and assigns different listeners to each cluster.
RunClusteringEventBus() - Constructor for class org.axonframework.quickstart.RunClusteringEventBus
 
RunClusteringEventBusWithSpring - Class in org.axonframework.quickstart
 
RunClusteringEventBusWithSpring() - Constructor for class org.axonframework.quickstart.RunClusteringEventBusWithSpring
 
RunClusteringEventBusWithSpring.AnotherThreadPrintingEventListener - Class in org.axonframework.quickstart
 
RunClusteringEventBusWithSpring.AnotherThreadPrintingEventListener() - Constructor for class org.axonframework.quickstart.RunClusteringEventBusWithSpring.AnotherThreadPrintingEventListener
 
RunClusteringEventBusWithSpring.ThreadPrintingEventListener - Class in org.axonframework.quickstart
 
RunClusteringEventBusWithSpring.ThreadPrintingEventListener() - Constructor for class org.axonframework.quickstart.RunClusteringEventBusWithSpring.ThreadPrintingEventListener
 
RunDisruptorCommandBus - Class in org.axonframework.quickstart
Setting up the basic ToDoItem sample with a disruptor command and event bus and a file based event store.
RunDisruptorCommandBus() - Constructor for class org.axonframework.quickstart.RunDisruptorCommandBus
 
RunDisruptorCommandBusWithSpring - Class in org.axonframework.quickstart
Setting up the basic ToDoItem sample with a disruptor command and event bus and a file based event store.
RunDisruptorCommandBusWithSpring() - Constructor for class org.axonframework.quickstart.RunDisruptorCommandBusWithSpring
 
RunDistributedCommandBus - Class in org.axonframework.quickstart
This runner demonstrates the basic capabilities of the distributed command bus.
RunDistributedCommandBus() - Constructor for class org.axonframework.quickstart.RunDistributedCommandBus
 
RunDistributedCommandBus.ToDoLoggingCommandHandler - Class in org.axonframework.quickstart
 
RunDistributedCommandBus.ToDoLoggingCommandHandler() - Constructor for class org.axonframework.quickstart.RunDistributedCommandBus.ToDoLoggingCommandHandler
 
RunDistributedCommandBusWithSpring - Class in org.axonframework.quickstart
See RunDistributedCommandBus, only difference is that we use spring to wire all the beans.
RunDistributedCommandBusWithSpring() - Constructor for class org.axonframework.quickstart.RunDistributedCommandBusWithSpring
 
RunEventReplay - Class in org.axonframework.quickstart
 
RunEventReplay() - Constructor for class org.axonframework.quickstart.RunEventReplay
 
RunEventReplay.AnotherThreadPrintingEventListener - Class in org.axonframework.quickstart
 
RunEventReplay.AnotherThreadPrintingEventListener() - Constructor for class org.axonframework.quickstart.RunEventReplay.AnotherThreadPrintingEventListener
 
RunEventReplay.StubEventStore - Class in org.axonframework.quickstart
 
RunEventReplay.StubEventStore() - Constructor for class org.axonframework.quickstart.RunEventReplay.StubEventStore
 
RunEventReplay.ThreadPrintingEventListener - Class in org.axonframework.quickstart
 
RunEventReplay.ThreadPrintingEventListener() - Constructor for class org.axonframework.quickstart.RunEventReplay.ThreadPrintingEventListener
 
RunEventReplayWithSpring - Class in org.axonframework.quickstart
 
RunEventReplayWithSpring() - Constructor for class org.axonframework.quickstart.RunEventReplayWithSpring
 
RunSaga - Class in org.axonframework.quickstart
Simple Example that shows how to Create Saga instances, schedule deadlines and inject resources
RunSaga() - Constructor for class org.axonframework.quickstart.RunSaga
 
RunSagaWithSpring - Class in org.axonframework.quickstart
Simple Example that shows how to Create Saga instances, schedule deadlines and inject resources using Spring.
RunSagaWithSpring() - Constructor for class org.axonframework.quickstart.RunSagaWithSpring
 
RunUpcaster - Class in org.axonframework.quickstart
 
RunUpcaster() - Constructor for class org.axonframework.quickstart.RunUpcaster
 
RunUpcaster.NewToDoItemWithDeadlineCreatedEvent - Class in org.axonframework.quickstart
This class represents the refactored ToDoItemCreatedEvent
RunUpcaster.NewToDoItemWithDeadlineCreatedEvent(String, String, DateTime) - Constructor for class org.axonframework.quickstart.RunUpcaster.NewToDoItemWithDeadlineCreatedEvent
 
RunUpcaster.ToDoItemUpcaster - Class in org.axonframework.quickstart
This is our upcaster.
RunUpcaster.ToDoItemUpcaster() - Constructor for class org.axonframework.quickstart.RunUpcaster.ToDoItemUpcaster
 
RunUpcasterWithSpring - Class in org.axonframework.quickstart
 
RunUpcasterWithSpring() - Constructor for class org.axonframework.quickstart.RunUpcasterWithSpring
 

S

Saga - Interface in org.axonframework.saga
Interface describing an implementation of a Saga.
sagaCollection() - Method in class org.axonframework.mongo3.saga.repository.DefaultMongoTemplate
 
sagaCollection() - Method in interface org.axonframework.mongo3.saga.repository.MongoTemplate
Returns a reference to the collection containing the saga instances.
sagaCollection() - Method in class org.axonframework.saga.repository.mongo.DefaultMongoTemplate
 
sagaCollection() - Method in interface org.axonframework.saga.repository.mongo.MongoTemplate
Returns a reference to the collection containing the saga instances.
SagaCreationPolicy - Enum in org.axonframework.saga
Enumeration containing the possible Creation Policies for Sagas.
SagaEntry - Class in org.axonframework.mongo3.saga.repository
Java representation of sagas stored in a mongo instance
SagaEntry(Saga, Serializer) - Constructor for class org.axonframework.mongo3.saga.repository.SagaEntry
Constructs a new SagaEntry for the given saga.
SagaEntry(Document) - Constructor for class org.axonframework.mongo3.saga.repository.SagaEntry
Initializes a Saga entry using a DBObject containing the Mongo Document
SagaEntry - Class in org.axonframework.saga.repository.jpa
Java Persistence Entity allowing sagas to be stored in a relational database.
SagaEntry(Saga, Serializer) - Constructor for class org.axonframework.saga.repository.jpa.SagaEntry
Constructs a new SagaEntry for the given saga.
SagaEntry() - Constructor for class org.axonframework.saga.repository.jpa.SagaEntry
Constructor required by JPA.
SagaEntry - Class in org.axonframework.saga.repository.mongo
Java representation of sagas stored in a mongo instance
SagaEntry(Saga, Serializer) - Constructor for class org.axonframework.saga.repository.mongo.SagaEntry
Constructs a new SagaEntry for the given saga.
SagaEntry(DBObject) - Constructor for class org.axonframework.saga.repository.mongo.SagaEntry
Initializes a Saga entry using a DBObject containing the Mongo Document
sagaEntryTable() - Method in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
 
SagaEventHandler - Annotation Type in org.axonframework.saga.annotation
Method-level annotation indicating that the annotated method i an event handler method for the saga instance.
SagaFactory - Interface in org.axonframework.saga
Interface describing a mechanism that creates implementations of a Saga.
SagaInitializationPolicy - Class in org.axonframework.saga
Describes the conditions under which a Saga should be created, and which AssociationValue it should be initialized with.
SagaInitializationPolicy(SagaCreationPolicy, AssociationValue) - Constructor for class org.axonframework.saga.SagaInitializationPolicy
Creates an instance using the given creationPolicy and initialAssociationValue.
SagaManager - Interface in org.axonframework.saga
Interface toward the Manager of one or more types of Saga.
SagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
Parses the saga-manager element.
SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager - Class in org.axonframework.contextsupport.spring
Manages the subscription of a SagaManager with an Event Bus.
SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager() - Constructor for class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
 
SagaMethodMessageHandler - Class in org.axonframework.saga.annotation
A data holder containing information of SagaEventHandler annotated methods.
SagaMethodMessageHandler(SagaCreationPolicy, MethodMessageHandler, String, String, Property) - Constructor for class org.axonframework.saga.annotation.SagaMethodMessageHandler
Creates a SagaMethodMessageHandler.
SagaMethodMessageHandlerInspector<T extends AbstractAnnotatedSaga> - Class in org.axonframework.saga.annotation
Utility class that inspects annotation on a Saga instance and returns the relevant configuration for its Event Handlers.
SagaMethodMessageHandlerInspector(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
Initialize the inspector to handle events for the given sagaType.
SagaRepository - Interface in org.axonframework.saga
Interface towards the storage mechanism of Saga instances.
SagaSqlSchema - Interface in org.axonframework.saga.repository.jdbc
Interface describing the SQL statements that the JdbcSagaRepository needs to execute against the underlying database.
SagaStorageException - Exception in org.axonframework.saga
Exception indicating that an error has occurred while storing a Saga.
SagaStorageException(String) - Constructor for exception org.axonframework.saga.SagaStorageException
Initialize a SagaStorageException with the given descriptive message.
SagaStorageException(String, Throwable) - Constructor for exception org.axonframework.saga.SagaStorageException
Initialize a SagaStorageException with the given descriptive message and cause.
save(T) - Method in interface org.axonframework.unitofwork.SaveAggregateCallback
Invoked when the UnitOfWork wishes to store an aggregate.
SaveAggregateCallback<T extends AggregateRoot> - Interface in org.axonframework.unitofwork
Callback used by UnitOfWork instances to be invoked when the UnitOfWork wishes to store an aggregate.
saveAggregates() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
saveAggregates() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
Saves all registered aggregates by calling their respective callbacks.
schedule(EventMessage<?>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.async.AsynchronousCluster
Schedules this task for execution when all pre-conditions have been met.
schedule(DateTime, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Schedule the given event for publication at the given triggerDateTime.
schedule(Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Schedule the given event for publication after the given triggerDuration.
schedule(DateTime, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
schedule(DateTime, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
schedule(DateTime, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
schedule(Duration, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
ScheduledItem - Interface in org.axonframework.test.eventscheduler
Interface describing an event to be scheduled at a given date and time.
scheduleEvent(EventMessage<?>) - Method in class org.axonframework.eventhandling.async.EventProcessor
Schedules an event for processing.
scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
 
scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in interface org.axonframework.commandhandling.gateway.RetryScheduler
Inspect the given commandMessage that failed with given lastFailure.
scheduleSnapshot(String, Object) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
 
scheduleSnapshot(String, Object) - Method in interface org.axonframework.eventsourcing.Snapshotter
Schedules snapshot taking for an aggregate with given typeIdentifier and aggregateIdentifier.
scheduleSnapshot(String, Object) - Method in class org.axonframework.gae.eventstore.GaeSnapshotter
 
ScheduleToken - Interface in org.axonframework.eventhandling.scheduling
Token that identifies a single scheduled Event.
SchedulingException - Exception in org.axonframework.eventhandling.scheduling
Exception indicating a problem in the Event Scheduling mechanism.
SchedulingException(String) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
Initialize a SchedulingException with the given message.
SchedulingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
Initialize a SchedulingException with the given message and cause.
schemaConfiguration - Variable in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
SchemaConfiguration - Class in org.axonframework.eventstore.jdbc
SchemaConfiguration allows specification of custom storage locations for domain event and snapshot event entries.
SchemaConfiguration() - Constructor for class org.axonframework.eventstore.jdbc.SchemaConfiguration
Initialize SchemaConfiguration with default values.
SchemaConfiguration(String, String) - Constructor for class org.axonframework.eventstore.jdbc.SchemaConfiguration
Initialize SchemaConfiguration with custom locations for event entry tables.
schemaConfiguration - Variable in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
SchemaConfiguration - Class in org.axonframework.saga.repository.jdbc
SchemaConfiguration allows specification of custom storage locations for the saga repositories.
SchemaConfiguration() - Constructor for class org.axonframework.saga.repository.jdbc.SchemaConfiguration
Initialize SchemaConfiguration with default values.
SchemaConfiguration(String, String) - Constructor for class org.axonframework.saga.repository.jdbc.SchemaConfiguration
Initialize SchemaConfiguration with custom locations for event entry tables.
segmentCount() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.Member
Returns the number of segments this member has on the consistent hash ring.
selectCluster(EventListener) - Method in class org.axonframework.eventhandling.AbstractClusterSelector
 
selectCluster(EventListener) - Method in class org.axonframework.eventhandling.AutowiringClusterSelector
 
selectCluster(EventListener) - Method in interface org.axonframework.eventhandling.ClusterSelector
Selects the cluster instance that the given eventListener should be member of.
selectCluster(EventListener) - Method in class org.axonframework.eventhandling.CompositeClusterSelector
 
selectCluster(EventListener) - Method in class org.axonframework.eventhandling.DefaultClusterSelector
Selects the cluster instance that the given eventListener should be member of.
send(String, CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Sends the given command to the node assigned to handle messages with the given routingKey.
send(String, CommandMessage<?>, CommandCallback<R>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Sends the given command to the node assigned to handle messages with the given routingKey.
send(String, CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
 
send(String, CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
 
send(Object, CommandCallback<R>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Sends the given command, and invokes the callback when the command is processed.
send(Object, CommandCallback<R>) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
Sends the given command, and have the result of the command's execution reported to the given callback.
send(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
Sends the given command and returns immediately, without waiting for the command to execute.
send(Object, CommandCallback<R>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
 
send(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Sends the given command and returns immediately.
sendAndForget(Object) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Dispatches a command without callback.
sendAndWait(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
Sends the given command and wait for it to execute.
sendAndWait(Object, long, TimeUnit) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
Sends the given command and wait for it to execute.
sendAndWait(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Sends the given command and waits for its execution to complete, or until the waiting thread is interrupted.
sendAndWait(Object, long, TimeUnit) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Sends the given command and waits for its execution to complete, or until the given timeout has expired, or the waiting thread is interrupted.
sendCommands(CommandGateway) - Static method in class org.axonframework.quickstart.CommandGenerator
 
SequenceEventStore - Class in org.axonframework.eventstore.supporting
Joins two EventStores together.
SequenceEventStore(EventStore, EventStoreManagement, EventStore, EventStoreManagement) - Constructor for class org.axonframework.eventstore.supporting.SequenceEventStore
 
SequenceMatcher - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers each match against an item that the previous matcher matched against.
SequenceMatcher(Matcher<?>...) - Constructor for class org.axonframework.test.matchers.SequenceMatcher
Construct a matcher that will return true if all the given matchers match against an item positioned after the item that the previous matcher matched against.
SequenceNumber - Annotation Type in org.axonframework.eventhandling.annotation
Annotation indication that a parameter on an Event Handler method should be injected with the SequenceNumber of a DomainEventMessage.
SequenceNumberParameterResolverFactory - Class in org.axonframework.eventhandling.annotation
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a Long type annotated with the SequenceNumber annotation and assigns the sequenceNumber of the DomainEventMessage.
SequenceNumberParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.annotation.SequenceNumberParameterResolverFactory
Initializes a ParameterResolverFactory for SequenceNumber annotated parameters
sequenceOf(Matcher<?>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a list of Events if each of the matchers match against an Event that comes after the Event that the previous matcher matched against.
SequencingPolicy<T> - Interface in org.axonframework.eventhandling.async
Interface to a policy definition for concurrent processing, for example event handling.
SequentialPerAggregatePolicy - Class in org.axonframework.eventhandling.async
Concurrency policy that requires sequential processing of events raised by the same aggregate.
SequentialPerAggregatePolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
 
SequentialPolicy - Class in org.axonframework.eventhandling.async
SequencingPolicy that requires serialized handling of all events delivered to an event handler.
SequentialPolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPolicy
 
SerializationAware - Interface in org.axonframework.serializer
Marker interface for messages that have special serialization awareness.
SerializationAwareDomainEventMessage<T> - Class in org.axonframework.serializer
Wrapper around a DomainEventMessage that adds "Serialization Awareness" to the message it wraps.
SerializationAwareDomainEventMessage(DomainEventMessage<T>) - Constructor for class org.axonframework.serializer.SerializationAwareDomainEventMessage
Initialize a new wrapper for the given message.
SerializationAwareEventMessage<T> - Class in org.axonframework.serializer
Wrapper around am EventMessage that adds "Serialization Awareness" to the message it wraps.
SerializationAwareEventMessage(EventMessage<T>) - Constructor for class org.axonframework.serializer.SerializationAwareEventMessage
Initializes a new wrapper for the given eventMessage.
SerializationException - Exception in org.axonframework.serializer
Indicates that an exception occurred while serializing or deserializing an object.
SerializationException(String) - Constructor for exception org.axonframework.serializer.SerializationException
Initializes the exception using the given message.
SerializationException(String, Throwable) - Constructor for exception org.axonframework.serializer.SerializationException
Initializes the exception using the given message and cause.
SerializationOptimizingInterceptor - Class in org.axonframework.commandhandling.interceptors
Interceptor that register a unit of work listener that wraps each EventMessage in a SerializationAware message.
SerializationOptimizingInterceptor() - Constructor for class org.axonframework.commandhandling.interceptors.SerializationOptimizingInterceptor
 
serialize(Object, Class<T>) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
Serialize the given object into a Serialized Object containing the given expectedRepresentation.
serialize(Object, Class<T>) - Method in class org.axonframework.serializer.JavaSerializer
 
serialize(Object, Class<T>) - Method in class org.axonframework.serializer.json.JacksonSerializer
 
serialize(Object, Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
 
serialize(Object, Class<T>) - Method in interface org.axonframework.serializer.Serializer
Serialize the given object into a Serialized Object containing the given expectedRepresentation.
SerializedDomainEventData<T> - Interface in org.axonframework.serializer
Interface describing the properties of serialized Domain Event Messages.
SerializedDomainEventMessage<T> - Class in org.axonframework.serializer
DomainEventMessage implementation that is optimized to cope with serialized Payload and MetaData.
SerializedDomainEventMessage(SerializedDomainEventData, Serializer) - Constructor for class org.axonframework.serializer.SerializedDomainEventMessage
Reconstructs a DomainEventMessage using the given domainEventData, containing data to be deserialized using the given serializer.
SerializedDomainEventMessage(SerializedEventMessage<T>, Object, long) - Constructor for class org.axonframework.serializer.SerializedDomainEventMessage
Wrapper constructor for wrapping a SerializedEventMessage as a SerializedDomainEventMessage, using given aggregateIdentifier and sequenceNumber.
SerializedDomainEventUpcastingContext - Class in org.axonframework.upcasting
Implementation of UpcastingContext that builds a context based on the information of a serialized domain event
SerializedDomainEventUpcastingContext(SerializedDomainEventData, Serializer) - Constructor for class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
Initializes the UpcastingContext using given serialized domainEventData.
SerializedEventMessage<T> - Class in org.axonframework.serializer
EventMessage implementation that is optimized to cope with serialized Payload and MetaData.
SerializedEventMessage(String, DateTime, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serializer.SerializedEventMessage
Constructor to reconstruct an EventMessage using serialized data
SerializedMessage<T> - Class in org.axonframework.serializer
Message implementation that is optimized to cope with serialized Payload and MetaData.
SerializedMessage(String, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serializer.SerializedMessage
Reconstructs a Message using the given identifier, serializedPayload, serializedMetaData and serializer.
SerializedMetaData<T> - Class in org.axonframework.serializer
Represents the serialized form of a MetaData instance.
SerializedMetaData(T, Class<T>) - Constructor for class org.axonframework.serializer.SerializedMetaData
Construct an instance with given bytes representing the serialized form of a MetaData instance.
SerializedObject<T> - Interface in org.axonframework.serializer
Interface describing the structure of a serialized object.
SerializedObjectHolder - Class in org.axonframework.serializer
Holder that keeps references to serialized representations of a payload and meta data of a specific message.
SerializedObjectHolder(Message) - Constructor for class org.axonframework.serializer.SerializedObjectHolder
Initialize the holder for the serialized representations of the payload and meta data of given message
SerializedSaga - Class in org.axonframework.saga.repository.jpa
Specialization of the SerializedObject for Sagas represented as byte array.
SerializedSaga(byte[], String, String) - Constructor for class org.axonframework.saga.repository.jpa.SerializedSaga
Initialize a SerializedSaga instance with given data, of given type and revision.
SerializedType - Interface in org.axonframework.serializer
Describes the type of a serialized object.
serializeMetaData(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serializer.MessageSerializer
Utility method that serializes the meta data of the given message using given serializer and expectedRepresentation.
serializeMetaData(Message<?>, Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
Serialize the meta data of given message to the given expectedRepresentation.
serializeMetaData(Serializer, Class<T>) - Method in interface org.axonframework.serializer.SerializationAware
Serialize the meta data of this message using given serializer, using given expectedRepresentation.
serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedEventMessage
 
serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedMessage
 
serializeMetaData(Serializer, Class<T>) - Method in class org.axonframework.serializer.SerializedObjectHolder
 
serializePayload(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serializer.MessageSerializer
Utility method that serializes the payload of the given message using given serializer and expectedRepresentation.
serializePayload(Message<?>, Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
Serialize the payload of given message to the given expectedRepresentation.
serializePayload(Serializer, Class<T>) - Method in interface org.axonframework.serializer.SerializationAware
Serialize the payload of this message using given serializer, using given expectedRepresentation.
serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedEventMessage
 
serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedMessage
 
serializePayload(Serializer, Class<T>) - Method in class org.axonframework.serializer.SerializedObjectHolder
 
Serializer - Interface in org.axonframework.serializer
Interface describing a serialization mechanism.
SerializerHandler - Class in org.axonframework.commandhandling.disruptor
Disruptor Event Handler that serializes EventMessage implementations that are also SerializationAware.
SerializerHandler(Serializer, int, Class<?>) - Constructor for class org.axonframework.commandhandling.disruptor.SerializerHandler
Initialize the handler using given serializer and processing the segment Id with given serializerId (in case of multiple serializer threads).
SerialVersionUIDRevisionResolver - Class in org.axonframework.serializer
RevisionResolver implementation that returns the (String representation of the) serialVersionUID of a class.
SerialVersionUIDRevisionResolver() - Constructor for class org.axonframework.serializer.SerialVersionUIDRevisionResolver
 
set(UnitOfWork) - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Binds the given unitOfWork to the current thread.
setAcknowledgeMode(AcknowledgeMode) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the acknowledge mode to use for the cluster
setAdditionalConverters(List<ContentTypeConverter>) - Method in class org.axonframework.serializer.ChainingConverterFactory
Setter for dependency injection frameworks that require property methods.
setAdditionalFactories(List<ParameterResolverFactory>) - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
Defines any additional parameter resovler factories that need to be use to resolve parameters.
setAdviceChain(Advice[]) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the Advice Chain to use for the cluster.
setAggregateCache(Cache) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
Sets the Cache instance used be Caching repositories.
setAggregateCaches(List<Cache>) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
Sets the Cache instances used be Caching repositories.
setAggregateFactories(List<AggregateFactory<?>>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
Sets the aggregate factory to use.
setAggregateFactories(List<AggregateFactory<?>>) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
Optionally sets the aggregate factories to use.
setAggregateFactory(AggregateFactory<? extends EventSourcedAggregateRoot>) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
Sets the aggregate factory used to create instances for the repository to create.
setAggregateType(Class<T>) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
Sets the type of aggregate to inspect for annotations.
setAggregateType(String) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Sets the type identifier of the aggregate handled in this unit of work
setApplicationContext(ApplicationContext) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
setApplicationContext(ApplicationContext) - Method in class org.axonframework.common.annotation.SpringBeanParameterResolverFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.AutowiringClusterSelector
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.gae.eventstore.GaeSnapshotter
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.saga.spring.SpringResourceInjector
 
setAttribute(String, String) - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Sets an attribute to this node.
setAttribute(String, String) - Method in class org.axonframework.serializer.bson.BSONNode
Sets an attribute to this node.
setAuditDataProvider(AuditDataProvider) - Method in class org.axonframework.auditing.AuditingInterceptor
Sets the AuditingDataProvider for this interceptor.
setAuditLogger(AuditLogger) - Method in class org.axonframework.auditing.AuditingInterceptor
Sets the logger that writes events to the audit logs.
setAutoConnectRetry(boolean) - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Setter for AutoConnectRetry.
setBatchSize(int) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
Sets the number of events that should be read at each database access.
setBatchSize(int) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Sets the number of events that should be read at each database access.
setBeanClassLoader(ClassLoader) - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
 
setBeanName(String) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
setBeanName(String) - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
 
setBeanName(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
setBufferSize(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the buffer size to use.
setBufferSize(int) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the size of the processing buffer.
setCache(Cache) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the cache in which loaded aggregates will be stored.
setCache(Cache) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
Set the cache to use for this repository.
setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
setCallbackBehavior(CallbackBehavior) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback.
setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.utils.RecordingCommandBus
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback.
setChannel(SubscribableChannel) - Method in class org.axonframework.integration.eventbus.SpringIntegrationEventBus
Sets the Spring Integration Channel that this event bus should publish events to.
setChannel(SubscribableChannel) - Method in class org.axonframework.springmessaging.eventbus.SpringMessagingEventBus
Sets the Spring Messaging Channel that this event bus should publish events to.
setChannelName(String) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Optionally sets the logical channel name of the channel.
setClearCountersAfterAppend(boolean) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
Indicates whether to maintain counters for aggregates after appending events to the event store for these aggregates.
setClusterName(String) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the name of the cluster to subscribe to.
setCommandBus(CommandBus) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
Sets the CommandBus to subscribe the handler to
setCommandBus(CommandBus) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
Sets the event bus to which detected event listeners should be subscribed.
setCommandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
Sets the command bus on which the Gateway must dispatch commands.
setCommandBus(DisruptorCommandBus) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
The DisruptorCommandBus instance to create the repository from.
setCommandCallbacks(List<CommandCallback<?>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
Registers the commandCallbacks, which are invoked for each sent command, unless Axon is able to detect that the result of the command does not match the type accepted by that callback.
setCommandDispatchInterceptors(Collection<CommandDispatchInterceptor>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Sets the interceptors that intercept commands just prior to dispatching them.
setCommandDispatchInterceptors(CommandDispatchInterceptor...) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
Sets the interceptors that should be invoked before a command is dispatched the the Command Bus.
setCommandDispatchInterceptors(List<CommandDispatchInterceptor>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
Sets the interceptors that should be invoked before a command is dispatched the the Command Bus.
setCommandGateway(CommandGateway) - Method in class org.axonframework.quickstart.saga.ToDoSaga
 
setCommandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
The resolver providing the identifier (and version) of the aggregate a command targets.
setCommandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the CommandTargetResolver that must be used to indicate which Aggregate instance will be invoked by an incoming command.
setConcurrentConsumers(int) - Method in class org.axonframework.eventhandling.amqp.spring.ExtendedMessageListenerContainer
Sets the number of concurrent consumers in this container.
setConcurrentConsumers(Integer) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the number of concurrent consumers to use for the cluster
setConfiguration(String) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the JGroups configuration file to load.
setConflictResolver(ConflictResolver) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Sets the conflict resolver to use for this repository.
setConnectionFactory(ConnectionFactory) - Method in class org.axonframework.eventhandling.amqp.spring.ExtendedMessageListenerContainer
 
setConnectionFactory(ConnectionFactory) - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerFactory
Sets the connection factory to use for the cluster
setConnectionFactory(ConnectionFactory) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the ConnectionFactory providing the Connections and Channels to send messages on.
setConnectionsPerHost(int) - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Setter for the connections per host that are allowed.
setConnectionsPerHost(int) - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Setter for the connections per host that are allowed.
setConnectionTimeout(int) - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Setter for the connection time out.
setConnectionTimeout(int) - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Setter for the connection time out.
setCoolingDownPeriod(long) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the cooling down period in milliseconds.
setCorrelationData(Map<String, ?>) - Static method in class org.axonframework.correlation.CorrelationDataHolder
Attaches the given data as correlation data to the current thread.
setCorrelationDataProvider(CorrelationDataProvider<? super EventMessage>) - Method in class org.axonframework.saga.AbstractSagaManager
Sets the correlation data provider for this SagaManager.
setCorrelationDataProvider(CorrelationDataProvider<? super EventMessage>) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the CorrelationDataProvider which provides the Meta Data to assign to messages generated by the Sagas that are managed by this SagaManager instance.
setCorrelationDataProviders(List<? extends CorrelationDataProvider<? super EventMessage>>) - Method in class org.axonframework.saga.AbstractSagaManager
Sets the given correlationDataProviders.
setCorrelationDataProviders(List<? extends CorrelationDataProvider<? super EventMessage>>) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the CorrelationDataProviders which provide the Meta Data to assign to messages generated by the Sagas that are managed by this SagaManager instance.
setDataSource(DataSource) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Registers the data source that allows the EventStore to detect the database type and define the error codes that represent concurrent access failures.
setDefaultConfiguration(SpringAMQPConsumerConfiguration) - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
Sets the configuration with the entries to use as defaults in case a registered cluster does not provide explicit values.
setDefaults(SpringAMQPConsumerConfiguration) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the defaults to use when this instance does not explicitly provide a configuration value.
setDispatchInterceptors(List<CommandDispatchInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Configures the CommandDispatchInterceptor to use with the DisruptorCommandBus when commands are dispatched.
setDispatchInterceptors(List<? extends CommandDispatchInterceptor>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Registers the given list of dispatch interceptors to the command bus.
setDurable(boolean) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Whether or not messages should be marked as "durable" when sending them out.
setEntityManager(EntityManager) - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
Sets the container managed entityManager to use.
setErrorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the Error Handler to use for the cluster.
setErrorHandler(ErrorHandler) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the ErrorHandler instance, which defines the behavior in case an error occurs while loading or invoking Sagas for an incoming Event.
setEventBus(EventBus) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
Sets the event bus to which the SagaManager should be subscribed
setEventBus(EventBus) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
Sets the event bus to which detected event listeners should be subscribed.
setEventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
Sets the eventBus that scheduled events should be published to.
setEventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the event bus to which scheduled events need to be published.
setEventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the event bus to which scheduled events need to be published.
setEventBus(EventBus) - Method in class org.axonframework.repository.AbstractRepository
Sets the event bus to which newly stored events should be published.
setEventJobDataBinder(EventJobDataBinder) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the QuartzEventScheduler.DirectEventJobDataBinder instance which reads / writes the event message to publish to the JobDataMap.
setEventJobDataBinder(EventJobDataBinder) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the EventJobDataBinder instance which reads / writes the event message to publish to the JobDataMap.
setEventScheduler(EventScheduler) - Method in class org.axonframework.quickstart.saga.ToDoSaga
 
setEventsToAlwaysCreateNewSagasFor(List<Class<?>>) - Method in class org.axonframework.saga.SimpleSagaManager
Sets the types of Events that should cause the creation of a new Saga instance, even if one already exists.
setEventsToOptionallyCreateNewSagasFor(List<Class<?>>) - Method in class org.axonframework.saga.SimpleSagaManager
Sets the types of Events that should cause the creation of a new Saga instance if one does not already exist.
setEventStore(SnapshotEventStore) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Sets the event store where the snapshotter can load domain events and store its snapshot events.
setEventStore(EventStore) - Method in class org.axonframework.eventsourcing.HybridJpaRepository
The event store to which events are appended.
setEventStreamDecorator(EventStreamDecorator) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Registers the EventStreamDecorator for events as part of this unit of work
setEventStreamDecorators(List<EventStreamDecorator>) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
Sets the (additional) decorators to use when loading and storing events from/to the Event Store.
setEventStreamDecorators(List<? extends EventStreamDecorator>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Sets the Event Stream Decorators that will process the event in the DomainEventStream when read, or written to the event store.
setExceptionResult(Throwable) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Registers the exception that occurred while processing the incoming command.
setExchange(Exchange) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the name of the exchange to dispatch published messages to.
setExchangeName(String) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the name of the exchange to dispatch published messages to.
setExclusive(SimpleMessageListenerContainer, boolean) - Method in class org.axonframework.eventhandling.amqp.spring.DefaultRabbitMqStrategy
 
setExclusive(boolean) - Method in class org.axonframework.eventhandling.amqp.spring.ExtendedMessageListenerContainer
Sets whether the listener container created by this factory should be exclusive.
setExclusive(SimpleMessageListenerContainer, boolean) - Method in class org.axonframework.eventhandling.amqp.spring.LegacyRabbitMqStrategy
 
setExclusive(SimpleMessageListenerContainer, boolean) - Method in interface org.axonframework.eventhandling.amqp.spring.RabbitMqStrategy
Define exclusive mode on the underlying container
setExclusive(Boolean) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets whether the listener container created by this factory should be exclusive.
setExecutor(Executor) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the Executor that provides the processing resources (Threads) for the components of the DisruptorCommandBus.
setExecutor(Executor) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Sets the executor that should process actual snapshot taking.
setExecutor(Executor) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the executor that provides the threads for the processors.
setExecutorService(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
Sets the ExecutorService implementation that monitors the triggers and provides the Threads to publish events.
setForceFlushOnSave(boolean) - Method in class org.axonframework.repository.GenericJpaRepository
Indicates whether the EntityManager's state should be flushed each time an aggregate is saved.
setForceUtc(boolean) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
Control if date time in the SQL scheme should use UTC time zone or system local time zone.
setGatewayInterface(Class<T>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
Sets the interface that describes the gateway instance to describe.
setGroupIdentifier(String) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the group identifier to use when scheduling jobs with Quartz.
setGroupIdentifier(String) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the group identifier to use when scheduling jobs with Quartz.
setHandlerInterceptors(List<? extends CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Registers the given list of interceptors to the command bus.
setHashChangeListener(HashChangeListener) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Register a HashChangeListener with the JGroupsConnector.
setInterceptors(List<CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the interceptor to use in the default local segment (a SimpleCommandBus).
setInvokerInterceptors(List<CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during in the invocation thread.
setInvokerThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the number of Threads that should be used to invoke the Command Handlers.
setJoinTimeout(long) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the number of milliseconds to wait for this member to join the group.
setListenerContainerLifecycleManager(ListenerContainerLifecycleManager) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the ListenerContainerLifecycleManager that creates and manages the lifecycle of Listener Containers for the clusters that are connected to this terminal.
setLoadFactor(int) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the load factor for this instance of the Distributed Command Bus.
setLocalSegment(CommandBus) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the CommandBus instance on which local commands must be dispatched.
setMaxSnapshotsArchived(int) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
Sets the maximum number of snapshots to archive for an aggregate.
setMaxSnapshotsArchived(int) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Sets the maximum number of snapshots to archive for an aggregate.
setMaxWaitTime(int) - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Set the max wait time for a blocked thread in milli seconds.
setMaxWaitTime(int) - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Set the max wait time for a blocked thread in milli seconds.
setMessageConverter(AMQPMessageConverter) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the Message Converter that creates AMQP Messages from Event Messages and vice versa.
setMessagePropertiesConverter(MessagePropertiesConverter) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the message properties converter to use for the cluster
setMetaDataValues(Map<String, Object>) - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
Sets the given metaDataValues in the Cluster.
setMongoAddresses(List<ServerAddress>) - Method in class org.axonframework.eventstore.mongo.MongoFactory
Provide a list of ServerAddress objects to use for locating the Mongo replica set.
setMongoAddresses(List<ServerAddress>) - Method in class org.axonframework.mongo3.eventstore.MongoFactory
Provide a list of ServerAddress objects to use for locating the Mongo replica set.
setMongoOptions(MongoOptions) - Method in class org.axonframework.eventstore.mongo.MongoFactory
Provide an instance of MongoOptions to be used for the connections.
setMongoOptions(MongoClientOptions) - Method in class org.axonframework.mongo3.eventstore.MongoFactory
Provide an instance of MongoOptions to be used for the connections.
setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
Sets the ParameterResolverFactory to create parameter resolver instances with.
setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Sets the ParameterResolverFactory to create the Parameter Resolvers with that provide the parameter values for the handler methods.
setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
Sets the parameter resolver with which parameters of annotated event handlers in the aggregae are resolved.
setPersistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
Sets the persistenceExceptionResolver that will help detect concurrency exceptions from the backing database.
setPersistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Sets the persistenceExceptionResolver that will help detect concurrency exceptions from the backing database.
setPhase(int) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the phase in which this bean must be started.
setPhase(int) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Sets the phase in which handlers are subscribed and unsubscribed.
setPhase(int) - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
Defines the phase in which Spring should manage this beans lifecycle.
setPrefetchCount(Integer) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the PrefetchCount to use for the cluster.
setProcessorCount(int) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the number of processors (threads) to process events with.
setProducerType(ProducerType) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the producer type to use.
setProperty(String, Object) - Method in interface org.axonframework.eventhandling.ClusterMetaData
Stores a property value under the given key.
setProperty(String, Object) - Method in class org.axonframework.eventhandling.DefaultClusterMetaData
 
setPrototypeBeanName(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
Sets the name of the prototype bean this repository serves.
setPublisherAckTimeout(long) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the maximum amount of time (in milliseconds) the publisher may wait for the acknowledgement of published messages.
setPublisherInterceptors(List<CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during the publication of changes.
setPublisherThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the number of Threads that should be used to store and publish the generated Events.
setQueueName(String) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the name of the Queue that a Cluster should be connected to.
setReceiveTimeout(Long) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the receive timeout to use for the cluster
setRecoveryInterval(Long) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the Recovery Interval to use for the cluster.
setReplayable(boolean) - Method in class org.axonframework.saga.AbstractReplayAwareSagaManager
Sets whether or not to allow event replay on managed Sagas.
setReportIllegalStateChange(boolean) - Method in interface org.axonframework.test.FixtureConfiguration
Sets whether or not the fixture should detect and report state changes that occur outside of Event Handler methods.
setReportIllegalStateChange(boolean) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
setRepository(Repository<T>) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
The repository from which to load aggregate instances.
setRescheduleCommandsOnCorruptState(boolean) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Indicates whether commands that failed because they were executed against potentially corrupted aggregate state should be automatically rescheduled.
setResourceInjector(ResourceInjector) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
Sets the ResourceInjector to use to inject Saga instances with any (temporary) resources they might need.
setResourceInjector(ResourceInjector) - Method in class org.axonframework.saga.GenericSagaFactory
Sets the resource injector that provides the resources needed by the Sagas created by this factory.
setResourceInjector(ResourceInjector) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
Sets the ResourceInjector to use to inject Saga instances with any (temporary) resources they might need.
setResourceInjector(ResourceInjector) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
Sets the ResourceInjector to use to inject Saga instances with any (temporary) resources they might need.
setResourceInjector(ResourceInjector) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
Sets the ResourceInjector to use to inject Saga instances with any (temporary) resources they might need.
setResult(Object) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Registers the result of the command's execution, if successful.
setRetryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
Sets the RetryScheduler that will be invoked when a command fails execution.
setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the rollback configuration for the DisruptorCommandBus to use.
setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Sets the RollbackConfiguration that allows you to change when the UnitOfWork is committed.
setRoutingKeyResolver(RoutingKeyResolver) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the RoutingKeyResolver that provides the Routing Key for each message to dispatch.
setSagaFactory(SagaFactory) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the SagaFactory responsible for creating new Saga instances when required.
setSagaManager(SagaManager) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
Sets the SagaManager instance to subscribe to the Event Bus
setSagaRepository(SagaRepository) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the saga repository to store and load Sagas from.
setScheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the backing Quartz Scheduler for this timer.
setScheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the backing Quartz Scheduler for this timer.
setSerializedRepresentation(Class<?>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the type of data the serialized object should be represented in.
setSerializer(Serializer) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the serializer to perform pre-serialization with, or null if no pre-serialization should be done.
setSerializer(Serializer) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the serializer used to serialize events before they are dispatched to the destination.
setSerializer(Serializer) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Sets the serializer to serialize messages with when sending them to the Exchange.
setSerializer(Serializer) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
Provide the serializer to use if the default JavaSagaSerializer is not the best solution.
setSerializer(Serializer) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
Sets the Serializer instance to serialize Sagas with.
setSerializer(Serializer) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
Sets the Serializer instance to serialize Sagas with.
setSerializer(Serializer) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
Provide the serializer to use if the default JavaSagaSerializer is not the best solution.
setSerializerThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the number of threads that should perform the pre-serialization step.
setShutdownTimeout(Long) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the shutdown timeout to use for the cluster
setSnapshotter(Snapshotter) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
Sets the snapshotter to notify when a snapshot needs to be taken.
setSnapshotterTrigger(SnapshotterTrigger) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
The snapshotter trigger instance that will decide when to trigger a snapshot
setSnapshotterTrigger(SnapshotterTrigger) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Sets the snapshotter trigger for this repository.
setSocketTimeOut(int) - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Setter for the socket time out.
setSocketTimeOut(int) - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Setter for the socket time out.
setStartTimeout(long) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the amount of time (in milliseconds) the AsyncSagaManager will wait for the async processors to be assigned a thread from the executor.
setSubscriptions(Map<?, ?>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Convenience method that allows you to register command handlers using a Dependency Injection framework.
setSuppressExceptions(boolean) - Method in class org.axonframework.saga.AbstractSagaManager
Sets whether or not to suppress any exceptions that are cause by invoking Sagas.
setSynchronizeSagaAccess(boolean) - Method in class org.axonframework.saga.AbstractSagaManager
Sets whether of not access to Saga's Event Handler should by synchronized.
setTaskExecutor(Executor) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the task executor to use for the cluster
setThreadsAllowedToBlockForConnectionMultiplier(int) - Method in class org.axonframework.eventstore.mongo.MongoOptionsFactory
Set the multiplier for the amount of threads to block in relation to the maximum amount of connections.
setThreadsAllowedToBlockForConnectionMultiplier(int) - Method in class org.axonframework.mongo3.eventstore.MongoOptionsFactory
Set the multiplier for the amount of threads to block in relation to the maximum amount of connections.
setTransactional(boolean) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Whether this Terminal should dispatch its Events in a transaction or not.
setTransactionAttribute(TransactionAttribute) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the transaction attribute to use for the cluster
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
The TransactionDefinition to use by the transaction manager.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
The TransactionDefinition to use by the transaction manager.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
Optionally sets the transaction definition to use.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.unitofwork.SpringTransactionManager
The TransactionDefinition to use by the transaction manager.
setTransactionManager(TransactionManager) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the transaction manager to use to manage a transaction around the storage and publication of events.
setTransactionManager(TransactionManager) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Sets the transaction manager that manages the transaction around command handling.
setTransactionManager(Object) - Method in class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
Sets the actual transaction manager.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the PlatformTransactionManager to use for the cluster.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
Sets the transaction manager that manages the transaction around the publication of an event.
setTransactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the transaction manager that manages a transaction around the publication of an event.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the transaction manager that manages the transaction around the publication of an event.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
Sets the transaction manager to manager underlying transaction with.
setTransactionManager(TransactionManager) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the TransactionManager used to manage any transactions required by the underlying storage mechanism.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.unitofwork.SpringTransactionManager
The PlatformTransactionManager that manages the transactions with the underlying data source.
setTrigger(int) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
Sets the number of events that will trigger the creation of a snapshot events.
setTxManager(TransactionManager<?>) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Sets the transactionManager that wraps the snapshot creation in a transaction.
setTxSize(Integer) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Sets the Transaction Size to use for the cluster.
setTypeIdentifier(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
Sets the type identifier of the aggregate served by this repository.
setUnitOfWorkFactory(UnitOfWorkFactory) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Sets the UnitOfWorkFactory that provides the UnitOfWork instances for handling incoming commands.
setUnitOfWorkFactory(UnitOfWorkFactory) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the Unit of Work Factory instance which provides the UnitOfWork that manages the publication of the scheduled event.
setUnsubscribeOnShutdown(boolean) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Indicates whether handlers should be unsubscribed on shutdown.
setUpcasterChain(UpcasterChain) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
 
setUpcasterChain(UpcasterChain) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
 
setUpcasterChain(UpcasterChain) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
 
setUpcasterChain(UpcasterChain) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
setUpcasterChain(UpcasterChain) - Method in class org.axonframework.gae.eventstore.GaeEventStore
 
setUpcasterChain(UpcasterChain) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
setUpcasterChain(UpcasterChain) - Method in interface org.axonframework.upcasting.UpcasterAware
Sets the UpcasterChain which allow older revisions of serialized objects to be deserialized.
setupConverters() - Method in class org.axonframework.gae.serializer.GaeXStream
 
setUseExplicitFlush(boolean) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
Sets whether or not to do an explicit EntityManager.flush() after each data modifying operation on the backing storage.
setValue(String) - Method in class org.axonframework.mongo3.serializer.bson.BSONNode
Sets the value of this node.
setValue(String) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
setValue(String) - Method in class org.axonframework.serializer.bson.BSONNode
Sets the value of this node.
setValue(String) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
setWaitForPublisherAck(boolean) - Method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
Enables or diables the RabbitMQ specific publisher acknowledgements (confirms).
setWaitStrategy(WaitStrategy) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the WaitStrategy, which used to make dependent threads wait for tasks to be completed.
setWaitStrategy(WaitStrategy) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Sets the WaitStrategy to use when event processors need to wait for incoming events.
setWriteConcern(WriteConcern) - Method in class org.axonframework.eventstore.mongo.MongoFactory
Provided a write concern to be used by the mongo instance.
setWriteConcern(WriteConcern) - Method in class org.axonframework.mongo3.eventstore.MongoFactory
Provided a write concern to be used by the mongo instance.
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.AggregateCommandHandlerBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.amqp.AMQPConfigurationBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.DisruptorCommandBusBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.EventBusBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JdbcEventStoreBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JdbcSagaRepositoryBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JpaRepositoryBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JpaSagaRepositoryBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.RepositoryBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SimpleCommandBusBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
 
shutdown() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
Shuts down the Executor used to asynchronously dispatch incoming commands.
SimpleCluster - Class in org.axonframework.eventhandling
A simple Cluster implementation that invokes each of the members of a cluster when an Event is published.
SimpleCluster(String) - Constructor for class org.axonframework.eventhandling.SimpleCluster
Initializes the cluster with given name.
SimpleCluster(String, OrderResolver) - Constructor for class org.axonframework.eventhandling.SimpleCluster
Initializes the cluster with given name, using given orderResolver to define the order in which listeners need to be invoked.
SimpleClusterFactoryBean - Class in org.axonframework.eventhandling
FactoryBean that creates an instance of a SimpleCluster, allowing easier access to the MetaData.
SimpleClusterFactoryBean() - Constructor for class org.axonframework.eventhandling.SimpleClusterFactoryBean
 
SimpleCommandBus - Class in org.axonframework.commandhandling
Implementation of the CommandBus that dispatches commands to the handlers subscribed to that specific type of command.
SimpleCommandBus() - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
Initializes the SimpleCommandBus.
SimpleCommandBusBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
The SimpleCommandBusBeanDefinitionParser does the actual work of parsing the commandBus element from the Axon namespace.
SimpleCommandBusBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SimpleCommandBusBeanDefinitionParser
 
SimpleCommandBusStatistics - Class in org.axonframework.commandhandling
Statistics object to store information about the internals of the SimpleCommandBus.
SimpleCommandBusStatistics() - Constructor for class org.axonframework.commandhandling.SimpleCommandBusStatistics
Creates an instance of this statistics MBean.
SimpleCommandBusStatisticsMXBean - Interface in org.axonframework.commandhandling
Management interface for the SimpleCommandBus monitor

As required by the JMX specification.

SimpleCorrelationDataProvider - Class in org.axonframework.correlation
CorrelationDataProvider implementation defines correlation headers by the header names.
SimpleCorrelationDataProvider(String...) - Constructor for class org.axonframework.correlation.SimpleCorrelationDataProvider
Initializes the CorrelationDataProvider to return the meta data of messages with given metaDataKeys as correlation data.
SimpleDomainEventStream - Class in org.axonframework.domain
Creates a DomainEventStream that streams the contents of a list.
SimpleDomainEventStream(Collection<? extends DomainEventMessage>) - Constructor for class org.axonframework.domain.SimpleDomainEventStream
Initialize the event stream using the given List of DomainEvent and aggregate identifier.
SimpleDomainEventStream(DomainEventMessage...) - Constructor for class org.axonframework.domain.SimpleDomainEventStream
Initialize the event stream using the given DomainEventMessages and aggregate identifier.
SimpleEntityManagerProvider - Class in org.axonframework.common.jpa
Simple implementation of the EntityManagerProvider that returns the EntityManager instance provided at construction time.
SimpleEntityManagerProvider(EntityManager) - Constructor for class org.axonframework.common.jpa.SimpleEntityManagerProvider
Initializes an instance that always returns the given entityManager.
SimpleEventBus - Class in org.axonframework.eventhandling
Implementation of the EventBus that directly forwards all published events (in the callers' thread) to all subscribed listeners.
SimpleEventBus() - Constructor for class org.axonframework.eventhandling.SimpleEventBus
Initializes the SimpleEventBus and registers the mbeans for management information.
SimpleEventBusStatistics - Class in org.axonframework.eventhandling
Statistics object to store information about the internal of the SimpleEventBus.
SimpleEventBusStatisticsMXBean - Interface in org.axonframework.eventhandling
Management interface the SimpleEventBus monitor.
SimpleEventBusWithoutStatistics - Class in org.axonframework.gae.commandhandling
This is a temporary copy of the SimpleEventBus, made to run on google app engine.
SimpleEventBusWithoutStatistics() - Constructor for class org.axonframework.gae.commandhandling.SimpleEventBusWithoutStatistics
 
SimpleEventFileResolver - Class in org.axonframework.eventstore.fs
Very straightforward implementation of the EventFileResolver that stores files in a directory structure underneath a given base directory.
SimpleEventFileResolver(File) - Constructor for class org.axonframework.eventstore.fs.SimpleEventFileResolver
Initialize the SimpleEventFileResolver with the given baseDir.
SimpleEventScheduler - Class in org.axonframework.eventhandling.scheduling.java
An EventScheduler implementation that uses Java's ScheduledExecutorService as scheduling and triggering mechanism.
SimpleEventScheduler(ScheduledExecutorService, EventBus) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
Initialize the SimpleEventScheduler using the given executorService as trigger and execution mechanism, and publishes events to the given eventBus.
SimpleEventScheduler(ScheduledExecutorService, EventBus, UnitOfWorkFactory) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
Initialize the SimpleEventScheduler using the given executorService as trigger and execution mechanism, and publishes events to the given eventBus.
SimpleEventSchedulerFactoryBean - Class in org.axonframework.eventhandling.scheduling.java
Spring FactoryBean that creates a SimpleEventScheduler instance using resources found in the Spring Application Context.
SimpleEventSchedulerFactoryBean() - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
SimpleMongoOperator - Class in org.axonframework.eventstore.mongo.criteria
Implementation of the simple Mongo Operators (those without special structural requirements), such as Less Than, Less Than Equals, etc.
SimpleMongoOperator(MongoProperty, String, Object) - Constructor for class org.axonframework.eventstore.mongo.criteria.SimpleMongoOperator
Initializes an criterium where the given property, operator and expression make a match.
SimpleMongoOperator - Class in org.axonframework.mongo3.eventstore.criteria
Implementation of the simple Mongo Operators (those without special structural requirements), such as Less Than, Less Than Equals, etc.
SimpleMongoOperator(MongoProperty, String, Object) - Constructor for class org.axonframework.mongo3.eventstore.criteria.SimpleMongoOperator
Initializes an criterium where the given property, operator and expression make a match.
SimpleOperator - Class in org.axonframework.eventstore.jdbc.criteria
Implementation of all simple operators (i.e.
SimpleOperator(JdbcProperty, String, Object) - Constructor for class org.axonframework.eventstore.jdbc.criteria.SimpleOperator
Initializes a simple operator where the given property, operator and expression match.
SimpleOperator - Class in org.axonframework.eventstore.jpa.criteria
Implementation of all simple operators (i.e.
SimpleOperator(JpaProperty, String, Object) - Constructor for class org.axonframework.eventstore.jpa.criteria.SimpleOperator
Initializes a simple operator where the given property, operator and expression match.
SimpleResourceInjector - Class in org.axonframework.saga
Resource injector that uses setter methods to inject resources.
SimpleResourceInjector(Object...) - Constructor for class org.axonframework.saga.SimpleResourceInjector
Initializes the resource injector to inject to given resources.
SimpleResourceInjector(Collection<?>) - Constructor for class org.axonframework.saga.SimpleResourceInjector
Initializes the resource injector to inject to given resources.
SimpleResourceParameterResolverFactory - Class in org.axonframework.common.annotation
ParameterResolverFactory implementation that resolves parameters for a specific given Resource.
SimpleResourceParameterResolverFactory(Object) - Constructor for class org.axonframework.common.annotation.SimpleResourceParameterResolverFactory
Initialize the ParameterResolverFactory to inject the given resource in applicable parameters.
SimpleSagaManager - Class in org.axonframework.saga
Simple SagaManager implementation.
SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, EventBus) - Constructor for class org.axonframework.saga.SimpleSagaManager
Deprecated. use SimpleSagaManager.SimpleSagaManager(Class, SagaRepository, AssociationValueResolver) and register using EventBus.subscribe(org.axonframework.eventhandling.EventListener)
SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, SagaFactory, EventBus) - Constructor for class org.axonframework.saga.SimpleSagaManager
Deprecated. use SimpleSagaManager.SimpleSagaManager(Class, SagaRepository, AssociationValueResolver, SagaFactory) and register using EventBus.subscribe(org.axonframework.eventhandling.EventListener)
SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver) - Constructor for class org.axonframework.saga.SimpleSagaManager
Initialize a SimpleSagaManager backed by the given resources, using a GenericSagaFactory.
SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, SagaFactory) - Constructor for class org.axonframework.saga.SimpleSagaManager
Initialize a SimpleSagaManager backed by the given resources.
SimpleScheduleToken - Class in org.axonframework.eventhandling.scheduling.java
ScheduleToken for tasks event scheduled using the SimpleEventScheduler.
SimpleScheduleToken(String) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
Creates a SimpleScheduleToken with the given tokenId.
SimpleSerializedDomainEventData<T> - Class in org.axonframework.eventstore.jpa
Simple implementation of the SerializedDomainEventData class, used to reduce memory consumptions by queries accessing Event Entries.
SimpleSerializedDomainEventData(String, String, long, Object, String, String, T, T) - Constructor for class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
Initialize an instance using given properties.
SimpleSerializedDomainEventData(String, String, long, Object, SerializedObject<T>, SerializedObject<T>) - Constructor for class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
Initialize an instance using given properties.
SimpleSerializedObject<T> - Class in org.axonframework.serializer
SerializedObject implementation that takes all properties as constructor parameters.
SimpleSerializedObject(T, Class<T>, SerializedType) - Constructor for class org.axonframework.serializer.SimpleSerializedObject
Initializes a SimpleSerializedObject using given data and serializedType.
SimpleSerializedObject(T, Class<T>, String, String) - Constructor for class org.axonframework.serializer.SimpleSerializedObject
Initializes a SimpleSerializedObject using given data and a serialized type identified by given type and revision.
SimpleSerializedType - Class in org.axonframework.serializer
SerializedType implementation that takes its properties as constructor parameters.
SimpleSerializedType(String, String) - Constructor for class org.axonframework.serializer.SimpleSerializedType
Initialize with given objectType and revisionNumber
SimpleUpcasterChain - Class in org.axonframework.upcasting
Represents a series of upcasters which are combined to upcast a SerializedObject to the most recent revision of that payload.
SimpleUpcasterChain(List<Upcaster>) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
Initializes the UpcasterChain with given upcasters and a ChainingConverterFactory to convert between content types.
SimpleUpcasterChain(Serializer, List<Upcaster>) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
Initializes the UpcasterChain with given serializer and upcasters.
SimpleUpcasterChain(ConverterFactory, List<Upcaster>) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
Initializes the UpcasterChain with given converterFactory and upcasters.
SimpleUpcasterChain(ConverterFactory, Upcaster...) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
Initialize a chain of the given upcasters and using the given converterFactory to create converters for the intermediate representations used by the upcasters.
size() - Method in class org.axonframework.domain.EventContainer
Returns the number of events currently inside this container.
size() - Method in class org.axonframework.domain.MetaData
 
size() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
size() - Method in interface org.axonframework.saga.AssociationValues
Returns the number of AssociationValue instances available in this container
size() - Method in class org.axonframework.saga.repository.AssociationValueMap
Returns an approximation of the size of this map.
size() - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
Returns the number of Sagas currently contained in this repository.
skip() - Static method in class org.axonframework.eventhandling.async.RetryPolicy
This policy will roll back the Unit of Work (and the transaction) and skip the event altogether.
snapshotEntryTable() - Method in class org.axonframework.eventstore.jdbc.SchemaConfiguration
 
snapshotEventCollection() - Method in class org.axonframework.eventstore.mongo.DefaultMongoTemplate
Returns a reference to the collection containing the snapshot events.
snapshotEventCollection() - Method in interface org.axonframework.eventstore.mongo.MongoTemplate
Returns a reference to the collection containing the snapshot events.
snapshotEventCollection() - Method in class org.axonframework.mongo3.eventstore.DefaultMongoTemplate
Returns a reference to the collection containing the snapshot events.
snapshotEventCollection() - Method in interface org.axonframework.mongo3.eventstore.MongoTemplate
Returns a reference to the collection containing the snapshot events.
SnapshotEventEntry - Class in org.axonframework.eventstore.jpa
JPA compatible entry that stores data required for the use of snapshot events.
SnapshotEventEntry() - Constructor for class org.axonframework.eventstore.jpa.SnapshotEventEntry
Default constructor, as required by JPA specification.
SnapshotEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.SnapshotEventEntry
Initialize an Event entry for the given event.
snapshotEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
The name of the SnapshotEventEntry entity to use when querying for snapshot events.
SnapshotEventStore - Interface in org.axonframework.eventstore
Interface describing an event store that is able to store snapshot events.
snapshotFileExists(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
Indicates whether there is a file containing snapshot events for the given aggregateIdentifier of given type.
snapshotFileExists(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
Snapshotter - Interface in org.axonframework.eventsourcing
Interface describing instances that are capable of creating snapshot events for aggregates.
SnapshotterBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
The SnapshotterBeanDefinitionParser is responsible for parsing the snapshotter element form the Axon namespace.
SnapshotterBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
 
SnapshotterTrigger - Interface in org.axonframework.eventsourcing
Interface for Event Stream Decorators that have the intent to trigger snapshots.
SnapshotterTriggerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that parses <snapshotter-trigger> elements.
SnapshotterTriggerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
 
SpringAggregateSnapshotter - Class in org.axonframework.eventsourcing
Implementation of the AggregateSnapshotter that eases the configuration when used within a Spring Application Context.
SpringAggregateSnapshotter() - Constructor for class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
SpringAMQPConsumerConfiguration - Class in org.axonframework.eventhandling.amqp.spring
AMQPConsumerConfiguration implementation that has additional support for all Spring-specific AMQP Configuration properties.
SpringAMQPConsumerConfiguration() - Constructor for class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
 
SpringAMQPTerminal - Class in org.axonframework.eventhandling.amqp.spring
EventBusTerminal implementation that uses an AMQP 0.9 compatible Message Broker to dispatch event messages.
SpringAMQPTerminal() - Constructor for class org.axonframework.eventhandling.amqp.spring.SpringAMQPTerminal
 
SpringAnnotationOrderResolver - Class in org.axonframework.eventhandling
OrderResolver implementation that checks for @Order annotations on the type level.
SpringAnnotationOrderResolver() - Constructor for class org.axonframework.eventhandling.SpringAnnotationOrderResolver
 
SpringBeanParameterResolverFactory - Class in org.axonframework.common.annotation
ParameterResolverFactory implementation that resolves parameters in the Spring Application Context.
SpringBeanParameterResolverFactory() - Constructor for class org.axonframework.common.annotation.SpringBeanParameterResolverFactory
 
SpringContextParameterResolverFactoryBuilder - Class in org.axonframework.contextsupport.spring
Creates and registers a bean definition for a Spring Context aware ParameterResolverFactory.
SpringDataSourceConnectionProvider - Class in org.axonframework.common.jdbc
ConnectionProvider implementation that is aware of Transaction Managers and provides the connection attached to an active transaction manager, instead of asking a Data Source directly.
SpringDataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.common.jdbc.SpringDataSourceConnectionProvider
Initialize the connection provider, using given dataSource to obtain a connection, when required.
SpringIntegrationEventBus - Class in org.axonframework.integration.eventbus
EventBus implementation that delegates all subscription and publishing requests to a Spring Integration channel.
SpringIntegrationEventBus() - Constructor for class org.axonframework.integration.eventbus.SpringIntegrationEventBus
 
SpringMessagingEventBus - Class in org.axonframework.springmessaging.eventbus
EventBus implementation that delegates all subscription and publishing requests to a Spring Messaging channel.
SpringMessagingEventBus() - Constructor for class org.axonframework.springmessaging.eventbus.SpringMessagingEventBus
 
SpringParameterResolverFactoryBean - Class in org.axonframework.contextsupport.spring
Spring factory bean that creates a ParameterResolverFactory instance that is capable of resolving parameter values as Spring Beans, in addition to the default behavior defined by Axon.
SpringParameterResolverFactoryBean() - Constructor for class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
 
SpringPrototypeAggregateFactory<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
AggregateFactory implementation that uses Spring prototype beans to create new uninitialized instances of Aggregates.
SpringPrototypeAggregateFactory() - Constructor for class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
SpringResourceInjector - Class in org.axonframework.saga.spring
ResourceInjector implementation that injects Saga instances with resources available from the Spring Application context the injector is registered in.
SpringResourceInjector() - Constructor for class org.axonframework.saga.spring.SpringResourceInjector
 
SpringTransactionManager - Class in org.axonframework.unitofwork
TransactionManager implementation that uses a PlatformTransactionManager as underlying transaction manager.
SpringTransactionManager(PlatformTransactionManager, TransactionDefinition) - Constructor for class org.axonframework.unitofwork.SpringTransactionManager
 
SpringTransactionManager(PlatformTransactionManager) - Constructor for class org.axonframework.unitofwork.SpringTransactionManager
Initializes the SpringTransactionManager with the given transactionManager and the default transaction definition.
SpringTransactionManager() - Constructor for class org.axonframework.unitofwork.SpringTransactionManager
Default constructor.
sql_createDomainEventEntryTable(Connection) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates a PreparedStatement that allows for the creation of the table to store Event entries.
sql_createDomainEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_createDomainEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.PostgresEventSqlSchema
 
sql_createSnapshotEventEntryTable(Connection) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates a PreparedStatement that allows for the creation of the table to store Snapshots.
sql_createSnapshotEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_createSnapshotEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.PostgresEventSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.HsqlSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.PostgresSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that creates the table for storing Association Values for Sagas.
sql_createTableSagaEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.PostgresSagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that creates the table for storing Sagas.
sql_dateTime(DateTime) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Converts a DateTime to a data value suitable for the database scheme.
sql_dateTime(DateTime) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_deleteAssociationEntries(Connection, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_deleteAssociationEntries(Connection, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that deletes all association entries for a Saga with given sagaIdentifier.
sql_deleteSagaEntry(Connection, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_deleteSagaEntry(Connection, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that deletes a Saga with given sagaIdentifier.
sql_fetchFromSequenceNumber(Connection, String, Object, long) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates a PreparedStatement that fetches event data for an aggregate with given type and identifier, starting at the given firstSequenceNumber.
sql_fetchFromSequenceNumber(Connection, String, Object, long) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that finds identifiers of Sagas of given sagaType associated with the given association key and value.
sql_findSnapshotSequenceNumbers(Connection, String, Object) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates a PreparedStatement that returns the sequence numbers of snapshots for an aggregate of given type and aggregateIdentifier.
sql_findSnapshotSequenceNumbers(Connection, String, Object) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_getFetchAll(Connection, String, Object[]) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates a PreparedStatement that fetches all event messages matching the given whereClause.
sql_getFetchAll(Connection, String, Object[]) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_insertDomainEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates the PreparedStatement for inserting a DomainEvent in the Event Store, using given attributes.
sql_insertDomainEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_insertSnapshotEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates the PreparedStatement for inserting a Snapshot Event in the Event Store, using given attributes.
sql_insertSnapshotEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_loadLastSnapshot(Connection, Object, String) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates the PreparedStatement for loading the last snapshot event for an aggregate with given identifier and of given aggregateType.
sql_loadLastSnapshot(Connection, Object, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_loadSaga(Connection, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_loadSaga(Connection, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that loads a single Saga, with given sagaId.
sql_pruneSnapshots(Connection, String, Object, long) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
Creates a PreparedStatement that deletes all snapshots with a sequence identifier equal or lower to the given sequenceOfFirstSnapshotToPrune, for an aggregate of given type and aggregateIdentifier.
sql_pruneSnapshots(Connection, String, Object, long) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
 
sql_removeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_removeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that removes an association value for given sagaIdentifier, where the association is identified with given key and value.
sql_storeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_storeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that stores an association with given key and value, for a Saga of given type and identifier.
sql_storeSaga(Connection, String, String, String, byte[]) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_storeSaga(Connection, String, String, String, byte[]) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that inserts a Saga entry, of given sagaType and with given sagaIdentifier.
sql_updateSaga(Connection, String, byte[], String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_updateSaga(Connection, String, byte[], String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that updates the serialized form of an existing Saga entry, of given sagaType and with given sagaIdentifier.
SQLErrorCodesResolver - Class in org.axonframework.eventstore.jpa
SQLErrorCodesResolver is an implementation of PersistenceExceptionResolver used to resolve sql error codes to see if it is an duplicate key constraint violation.
SQLErrorCodesResolver(List<Integer>) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
Initializes the SQLErrorCodesResolver using the given list of SQL Codes representing Key Constraint Violations.
SQLErrorCodesResolver(DataSource) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
SQLErrorCodesResolver(String) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
SQLErrorCodesResolver(Properties, String) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
SQLErrorCodesResolver(Properties, DataSource) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
Initialize the SQLErrorCodesResolver with the given properties and use the dataSource to automatically retrieve the database product name.
SQLStateResolver - Class in org.axonframework.eventstore.jpa
SQLStateResolver is an implementation of PersistenceExceptionResolver used to resolve sql state values to see if it violates a unique key constraint.
SQLStateResolver() - Constructor for class org.axonframework.eventstore.jpa.SQLStateResolver
Constructor that uses the standard SQL state category for the check.
SQLStateResolver(String) - Constructor for class org.axonframework.eventstore.jpa.SQLStateResolver
Constructor that can be used to supply a specific SQL state code for the check.
start() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
start() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
start() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
 
start() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
 
start() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
start() - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
start() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Starts the Saga Manager by starting the processor threads and subscribes it with the eventBus.
start() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
 
start() - Method in interface org.axonframework.unitofwork.UnitOfWork
Starts the current unit of work, preparing it for aggregate registration.
startAndGet() - Static method in class org.axonframework.unitofwork.DefaultUnitOfWork
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork.
startAndGet(TransactionManager<?>) - Static method in class org.axonframework.unitofwork.DefaultUnitOfWork
Starts a new DefaultUnitOfWork instance using the given transactionManager to provide a backing transaction, registering it a CurrentUnitOfWork.
startNode(String) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
startNode(String, Class) - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
startNode(String) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
startNode(String, Class) - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
startRecording() - Method in class org.axonframework.test.saga.CommandValidator
Starts recording commands on the command bus.
startRecording() - Method in class org.axonframework.test.saga.EventValidator
Starts recording event published by the event bus.
startRecording() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
Tells this class to start monitoring activity in infrastructure classes.
startReplay() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Starts a replay process on the current thread.
startReplay(Criteria) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Start a replay process on the current thread, only reading events matching the given criteria.
startReplay(Executor) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Starts a replay process using the given executor.
startReplay(Executor, Criteria) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Starts a replay process using the given executor, only reading events matching the given criteria.
StartSaga - Annotation Type in org.axonframework.saga.annotation
Indicates that the annotated SagaEventHandler method can trigger the creation of a new Saga instance.
startTransaction() - Method in class org.axonframework.unitofwork.NoTransactionManager
 
startTransaction() - Method in class org.axonframework.unitofwork.SpringTransactionManager
 
startTransaction() - Method in interface org.axonframework.unitofwork.TransactionManager
Starts a transaction.
state(boolean, String) - Static method in class org.axonframework.common.Assert
Asserts that the value of state is true.
stop() - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Shuts down the command bus.
stop() - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
stop(Runnable) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
stop(Runnable) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
 
stop() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
 
stop() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
 
stop(Runnable) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
 
stop(Runnable) - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
stop() - Method in class org.axonframework.eventhandling.amqp.spring.ListenerContainerLifecycleManager
 
stop(Runnable) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
stop() - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
stop() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
Unsubscribes this Saga Manager from the event bus and stops accepting new events.
StorageStrategy - Interface in org.axonframework.eventstore.mongo
Interface towards the mechanism that prescribes the structure in which events are stored in the Event Store.
StorageStrategy - Interface in org.axonframework.mongo3.eventstore
Interface towards the mechanism that prescribes the structure in which events are stored in the Event Store.
storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Store the given associationValue, which has been associated with given sagaIdentifier.
storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 
storeSaga(Saga) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
storeSaga(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Stores a newly created Saga instance.
storeSaga(Saga) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
storeSaga(Saga) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
storeSaga(Saga) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 
StringToByteArrayConverter - Class in org.axonframework.serializer.converters
ContentTypeConverter that converts String into byte arrays.
StringToByteArrayConverter() - Constructor for class org.axonframework.serializer.converters.StringToByteArrayConverter
 
StringToDBObjectContentTypeConverter - Class in org.axonframework.mongo3.serializer.bson
ContentTypeConverter implementation that converts a String containing its Binary JSON representation into a DBObject structure.
StringToDBObjectContentTypeConverter() - Constructor for class org.axonframework.mongo3.serializer.bson.StringToDBObjectContentTypeConverter
 
StringToDBObjectContentTypeConverter - Class in org.axonframework.serializer.bson
ContentTypeConverter implementation that converts a String containing its Binary JSON representation into a DBObject structure.
StringToDBObjectContentTypeConverter() - Constructor for class org.axonframework.serializer.bson.StringToDBObjectContentTypeConverter
 
StructuralCommandValidationFailedException - Exception in org.axonframework.commandhandling
Exception indicating that a Command has been refused due to a structural validation failure.
StructuralCommandValidationFailedException(String) - Constructor for exception org.axonframework.commandhandling.StructuralCommandValidationFailedException
Initializes an exception with the given message.
StubEventScheduler - Class in org.axonframework.test.eventscheduler
EventScheduler implementation that uses it's own concept of "Current Time" for the purpose of testing.
StubEventScheduler() - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
Creates an instance of the StubScheduler that uses the current date time as its conceptual "current time".
StubEventScheduler(ReadableInstant) - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
Creates an instance of the StubScheduler that uses the given currentDateTime as its conceptual "current time".
StubScheduleToken - Class in org.axonframework.test.eventscheduler
ScheduleToken returned by the StubEventScheduler.
Subscribable - Interface in org.axonframework.common
Deprecated. as of 2.1. This interface will be removed in future versions. Self subscribing components give problems when wrapping components (using compositions or proxies). Therefore, subscriptions should be managed by the creating component.
subscribe(Class<T>, Repository<T>, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Subscribe a handler for the given aggregate type to the given command bus.
subscribe(Class<T>, Repository<T>, CommandBus, CommandTargetResolver) - Static method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Subscribe a handler for the given aggregate type to the given command bus.
subscribe(AggregateAnnotationCommandHandler<?>, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Subscribe the given aggregateAnnotationCommandHandler to the given commandBus.
subscribe() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Deprecated. subscribing this handler should be done using CommandBus.subscribe(String, org.axonframework.commandhandling.CommandHandler). Retrieve the supported commands with AggregateAnnotationCommandHandler.supportedCommands().
subscribe(Object, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Subscribe the annotated command handler to the given command bus.
subscribe(AnnotationCommandHandlerAdapter, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Subscribe the given annotationCommandHandler to the given commandBus.
subscribe() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Deprecated. Instead, subscribe this instance using CommandBus.subscribe(String, org.axonframework.commandhandling.CommandHandler), using AnnotationCommandHandlerAdapter.supportedCommands() to retrieve the commands the annotated handler supports.
subscribe(CommandHandler, AnnotationCommandHandlerAdapter) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
subscribe(String, CommandHandler<? super C>) - Method in interface org.axonframework.commandhandling.CommandBus
Subscribe the given handler to commands of type commandType.
subscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
 
subscribe(String, CommandHandler<? super C>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Subscribe the given handler to commands of type commandType to the local segment of the command bus.
subscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Subscribe the given handler to commands of type commandType.
subscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
 
subscribe(String, CommandHandler<? super T>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Subscribe the given handler to commands of type commandType.
subscribe(I, T) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Subscribe the given proxy bean (with its annotated methods managed by given adapter) to the messaging infrastructure.
subscribe() - Method in interface org.axonframework.common.Subscribable
Deprecated. Subscribe this instance with its configured component.
subscribe(EventListener) - Method in class org.axonframework.eventhandling.AbstractCluster
 
subscribe(Object, EventBus) - Static method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Subscribe the given annotatedEventListener to the given eventBus.
subscribe() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Deprecated. Use EventBus.subscribe(org.axonframework.eventhandling.EventListener) and pass this adapter instance to subscribe it.
subscribe(EventListener, AnnotationEventListenerAdapter) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
subscribe(EventListener) - Method in interface org.axonframework.eventhandling.Cluster
Subscribe the given eventListener to this cluster.
subscribe(EventListener) - Method in class org.axonframework.eventhandling.ClusteringEventBus
 
subscribe(EventListener) - Method in interface org.axonframework.eventhandling.EventBus
Subscribe the given eventListener to this bus.
subscribe(EventListener) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Subscribe the given eventListener to this cluster.
subscribe(EventListener) - Method in class org.axonframework.eventhandling.SimpleEventBus
Subscribe the given eventListener to this bus.
subscribe(EventListener) - Method in class org.axonframework.gae.commandhandling.SimpleEventBusWithoutStatistics
 
subscribe(EventListener) - Method in class org.axonframework.integration.eventbus.SpringIntegrationEventBus
 
subscribe() - Method in class org.axonframework.saga.AbstractSagaManager
Deprecated. Use EventBus.subscribe(org.axonframework.eventhandling.EventListener) to subscribe this instance
subscribe() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
 
subscribe(EventListener) - Method in class org.axonframework.springmessaging.eventbus.SpringMessagingEventBus
 
subscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.AbstractCluster
 
subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.EventProcessingMonitorCollection
 
subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in interface org.axonframework.eventhandling.EventProcessingMonitorSupport
Subscribes the given monitor.
subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
 
subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
 
supportedCommands() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Returns the set of commands supported by the annotated command handler managed by this adapter.
supportedCommands() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Returns the set of commands supported by the annotated command handler managed by this adapter.
supportedCommands() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.Member
Returns the set of commands supported by this member.
supports(Class<? extends Saga>) - Method in class org.axonframework.saga.GenericSagaFactory
Indicates whether or not this factory can create instances of the given sagaType.
supports(Class<? extends Saga>) - Method in interface org.axonframework.saga.SagaFactory
Indicates whether or not this factory can create instances of the given sagaType.
SyncSagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that parses saga-manager elements in the application context.
SyncSagaManagerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
 

T

TargetAggregateIdentifier - Annotation Type in org.axonframework.commandhandling.annotation
Field or method level annotation that marks a field or method providing the identifier of the aggregate that a command targets.
TargetAggregateVersion - Annotation Type in org.axonframework.commandhandling.annotation
Field or method level annotation that marks a field or method providing the expected version of the aggregate that a command targets.
targetType() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectToStringContentTypeConverter
 
targetType() - Method in class org.axonframework.mongo3.serializer.bson.StringToDBObjectContentTypeConverter
 
targetType() - Method in class org.axonframework.serializer.bson.DBObjectToStringContentTypeConverter
 
targetType() - Method in class org.axonframework.serializer.bson.StringToDBObjectContentTypeConverter
 
targetType() - Method in class org.axonframework.serializer.ChainedConverter
 
targetType() - Method in interface org.axonframework.serializer.ContentTypeConverter
The returned type of IntermediateRepresentation
targetType() - Method in class org.axonframework.serializer.converters.BlobToInputStreamConverter
 
targetType() - Method in class org.axonframework.serializer.converters.ByteArrayToInputStreamConverter
 
targetType() - Method in class org.axonframework.serializer.converters.ByteArrayToStringConverter
 
targetType() - Method in class org.axonframework.serializer.converters.InputStreamToByteArrayConverter
 
targetType() - Method in class org.axonframework.serializer.converters.StringToByteArrayConverter
 
targetType() - Method in class org.axonframework.serializer.json.ByteArrayToJsonNodeConverter
 
targetType() - Method in class org.axonframework.serializer.json.JsonNodeToByteArrayConverter
 
targetType() - Method in class org.axonframework.serializer.xml.Dom4JToByteArrayConverter
 
targetType() - Method in class org.axonframework.serializer.xml.InputStreamToDom4jConverter
 
targetType() - Method in class org.axonframework.serializer.xml.InputStreamToXomConverter
 
targetType() - Method in class org.axonframework.serializer.xml.XomToStringConverter
 
TerminalBeanDefinitionParser - Class in org.axonframework.contextsupport.spring.amqp
BeanDefinitionParser that parses <amqp-terminal> elements into a SpringAMQPTerminal instance.
TerminalBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.amqp.TerminalBeanDefinitionParser
 
TestExecutor - Interface in org.axonframework.test
Interface describing the operations available on a test fixture in the execution stage.
Timeout - Annotation Type in org.axonframework.commandhandling.gateway
Class or method level annotation that indicates the calling thread should not wait longer than the provided timeout for the results of a command.
Timestamp - Annotation Type in org.axonframework.eventhandling.annotation
Annotation indication that a parameter on an Event Handler method should be injected with the Timestamp of an Event Message.
TimestampCutoffReadonlyEventStore - Class in org.axonframework.eventstore.supporting
Takes a backend, both EventStore and EventStoreManagement, and functions as a filter based on a DateTime.
TimestampCutoffReadonlyEventStore(EventStore, EventStoreManagement, DateTime) - Constructor for class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
 
TimestampParameterResolverFactory - Class in org.axonframework.eventhandling.annotation
AbstractAnnotatedParameterResolverFactory that accepts parameters with type DateTime that are annotated with the Timestamp annotation and assigns the timestamp of the EventMessage.
TimestampParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.annotation.TimestampParameterResolverFactory
Initializes a ParameterResolverFactory for Timestamp annotated parameters
ToDoEventHandler - Class in org.axonframework.quickstart.annotated
Event handler that listens to both events and prints a message to the system output stream.
ToDoEventHandler() - Constructor for class org.axonframework.quickstart.annotated.ToDoEventHandler
 
ToDoEventListener - Class in org.axonframework.quickstart.handler
Event listener for all events, results are printed to system out.
ToDoEventListener() - Constructor for class org.axonframework.quickstart.handler.ToDoEventListener
 
ToDoItem - Class in org.axonframework.quickstart.annotated
 
ToDoItem() - Constructor for class org.axonframework.quickstart.annotated.ToDoItem
 
ToDoItem(CreateToDoItemCommand) - Constructor for class org.axonframework.quickstart.annotated.ToDoItem
 
ToDoItem - Class in org.axonframework.quickstart.handler
 
ToDoItem() - Constructor for class org.axonframework.quickstart.handler.ToDoItem
 
ToDoItem(String, String) - Constructor for class org.axonframework.quickstart.handler.ToDoItem
 
ToDoItemCompletedEvent - Class in org.axonframework.quickstart.api
The ToDoItem belonging to the provided aggregate identifier is completed.
ToDoItemCompletedEvent(String) - Constructor for class org.axonframework.quickstart.api.ToDoItemCompletedEvent
 
ToDoItemCreatedEvent - Class in org.axonframework.quickstart.api
A new ToDoItem is created
ToDoItemCreatedEvent(String, String) - Constructor for class org.axonframework.quickstart.api.ToDoItemCreatedEvent
 
ToDoItemDeadlineExpiredEvent - Class in org.axonframework.quickstart.api
 
ToDoItemDeadlineExpiredEvent(String) - Constructor for class org.axonframework.quickstart.api.ToDoItemDeadlineExpiredEvent
 
ToDoSaga - Class in org.axonframework.quickstart.saga
 
ToDoSaga() - Constructor for class org.axonframework.quickstart.saga.ToDoSaga
 
toJobData(Object) - Method in interface org.axonframework.eventhandling.scheduling.quartz.EventJobDataBinder
Write an eventMessage (or its payload) to a JobDataMap.
toJobData(Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
 
toString() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
toString() - Method in class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
 
toString() - Method in class org.axonframework.common.annotation.MethodMessageHandler
 
toString() - Method in class org.axonframework.domain.GenericDomainEventMessage
 
toString() - Method in class org.axonframework.domain.GenericEventMessage
 
toString() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
 
toString() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData.PK
 
toString() - Method in class org.axonframework.eventstore.mongo.criteria.MongoCriteria
 
toString() - Method in class org.axonframework.mongo3.eventstore.criteria.MongoCriteria
 
toString() - Method in class org.axonframework.quickstart.api.ToDoItemCompletedEvent
 
toString() - Method in class org.axonframework.quickstart.api.ToDoItemCreatedEvent
 
toString() - Method in class org.axonframework.quickstart.api.ToDoItemDeadlineExpiredEvent
 
toString() - Method in class org.axonframework.quickstart.RunUpcaster.NewToDoItemWithDeadlineCreatedEvent
 
toString() - Method in class org.axonframework.serializer.SimpleSerializedObject
 
toString() - Method in class org.axonframework.serializer.SimpleSerializedType
 
TransactionManager<T> - Interface in org.axonframework.unitofwork
Interface towards a mechanism that manages transactions

Typically, this will involve opening database transactions or connecting to external systems.

TransactionManagerFactoryBean - Class in org.axonframework.contextsupport.spring
Factory Bean that wraps transaction manager instances with an implementation of TransactionManager, if necessary (and possible).
TransactionManagerFactoryBean() - Constructor for class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
 
TransactionMethodExecutionException - Exception in org.axonframework.eventhandling.annotation
Wrapper for exceptions that occurred while calling an @BeforeTransaction or @AfterTransaction annotated method.
TransactionMethodExecutionException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.annotation.TransactionMethodExecutionException
Initialize the exception with given message and cause.
typeForClass(Class) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
 
typeForClass(Class) - Method in class org.axonframework.serializer.JavaSerializer
 
typeForClass(Class) - Method in class org.axonframework.serializer.json.JacksonSerializer
 
typeForClass(Class) - Method in class org.axonframework.serializer.MessageSerializer
 
typeForClass(Class) - Method in interface org.axonframework.serializer.Serializer
Returns the type identifier for the given class.
typeOf(Class<? extends Saga>) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
typeOf(Class<? extends Saga>) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Returns the type identifier to use for the given sagaClass.
typeOf(Class<? extends Saga>) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
typeOf(Class<? extends Saga>) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
typeOf(Class<? extends Saga>) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 

U

underlyingReader() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamReader
 
underlyingReader() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamReader
 
underlyingWriter() - Method in class org.axonframework.mongo3.serializer.bson.DBObjectHierarchicalStreamWriter
 
underlyingWriter() - Method in class org.axonframework.serializer.bson.DBObjectHierarchicalStreamWriter
 
UniformPropertyAccessStrategy - Class in org.axonframework.common.property
PropertyAccessStrategy implementation that finds properties defined according to the Uniform Access Principle (see wikipedia).
UniformPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.UniformPropertyAccessStrategy
 
UNIT_OF_WORK_FACTORY_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the optional EventTriggerCallback in the scheduler context.
UnitOfWork - Interface in org.axonframework.unitofwork
This class represents a UnitOfWork in which modifications are made to aggregates.
UnitOfWorkAwareConnectionProviderWrapper - Class in org.axonframework.common.jdbc
Wrapper for a ConnectionProvider that checks if a connection is already attached to the Unit of Work, favoring that connection over creating a new one.
UnitOfWorkAwareConnectionProviderWrapper(ConnectionProvider) - Constructor for class org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper
Initializes a ConnectionProvider, using given delegate to create a new instance, when on is not already attached to the Unit of Work.
UnitOfWorkAwareConnectionProviderWrapper(ConnectionProvider, boolean) - Constructor for class org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper
Initializes a ConnectionProvider, using given delegate to create a new instance, when on is not already attached to the Unit of Work.
UnitOfWorkFactory - Interface in org.axonframework.unitofwork
The UnitOfWorkFactory interface is used to obtain UnitOfWork instances to manage activity in command handling processes.
UnitOfWorkListener - Interface in org.axonframework.unitofwork
Interface describing a listener that is notified of state changes in the UnitOfWork it has been registered with.
UnitOfWorkListenerAdapter - Class in org.axonframework.unitofwork
Abstract implementation of the UnitOfWorkListener that provides empty implementation of all methods declared in UnitOfWorkListener.
UnitOfWorkListenerAdapter() - Constructor for class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
 
UnitOfWorkListenerCollection - Class in org.axonframework.unitofwork
This class is responsible for notifying registered listeners in a specific order of precedence.
UnitOfWorkListenerCollection() - Constructor for class org.axonframework.unitofwork.UnitOfWorkListenerCollection
 
UnknownSerializedTypeException - Exception in org.axonframework.serializer
Exception indicating that an object could not be deserialized, because its serialized type cannot be mapped to a class.
UnknownSerializedTypeException(SerializedType) - Constructor for exception org.axonframework.serializer.UnknownSerializedTypeException
Initialize the constructor with a default message, containing details of the given serializedType
UnknownSerializedTypeException(SerializedType, Throwable) - Constructor for exception org.axonframework.serializer.UnknownSerializedTypeException
Initialize the constructor with a default message, containing details of the given serializedType
unregister(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
Removes all strategies registered using the PropertyAccessStrategy.register(PropertyAccessStrategy) method.
unregisterCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.AbstractCacheAdapter
 
unregisterCacheEntryListener(Cache.EntryListener) - Method in interface org.axonframework.cache.Cache
Unregisters the previously registered cacheEntryListener.
unregisterCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.NoCache
 
unregisterCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.WeakReferenceCache
 
UnresolvedRoutingKeyPolicy - Enum in org.axonframework.commandhandling.distributed
 
unsubscribe() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Deprecated. unsubscribing this handler should be done using CommandBus.unsubscribe(String, org.axonframework.commandhandling.CommandHandler). Retrieve the supported commands with AggregateAnnotationCommandHandler.supportedCommands().
unsubscribe() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Deprecated. Instead, subscribe this instance using CommandBus.subscribe(String, org.axonframework.commandhandling.CommandHandler), using AnnotationCommandHandlerAdapter.supportedCommands() to retrieve the commands the annotated handler supports.
unsubscribe(CommandHandler, AnnotationCommandHandlerAdapter) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
unsubscribe(String, CommandHandler<? super C>) - Method in interface org.axonframework.commandhandling.CommandBus
Unsubscribe the given handler to commands of type commandType.
unsubscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
 
unsubscribe(String, CommandHandler<? super C>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Unsubscribe the given handler to commands of type commandType.
unsubscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Unsubscribe the given handler to commands of type commandType.
unsubscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.commandhandling.distributed.jgroups.JGroupsConnector
 
unsubscribe(String, CommandHandler<? super T>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Unsubscribe the given handler to commands of type commandType.
unsubscribe(I, T) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
Unsubscribe the given proxy bean (with its annotated methods managed by given adapter) to the messaging infrastructure.
unsubscribe() - Method in interface org.axonframework.common.Subscribable
Deprecated. Unsubscribe this instance from its subscribed component.
unsubscribe(EventListener) - Method in class org.axonframework.eventhandling.AbstractCluster
 
unsubscribe() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Deprecated. Use EventBus.unsubscribe(org.axonframework.eventhandling.EventListener) and pass this adapter instance to unsubscribe it.
unsubscribe(EventListener, AnnotationEventListenerAdapter) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
unsubscribe(EventListener) - Method in interface org.axonframework.eventhandling.Cluster
Unsubscribes the given eventListener from this cluster.
unsubscribe(EventListener) - Method in class org.axonframework.eventhandling.ClusteringEventBus
 
unsubscribe(EventListener) - Method in interface org.axonframework.eventhandling.EventBus
Unsubscribe the given eventListener to this bus.
unsubscribe(EventListener) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
Unsubscribes the given eventListener from this cluster.
unsubscribe(EventListener) - Method in class org.axonframework.eventhandling.SimpleEventBus
Unsubscribe the given eventListener to this bus.
unsubscribe(EventListener) - Method in class org.axonframework.gae.commandhandling.SimpleEventBusWithoutStatistics
 
unsubscribe(EventListener) - Method in class org.axonframework.integration.eventbus.SpringIntegrationEventBus
 
unsubscribe() - Method in class org.axonframework.saga.AbstractSagaManager
Deprecated. Use EventBus.unsubscribe(org.axonframework.eventhandling.EventListener) to unsubscribe this instance
unsubscribe() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
 
unsubscribe(EventListener) - Method in class org.axonframework.springmessaging.eventbus.SpringMessagingEventBus
 
unsubscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
unsubscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.AbstractCluster
 
unsubscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.EventProcessingMonitorCollection
 
unsubscribeEventProcessingMonitor(EventProcessingMonitor) - Method in interface org.axonframework.eventhandling.EventProcessingMonitorSupport
Unsubscribed the given monitor.
unsubscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
 
unsubscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
 
UnsupportedHandlerException - Exception in org.axonframework.common.annotation
Thrown when an @...Handler annotated method was found that does not conform to the rules that apply to those methods.
UnsupportedHandlerException(String, Member) - Constructor for exception org.axonframework.common.annotation.UnsupportedHandlerException
Initialize the exception with a message and the violatingMethod.
upcast(SerializedObject<T>, List<SerializedType>, UpcastingContext) - Method in class org.axonframework.upcasting.AbstractSingleEntryUpcaster
 
upcast(SerializedType) - Method in class org.axonframework.upcasting.AbstractSingleEntryUpcaster
 
upcast(SerializedObject, UpcastingContext) - Method in class org.axonframework.upcasting.AbstractUpcasterChain
 
upcast(SerializedType, SerializedObject<T>) - Method in interface org.axonframework.upcasting.ExtendedUpcaster
Upcast the given serializedType into its new format.
upcast(SerializedType) - Method in interface org.axonframework.upcasting.ExtendedUpcaster
Upcast the given serializedType into its new format.
upcast(SerializedObject<T>, List<SerializedType>, UpcastingContext) - Method in interface org.axonframework.upcasting.Upcaster
Upcasts the given intermediateRepresentation into zero or more other representations.
upcast(SerializedType) - Method in interface org.axonframework.upcasting.Upcaster
Upcast the given serializedType into its new format.
upcast(SerializedObject, UpcastingContext) - Method in interface org.axonframework.upcasting.UpcasterChain
Pass the given serializedObject through the chain of upcasters.
upcastAndDeserialize(SerializedDomainEventData, Object, Serializer, UpcasterChain, boolean) - Static method in class org.axonframework.upcasting.UpcastUtils
Upcasts and deserializes the given entry using the given serializer and upcasterChain.
Upcaster<T> - Interface in org.axonframework.upcasting
Interface for Upcasters.
UpcasterAware - Interface in org.axonframework.upcasting
Interface indicating that the implementing mechanism is aware of Upcasters.
UpcasterChain - Interface in org.axonframework.upcasting
Represents a series of upcasters which are combined to upcast a SerializedObject to the most recent revision of that payload.
UpcasterChainBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that parses UpcasterChain elements.
UpcasterChainBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.UpcasterChainBeanDefinitionParser
 
UpcastingContext - Interface in org.axonframework.upcasting
Interface describing an object that provides contextual information about the object being upcast.
UpcastSerializedDomainEventData<T> - Class in org.axonframework.upcasting
SerializedDomainEventData implementation that can be used to duplicate existing SerializedDomainEventData instances after upcasting a payload.
UpcastSerializedDomainEventData(SerializedDomainEventData<T>, Object, SerializedObject<T>) - Constructor for class org.axonframework.upcasting.UpcastSerializedDomainEventData
Reconstruct the given original SerializedDomainEventData replacing the aggregateIdentifier with given aggregateIdentifier and payload with upcastPayload.
UpcastUtils - Class in org.axonframework.upcasting
Utility class that optimizes tasks related to upcasting.
update(byte[]) - Method in class org.axonframework.common.digest.Digester
Update the Digester with given additionalData.
updateSaga(Saga) - Method in class org.axonframework.mongo3.saga.repository.MongoSagaRepository
 
updateSaga(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Update a stored Saga, by replacing it with the given saga instance.
updateSaga(Saga) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
 
updateSaga(Saga) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
updateSaga(Saga) - Method in class org.axonframework.saga.repository.mongo.MongoSagaRepository
 
UTF8 - Static variable in class org.axonframework.common.io.IOUtils
Represents the UTF-8 character set.

V

validateCommand(Object, Validator) - Method in class org.axonframework.commandhandling.interceptors.BeanValidationInterceptor
Validate the given command using the given validator.
validateIdentifier(Class<?>) - Static method in class org.axonframework.common.IdentifierValidator
Verifies whether the given aggregateIdentifier complies with the toString requirements and throws IllegalArgumentException if that is not the case.
validateLock(AggregateRoot) - Method in interface org.axonframework.repository.LockManager
Make sure that the current thread holds a valid lock for the given aggregate.
validateLock(AggregateRoot) - Method in class org.axonframework.repository.NullLockManager
Make sure that the current thread holds a valid lock for the given aggregate.
validateLock(AggregateRoot) - Method in class org.axonframework.repository.OptimisticLockManager
Make sure that the current thread holds a valid lock for the given aggregate.
validateLock(AggregateRoot) - Method in class org.axonframework.repository.PessimisticLockManager
Make sure that the current thread holds a valid lock for the given aggregate.
validateOnLoad(T, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Checks the aggregate for concurrent changes.
validateOnLoad(T, Long) - Method in class org.axonframework.repository.AbstractRepository
Checks the aggregate for concurrent changes.
valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.contextsupport.spring.LockingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.io.EventMessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.saga.SagaCreationPolicy
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.contextsupport.spring.LockingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.axonframework.domain.MetaData
 
values() - Static method in enum org.axonframework.eventhandling.io.EventMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.saga.SagaCreationPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
VersionedAggregateIdentifier - Class in org.axonframework.commandhandling
Structure that holds an Aggregate Identifier and an expected version of an aggregate.
VersionedAggregateIdentifier(Object, Long) - Constructor for class org.axonframework.commandhandling.VersionedAggregateIdentifier
Initializes a VersionedAggregateIdentifier with the given identifier and version.
visited() - Method in class org.axonframework.eventstore.supporting.CapturingEventVisitor
 
visitEvents(EventVisitor) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
 
visitEvents(EventVisitor) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
 
visitEvents(EventVisitor) - Method in interface org.axonframework.eventstore.management.EventStoreManagement
Loads all events available in the event store and calls EventVisitor.doWithEvent(org.axonframework.domain.DomainEventMessage) for each event found.
visitEvents(Criteria, EventVisitor) - Method in interface org.axonframework.eventstore.management.EventStoreManagement
Loads all events available in the event store that match the given criteria and calls EventVisitor.doWithEvent(org.axonframework.domain.DomainEventMessage) for each event found.
visitEvents(EventVisitor) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.eventstore.mongo.MongoEventStore
 
visitEvents(EventVisitor) - Method in class org.axonframework.eventstore.supporting.SequenceEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.eventstore.supporting.SequenceEventStore
 
visitEvents(EventVisitor) - Method in class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
 
visitEvents(EventVisitor) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
 
visitEvents(EventVisitor) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.mongo3.eventstore.MongoEventStore
 
visitEvents(EventVisitor) - Method in class org.axonframework.quickstart.RunEventReplay.StubEventStore
 
visitEvents(Criteria, EventVisitor) - Method in class org.axonframework.quickstart.RunEventReplay.StubEventStore
 
VoidCallback - Class in org.axonframework.commandhandling.callbacks
Abstract callback that can be extended when no result is expected from the command handler execution.
VoidCallback() - Constructor for class org.axonframework.commandhandling.callbacks.VoidCallback
 
VolatileEventStore - Class in org.axonframework.eventstore.supporting
 
VolatileEventStore() - Constructor for class org.axonframework.eventstore.supporting.VolatileEventStore
 

W

waitForSagaCreationVote(boolean, int, boolean) - Method in class org.axonframework.saga.annotation.AsyncSagaCreationElector
Forces the current thread to wait for the voting to complete if it is responsible for creating the Saga.
waitForSagaCreationVote(boolean, int, boolean) - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
Forces the current thread to wait for the voting to complete if it is responsible for creating the Saga.
waitTime() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
 
waitTime() - Method in class org.axonframework.eventhandling.async.RetryPolicy
Returns the time the scheduler should wait before continuing processing.
WeakReferenceCache - Class in org.axonframework.cache
Cache implementation that keeps values in the cache until the garbage collector has removed them.
WeakReferenceCache() - Constructor for class org.axonframework.cache.WeakReferenceCache
 
when(Object) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
when(Object, Map<String, ?>) - Method in class org.axonframework.test.GivenWhenThenTestFixture
 
when(Object) - Method in interface org.axonframework.test.TestExecutor
Dispatches the given command to the appropriate command handler and records all activity in the fixture for result validation.
when(Object, Map<String, ?>) - Method in interface org.axonframework.test.TestExecutor
Dispatches the given command and meta data to the appropriate command handler and records all activity in the fixture for result validation.
whenAggregate(Object) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
whenAggregate(Object) - Method in interface org.axonframework.test.saga.WhenState
Use this method to indicate that an aggregate with given identifier should publish certain events, while recording the outcome.
WhenAggregateEventPublisher - Interface in org.axonframework.test.saga
Interface to an object that publishes events on behalf of an aggregate.
whenPublishingA(Object) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
whenPublishingA(Object) - Method in interface org.axonframework.test.saga.WhenState
Use this method to indicate an application is published, while recording the outcome.
WhenState - Interface in org.axonframework.test.saga
Interface providing an API to methods in the "when" state of the fixture execution.
whenTimeAdvancesTo(DateTime) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
whenTimeAdvancesTo(DateTime) - Method in interface org.axonframework.test.saga.WhenState
Mimic an elapsed time with no relevant activity for the Saga.
whenTimeElapses(Duration) - Method in class org.axonframework.test.saga.AnnotatedSagaTestFixture
 
whenTimeElapses(Duration) - Method in interface org.axonframework.test.saga.WhenState
Mimic an elapsed time with no relevant activity for the Saga.
withAdditionalNode(String, int, Set<String>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns a ConsistentHash with the given additional nodeName, which is given segmentCount segments on the ring.
withExclusively(Collection<String>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns a ConsistentHash instance where only segments leading to the given nodes are available.
withMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandMessage
Returns a copy of this CommandMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.DomainEventMessage
Returns a copy of this DomainEventMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.EventMessage
Returns a copy of this EventMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericDomainEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.Message
Returns a copy of this Message with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializationAwareEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedDomainEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedMessage
 
withoutKeys(Set<String>) - Method in class org.axonframework.domain.MetaData
Returns a MetaData instance with the items with given keys removed.
wrap(Connection, Class<I>, I, ConnectionWrapperFactory.ConnectionCloseHandler) - Static method in class org.axonframework.common.jdbc.ConnectionWrapperFactory
Wrap the given connection, creating a Proxy with an additional wrapperInterface (implemented by given wrapperHandler).
wrap(Connection, ConnectionWrapperFactory.ConnectionCloseHandler) - Static method in class org.axonframework.common.jdbc.ConnectionWrapperFactory
Wrap the given connection, creating a Proxy with an additional wrapperInterface (implemented by given wrapperHandler).
wrap(AMQPConsumerConfiguration) - Static method in class org.axonframework.eventhandling.amqp.spring.SpringAMQPConsumerConfiguration
Creates a SpringAMQPConsumerConfiguration instance from the given configuration.
wrap(DomainEventMessage<T>) - Static method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
Wrap the given message to make it SerializationAware.
wrap(EventMessage<T>) - Static method in class org.axonframework.serializer.SerializationAwareEventMessage
Wrap the given message to make it SerializationAware.
wrapToFireAndForget(GatewayProxyFactory.InvocationHandler<Future<R>>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Wrap the given delegate in an InvocationHandler that returns immediately after invoking the delegate.
wrapToReturnNullOnInterrupted(GatewayProxyFactory.InvocationHandler<R>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Wrap the given delegate in an InvocationHandler that returns null when the delegate throws an InterruptedException.
wrapToReturnNullOnTimeout(GatewayProxyFactory.InvocationHandler<R>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Wrap the given delegate in an InvocationHandler that returns null when the delegate throws a TimeoutException.
wrapToReturnWithFixedTimeout(GatewayProxyFactory.InvocationHandler<Future<R>>, long, TimeUnit) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Wraps the given delegate and waits for the result in the Future to become available, with given timeout and timeUnit.
wrapToReturnWithTimeoutInArguments(GatewayProxyFactory.InvocationHandler<Future<R>>, int, int) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Wraps the given delegate and waits for the result in the Future to become available using given indices to resolve the parameters that provide the timeout to use.
wrapToWaitForResult(GatewayProxyFactory.InvocationHandler<Future<R>>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Wraps the given delegate and waits for the result in the Future to become available.
wrapUndeclaredExceptions(GatewayProxyFactory.InvocationHandler<R>, Class<?>[]) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
Wraps the given delegate in an InvocationHandler that wraps exceptions not declared on the method in a CommandExecutionException.
writeEventMessage(EventMessage) - Method in class org.axonframework.eventhandling.io.EventMessageWriter
Writes the given eventMessage to the underling output.
writeEventMessage(DomainEventMessage) - Method in class org.axonframework.eventstore.fs.FileSystemEventMessageWriter
Writes the given eventMessage to the underling output.
writeExternal(ObjectOutput) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
writeExternal(ObjectOutput) - Method in class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
 
writeExternal(ObjectOutput) - Method in class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
 
writeExternal(ObjectOutput) - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
 
writeReplace() - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
Replacement function for Java Serialization API.
writeReplace() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
Replacement function for Java Serialization API.
writeReplace() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
Java Serialization API Method that provides a replacement to serialize, as the fields contained in this instance are not serializable themselves.
writeReplace() - Method in class org.axonframework.serializer.SerializedEventMessage
Java Serialization API Method that provides a replacement to serialize, as the fields contained in this instance are not serializable themselves.
writeReplace() - Method in class org.axonframework.serializer.SerializedMessage
Java Serialization API Method that provides a replacement to serialize, as the fields contained in this instance are not serializable themselves.
writeSnapshotEvent(DomainEventMessage) - Method in class org.axonframework.eventstore.fs.FileSystemSnapshotEventWriter
Writes the given snapshotEvent to the FileSystemSnapshotEventWriter.snapshotEventFile.
writeTo(DataOutput) - Method in class org.axonframework.commandhandling.distributed.jgroups.DispatchMessage
 
writeTo(DataOutput) - Method in class org.axonframework.commandhandling.distributed.jgroups.JoinMessage
 
writeTo(DataOutput) - Method in class org.axonframework.commandhandling.distributed.jgroups.ReplyMessage
 

X

XomToStringConverter - Class in org.axonframework.serializer.xml
Converter that converts XOM Document instances to a String.
XomToStringConverter() - Constructor for class org.axonframework.serializer.xml.XomToStringConverter
 
XStreamFactory - Class in org.axonframework.gae.serializer
 
XStreamFactory() - Constructor for class org.axonframework.gae.serializer.XStreamFactory
 
XStreamSerializer - Class in org.axonframework.serializer.xml
Serializer that uses XStream to serialize and deserialize arbitrary objects.
XStreamSerializer() - Constructor for class org.axonframework.serializer.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(RevisionResolver) - Constructor for class org.axonframework.serializer.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(XStream) - Constructor for class org.axonframework.serializer.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(Charset) - Constructor for class org.axonframework.serializer.xml.XStreamSerializer
Initialize the serializer using the given charset.
XStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.xml.XStreamSerializer
Initialize the serializer using the given charset and xStream instance.
XStreamSerializer(Charset, XStream, RevisionResolver, ConverterFactory) - Constructor for class org.axonframework.serializer.xml.XStreamSerializer
Initialize the serializer using the given charset and xStream instance.

A B C D E F G H I J K L M N O P Q R S T U V W X

Copyright © 2010-2016. All Rights Reserved.