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

A

AbstractAggregateIdentifier - Class in org.axonframework.domain
Abstract implementation of the aggregate identifier providing basic functionality as defined by AggregateIdentifier.
AbstractAggregateIdentifier() - Constructor for class org.axonframework.domain.AbstractAggregateIdentifier
 
AbstractAggregateRoot - Class in org.axonframework.domain
Very basic implementation of the AggregateRoot interface.
AbstractAggregateRoot() - Constructor for class org.axonframework.domain.AbstractAggregateRoot
Initializes the aggregate root using a random aggregate identifier.
AbstractAggregateRoot(AggregateIdentifier) - Constructor for class org.axonframework.domain.AbstractAggregateRoot
Initializes the aggregate root using the provided aggregate identifier.
AbstractAnnotatedAggregateRoot - Class in org.axonframework.eventsourcing.annotation
Convenience super type for aggregate roots that have their event handler methods annotated with the EventHandler annotation.
AbstractAnnotatedAggregateRoot() - Constructor for class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
Initialize the aggregate root with a random identifier.
AbstractAnnotatedAggregateRoot(AggregateIdentifier) - Constructor for class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
Initializes the aggregate root using the provided aggregate identifier.
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 for AnnotatedEntities
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 - Class in org.axonframework.util
Abstract bean post processor that finds candidates for proxying.
AbstractAnnotationHandlerBeanPostProcessor() - Constructor for class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
 
AbstractCluster - Class in org.axonframework.eventhandling
Abstract Cluster implementation that keeps track of Cluster members (EventListeners).
AbstractCluster() - Constructor for class org.axonframework.eventhandling.AbstractCluster
 
AbstractEventSourcedAggregateRoot - Class in org.axonframework.eventsourcing
Abstract convenience class to be extended by all aggregate roots.
AbstractEventSourcedAggregateRoot() - Constructor for class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Initializes the aggregate root using a random aggregate identifier.
AbstractEventSourcedAggregateRoot(AggregateIdentifier) - Constructor for class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Initializes the aggregate root using the provided aggregate identifier.
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
 
AbstractHandlerInspector - Class in org.axonframework.util
Abstract utility class that inspects handler methods.
AbstractHandlerInspector(Class<?>, Class<? extends Annotation>) - Constructor for class org.axonframework.util.AbstractHandlerInspector
Initialize an AbstractHandlerInspector, where the given annotationType is used to annotate the Event Handler methods.
AbstractHandlerInvoker - Class in org.axonframework.util
Abstract class to support implementations that need to invoke methods based on an annotation.
AbstractHandlerInvoker(Object, Class<? extends Annotation>) - Constructor for class org.axonframework.util.AbstractHandlerInvoker
Initialize a handler invoker for the given target object that has handler method annotated with given annotationType.
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() - Constructor for class org.axonframework.repository.AbstractRepository
 
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) - Constructor for class org.axonframework.saga.AbstractSagaManager
Initializes the SagaManager with the given eventBus and sagaRepository.
AbstractSagaManager(EventBus, SagaRepository, SagaFactory, Executor, TransactionManager) - Constructor for class org.axonframework.saga.AbstractSagaManager
Initializes the SagaManager with the given eventBus and sagaRepository which handles the saga lookup and invocation asynchronously using the given executor and transactionManager.
AbstractSagaRepository - Class in org.axonframework.saga.repository
Abstract implementation for saga repositories.
AbstractSagaRepository() - Constructor for class org.axonframework.saga.repository.AbstractSagaRepository
 
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
 
AbstractUnitOfWork - Class in org.axonframework.unitofwork
Abstract implementation of the UnitOfWork interface.
AbstractUnitOfWork() - Constructor for class org.axonframework.unitofwork.AbstractUnitOfWork
 
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.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(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
 
add(AssociationValue, 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.inmemory.InMemorySagaRepository
 
add(Saga) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
add(Saga) - Method in interface org.axonframework.saga.SagaRepository
Registers a newly created Saga with the Repository.
addAlias(String, Class) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Adds an alias to use instead of the fully qualified class name.
addAlias(String, Class) - Method in class org.axonframework.serializer.XStreamSerializer
Adds an alias to use instead of the fully qualified class name.
addAll(Collection<? extends AssociationValue>) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
addChangeListener(AssociationValues.ChangeListener) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
addChangeListener(AssociationValues.ChangeListener) - Method in interface org.axonframework.saga.AssociationValues
Registers a listener that is notified when AssociationValue instances are wither added or removed from this collection.
addFieldAlias(String, Class, String) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Adds an alias to use for a given field in the given class.
addFieldAlias(String, Class, String) - Method in class org.axonframework.serializer.XStreamSerializer
Adds an alias to use for a given field in the given class.
addMetaData(String, Serializable) - Method in class org.axonframework.domain.EventBase
Insert a key-value pair into the meta data of this event.
addPackageAlias(String, String) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Add an alias for a package.
addPackageAlias(String, String) - Method in class org.axonframework.serializer.XStreamSerializer
Add an alias for a package.
afterCommit() - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
 
afterCommit() - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked when the UnitOfWork is committed.
afterCommit() - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Invoked when the UnitOfWork is committed.
afterPropertiesSet() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
afterPropertiesSet() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
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.scheduling.SpringTransactionalTriggerCallback
 
afterPropertiesSet() - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
afterPropertiesSet() - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
afterPropertiesSet() - Method in class org.axonframework.eventsourcing.SpringPrototypeEventSourcingRepository
 
afterPublicationFailure(RuntimeException) - Method in interface org.axonframework.eventhandling.scheduling.EventTriggerCallback
Invoked when the publication of a scheduled event failed.
afterPublicationFailure(RuntimeException) - Method in class org.axonframework.eventhandling.scheduling.SpringTransactionalTriggerCallback
 
afterPublicationSuccess() - Method in interface org.axonframework.eventhandling.scheduling.EventTriggerCallback
Invoked after the publication of a scheduled event has been executed successfully.
afterPublicationSuccess() - Method in class org.axonframework.eventhandling.scheduling.SpringTransactionalTriggerCallback
 
AfterTransaction - Annotation Type in org.axonframework.eventhandling.annotation
Annotation that marks a method to be called after a transactional batch of events is being handled.
afterTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Invoked by the EventProcessingScheduler after a series of events is processed.
afterTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.annotation.AnnotationTransactionManager
Invoked by the EventProcessingScheduler after a series of events is processed.
afterTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.NoTransactionManager
 
afterTransaction(TransactionStatus) - Method in interface org.axonframework.eventhandling.TransactionManager
Invoked by the EventProcessingScheduler after a series of events is processed.
afterTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.transactionmanagers.SpringTransactionManager
 
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>, CommandBus) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType, to be registered on the given commandBus.
AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandBus, CommandTargetResolver) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType, to be registered on the given commandBus.
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>) - Constructor for class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
Initialize an AbstractHandlerInspector, where the given annotationType is used to annotate the Event Handler methods.
AggregateDeletedEvent - Interface in org.axonframework.domain
Special type of event that indicates that the aggregate from which this event was raised has been removed.
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(AggregateIdentifier, String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier and given message.
AggregateDeletedException(AggregateIdentifier) - 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 - Interface in org.axonframework.domain
Interface to the type that uniquely identifies an aggregate of a certain type.
AggregateIdentifierConverter - Class in org.axonframework.serializer
XStream converter to minimize the amount of output used when serializing aggregate identifiers.
AggregateIdentifierConverter() - Constructor for class org.axonframework.serializer.AggregateIdentifierConverter
 
AggregateNotFoundException - Exception in org.axonframework.repository
Exception indicating that the an aggregate could not be found in the repository.
AggregateNotFoundException(AggregateIdentifier, String) - Constructor for exception org.axonframework.repository.AggregateNotFoundException
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier and given message.
AggregateNotFoundException(AggregateIdentifier, 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 - Interface in org.axonframework.domain
Interface defining a contract for entities that represent the aggregate root.
AggregateSnapshot<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Snapshot event that captures the entire aggregate.
AggregateSnapshot(T) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshot
Initialize a new AggregateSnapshot for the given aggregate.
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
 
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
Initialize the AnnotatedSagaManager using the given resources, and using a GenericSagaFactory.
AnnotatedSagaManager(SagaRepository, SagaFactory, EventBus, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using the given resources.
AnnotatedSagaManager(SagaRepository, SagaFactory, EventBus, Executor, TransactionManager, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using the given resources.
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
Initialize the command handler adapter for the given target which is to be subscribed with the given commandBus.
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 AggregateIdentifier 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
 
AnnotationEventHandlerInvoker - Class in org.axonframework.eventhandling.annotation
Utility class that supports invocation of specific handler methods for a given event.
AnnotationEventHandlerInvoker(Object) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventHandlerInvoker
Initialize an event handler invoker that invokes handlers on the given target.
AnnotationEventListenerAdapter - Class in org.axonframework.eventhandling.annotation
Adapter that turns any bean with EventHandler annotated methods into an EventListener.
AnnotationEventListenerAdapter(Object, EventBus) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Initialize the AnnotationEventListenerAdapter for the given annotatedEventListener.
AnnotationEventListenerAdapter(Object, Executor, EventBus) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Initialize the AnnotationEventListenerAdapter for the given annotatedEventListener.
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
 
AnnotationTransactionManager - Class in org.axonframework.eventhandling.annotation
A transaction manager that delegates calls to the appropriate annotated methods in a bean.
AnnotationTransactionManager(Object) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationTransactionManager
Initialize a transaction manager that delegates calls tot he given bean.
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.jpa.JpaEventStore
Append the events in the given stream to the event store.
appendSnapshotEvent(String, DomainEvent) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
Append the given snapshotEvent to the snapshot event log for the given type type.
appendSnapshotEvent(String, DomainEvent) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Append the given snapshotEvent to the snapshot event log for the given type type.
appendSnapshotEvent(String, DomainEvent) - Method in interface org.axonframework.eventstore.SnapshotEventStore
Append the given snapshotEvent to the snapshot event log for the given type type.
appendTo(Collection<DomainEvent>) - Method in class org.axonframework.domain.SimpleDomainEventStream
Append the contents of this stream to the given collection.
appendUncommittedEventsTo(Collection<DomainEvent>) - Method in class org.axonframework.domain.AbstractAggregateRoot
Appends all the uncommitted events to the given collection.
ApplicationEvent - Class in org.axonframework.domain
Represents an event that does not represent a state change of an application but does have functional meaning to the application.
ApplicationEvent(Object) - Constructor for class org.axonframework.domain.ApplicationEvent
Initialize an application event with the given source.
ApplicationEvent(String, DateTime, long, String) - Constructor for class org.axonframework.domain.ApplicationEvent
Initializes the event using given parameters.
apply(DomainEvent) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Apply the provided event.
apply(DomainEvent) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Apply the provided event.
Assert - Class in org.axonframework.util
Utility class (inspired by Springs Assert class) for doing assertions on parameters and object state.
associateWith(AssociationValue) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Registers a AssociationValue with the given saga.
associateWith(String, Object) - 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, Object) - Constructor for class org.axonframework.saga.AssociationValue
Deprecated.
The storage of arbitrary objects is deprecated. Use AssociationValue.AssociationValue(String, String) instead. This constructor may still be used, but requires all given values implement a toString() method that provides a representative String value.
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, AssociationValue, SagaSerializer) - 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 collection of Association Values for a single Saga instance.
AssociationValues.ChangeListener - Interface in org.axonframework.saga
Interface describing instances that listen for modification in an AssociationValues instance.
AssociationValuesImpl - Class in org.axonframework.saga.annotation
Default implementation of the AssociationValues interface.
AssociationValuesImpl() - Constructor for class org.axonframework.saga.annotation.AssociationValuesImpl
 
asString() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
 
asString() - Method in interface org.axonframework.domain.AggregateIdentifier
Returns the String representation of this aggregate identifier.
asString() - Method in class org.axonframework.domain.StringAggregateIdentifier
 
asUUID() - Method in class org.axonframework.domain.UUIDAggregateIdentifier
Returns a UUID representation of this aggregate identifier.
AsynchronousEventHandlerWrapper - Class in org.axonframework.eventhandling
The AsynchronousEventHandlerWrapper can wrap any event listener to give it asynchronous behavior.
AsynchronousEventHandlerWrapper(EventListener, TransactionManager, SequencingPolicy<? super Event>, Executor) - Constructor for class org.axonframework.eventhandling.AsynchronousEventHandlerWrapper
Initialize the AsynchronousEventHandlerWrapper for the given eventListener using the given executor and transactionManager.
AsynchronousEventHandlerWrapper(EventListener, SequencingPolicy<? super Event>, Executor) - Constructor for class org.axonframework.eventhandling.AsynchronousEventHandlerWrapper
Initialize the AsynchronousEventHandlerWrapper for the given eventListener using the given executor.
AsynchronousEventListener - Annotation Type in org.axonframework.eventhandling.annotation

Annotation that marks a class as an Asynchronous EventListener.

AsynchronousExecutionWrapper<T> - Class in org.axonframework.eventhandling
Abstract implementation that schedules tasks for execution.
AsynchronousExecutionWrapper(Executor, TransactionManager, SequencingPolicy<? super T>) - Constructor for class org.axonframework.eventhandling.AsynchronousExecutionWrapper
Initialize the AsynchronousExecutionWrapper using the given executor and transactionManager.
AsynchronousExecutionWrapper(Executor, SequencingPolicy<? super T>) - Constructor for class org.axonframework.eventhandling.AsynchronousExecutionWrapper
Initialize the AsynchronousExecutionWrapper using the given executor.
AsynchronousSagaExecutor - Class in org.axonframework.saga
Executor that processes saga lookups and saga event handling using an Executor.
AsynchronousSagaExecutor(Executor, TransactionManager) - Constructor for class org.axonframework.saga.AsynchronousSagaExecutor
Initializes an AsynchronousSagaExecutor using the given executor and transactionManager.
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(Object, 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.
AutowiredBean - Class in org.axonframework.contextsupport.spring
Special type of BeanDefinition that references can be use to explicitly define a property as being autowired.
AutowiredBean(Class<?>) - Constructor for class org.axonframework.contextsupport.spring.AutowiredBean
Creates an autowired dependency on the given autowiredType.
AutowiredDependencyFactoryBean<T> - Class in org.axonframework.contextsupport.spring
Convenience factory bean that locates a bean of the given type.
AutowiredDependencyFactoryBean(Class<T>) - Constructor for class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
Creates a factory bean that automatically resolved to a bean of the give beanType.
AxonConfigurationException - Exception in org.axonframework.util
Exception indicating that a configuration error has been made in the Axon configuration.
AxonConfigurationException(String) - Constructor for exception org.axonframework.util.AxonConfigurationException
Initializes the exception using the given message.
AxonConfigurationException(String, Throwable) - Constructor for exception org.axonframework.util.AxonConfigurationException
Initializes the exception using the given message and cause.
AxonException - Exception in org.axonframework.util
Base exception of all Axon Framework related exceptions.
AxonException(String) - Constructor for exception org.axonframework.util.AxonException
Initializes the exception using the given message.
AxonException(String, Throwable) - Constructor for exception org.axonframework.util.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.util
Exception indicating an error has been cause that cannot be resolved without intervention.
AxonNonTransientException(String) - Constructor for exception org.axonframework.util.AxonNonTransientException
Initializes the exception using the given message.
AxonNonTransientException(String, Throwable) - Constructor for exception org.axonframework.util.AxonNonTransientException
Initializes the exception using the given message and cause.
AxonTransientException - Exception in org.axonframework.util
Exception indicating an error occurred that might be resolved by retrying the operation that caused the exception.
AxonTransientException(String) - Constructor for exception org.axonframework.util.AxonTransientException
Initializes the exception using the given message.
AxonTransientException(String, Throwable) - Constructor for exception org.axonframework.util.AxonTransientException
Initializes the exception using the given message and cause.

B

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.
beforePublication(ApplicationEvent) - Method in interface org.axonframework.eventhandling.scheduling.EventTriggerCallback
Invoked just before the given event is published.
beforePublication(ApplicationEvent) - Method in class org.axonframework.eventhandling.scheduling.SpringTransactionalTriggerCallback
 
beforeTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Invoked by the EventProcessingScheduler before processing a series of events.
beforeTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.annotation.AnnotationTransactionManager
Invoked by the EventProcessingScheduler before processing a series of events.
BeforeTransaction - Annotation Type in org.axonframework.eventhandling.annotation
Annotation that marks a method to be called before a transactional batch of events is handled.
beforeTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.NoTransactionManager
 
beforeTransaction(TransactionStatus) - Method in interface org.axonframework.eventhandling.TransactionManager
Invoked by the EventProcessingScheduler before processing a series of events.
beforeTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.transactionmanagers.SpringTransactionManager
 
BinaryEntryInputStream - Class in org.axonframework.util.io
Wrapper around an input stream that can be used to read simple values, written using the BinaryEntryOutputStream.
BinaryEntryInputStream(InputStream) - Constructor for class org.axonframework.util.io.BinaryEntryInputStream
Initialize a BinaryEntryInputStream reading its data from the given inputStream.
BinaryEntryOutputStream - Class in org.axonframework.util.io
Wrapper around an output stream that can be used to write simple values, that can be read back in by the BinaryEntryInputStream.
BinaryEntryOutputStream(OutputStream) - Constructor for class org.axonframework.util.io.BinaryEntryOutputStream
Initialize a BinaryEntryOutputStream writing its entries to the given outputStream.

C

CachingEventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Implementation of the event sourcing repository that uses a cache to improve loading performance.
CachingEventSourcingRepository() - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
CachingEventSourcingRepository(AggregateFactory<T>) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Initializes a repository with a the given aggregateFactory and a pessimistic locking strategy.
CachingGenericEventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
The CachingGenericEventSourcingRepository is a special EventSourcingRepository implementation that can act as a repository for any type of EventSourcedAggregateRoot.
CachingGenericEventSourcingRepository(Class<T>) - Constructor for class org.axonframework.eventsourcing.CachingGenericEventSourcingRepository
Creates a GenericEventSourcingRepository for aggregates of the given aggregateType, using the default locking strategy (optimistic locking).
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
 
canConvert(Class) - Method in class org.axonframework.serializer.AggregateIdentifierConverter
 
clear() - Static method in class org.axonframework.eventhandling.TransactionStatus
Clears the TransactionStatus related to the current thread.
clear() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
clear() - Method in class org.axonframework.saga.repository.AssociationValueMap
Clears all the associations.
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.
Cluster - Interface in org.axonframework.eventhandling
A cluster represents a group of Event Listeners that are treated as a single group by the ClusteringEventBus.
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.
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.
CollectionUtils - Class in org.axonframework.util
Utility methods for operations on collections.
CommandBus - Interface in org.axonframework.commandhandling
The mechanism that dispatches Command objects to their appropriate CommandHandler.
CommandCallback<R> - Interface in org.axonframework.commandhandling
Interface describing a callback that is invoked when command handler execution has finished.
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.
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.
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.
CommandTemplate - Class in org.axonframework.commandhandling.template
This class simplifies the use of the CommandBus, by providing methods for common usage patterns.
CommandTemplate(CommandBus) - Constructor for class org.axonframework.commandhandling.template.CommandTemplate
Constructs a CommandTemplate that uses the given commandBus to send its commands.
commit(Saga) - Method in class org.axonframework.saga.AbstractSagaManager
Commits the given saga to the registered repository.
commit(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
 
commit(Saga) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
commit(Saga) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
commit(Saga) - Method in interface org.axonframework.saga.SagaRepository
Commits the changes made to the Saga instance.
commit() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
 
commit() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Commits the current UnitOfWork.
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".
commitEvents() - Method in interface org.axonframework.domain.AggregateRoot
Clears the events currently marked as "uncommitted".
commitInnerUnitOfWork() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
Commit all registered inner units of work.
commitTransaction(TransactionStatus) - Method in class org.axonframework.commandhandling.interceptors.SpringTransactionalInterceptor
 
commitTransaction(T) - Method in class org.axonframework.commandhandling.interceptors.TransactionInterceptor
Commits the transaction for the command execution described by the given context.
compareTo(AggregateIdentifier) - Method in class org.axonframework.domain.AbstractAggregateIdentifier

This implementation compared the string representations of both identifiers.

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(AggregateIdentifier, long, long) - Constructor for exception org.axonframework.repository.ConflictingAggregateVersionException
Initializes the exception using the given message.
ConflictingAggregateVersionException(AggregateIdentifier, 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.
ContainerManagedEntityManagerProvider - Class in org.axonframework.util.jpa
EntityManagerProvider implementation that expects the container to inject the default container managed EntityManager instance.
ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.util.jpa.ContainerManagedEntityManagerProvider
 
contains(Object) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
containsAll(Collection<?>) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
containsKey(String) - Method in interface org.axonframework.domain.EventMetaData
Indicates whether the given key has been associated with a value (which includes null).
containsKey(String) - Method in class org.axonframework.domain.MutableEventMetaData
 
createAggregate(AggregateIdentifier, DomainEvent) - Method in interface org.axonframework.eventsourcing.AggregateFactory
Instantiate the aggregate using the given aggregate identifier and first event.
createAggregate(AggregateIdentifier, DomainEvent) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Deprecated.
createAggregate(AggregateIdentifier, DomainEvent) - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
Instantiate the aggregate using the given aggregate identifier and first event.
createAggregate(AggregateIdentifier, DomainEvent) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
createSaga(Class<T>) - Method in class org.axonframework.saga.AbstractSagaManager
Create a new instance of a Saga of the given sagaType.
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.
createSnapshot(String, 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, DomainEventStream) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
 
createSnapshotterTask(String, AggregateIdentifier) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Creates an instance of a task that contains the actual snapshot creation logic.
createSnapshotterTask(String, AggregateIdentifier) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
 
createUnitOfWork() - Method in class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
 
createUnitOfWork() - Method in interface org.axonframework.unitofwork.UnitOfWorkFactory
Creates a new UnitOfWork instance.
current() - Static method in class org.axonframework.eventhandling.TransactionStatus
Returns the TransactionStatus object related to a transaction running on the current thread.
CurrentUnitOfWork - Class in org.axonframework.unitofwork
Default entry point to gain access to the current UnitOfWork.

D

declaringClass(Class<?>, String, Class<?>...) - Static method in class org.axonframework.util.ReflectionUtils
Returns the class on which the method with name "methodName" and parameters of type parameterTypes is declared.
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, AggregateIdentifier, DomainEventStream) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
 
decorateForRead(String, AggregateIdentifier, DomainEventStream) - Method in interface org.axonframework.eventsourcing.EventStreamDecorator
Called when an event stream is read from the event store.
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, to which this instance will assign all Event Listeners.
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(Object, 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.
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
 
DefaultUnitOfWorkFactory - Class in org.axonframework.unitofwork
UnitOfWorkFactory implementation that creates instances of the DefaultUnitOfWork.
DefaultUnitOfWorkFactory() - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
 
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.jpa.JpaSagaRepository
 
deserialize(byte[]) - Method in interface org.axonframework.eventstore.EventSerializer
Deprecated.
Deserialize a DomainEvent using the given serializedEvents.
deserialize(InputStream) - Method in class org.axonframework.eventstore.legacy.LegacyEventSerializerWrapper
Deprecated.
 
deserialize(byte[]) - Method in class org.axonframework.eventstore.legacy.LegacyEventSerializerWrapper
Deprecated.
 
deserialize(byte[]) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Deserializes the first object read from the given bytes.
deserialize(InputStream) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Deserializes the first object read from the given inputStream.
deserialize(byte[]) - Method in class org.axonframework.saga.repository.JavaSagaSerializer
 
deserialize(byte[]) - Method in interface org.axonframework.saga.repository.SagaSerializer
Deserializes the given serializedSaga.
deserialize(byte[]) - Method in class org.axonframework.saga.repository.XStreamSagaSerializer
 
deserialize(InputStream) - Method in interface org.axonframework.serializer.Serializer
Deserializes the first object read from the given inputStream.
deserialize(byte[]) - Method in interface org.axonframework.serializer.Serializer
Deserializes the first object read from the given bytes.
deserialize(InputStream) - Method in class org.axonframework.serializer.XStreamSerializer
Deserializes the first object read from the given inputStream.
deserialize(byte[]) - Method in class org.axonframework.serializer.XStreamSerializer
Deserializes the first object read from the given bytes.
deserialize(HierarchicalStreamReader) - Method in class org.axonframework.serializer.XStreamSerializer
Deserialize the object provided by the given hierarchicalStreamReader.
deserializeAssociationValue(byte[]) - Method in class org.axonframework.saga.repository.JavaSagaSerializer
 
deserializeAssociationValue(byte[]) - Method in interface org.axonframework.saga.repository.SagaSerializer
Deserializes the given serializedAssociationValue.
deserializeAssociationValue(byte[]) - Method in class org.axonframework.saga.repository.XStreamSagaSerializer
 
DirectExecutor - Class in org.axonframework.util
Simple executor implementation that runs a given Runnable immediately in the calling thread.
DirectExecutor() - Constructor for class org.axonframework.util.DirectExecutor
 
disableMonitoring() - Method in class org.axonframework.monitoring.jmx.JmxConfiguration
Disables monitoring.
dispatch(Object) - Method in interface org.axonframework.commandhandling.CommandBus
Dispatch the given command to the CommandHandler subscribed to that type of command.
dispatch(Object, CommandCallback<R>) - Method in interface org.axonframework.commandhandling.CommandBus
Dispatch the given command to the CommandHandler subscribed to that type of command.
dispatch(Object) - Method in class org.axonframework.commandhandling.SimpleCommandBus
 
dispatch(Object, CommandCallback<R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
 
doCommit() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
Executes the logic required to commit this unit of work.
doCommit() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
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.CachingEventSourcingRepository
 
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.
doHandle(Event) - Method in class org.axonframework.eventhandling.AsynchronousEventHandlerWrapper
 
doHandle(T) - Method in class org.axonframework.eventhandling.AsynchronousExecutionWrapper
Does the actual processing of the task.
doHandle(T) - Method in class org.axonframework.eventhandling.EventProcessingScheduler
Does the actual processing of the event.
doHandle(Runnable) - Method in class org.axonframework.saga.AsynchronousSagaExecutor
 
doLoad(AggregateIdentifier, Long) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
Perform the actual loading of an aggregate.
doLoad(AggregateIdentifier, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Perform the actual loading of an aggregate.
doLoad(AggregateIdentifier, Long) - Method in class org.axonframework.repository.AbstractRepository
Loads and initialized the aggregate with the given aggregateIdentifier.
doLoad(AggregateIdentifier, Long) - Method in class org.axonframework.repository.GenericJpaRepository
 
doLoad(AggregateIdentifier, Long) - Method in class org.axonframework.repository.LockingRepository
Perform the actual loading of an aggregate.
DomainEvent - Class in org.axonframework.domain
Base class for all Domain Events.
DomainEvent() - Constructor for class org.axonframework.domain.DomainEvent
Initialize the domain event.
DomainEvent(long) - Constructor for class org.axonframework.domain.DomainEvent
Initialize the domain event using the given eventRevision.
DomainEvent(long, AggregateIdentifier) - Constructor for class org.axonframework.domain.DomainEvent
Initialize the domain event.
DomainEvent(String, DateTime, long, long, AggregateIdentifier) - Constructor for class org.axonframework.domain.DomainEvent
Initialize the domain event using given parameters.
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, DomainEvent, byte[]) - Constructor for class org.axonframework.eventstore.jpa.DomainEventEntry
Initialize a DomainEventEntry for the given event, to be serialized using the given serializer.
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.JpaEventStoreBeanDefinitionParser
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
 
doRollback(Throwable) - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
Executes the logic required to commit this unit of work.
doRollback(Throwable) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
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.CachingEventSourcingRepository
Saves the aggregate and stores it in the cache (if configured) for fast retrieval.
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.
doStart() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
Performs logic required when starting this UnitOfWork instance.
doWithEvent(DomainEvent) - Method in interface org.axonframework.eventstore.EventVisitor
Called for each event loaded by the event store.

E

EmptyDataProvider - Class in org.axonframework.auditing
Implementation of AuditDataProvider that provides no information (empty map).
EmptyDataProvider() - Constructor for class org.axonframework.auditing.EmptyDataProvider
 
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.
EndSaga - Annotation Type in org.axonframework.saga.annotation
Indicates that the annotated SagaEventHandler method indicates the end of a Saga instance's lifecycle.
ensureAccessible(AccessibleObject) - Static method in class org.axonframework.util.ReflectionUtils
Makes the given member accessible via reflection if it is not the case already.
EntityManagerProvider - Interface in org.axonframework.util.jpa
Provides components with an EntityManager to access the persistence mechanism.
equals(Object) - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
 
equals(Object) - Method in class org.axonframework.domain.AbstractAggregateIdentifier
 
equals(Object) - Method in interface org.axonframework.domain.AggregateIdentifier
equals(Object) - Method in class org.axonframework.domain.DomainEvent
Checks for equality of two events.
equals(Object) - Method in class org.axonframework.domain.EventBase
Checks the equality of two events.
equals(Object) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
equals(Object) - Method in class org.axonframework.saga.AssociationValue
 
Event - Interface in org.axonframework.domain
Base interface for all events in the application.
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_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the event in the JobExecutionContext.
EventBase - Class in org.axonframework.domain
Base class for all types of events.
EventBase() - Constructor for class org.axonframework.domain.EventBase
Initialize a new event.
EventBase(long) - Constructor for class org.axonframework.domain.EventBase
Constructs a newly created event with the given eventRevision number.
EventBase(String, DateTime, long) - Constructor for class org.axonframework.domain.EventBase
Initializes the event with given parameters.
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.
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
 
EventEntryStore - Interface in org.axonframework.eventstore.jpa
Interface describing the mechanism that stores Events into the backing data store.
eventFileExists(String, AggregateIdentifier) - 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, AggregateIdentifier) - 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.
EventHandler - Annotation Type in org.axonframework.eventhandling.annotation
Annotation to be placed on methods that can handle events.
EventHandlerInvocationException - Exception in org.axonframework.eventhandling.annotation
EventHandlerInvocationException is a runtime exception that wraps an exception thrown by an invoked event handler.
EventHandlerInvocationException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.annotation.EventHandlerInvocationException
Initialize the EventHandlerInvocationException using given message and cause.
EventListener - Interface in org.axonframework.eventhandling
Interface to be implemented by classes that can handle events.
EventListenerProxy - Interface in org.axonframework.eventhandling
Specialist interface for implementations of an event listener that redirect actual processing to another instance.
EventMetaData - Interface in org.axonframework.domain
Interface towards the meta data properties of an event.
EventProcessingScheduler<T> - Class in org.axonframework.eventhandling
Scheduler that keeps track of (Event processing) tasks that need to be executed sequentially.
EventProcessingScheduler(TransactionManager, Executor, EventProcessingScheduler.ShutdownCallback) - Constructor for class org.axonframework.eventhandling.EventProcessingScheduler
Initialize a scheduler using the given executor.
EventProcessingScheduler(TransactionManager, Queue<T>, Executor, EventProcessingScheduler.ShutdownCallback) - Constructor for class org.axonframework.eventhandling.EventProcessingScheduler
Initialize a scheduler using the given executor.
EventScheduler - Interface in org.axonframework.eventhandling.scheduling
Interface towards a mechanism capable of scheduling the publication of events.
EventSerializer - Interface in org.axonframework.eventstore
Deprecated.
will be replaced by Serializer<Event> in future versions.
EventSourcedAggregateRoot - Interface in org.axonframework.eventsourcing
Aggregate that can be initialized using a DomainEventStream.
EventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Abstract repository implementation that allows easy implementation of an Event Sourcing mechanism.
EventSourcingRepository() - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Deprecated.
This constructor will be removed in future releases. Use EventSourcingRepository.EventSourcingRepository(AggregateFactory) instead.
EventSourcingRepository(LockingStrategy) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Deprecated.
EventSourcingRepository(AggregateFactory<T>) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initializes a repository with the default locking strategy.
EventSourcingRepository(AggregateFactory<T>, LockingStrategy) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initialize a repository with the given locking strategy.
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
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, AggregateIdentifier) - 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.
EventTriggerCallback - Interface in org.axonframework.eventhandling.scheduling
Callback interface that is invoked before and after a scheduled event is published.
EventUpcaster<T> - Interface in org.axonframework.eventstore
Interface for Upcasters.
EventVisitor - Interface in org.axonframework.eventstore
Interface describing an instance of a visitor that receives events for processing.
execute(JobExecutionContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
 
execute(Runnable) - Method in class org.axonframework.util.DirectExecutor
Executes the given command immediately in the current thread.
explicitlyUnequal(Object, Object) - Static method in class org.axonframework.util.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.
extractAssociationValue(Event) - Method in interface org.axonframework.saga.AssociationValueResolver
Extracts the Association Values from the given event.

F

fetchBatch(int, int, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Fetches a selection (starting at startPosition and including batchSize entries) of events in the entire event store.
fetchBatch(String, AggregateIdentifier, long, int, EntityManager) - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
Fetches a selection of events for an aggregate of given type and given identifier starting at given firstSequenceNumber with given batchSize.
FieldAccessibilityCallback - Class in org.axonframework.util
PrivilegedAction that makes the given field accessible for reflection.
FieldAccessibilityCallback(Field) - Constructor for class org.axonframework.util.FieldAccessibilityCallback
Initialize the callback to make the given field accessible for reflection.
fieldsOf(Class<?>) - Static method in class org.axonframework.util.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.
FileSystemEventStore - Class in org.axonframework.eventstore.fs
Implementation of the EventStore that serializes objects using XStream and writes them to files to disk.
FileSystemEventStore() - Constructor for class org.axonframework.eventstore.fs.FileSystemEventStore
Basic initialization of the event store.
FileSystemEventStore(EventSerializer) - Constructor for class org.axonframework.eventstore.fs.FileSystemEventStore
FileSystemEventStore(Serializer<? super DomainEvent>) - 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
 
filterByType(Iterable<?>, Class<T>) - Static method in class org.axonframework.util.CollectionUtils
Returns a list of objects of expectedType contained in the given collection.
find(Class<T>, Set<AssociationValue>) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
 
find(Class<T>, Set<AssociationValue>) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
find(Class<T>, Set<AssociationValue>) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
find(Class<T>, Set<AssociationValue>) - Method in interface org.axonframework.saga.SagaRepository
Find saga instances of the given type that have been associated with the given associationValue.
findAnnotation(Class<?>, Class<A>) - Static method in class org.axonframework.util.ReflectionUtils
Inspects the given type and returns the annotation of given annotationType.
findFieldValuesOfType(Object, Class<T>) - Static method in class org.axonframework.util.ReflectionUtils
Returns a collection of values contained in the fields of the given instance that are assignable to the given type.
findHandlerMethod(Class<?>) - Method in class org.axonframework.util.AbstractHandlerInspector
Returns the handler method that handles objects of the given parameterType.
findSagas(Event) - Method in class org.axonframework.saga.AbstractSagaManager
Finds the saga instances that the given event needs to be routed to.
findSagas(Event) - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
 
findSagas(AssociationValue) - Method in class org.axonframework.saga.repository.AssociationValueMap
Returns the identifiers of the Sagas that have been associated with the given associationValue.
findSagas(Event) - Method in class org.axonframework.saga.SimpleSagaManager
 
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
 
FullConcurrencyPolicy - Class in org.axonframework.eventhandling
SequencingPolicy that does not enforce any sequencing requirements on event processing.
FullConcurrencyPolicy() - Constructor for class org.axonframework.eventhandling.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

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.
GenericEventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
The GenericEventSourcingRepository is a special EventSourcingRepository implementation that can act as a repository for any type of EventSourcedAggregateRoot.
GenericEventSourcingRepository(Class<T>) - Constructor for class org.axonframework.eventsourcing.GenericEventSourcingRepository
Creates a GenericEventSourcingRepository for aggregates of the given aggregateType, using the default locking strategy (pessimistic locking).
GenericEventSourcingRepository(Class<T>, LockingStrategy) - Constructor for class org.axonframework.eventsourcing.GenericEventSourcingRepository
Creates a GenericEventSourcingRepository for aggregates of the given aggregateType, using the given lockingStrategy.
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(EntityManagerProvider, Class<T>, LockingStrategy) - Constructor for class org.axonframework.repository.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType with an additional lockingStrategy.
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
 
GenericXStreamSerializer - Class in org.axonframework.serializer
Deprecated.
Use XStreamSerializer instead
GenericXStreamSerializer() - Constructor for class org.axonframework.serializer.GenericXStreamSerializer
Deprecated.
Initialize a generic serializer using the UTF-8 character set.
GenericXStreamSerializer(XStream) - Constructor for class org.axonframework.serializer.GenericXStreamSerializer
Deprecated.
Initialize a generic serializer using the UTF-8 character set.
GenericXStreamSerializer(Charset) - Constructor for class org.axonframework.serializer.GenericXStreamSerializer
Deprecated.
Initialize the serializer using the given charset.
GenericXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.serializer.GenericXStreamSerializer
Deprecated.
Initialize the serializer using the given charset and xStream instance.
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(String) - Method in interface org.axonframework.domain.EventMetaData
Returns the value associated with the given key.
get(String) - Method in class org.axonframework.domain.MutableEventMetaData
 
get(String) - Method in class org.axonframework.saga.repository.SagaCache
Retrieves the Saga instance with the given sagaIdentifier, or null if none was found.
get() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Gets the UnitOfWork bound to the current thread.
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.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
getAdapterInterface() - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
Returns the interface that the adapter implements to connect the annotated method to the actual interface definition.
getAggregate() - Method in class org.axonframework.eventsourcing.AggregateSnapshot
Return the aggregate that was captured in this snapshot.
getAggregateFactory() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Returns the factory used by this repository.
getAggregateIdentifier() - Method in class org.axonframework.domain.DomainEvent
Returns the identifier of the aggregate that reported this event.
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.
getAggregateType() - Method in class org.axonframework.repository.GenericJpaRepository
Returns the aggregate type stored by this repository.
getAggregateVersion() - Method in class org.axonframework.domain.DomainEvent
Returns the version number of the aggregate generating this event.
getApplicationContext() - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
Returns the ApplicationContext this Bean Post Processor is registered in.
getAssociationValue(SagaSerializer) - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
Returns the association value contained in this entry.
getAssociationValueMap() - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Returns the AssociationValueMap containing the mappings of AssociationValue to Saga.
getAssociationValues() - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
 
getAssociationValues() - Method in interface org.axonframework.saga.Saga
Returns a view on the Association Values for this saga instance.
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
 
getCause() - Method in class org.axonframework.domain.SystemEvent
Returns the cause that was attached to this event.
getCharset() - Method in class org.axonframework.eventstore.XStreamEventSerializer
Returns the character set used to serialize XML to bytes and vice versa.
getCharset() - Method in class org.axonframework.serializer.XStreamSerializer
Returns the character set used to convert character to bytes and vice versa.
getChildEntities() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Returns a list of event sourced entities directly referenced by the aggregate root.
getChildEntities() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Returns a list of event sourced entities directly referenced by this entity.
getCommandHandlerCount() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
Returns the amount of registered handlers.
getConstructorHandlers() - Method in class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
Returns a list of constructor handlers on the given aggregate type.
getDeclaringClass() - Method in class org.axonframework.util.Handler
Returns the class on which the handler method is declared.
getEntityManager() - Method in class org.axonframework.util.jpa.ContainerManagedEntityManagerProvider
 
getEntityManager() - Method in interface org.axonframework.util.jpa.EntityManagerProvider
Returns an instance of an EntityManager for the EventStore to use.
getEntityManager() - Method in class org.axonframework.util.jpa.SimpleEntityManagerProvider
 
getEventBus() - Method in class org.axonframework.saga.AbstractSagaManager
Returns the EventBus that delivers the events to route to Sagas.
getEventIdentifier() - Method in interface org.axonframework.domain.Event
Returns the identifier of this event.
getEventIdentifier() - Method in class org.axonframework.domain.EventBase
Returns the identifier of this event.
getEventIdentifier() - Method in interface org.axonframework.domain.EventMetaData
Returns the identifier of this event.
getEventIdentifier() - Method in class org.axonframework.domain.MutableEventMetaData
 
getEventRevision() - Method in class org.axonframework.domain.EventBase
Returns the revision number of this event definition.
getEventsProcessedInTransaction() - Method in class org.axonframework.eventhandling.TransactionStatus
Returns the number of events processed (so far) in the current transaction.
getEventsProcessedSinceLastYield() - Method in class org.axonframework.eventhandling.TransactionStatus
Returns the number of events processed (so far) since the scheduler last yielded to other threads.
getEventStore() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Returns the event store this snapshotter uses to load domain events and store snapshot events.
getException() - Method in class org.axonframework.eventhandling.TransactionStatus
Returns the exception that caused the transaction to be marked as failed.
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.
getFieldValue(Field, Object) - Static method in class org.axonframework.util.ReflectionUtils
Returns the value of the given field in the given object.
getHandlers() - Method in class org.axonframework.util.AbstractHandlerInspector
Returns the list of handlers found on target type.
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.VersionedAggregateIdentifier
Returns the identifier of the targeted Aggregate.
getIdentifier() - Method in class org.axonframework.domain.AbstractAggregateRoot
Returns the identifier of this aggregate.
getIdentifier() - Method in interface org.axonframework.domain.AggregateRoot
Returns the identifier of this aggregate.
getInstance() - Static method in class org.axonframework.domain.IdentifierFactory
Returns an instance of the IdentifierFactory discovered on the classpath.
getInstance() - Static method in class org.axonframework.monitoring.jmx.JmxConfiguration
Returns the singleton instance of JmxConfiguration.
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.
getListenerCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
Returns the amount of 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.
getMaxTransactionSize() - Method in class org.axonframework.eventhandling.TransactionStatus
Returns the maximum number of events that may be processed inside the current transaction.
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.
getMetaData() - Method in interface org.axonframework.domain.Event
Returns the meta data for this event.
getMetaData() - Method in class org.axonframework.domain.EventBase
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.
getMetaDataValue(String) - Method in interface org.axonframework.domain.Event
Returns the value registered in the meta data under the given key.
getMetaDataValue(String) - Method in class org.axonframework.domain.EventBase
Returns the value registered in the meta data under the given key.
getMethod() - Method in class org.axonframework.util.Handler
Returns the method found to be a handler.
getObject() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
getObject() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
getObject() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
getObjectType() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
getObjectType() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
getObjectType() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
getParameterType() - Method in class org.axonframework.util.Handler
Returns the main parameter of the handler.
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
 
getReceivedCommandCount() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
Returns the amount of received commands.
getReceivedEventsCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
Returns the amount of received events.
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.
getRetryInterval() - Method in class org.axonframework.eventhandling.TransactionStatus
Returns the current retry interval.
getRetryPolicy() - Method in class org.axonframework.eventhandling.TransactionStatus
Returns the retry policy for the current transaction
getSaga(SagaSerializer) - Method in class org.axonframework.saga.repository.jpa.SagaEntry
Returns the Saga instance stored in this entry.
getSagaCache() - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Returns the SagaCache used to prevent multiple instances of the same conceptual Saga (i.e. with same identifier) from being active in the JVM.
getSagaId() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
Returns the Identifier of the Saga stored 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.
getSagaRepository() - Method in class org.axonframework.saga.AbstractSagaManager
Returns the repository that provides access to Saga instances.
getScheduledTime() - Method in class org.axonframework.eventhandling.scheduling.ScheduledEvent
The time at which the event is to be published.
getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.FullConcurrencyPolicy
Returns the sequence identifier for the given event.
getSequenceIdentifierFor(T) - Method in interface org.axonframework.eventhandling.SequencingPolicy
Returns the sequence identifier for the given event.
getSequenceIdentifierFor(Event) - Method in class org.axonframework.eventhandling.SequentialPerAggregatePolicy
Returns the sequence identifier for the given event.
getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.SequentialPolicy
Returns the sequence identifier for the given event.
getSequenceNumber() - Method in class org.axonframework.domain.DomainEvent
Returns the sequence number of this event, if available.
getSource() - Method in class org.axonframework.domain.ApplicationEvent
Returns the instance that reported this event.
getSourceDescription() - Method in class org.axonframework.domain.ApplicationEvent
Returns the description of the instance that reported this event.
getSourceType() - Method in class org.axonframework.domain.ApplicationEvent
Returns the type of the instance that reported this event.
getSupportedRepresentation() - Method in interface org.axonframework.eventstore.EventUpcaster
Since Java's generics are erased, this method allows serializers to verify the supported event representation of this upcaster.
getSupportedRepresentation() - Method in class org.axonframework.eventstore.legacy.LegacyAxonEventUpcaster
 
getTarget() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
 
getTarget() - Method in class org.axonframework.eventhandling.AsynchronousEventHandlerWrapper
 
getTarget() - Method in interface org.axonframework.eventhandling.EventListenerProxy
Returns the instance that this proxy delegates all event handling to.
getTarget() - Method in class org.axonframework.util.AbstractHandlerInvoker
Returns the target on which handler methods are invoked.
getTargetType() - Method in class org.axonframework.util.AbstractHandlerInspector
Returns the targetType on which handler methods are invoked.
getTimestamp() - Method in interface org.axonframework.domain.Event
Returns the timestamp of this event.
getTimestamp() - Method in class org.axonframework.domain.EventBase
Returns the timestamp of this event.
getTimestamp() - Method in interface org.axonframework.domain.EventMetaData
Returns the time this event was created.
getTimestamp() - Method in class org.axonframework.domain.MutableEventMetaData
 
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.
getValue() - Method in class org.axonframework.saga.AssociationValue
Returns the value of this association.
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.eventhandling.UnsupportedHandlerMethodException
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.
getXStream() - Method in class org.axonframework.eventstore.XStreamEventSerializer
Returns a reference to the underlying XStream instance, that does the actual serialization.
getXStream() - Method in class org.axonframework.serializer.XStreamSerializer
Returns a reference to the underlying XStream instance, that does the actual serialization.
getYieldPolicy() - Method in class org.axonframework.eventhandling.TransactionStatus
Returns the YieldPolicy applicable to the current transaction.

H

handle(Object, UnitOfWork, InterceptorChain) - Method in class org.axonframework.auditing.AuditingInterceptor
 
handle(Object, UnitOfWork) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Invokes the @CommandHandler annotated method that accepts the given command.
handle(T, UnitOfWork) - Method in interface org.axonframework.commandhandling.CommandHandler
Handles the given command.
handle(Object, 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(Object, UnitOfWork, InterceptorChain) - Method in class org.axonframework.commandhandling.interceptors.BeanValidationInterceptor
 
handle(Object, UnitOfWork, InterceptorChain) - Method in class org.axonframework.commandhandling.interceptors.LoggingInterceptor
 
handle(Object, UnitOfWork, InterceptorChain) - Method in class org.axonframework.commandhandling.interceptors.TransactionInterceptor
 
handle(Event) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Process the given event.
handle(Event) - Method in class org.axonframework.eventhandling.AsynchronousEventHandlerWrapper
Handles the event by scheduling it for execution by the target event handler.
handle(Event) - Method in interface org.axonframework.eventhandling.EventListener
Process the given event.
handle(DomainEvent) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
Apply state changes based on the given event.
handle(DomainEvent) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Apply state changes based on the given event.
handle(DomainEvent) - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
Calls the appropriate EventHandler annotated handler with the provided event.
handle(DomainEvent) - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
Calls the appropriate EventHandler annotated handler with the provided event.
handle(Event) - Method in class org.axonframework.saga.AbstractSagaManager
 
handle(Event) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
 
handle(Event) - Method in interface org.axonframework.saga.Saga
Handle the given event.
handle(Event) - 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.
Handler - Class in org.axonframework.util
Represents a method recognized as a handler by the handler inspector (see AbstractHandlerInspector).
Handler(Method) - Constructor for class org.axonframework.util.Handler
Create a handler instance for the given method.
hasEqualsMethod(Class<?>) - Static method in class org.axonframework.util.ReflectionUtils
Indicates whether the given class implements a customized equals method.
hashCode() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
 
hashCode() - Method in class org.axonframework.domain.AbstractAggregateIdentifier

This implementation returns the hashCode of the string representation of the identifier.

hashCode() - Method in class org.axonframework.domain.DomainEvent
hashCode() - Method in class org.axonframework.domain.EventBase
hashCode() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
hashCode() - Method in class org.axonframework.saga.AssociationValue
 
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.
hasOptionalParameter() - Method in class org.axonframework.util.Handler
Indicates whether or not this handler has an optional second parameter.
HybridJpaRepository<T extends EventSourcedAggregateRoot> - 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>, LockingStrategy) - 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 lockingStrategy.
HybridJpaRepository(EntityManagerProvider, Class<T>, String, LockingStrategy) - 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 lockingStrategy.

I

IdentifierFactory - Class in org.axonframework.domain
Abstract Factory class that provides access to an IdentifierFactory implementation.
IdentifierFactory() - Constructor for class org.axonframework.domain.IdentifierFactory
 
IncompatibleAggregateException - Exception in org.axonframework.eventsourcing
Exception indicating that an aggregate was not compatible with the requirements of the GenericEventSourcingRepository.
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.AxonNamespaceHandler
initialize() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Initializes the QuartzEventScheduler.
initializeAdapterFor(Object) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
initializeAdapterFor(Object) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
Create an AnnotationEventListenerAdapter instance of the given bean.
initializeAdapterFor(Object) - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
Create an AnnotationEventListenerAdapter instance of the given bean.
initializeEventStream(long) - Method in class org.axonframework.domain.AbstractAggregateRoot
Initialize the event stream using the given sequence number of the last known 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.spring.SpringResourceInjector
 
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
 
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.commandhandling.callbacks.NoOpCallback
Deprecated.
A statically available instance of the NoOpCallback.
INSTANCE - Static variable in class org.axonframework.util.DirectExecutor
Returns a singleton instance of the DirectExecutor.
instantiateAggregate(AggregateIdentifier, DomainEvent) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Deprecated.
Explicit use of this method is deprecated. Instead of overriding this method, use theEventSourcingRepository.EventSourcingRepository(AggregateFactory) or EventSourcingRepository.EventSourcingRepository(AggregateFactory, org.axonframework.repository.LockingStrategy) constructor to indicate how an aggregate should be created.
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.
invoke(Object, Object, Object) - Method in class org.axonframework.util.Handler
Invokes the handler method on given target using given parameter and -when available on the handler- the given secondHandlerParameter.
invokeAfterTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventHandlerInvoker
Invoke the "AfterTransaction" method on the target.
invokeBeforeTransaction(TransactionStatus) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventHandlerInvoker
Invoke the "BeforeTransaction" method on the target.
invokeEventHandlerMethod(Event) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventHandlerInvoker
Invoke the event handler on the target for the given event.
invokeHandlerMethod(Object) - Method in class org.axonframework.util.AbstractHandlerInvoker
Invoke the handler demarcated with the given annotationClass on the target for the given event.
invokeHandlerMethod(Object, Object) - Method in class org.axonframework.util.AbstractHandlerInvoker
Invoke the handler demarcated with the given annotationClass on the target for the given event and an optional secondHandlerParameter.
isAccessible(AccessibleObject) - Static method in class org.axonframework.util.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.
isCancelled() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Always returns false, since command execution cannot be cancelled.
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.
isDone() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Indicates whether command handler execution has finished.
isDuplicateKeyViolation(Exception) - Method in interface org.axonframework.eventstore.jpa.PersistenceExceptionResolver
Indicates whether the given exception represents a duplicate key violation.
isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
 
isEmpty() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
isEmpty() - Method in class org.axonframework.saga.repository.AssociationValueMap
Indicates whether any elements are contained within this map.
isEmpty() - Method in class org.axonframework.saga.repository.SagaCache
Indicates whether or not this cache is empty.
isFalse(boolean, String) - Static method in class org.axonframework.util.Assert
Asserts that the given expression is false.
isNonFinalPublicMember(Member) - Static method in class org.axonframework.util.ReflectionUtils
Checks whether the given member is public and non-final.
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
 
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
 
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
Indicates whether an object of the given targetClass should be post processed.
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
 
isSingleton() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
isSingleton() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
isSingleton() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
isStarted() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
 
isStarted() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Indicates whether a unit of work has already been started.
isStarted() - Method in interface org.axonframework.unitofwork.UnitOfWork
Indicates whether this UnitOfWork is started.
isSuccessful() - Method in class org.axonframework.eventhandling.TransactionStatus
Indicates whether the current transactional batch is executed successfully.
isTransactionSizeReached() - Method in class org.axonframework.eventhandling.TransactionStatus
Indicates whether or not the maximum amount of events have been processed in this transaction.
isTrue(boolean, String) - Static method in class org.axonframework.util.Assert
Asserts that the given expression is true.
iterator() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 

J

JavaSagaSerializer - Class in org.axonframework.saga.repository
SagaSerializer implementation that uses Java serialization to serialize and deserialize Sagas.
JavaSagaSerializer() - Constructor for class org.axonframework.saga.repository.JavaSagaSerializer
 
JmxConfiguration - Class in org.axonframework.monitoring.jmx
Utility class that allows Axon-related components to be configured with an MBeanServer.
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 XStreamEventSerializer, which serializes events as XML and the default Event Entry store.
JpaEventStore(EntityManagerProvider, EventSerializer) - Constructor for class org.axonframework.eventstore.jpa.JpaEventStore
JpaEventStore(EntityManagerProvider, Serializer<? super DomainEvent>) - Constructor for class org.axonframework.eventstore.jpa.JpaEventStore
Initialize a JpaEventStore which serializes events using the given eventSerializer 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 XStreamEventSerializer, which serializes events as XML.
JpaEventStore(EntityManagerProvider, Serializer<? super DomainEvent>, 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
 
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 JavaSagaSerializer.
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
 
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(String, Set<ConstraintViolation<Object>>) - Constructor for exception org.axonframework.commandhandling.interceptors.JSR303ViolationException
Initializes an exception with the given message and violations.

K

keySet() - Method in interface org.axonframework.domain.EventMetaData
Returns a Set containing the keys registered in the event's meta data.
keySet() - Method in class org.axonframework.domain.MutableEventMetaData
 

L

LegacyAxonEventUpcaster - Class in org.axonframework.eventstore.legacy
Event preprocessor that upcasts events serialized by the XStreamEventSerializer in versions 0.6 and prior of AxonFramework, to the event format supported since 0.7.
LegacyAxonEventUpcaster() - Constructor for class org.axonframework.eventstore.legacy.LegacyAxonEventUpcaster
 
LegacyEventSerializerWrapper - Class in org.axonframework.eventstore.legacy
Deprecated.
Do not use.
LegacyEventSerializerWrapper(EventSerializer) - Constructor for class org.axonframework.eventstore.legacy.LegacyEventSerializerWrapper
Deprecated.
Initialize a wrapper for the given eventSerializer.
load(AggregateIdentifier, 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(AggregateIdentifier) - Method in class org.axonframework.repository.AbstractRepository
Load the aggregate with the given unique identifier.
load(AggregateIdentifier, 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(AggregateIdentifier, 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(AggregateIdentifier) - Method in interface org.axonframework.repository.Repository
Load the aggregate with the given unique identifier.
load(Class<T>, String) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
 
load(Class<T>, String) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
 
load(Class<T>, String) - Method in interface org.axonframework.saga.SagaRepository
Loads a known Saga instance by its unique identifier.
loadLastSnapshotEvent(String, AggregateIdentifier, 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.
loadSaga(Class<T>, String) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Loads a known Saga instance by its unique identifier.
loadSaga(Class<T>, String) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
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() - Constructor for class org.axonframework.repository.LockingRepository
Initialize a repository with a pessimistic locking strategy.
LockingRepository(LockingStrategy) - Constructor for class org.axonframework.repository.LockingRepository
Initialize the repository with the given lockingStrategy.
LockingStrategy - Enum in org.axonframework.repository
Enum indicating possible locking strategies for repositories.
logFailed(Object, Throwable, List<Event>) - Method in interface org.axonframework.auditing.AuditLogger
Writes a failure entry to the audit logs.
logFailed(Object, Throwable, List<Event>) - Method in class org.axonframework.auditing.NullAuditLogger
Writes a failure entry to the audit logs.
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(Object, Object, List<Event>) - Method in interface org.axonframework.auditing.AuditLogger
Writes a success entry to the audit logs.
logSuccessful(Object, Object, List<Event>) - Method in class org.axonframework.auditing.NullAuditLogger
Writes a success entry to the audit logs.

M

markDeleted() - Method in class org.axonframework.domain.AbstractAggregateRoot
Marks this aggregate as deleted, instructing a Repository to remove that aggregate at an appropriate time.
markFailed(Throwable) - Method in class org.axonframework.eventhandling.TransactionStatus
Mark the current transaction as failed.
marshal(Object, HierarchicalStreamWriter, MarshallingContext) - Method in class org.axonframework.serializer.AggregateIdentifierConverter
 
MemberAccessibilityCallback - Class in org.axonframework.util
PrivilegedAction that makes the given method accessible for reflection.
MemberAccessibilityCallback(AccessibleObject) - Constructor for class org.axonframework.util.MemberAccessibilityCallback
Initialize the callback to make the given method accessible for reflection.
methodsOf(Class<?>) - Static method in class org.axonframework.util.ReflectionUtils
Returns an Iterable of all the methods declared on the given class and its super classes.
MutableEventMetaData - Class in org.axonframework.domain
Implementation of EventMetaData that allows values to be set, as well as read.
MutableEventMetaData(DateTime, String) - Constructor for class org.axonframework.domain.MutableEventMetaData
Create a meta-data instance with the given timestamp and eventIdentifier as initial values.
MutableEventMetaData(DateTime, UUID) - Constructor for class org.axonframework.domain.MutableEventMetaData
Deprecated.
Hard-coded dependency on UUID type is deprecated for performance reasons. Use MutableEventMetaData.MutableEventMetaData(org.joda.time.DateTime, String) instead.

N

newProcessingScheduler(EventProcessingScheduler.ShutdownCallback) - Method in class org.axonframework.eventhandling.AsynchronousExecutionWrapper
Creates a new scheduler instance that schedules tasks on the executor service for the managed EventListener.
newProcessingScheduler(EventProcessingScheduler.ShutdownCallback, Queue<T>) - Method in class org.axonframework.eventhandling.AsynchronousExecutionWrapper
Creates a new scheduler instance schedules tasks on the executor service for the managed EventListener.
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.
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.
NoOpCallback - Class in org.axonframework.commandhandling.callbacks
Deprecated.
Use the CommandBus.dispatch(Object) method instead to indicate that no callback action is required..
NoOpCallback() - Constructor for class org.axonframework.commandhandling.callbacks.NoOpCallback
Deprecated.
 
NoSuchSagaException - Exception in org.axonframework.saga
Exception indicating that the specified Saga could not be found.
NoSuchSagaException(Class<?>, String) - Constructor for exception org.axonframework.saga.NoSuchSagaException
Initializes a NoSuchSagaException, indicating that a saga of given type and sagaIdentifier could not be found.
notifyListenersAfterCommit() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
Send a UnitOfWorkListener.afterCommit() notification to all registered listeners.
notifyListenersCleanup() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
Send a UnitOfWorkListener.onCleanup() notification to all registered listeners.
notifyListenersCleanup() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
notifyListenersPrepareCommit() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
Send a UnitOfWorkListener.onPrepareCommit(java.util.Set, java.util.List) notification to all registered listeners.
notifyListenersPrepareCommit() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
notifyListenersRollback(Throwable) - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
Send a UnitOfWorkListener.onRollback(Throwable) notification to all registered listeners.
notifyListenersRollback(Throwable) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
notNull(Object, String) - Static method in class org.axonframework.util.Assert
Assert that the given value is not null.
NoTransactionManager - Class in org.axonframework.eventhandling
TransactionManager implementation that does nothing.
NoTransactionManager() - Constructor for class org.axonframework.eventhandling.NoTransactionManager
 
NullAuditLogger - Class in org.axonframework.auditing
An implementation of AuditLogger that does nothing.
NullAuditLogger() - Constructor for class org.axonframework.auditing.NullAuditLogger
 

O

onAssociationValueAdded(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues.ChangeListener
Invoked when an AssociationValue has been added to the collection.
onAssociationValueRemoved(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues.ChangeListener
Invoked when an AssociationValue is removed from the collection.
onCleanup() - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
 
onCleanup() - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Notifies listeners that the UnitOfWork is being cleaned up.
onCleanup() - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Notifies listeners that the UnitOfWork is being cleaned up.
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.
onFailure(Throwable) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
 
onFailure(Throwable) - Method in class org.axonframework.commandhandling.callbacks.NoOpCallback
Deprecated.
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.
onNoMethodFound(Class<?>) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
 
onNoMethodFound(Class<?>) - Method in class org.axonframework.util.AbstractHandlerInvoker
Indicates what needs to happen when no handler is found for a given parameter.
onPrepareCommit(Set<AggregateRoot>, List<Event>) - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
 
onPrepareCommit(Set<AggregateRoot>, List<Event>) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked before aggregates are committed, and before any events are published.
onPrepareCommit(Set<AggregateRoot>, List<Event>) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Invoked before aggregates are committed, and before any events are published.
onRollback(Throwable) - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
 
onRollback(Throwable) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
Invoked when the UnitOfWork is rolled back.
onRollback(Throwable) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
Invoked when the UnitOfWork is rolled back.
onSuccess(R) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
 
onSuccess(Object) - Method in class org.axonframework.commandhandling.callbacks.NoOpCallback
Deprecated.
Invoked when command handling execution was successful.
onSuccess(Class<Void>) - 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.
openEventFileForReading(String, AggregateIdentifier) - 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, AggregateIdentifier) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
openEventFileForWriting(String, AggregateIdentifier) - 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, AggregateIdentifier) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
openSnapshotFileForReading(String, AggregateIdentifier) - 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, AggregateIdentifier) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
openSnapshotFileForWriting(String, AggregateIdentifier) - 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, AggregateIdentifier) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
 
org.axonframework.auditing - package org.axonframework.auditing
 
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.interceptors - package org.axonframework.commandhandling.interceptors
Contains some useful implementations of interceptors that many application can benefit from.
org.axonframework.commandhandling.template - package org.axonframework.commandhandling.template
 
org.axonframework.contextsupport.spring - package org.axonframework.contextsupport.spring
 
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.annotation - package org.axonframework.eventhandling.annotation
Classes in support of the configuration of Event Handlers using annotations.
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.eventhandling.transactionmanagers - package org.axonframework.eventhandling.transactionmanagers
 
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.jpa - package org.axonframework.eventstore.jpa
JPA Implementation of the EventStore.
org.axonframework.eventstore.legacy - package org.axonframework.eventstore.legacy
 
org.axonframework.monitoring.jmx - package org.axonframework.monitoring.jmx
 
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.jpa - package org.axonframework.saga.repository.jpa
 
org.axonframework.saga.spring - package org.axonframework.saga.spring
 
org.axonframework.serializer - package org.axonframework.serializer
 
org.axonframework.unitofwork - package org.axonframework.unitofwork
Classes in support of the UnitOfWork pattern in Axon Framework.
org.axonframework.util - package org.axonframework.util
Generic utility classes used throughout the Axon Framework.
org.axonframework.util.io - package org.axonframework.util.io
 
org.axonframework.util.jpa - package org.axonframework.util.jpa
 

P

parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.AggregateCommandHandlerBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
parseInternal(Element, ParserContext) - Method in class org.axonframework.contextsupport.spring.EventBusBeanDefinitionParser
 
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
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.
performPostLoadInitialization() - Method in class org.axonframework.domain.AbstractAggregateRoot
JPA / EJB3 @PostLoad annotated method used to initialize the fields in this class after an instance has been loaded from persistent storage.
PersistenceExceptionResolver - Interface in org.axonframework.eventstore.jpa
The PersistenceExceptionResolver is used to find out if an exception is caused by duplicate keys.
persistEvent(String, DomainEvent, byte[], 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, DomainEvent, byte[], 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.
postProcessAfterInitialization(Object, String) - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
postProcessBeforeDestruction(Object, String) - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
postProcessBeforeInitialization(Object, String) - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
proceed(Object) - 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(Object) - Method in interface org.axonframework.commandhandling.InterceptorChain
Signals the Interceptor Chain to continue processing the given command.
provideAuditDataFor(Object) - Method in interface org.axonframework.auditing.AuditDataProvider
Return the relevant auditing information for the given command.
provideAuditDataFor(Object) - Method in class org.axonframework.auditing.EmptyDataProvider
Return the relevant auditing information for the given command.
pruneSnapshots(String, DomainEvent, 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(Event) - Method in interface org.axonframework.eventhandling.Cluster
Publishes the given Event to the members of this cluster.
publish(Event) - Method in class org.axonframework.eventhandling.ClusteringEventBus
 
publish(Event) - Method in interface org.axonframework.eventhandling.EventBus
Publish an event on this bus.
publish(Event) - Method in interface org.axonframework.eventhandling.EventBusTerminal
Publishes the given event to all clusters on the Event Bus.
publish(Event) - Method in class org.axonframework.eventhandling.SimpleCluster
 
publish(Event) - Method in class org.axonframework.eventhandling.SimpleEventBus
Publish an event on this bus.
publishEvent(Event, EventBus) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
publishEvent(Event, 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.
purge() - Method in class org.axonframework.saga.repository.SagaCache
Clears any entries whose saga instances have been cleaned up by the garbage collector.
purgeCache() - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Remove all elements from the cache pointing to Saga instances that have been garbage collected.
put(String, Serializable) - Method in class org.axonframework.domain.MutableEventMetaData
Put a key-value pair in the meta data.
put(Saga) - Method in class org.axonframework.saga.repository.SagaCache
Puts the given saga in this cache, if no saga with the same identifier already exists.

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
 
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
 

R

readBytes() - Method in class org.axonframework.util.io.BinaryEntryInputStream
Reads the next entry as a byte array.
readDocument(byte[]) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Reads the given serializedEvent into a Dom4J document.
readDocument(InputStream) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Reads the event from the given stream into a Dom4J document.
readEvents(String, AggregateIdentifier) - 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, AggregateIdentifier) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
Read the events of the aggregate identified by the given type and identifier that allow the current aggregate state to be rebuilt.
readEvents(String, AggregateIdentifier) - 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.
readNumber() - Method in class org.axonframework.util.io.BinaryEntryInputStream
Reads the next entry as a number (long).
readString() - Method in class org.axonframework.util.io.BinaryEntryInputStream
Reads the next entry as a String value.
recordEventProcessed() - Method in class org.axonframework.eventhandling.TransactionStatus
Record the fact that an event has been processed.
ReflectionUtils - Class in org.axonframework.util
Utility class for working with Java Reflection API.
registerAggregate(T, SaveAggregateCallback<T>) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
registerAggregate(T, SaveAggregateCallback<T>) - Method in interface org.axonframework.unitofwork.UnitOfWork
Register an aggregate with this UnitOfWork.
registerAggregateRoot(AbstractEventSourcedAggregateRoot) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
Register the aggregate root with this entity.
registerEvent(DomainEvent) - Method in class org.axonframework.domain.AbstractAggregateRoot
Registers an event to be published when the aggregate is saved.
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.
registerMBean(Object, Class<?>) - Method in class org.axonframework.monitoring.jmx.JmxConfiguration
Attempts to register the given mBean as an MBean with the default MBeanServer.
remove(Object) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
remove(AssociationValue, String) - Method in class org.axonframework.saga.repository.AssociationValueMap
Removes an association between the given associationValue and sagaIdentifier.
removeAll(Collection<?>) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
removeAssociationValue(AssociationValue, 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) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
removeAssociationWith(AssociationValue) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Removes the given association from this Saga.
removeAssociationWith(String, Object) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
Removes the given association from this Saga.
removeChangeListener(AssociationValues.ChangeListener) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
removeChangeListener(AssociationValues.ChangeListener) - Method in interface org.axonframework.saga.AssociationValues
Removes the registered changeListener.
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
 
Repository<T extends AggregateRoot> - 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
 
requestImmediateCommit() - Method in class org.axonframework.eventhandling.TransactionStatus
Requests the EventProcessingScheduler to commit the transaction immediately.
requestImmediateYield() - Method in class org.axonframework.eventhandling.TransactionStatus
Forces the EventProcessingScheduler to immediately yield to other schedulers after processing this event.
resetReceivedCommandsCounter() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
Reset the amount of commands received counter.
resetReceivedEventsCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
resets the amount of events received.
resetTransactionStatus() - Method in class org.axonframework.eventhandling.TransactionStatus
Resets the event count for current transaction to 0 and sets the YieldPolicy to the default value (YIELD_AFTER_TRANSACTION).
resolveConflicts(List<DomainEvent>, List<DomainEvent>) - Method in interface org.axonframework.eventsourcing.ConflictResolver
Checks the given list of appliedChanges and committedChanges for any conflicting changes.
resolveConflicts(List<DomainEvent>, List<DomainEvent>) - Method in class org.axonframework.eventsourcing.conflictresolvers.AcceptAllConflictResolver
Checks the given list of appliedChanges and committedChanges for any conflicting changes.
resolveTarget(Object) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandTargetResolver
 
resolveTarget(Object) - 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.
ResourceInjector - Interface in org.axonframework.saga
Interface describing a mechanism to inject resources into Saga instances.
retainAll(Collection<?>) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
RetryPolicy - Enum in org.axonframework.eventhandling
This policy tells the EventProcessingScheduler how it should deal with failed transactions.
rollback() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
 
rollback(Throwable) - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
 
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(TransactionStatus) - Method in class org.axonframework.commandhandling.interceptors.SpringTransactionalInterceptor
 
rollbackTransaction(T) - Method in class org.axonframework.commandhandling.interceptors.TransactionInterceptor
Rolls back a transaction for a command execution described by the given context.
run() - Method in class org.axonframework.eventhandling.EventProcessingScheduler
run() - Method in class org.axonframework.util.FieldAccessibilityCallback
 
run() - Method in class org.axonframework.util.MemberAccessibilityCallback

S

Saga - Interface in org.axonframework.saga
Interface describing an implementation of a Saga.
SagaCache - Class in org.axonframework.saga.repository
Wrapper around a map of String to Saga that keeps Weak References to the saga instances.
SagaCache() - Constructor for class org.axonframework.saga.repository.SagaCache
Initializes an empty cache.
SagaEntry - Class in org.axonframework.saga.repository.jpa
Java Persistence Entity allowing sagas to be stored in a relational database.
SagaEntry(Saga, SagaSerializer) - 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.
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.
SagaHandlerExecutor - Interface in org.axonframework.saga
Interface describing the tasks needed to handle events by sagas.
SagaManager - Interface in org.axonframework.saga
Interface toward the Manager of one or more types of Saga.
SagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
BeanDefinitionParser that parses saga-manager elements in the application context.
SagaManagerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser
 
SagaRepository - Interface in org.axonframework.saga
Interface towards the storage mechanism of Saga instances.
SagaSerializer - Interface in org.axonframework.saga.repository
Interface towards a serialization mechanism for Saga instances.
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.AbstractUnitOfWork
Saves all registered aggregates by calling their respective callbacks.
saveAggregates() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
 
schedule(T) - Method in class org.axonframework.eventhandling.AsynchronousExecutionWrapper
Schedules this task for execution when all pre-conditions have been met.
schedule(DateTime, ApplicationEvent) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Schedule the given event for publication at the given triggerDateTime.
schedule(Duration, ApplicationEvent) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Schedule the given event for publication after the given triggerDuration.
schedule(ScheduledEvent) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Schedules the given event for publication.
schedule(DateTime, ApplicationEvent) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
schedule(Duration, ApplicationEvent) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
schedule(ScheduledEvent) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
schedule(DateTime, ApplicationEvent) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
schedule(Duration, ApplicationEvent) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
schedule(ScheduledEvent) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
ScheduledEvent - Class in org.axonframework.eventhandling.scheduling
Abstract implementation of the ApplicationEvent that contains the timestamp of the moment the event is scheduled for publication.
ScheduledEvent(Object, Duration) - Constructor for class org.axonframework.eventhandling.scheduling.ScheduledEvent
Initializes a new scheduled event, scheduled for publication after a given duration.
ScheduledEvent(Object, DateTime) - Constructor for class org.axonframework.eventhandling.scheduling.ScheduledEvent
Initializes a new scheduled event, scheduled for publication at the given timestamp.
ScheduledEvent(String, DateTime, long, String, DateTime) - Constructor for class org.axonframework.eventhandling.scheduling.ScheduledEvent
Initializes the event using given parameters.
scheduleEvent(T) - Method in class org.axonframework.eventhandling.EventProcessingScheduler
Schedules an event for processing.
scheduleEventProcessingTask(Saga, Runnable) - Method in class org.axonframework.saga.AsynchronousSagaExecutor
 
scheduleEventProcessingTask(Saga, Runnable) - Method in interface org.axonframework.saga.SagaHandlerExecutor
Schedules the given task for execution.
scheduleEventProcessingTask(Saga, Runnable) - Method in class org.axonframework.saga.SynchronousSagaExecutionWrapper
 
scheduleLookupTask(Runnable) - Method in class org.axonframework.saga.AsynchronousSagaExecutor
 
scheduleLookupTask(Runnable) - Method in interface org.axonframework.saga.SagaHandlerExecutor
Schedules the given task for execution.
scheduleLookupTask(Runnable) - Method in class org.axonframework.saga.SynchronousSagaExecutionWrapper
 
scheduleSnapshot(String, AggregateIdentifier) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
 
scheduleSnapshot(String, AggregateIdentifier) - Method in interface org.axonframework.eventsourcing.Snapshotter
Schedules snapshot taking for an aggregate with given typeIdentifier and aggregateIdentifier.
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.
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.DefaultClusterSelector
Selects the cluster instance that the given eventListener should be member of.
send(Object) - Method in class org.axonframework.commandhandling.template.CommandTemplate
Sends the given command and returns a Future instance that allows the caller to retrieve the result at an appropriate time.
sendAndWait(Object) - Method in class org.axonframework.commandhandling.template.CommandTemplate
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.template.CommandTemplate
Sends the given command and waits for its execution to complete, until the given timeout has expired, or the waiting thread is interrupted.
SequencingPolicy<T> - Interface in org.axonframework.eventhandling
Interface to a policy definition for concurrent processing, for example event handling.
SequentialPerAggregatePolicy - Class in org.axonframework.eventhandling
Concurrency policy that requires sequential processing of events raised by the same aggregate.
SequentialPerAggregatePolicy() - Constructor for class org.axonframework.eventhandling.SequentialPerAggregatePolicy
 
SequentialPolicy - Class in org.axonframework.eventhandling
SequencingPolicy that requires serialized handling of all events delivered to an event handler.
SequentialPolicy() - Constructor for class org.axonframework.eventhandling.SequentialPolicy
 
SerializationException - Exception in org.axonframework.util
Indicates that an exception occurred while serializing or deserializing an object.
SerializationException(String) - Constructor for exception org.axonframework.util.SerializationException
Initializes the exception using the given message.
SerializationException(String, Throwable) - Constructor for exception org.axonframework.util.SerializationException
Initializes the exception using the given message and cause.
serialize(DomainEvent) - Method in interface org.axonframework.eventstore.EventSerializer
Deprecated.
Serialize the given events into a byte[].
serialize(DomainEvent, OutputStream) - Method in class org.axonframework.eventstore.legacy.LegacyEventSerializerWrapper
Deprecated.
 
serialize(DomainEvent) - Method in class org.axonframework.eventstore.legacy.LegacyEventSerializerWrapper
Deprecated.
 
serialize(Event) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Serialize the given object into a byte[].
serialize(Event, OutputStream) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Serializes the given object to the given outputStream.
serialize(Saga) - Method in class org.axonframework.saga.repository.JavaSagaSerializer
 
serialize(Saga) - Method in interface org.axonframework.saga.repository.SagaSerializer
Serialize the given saga to a byte array.
serialize(Saga) - Method in class org.axonframework.saga.repository.XStreamSagaSerializer
 
serialize(T, OutputStream) - Method in interface org.axonframework.serializer.Serializer
Serializes the given object to the given outputStream.
serialize(T) - Method in interface org.axonframework.serializer.Serializer
Serialize the given object into a byte[].
serialize(Object, OutputStream) - Method in class org.axonframework.serializer.XStreamSerializer
Serialize the given object to Compact XML (see CompactWriter) and write the bytes to the given outputStream.
serialize(Object, HierarchicalStreamWriter) - Method in class org.axonframework.serializer.XStreamSerializer
Serialize the given object and write the bytes to the given writer.
serialize(Object) - Method in class org.axonframework.serializer.XStreamSerializer
Serialize the given object into a byte[].
serializeAssociationValue(Object) - Method in class org.axonframework.saga.repository.JavaSagaSerializer
 
serializeAssociationValue(Object) - Method in interface org.axonframework.saga.repository.SagaSerializer
Serializes the given associationValue.
serializeAssociationValue(Object) - Method in class org.axonframework.saga.repository.XStreamSagaSerializer
 
Serializer<T> - Interface in org.axonframework.serializer
Interface describing a serialization mechanism.
set(TransactionStatus) - Static method in class org.axonframework.eventhandling.TransactionStatus
Sets the TransactionStatus object related to the transaction running in the current thread.
set(UnitOfWork) - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
Binds the given unitOfWork to the current thread.
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.
setApplicationContext(ApplicationContext) - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
 
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.eventsourcing.SpringPrototypeEventSourcingRepository
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.saga.spring.SpringResourceInjector
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.util.AbstractAnnotationHandlerBeanPostProcessor
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.
setBaseDir(File) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
Sets the base directory where the event store will store all events.
setBatchSize(int) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Sets the number of events that should be read at each database access.
setBeanName(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
 
setBeanName(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeEventSourcingRepository
 
setCache(Cache) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
Set the cache to use for this repository.
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.
setCommandBus(CommandBus) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
Sets the event bus to which detected event listeners should be subscribed.
setConflictResolver(ConflictResolver) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Sets the conflict resolver to use for this repository.
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.
setEntityManager(EntityManager) - Method in class org.axonframework.util.jpa.ContainerManagedEntityManagerProvider
Sets the container managed entityManager to use.
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.
setEventFileResolver(EventFileResolver) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
Sets the event file resolver to use.
setEventRevision(long) - Method in class org.axonframework.domain.EventBase
Deprecated.
Set event revision in the constructor instead
setEventsToAlwaysCreateNewSagasFor(List<Class<? extends Event>>) - 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<? extends Event>>) - 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.EventSourcingRepository
Sets the event store that would physically store the events.
setEventStore(EventStore) - Method in class org.axonframework.eventsourcing.HybridJpaRepository
The event store to which events are appended.
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.
setEventTriggerCallback(EventTriggerCallback) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the callback to invoke before and after publication of a scheduled event.
setEventUpcasters(List<EventUpcaster<Document>>) - Method in class org.axonframework.eventstore.XStreamEventSerializer
Sets the event upcasters the serializer may use.
setExecutor(Executor) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
Sets the Executor to use when the AnnotationEventListenerBeanPostProcessor encounters event listeners with the AsynchronousEventListener annotation.
setExecutor(Executor) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Sets the executor that should process actual snapshot taking.
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.
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.
setInterceptors(List<? extends CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Registers the given list of interceptors to the command bus.
setMaxSnapshotsArchived(int) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Sets the maximum number of snapshots to archive for an aggregate.
setMaxTransactionSize(int) - Method in class org.axonframework.eventhandling.TransactionStatus
Sets the maximum number of events to process inside the current transaction.
setPersistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
Sets the persistenceExceptionResolver that will help detect concurrency exceptions from the backing database.
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.
setPrototypeBeanName(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeEventSourcingRepository
Sets the name of the prototype bean this repository serves.
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.jpa.JpaSagaRepository
Sets the ResourceInjector to use to inject Saga instances with any (temporary) resources they might need.
setRetryInterval(long) - Method in class org.axonframework.eventhandling.TransactionStatus
Sets the retry interval for the current transaction. his is the number of milliseconds processing should wait before retrying this transaction.
setRetryPolicy(RetryPolicy) - Method in class org.axonframework.eventhandling.TransactionStatus
Sets the retry policy for the current transaction.
setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Sets the RollbackConfiguration that allows you to change when the UnitOfWork is committed.
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.
setSerializer(SagaSerializer) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
Sets the SagaSerializer instance to serialize Sagas with.
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.eventsourcing.EventSourcingRepository
Sets the snapshotter trigger for this repository.
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.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.commandhandling.interceptors.SpringTransactionalInterceptor
Sets the definition of the transaction to use.
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.eventhandling.scheduling.SpringTransactionalTriggerCallback
Sets the TransactionDefinition to use when starting a transaction.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
Optionally sets the transaction definition to use.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.commandhandling.interceptors.SpringTransactionalInterceptor
Sets the transactionManager to use to manage transactions.
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(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.eventhandling.scheduling.SpringTransactionalTriggerCallback
Sets the PlatformTransactionManager that this callback uses to start and stop a transaction.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventhandling.transactionmanagers.SpringTransactionManager
The PlatformTransactionManager that manages the transactions with the underlying data source.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
Sets the transaction manager to manager underlying transaction with.
setTrigger(int) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
Sets the number of events that will trigger the creation of a snapshot events.
setTypeIdentifier(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
Sets the type identifier of the aggregate served by this repository.
setTypeIdentifier(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeEventSourcingRepository
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.
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.
setYieldPolicy(YieldPolicy) - Method in class org.axonframework.eventhandling.TransactionStatus
Sets the YieldPolicy for the current transaction.
shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
 
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() - Constructor for class org.axonframework.eventhandling.SimpleCluster
 
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 and registers the mbeans for management information.
SimpleCommandBus(boolean) - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
Initiates the SimpleCommandBus and makes the registration of mbeans for management information optional.
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
 
SimpleCommandBusStatisticsMXBean - Interface in org.axonframework.commandhandling
Management interface for the SimpleCommandBus monitor

As required by the JMX specification.

SimpleDomainEventStream - Class in org.axonframework.domain
Creates a DomainEventStream that streams the contents of a list.
SimpleDomainEventStream(Collection<? extends DomainEvent>) - Constructor for class org.axonframework.domain.SimpleDomainEventStream
Initialize the event stream using the given List of DomainEvent and aggregate identifier.
SimpleDomainEventStream(DomainEvent...) - Constructor for class org.axonframework.domain.SimpleDomainEventStream
Initialize the event stream using the given DomainEvents and aggregate identifier.
SimpleEntityManagerProvider - Class in org.axonframework.util.jpa
Simple implementation of the EntityManagerProvider that returns the EntityManager instance provided at construction time.
SimpleEntityManagerProvider(EntityManager) - Constructor for class org.axonframework.util.jpa.SimpleEntityManagerProvider
Initializes the SimpleEntityManagerProvider to return the given entityManager each time SimpleEntityManagerProvider.getEntityManager() is called.
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.
SimpleEventBus(boolean) - Constructor for class org.axonframework.eventhandling.SimpleEventBus
Initiates the SimpleEventBus and makes the registration of mbeans for management information optional.
SimpleEventBusStatisticsMXBean - Interface in org.axonframework.eventhandling
Management interface the SimpleEventBus monitor.
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, EventTriggerCallback) - 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
 
SimpleSagaManager - Class in org.axonframework.saga
Simple SagaManager implementation.
SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, SagaFactory, EventBus) - Constructor for class org.axonframework.saga.SimpleSagaManager
Initialize a SimpleSagaManager backed by the given resources.
SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, EventBus) - 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, EventBus, Executor, TransactionManager) - Constructor for class org.axonframework.saga.SimpleSagaManager
Initialize the AnnotatedSagaManager using the given resources.
size() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
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.
size() - Method in class org.axonframework.saga.repository.SagaCache
Returns an approximation of the number of items in the cache.
SnapshotEventStore - Interface in org.axonframework.eventstore
Interface describing an event store that is able to store snapshot events.
snapshotFileExists(String, AggregateIdentifier) - 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, AggregateIdentifier) - 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
 
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
 
SpringPrototypeEventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
Repository implementation that creates and initializes aggregates based on a Spring prototype bean.
SpringPrototypeEventSourcingRepository() - Constructor for class org.axonframework.eventsourcing.SpringPrototypeEventSourcingRepository
Deprecated.
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
 
SpringTransactionalInterceptor - Class in org.axonframework.commandhandling.interceptors
A CommandHandlerInterceptor that uses a PlatformTransactionManager to manage transactions around command handling.
SpringTransactionalInterceptor() - Constructor for class org.axonframework.commandhandling.interceptors.SpringTransactionalInterceptor
 
SpringTransactionalTriggerCallback - Class in org.axonframework.eventhandling.scheduling
EventTriggerCallback implementation that starts a Spring-managed transaction prior to sending an event, and commits or rollbacks the transaction after publication success or failure, respectively.
SpringTransactionalTriggerCallback() - Constructor for class org.axonframework.eventhandling.scheduling.SpringTransactionalTriggerCallback
 
SpringTransactionManager - Class in org.axonframework.eventhandling.transactionmanagers
TransactionManager implementation that uses a PlatformTransactionManager as underlying transaction manager.
SpringTransactionManager() - Constructor for class org.axonframework.eventhandling.transactionmanagers.SpringTransactionManager
 
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.
start() - Method in class org.axonframework.unitofwork.AbstractUnitOfWork
 
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.
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.commandhandling.interceptors.SpringTransactionalInterceptor
 
startTransaction() - Method in class org.axonframework.commandhandling.interceptors.TransactionInterceptor
Start a new transaction for a command execution described by the given context.
state(boolean, String) - Static method in class org.axonframework.util.Assert
Asserts that the value of state is true.
storeAssociationValue(AssociationValue, String) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
Store the given associationValue, which has been associated with given sagaIdentifier.
storeAssociationValue(AssociationValue, String) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
 
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.jpa.JpaSagaRepository
 
StringAggregateIdentifier - Class in org.axonframework.domain
Aggregate identifier implementation that requires a String as the actual backing identifier value.
StringAggregateIdentifier(String) - Constructor for class org.axonframework.domain.StringAggregateIdentifier
Creates a String based AggregateIdentifier instance backed with the given identifier.
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.
Subscribable - Interface in org.axonframework.util
Interface describing components that are able to subscribe themselves to a component that can be subscribed to, such as the CommandBus and EventBus.
subscribe() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
 
subscribe() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Subscribe the command handlers to the command bus assigned during the initialization.
subscribe(Class<C>, CommandHandler<? super C>) - Method in interface org.axonframework.commandhandling.CommandBus
Subscribe the given handler to commands of type commandType.
subscribe(Class<T>, CommandHandler<? super T>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Subscribe the given handler to commands of type commandType.
subscribe(EventListener) - Method in class org.axonframework.eventhandling.AbstractCluster
 
subscribe() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Subscribe the EventListener with the configured EventBus.
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.SimpleEventBus
Subscribe the given eventListener to this bus.
subscribe() - Method in class org.axonframework.saga.AbstractSagaManager
Subscribe the EventListener with the configured EventBus.
subscribe() - Method in interface org.axonframework.util.Subscribable
Subscribe this instance with its configured component.
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.
SynchronousSagaExecutionWrapper - Class in org.axonframework.saga
Execution wrapper that executes saga related tasks (lookup and invocation) in the thread that schedules these tasks.
SynchronousSagaExecutionWrapper() - Constructor for class org.axonframework.saga.SynchronousSagaExecutionWrapper
 
SystemEvent - Class in org.axonframework.domain
System events are a special type of application event.
SystemEvent(Object) - Constructor for class org.axonframework.domain.SystemEvent
Initialize a system event with the given source, and without an explicit cause.
SystemEvent(Object, Throwable) - Constructor for class org.axonframework.domain.SystemEvent
Initialize a system event with the given source and cause.
SystemEvent(String, DateTime, long, String, Throwable) - Constructor for class org.axonframework.domain.SystemEvent
Initializes the event using given parameters.
SystemEvent(String, DateTime, long, String) - Constructor for class org.axonframework.domain.SystemEvent
Initializes the event using given parameters.

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.
toArray() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
toArray(T[]) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
 
toString() - Method in class org.axonframework.domain.AbstractAggregateIdentifier

This implementation returns the result of AggregateIdentifier.asString().

TransactionInterceptor<T> - Class in org.axonframework.commandhandling.interceptors
Abstract implementation of a CommandHandlerInterceptor that starts a transaction and binds a UnitOfWork to the current thread.
TransactionInterceptor() - Constructor for class org.axonframework.commandhandling.interceptors.TransactionInterceptor
 
TransactionManager - Annotation Type in org.axonframework.eventhandling.annotation
Annotation that demarcates a field to use as the transaction manager for an EventListener.
TransactionManager - Interface in org.axonframework.eventhandling
org.axonframework.eventhandling.EventListener} interface that provides implementations the ability to do work at the start and end of a transaction.
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.
TransactionStatus - Class in org.axonframework.eventhandling
Provides details about the current status of an event handling transaction.
TransactionStatus() - Constructor for class org.axonframework.eventhandling.TransactionStatus
Initialize a TransactionStatus instance with default settings.
TRIGGER_CALLBACK_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the optional EventTriggerCallback in the scheduler context.

U

UnitOfWork - Interface in org.axonframework.unitofwork
This class represents a UnitOfWork in which modifications are made to aggregates.
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
 
unmarshal(HierarchicalStreamReader, UnmarshallingContext) - Method in class org.axonframework.serializer.AggregateIdentifierConverter
 
unsubscribe() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
 
unsubscribe() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
Unsubscribe the command handlers from the command bus assigned during the initialization.
unsubscribe(Class<C>, CommandHandler<? super C>) - Method in interface org.axonframework.commandhandling.CommandBus
Unsubscribe the given handler to commands of type commandType.
unsubscribe(Class<T>, CommandHandler<? super T>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Unsubscribe the given handler to commands of type commandType.
unsubscribe(EventListener) - Method in class org.axonframework.eventhandling.AbstractCluster
 
unsubscribe() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
Unsubscribe the EventListener with the configured EventBus.
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.SimpleEventBus
Unsubscribe the given eventListener to this bus.
unsubscribe() - Method in class org.axonframework.saga.AbstractSagaManager
Unsubscribe the EventListener with the configured EventBus.
unsubscribe() - Method in interface org.axonframework.util.Subscribable
Unsubscribe this instance from its subscribed component.
UnsupportedHandlerMethodException - Exception in org.axonframework.eventhandling
Thrown when an EventHandler annotated method was found that does not conform to the rules that apply to those methods.
UnsupportedHandlerMethodException(String, Method) - Constructor for exception org.axonframework.eventhandling.UnsupportedHandlerMethodException
Initialize the exception with a message and the violatingMethod.
UnsupportedPolicyException - Exception in org.axonframework.eventhandling.annotation
Exception indicating that a given SequencingPolicy could not be initialized.
UnsupportedPolicyException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.annotation.UnsupportedPolicyException
Initializes this exception with given message and cause.
upcast(T) - Method in interface org.axonframework.eventstore.EventUpcaster
Upcast the given event to make it parsable by the EventSerializer.
upcast(Document) - Method in class org.axonframework.eventstore.legacy.LegacyAxonEventUpcaster
 
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.jpa.JpaSagaRepository
 
UUIDAggregateIdentifier - Class in org.axonframework.domain
Implementation of an AggregateIdentifier that uses a UUID as backing identifier.
UUIDAggregateIdentifier() - Constructor for class org.axonframework.domain.UUIDAggregateIdentifier
Creates a new instance using a randomly chosen UUID as identifier value.
UUIDAggregateIdentifier(UUID) - Constructor for class org.axonframework.domain.UUIDAggregateIdentifier
Creates a new instance using the given UUID as identifier value.
UUIDAggregateIdentifier(String) - Constructor for class org.axonframework.domain.UUIDAggregateIdentifier
Creates a new instance using the UUID-formatted identifier.

V

validateCommand(Object, Validator) - Method in class org.axonframework.commandhandling.interceptors.BeanValidationInterceptor
Validate the given command using the given validator.
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.eventhandling.RetryPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.YieldPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.repository.LockingStrategy
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.axonframework.eventhandling.RetryPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventhandling.YieldPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.repository.LockingStrategy
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 AggregateIdentifier and an expected version of an aggregate.
VersionedAggregateIdentifier(AggregateIdentifier, Long) - Constructor for class org.axonframework.commandhandling.VersionedAggregateIdentifier
Initializes a VersionedAggregateIdentifier with the given identifier and version.
visitEvents(EventVisitor) - Method in interface org.axonframework.eventstore.EventStoreManagement
Loads all events available in the event store and calls EventVisitor.doWithEvent(org.axonframework.domain.DomainEvent) for each event found.
visitEvents(EventVisitor) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
 
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
 

W

writeBytes(byte[]) - Method in class org.axonframework.util.io.BinaryEntryOutputStream
Writes the given bytes to the backing stream.
writeNumber(long) - Method in class org.axonframework.util.io.BinaryEntryOutputStream
Writes a numeric entry.
writeNumber(int) - Method in class org.axonframework.util.io.BinaryEntryOutputStream
Writes a numeric entry.
writeString(String) - Method in class org.axonframework.util.io.BinaryEntryOutputStream
Writes a String entry.

X

XStreamEventSerializer - Class in org.axonframework.eventstore
Implementation of the serializer that uses XStream as underlying serialization mechanism.
XStreamEventSerializer() - Constructor for class org.axonframework.eventstore.XStreamEventSerializer
Initialize an EventSerializer that uses XStream to serialize Events.
XStreamEventSerializer(XStream) - Constructor for class org.axonframework.eventstore.XStreamEventSerializer
Initialize an EventSerializer that uses XStream to serialize Events.
XStreamEventSerializer(String) - Constructor for class org.axonframework.eventstore.XStreamEventSerializer
Initialize an EventSerializer that uses XStream to serialize Events.
XStreamEventSerializer(Charset) - Constructor for class org.axonframework.eventstore.XStreamEventSerializer
Initialize an EventSerializer that uses XStream to serialize Events.
XStreamEventSerializer(Charset, XStream) - Constructor for class org.axonframework.eventstore.XStreamEventSerializer
Initialize an EventSerializer that uses XStream to serialize Events.
XStreamEventSerializer(XStreamSerializer) - Constructor for class org.axonframework.eventstore.XStreamEventSerializer
Initializes an XStreamEventSerializer with the given delegate to perform the actual serialization logic.
XStreamSagaSerializer - Class in org.axonframework.saga.repository
Implementation of the SagaSerializer that uses XStream to serialize Saga instances to XML.
XStreamSagaSerializer() - Constructor for class org.axonframework.saga.repository.XStreamSagaSerializer
Initialize an XStreamSagaSerializer with UTF-8 character set and default XStream instance.
XStreamSagaSerializer(Charset) - Constructor for class org.axonframework.saga.repository.XStreamSagaSerializer
Initialize an XStreamSagaSerializer with given charset and a default XStream instance.
XStreamSagaSerializer(XStream) - Constructor for class org.axonframework.saga.repository.XStreamSagaSerializer
Initialize an XStreamSagaSerializer with UTF-8 character set and the given xStream instance.
XStreamSagaSerializer(Charset, XStream) - Constructor for class org.axonframework.saga.repository.XStreamSagaSerializer
Initialize an XStreamSagaSerializer with given charset and xStream instance.
XStreamSerializer - Class in org.axonframework.serializer
Serializer that uses XStream to serialize and deserialize arbitrary objects.
XStreamSerializer() - Constructor for class org.axonframework.serializer.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(XStream) - Constructor for class org.axonframework.serializer.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(Charset) - Constructor for class org.axonframework.serializer.XStreamSerializer
Initialize the serializer using the given charset.
XStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.serializer.XStreamSerializer
Initialize the serializer using the given charset and xStream instance.

Y

YieldPolicy - Enum in org.axonframework.eventhandling
The yielding policy for transactions.
A B C D E F G H I J K L M N O P Q R S T U V W X Y 

Copyright © 2012. All Rights Reserved.