- AbstractAggregateFactory<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
-
Abstract AggregateFactory implementation that is aware of snapshot events.
- AbstractAggregateFactory() - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
-
- AbstractAggregateFactory(ParameterResolverFactory) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
-
- AbstractAggregateRoot<I> - Class in org.axonframework.domain
-
Very basic implementation of the AggregateRoot interface.
- AbstractAggregateRoot() - Constructor for class org.axonframework.domain.AbstractAggregateRoot
-
- AbstractAnnotatedAggregateRoot<I> - Class in org.axonframework.eventsourcing.annotation
-
Convenience super type for aggregate roots that have their event handler methods annotated with the
EventSourcingHandler
annotation (and
EventHandler
for backwards compatibility).
- AbstractAnnotatedAggregateRoot() - Constructor for class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
-
- AbstractAnnotatedEntity - Class in org.axonframework.eventsourcing.annotation
-
Convenience super type for entities (other than aggregate roots) that have their event handler methods annotated
with the
EventHandler
annotation.
- AbstractAnnotatedEntity() - Constructor for class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
-
Default constructor.
- AbstractAnnotatedHandlerDefinition<T extends Annotation> - Class in org.axonframework.common.annotation
-
Abstract implementation of the HandlerDefinition that uses annotations to recognise handler methods or constructors.
- AbstractAnnotatedHandlerDefinition(Class<T>) - Constructor for class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
-
Initialize the Definition, using where handlers are annotated with given annotationType
.
- AbstractAnnotatedParameterResolverFactory<A,P> - Class in org.axonframework.eventhandling.annotation
-
ParameterResolverFactory that will supply a parameter resolver when a matching parameter annotation is paired
with a suitable type of parameter.
- AbstractAnnotatedParameterResolverFactory(Class<A>, Class<P>) - Constructor for class org.axonframework.eventhandling.annotation.AbstractAnnotatedParameterResolverFactory
-
Initialize a ParameterResolverFactory instance that resolves parameters of type
declaredParameterType
annotated with the given annotationType
.
- AbstractAnnotatedSaga - Class in org.axonframework.saga.annotation
-
- AbstractAnnotatedSaga() - Constructor for class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Initialize the saga with a random identifier.
- AbstractAnnotatedSaga(String) - Constructor for class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Initialize the saga with the given identifier.
- AbstractAnnotationHandlerBeanPostProcessor<I,T extends I> - Class in org.axonframework.common.annotation
-
Abstract bean post processor that finds candidates for proxying.
- AbstractAnnotationHandlerBeanPostProcessor() - Constructor for class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
- AbstractCacheAdapter<L> - Class in org.axonframework.cache
-
Abstract implementation of the Cache interface which makes it easier to implement Adapters.
- AbstractCacheAdapter() - Constructor for class org.axonframework.cache.AbstractCacheAdapter
-
- AbstractCluster - Class in org.axonframework.eventhandling
-
Abstract
Cluster
implementation that keeps track of Cluster members (
EventListeners
).
- AbstractCluster(String) - Constructor for class org.axonframework.eventhandling.AbstractCluster
-
Initializes the cluster with given name
.
- AbstractCluster(String, Comparator<EventListener>) - Constructor for class org.axonframework.eventhandling.AbstractCluster
-
Initializes the cluster with given name
, using given comparator
to order the listeners
in the cluster.
- AbstractClusterSelector - Class in org.axonframework.eventhandling
-
Abstract implementation of the ClusterSelector interface that detects proxies and passes the actual Class of the
Event Listener implementation.
- AbstractClusterSelector() - Constructor for class org.axonframework.eventhandling.AbstractClusterSelector
-
- AbstractCommandGateway - Class in org.axonframework.commandhandling.gateway
-
Abstract implementation of a CommandGateway, which handles the dispatch interceptors and retrying on failure.
- AbstractCommandGateway(CommandBus, RetryScheduler, List<CommandDispatchInterceptor>) - Constructor for class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Initialize the AbstractCommandGateway with given commandBus
, retryScheduler
and
commandDispatchInterceptors
.
- AbstractContentTypeConverter<S,T> - Class in org.axonframework.serializer
-
Abstract implementation of the ContentTypeConverter for convenience purposes.
- AbstractContentTypeConverter() - Constructor for class org.axonframework.serializer.AbstractContentTypeConverter
-
- AbstractEventEntry - Class in org.axonframework.eventstore.jpa
-
Data needed by different types of event logs.
- AbstractEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntry
-
Initialize an Event entry for the given event
.
- AbstractEventEntry(String, DomainEventMessage, DateTime, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntry
-
Initialize an Event entry for the given event
.
- AbstractEventEntry() - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntry
-
Default constructor, as required by JPA specification.
- AbstractEventEntryData<T> - Class in org.axonframework.eventstore.jpa
-
Abstract JPA Entity, which defines all fields except for the payload and metaData field.
- AbstractEventEntryData(String, String, String, long, DateTime, SerializedType) - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
Initializes the fields in this entity using the values provided in the given parameters.
- AbstractEventEntryData() - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
Constructor required by JPA.
- AbstractEventEntryData.PK - Class in org.axonframework.eventstore.jpa
-
Primary key definition of the AbstractEventEntry class.
- AbstractEventEntryData.PK() - Constructor for class org.axonframework.eventstore.jpa.AbstractEventEntryData.PK
-
Constructor for JPA.
- AbstractEventSourcedAggregateRoot<I> - Class in org.axonframework.eventsourcing
-
Abstract convenience class to be extended by all aggregate roots.
- AbstractEventSourcedAggregateRoot() - Constructor for class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
-
- AbstractEventSourcedEntity - Class in org.axonframework.eventsourcing
-
Base class for Event Sourced entities that are not at the root of the aggregate.
- AbstractEventSourcedEntity() - Constructor for class org.axonframework.eventsourcing.AbstractEventSourcedEntity
-
- AbstractMessageHandler - Class in org.axonframework.common.annotation
-
Abstract superclass for annotation based Message handlers.
- AbstractMessageHandler(Class<?>, Class<?>, ParameterResolver...) - Constructor for class org.axonframework.common.annotation.AbstractMessageHandler
-
Initializes the MessageHandler to handle messages with the given payloadType
, declared in the given
declaringClass
and using the given parameterValueResolvers
.
- AbstractMessageHandler(AbstractMessageHandler) - Constructor for class org.axonframework.common.annotation.AbstractMessageHandler
-
Constructor used for implementations that delegate activity to another handler.
- AbstractMethodPropertyAccessStrategy - Class in org.axonframework.common.property
-
Abstract implementation of the PropertyAccessStrategy that uses a no-arg, public method to access the property
value.
- AbstractMethodPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-
- AbstractReplayAwareSagaManager - Class in org.axonframework.saga
-
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager
implementations.
- AbstractReplayAwareSagaManager() - Constructor for class org.axonframework.saga.AbstractReplayAwareSagaManager
-
- AbstractRepository<T extends AggregateRoot> - Class in org.axonframework.repository
-
Abstract implementation of the
Repository
that takes care of the dispatching of events when an aggregate is
persisted.
- AbstractRepository(Class<T>) - Constructor for class org.axonframework.repository.AbstractRepository
-
Initializes a repository that stores aggregate of the given aggregateType
.
- AbstractSagaManager - Class in org.axonframework.saga
-
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager
implementations.
- AbstractSagaManager(EventBus, SagaRepository, SagaFactory, Class<? extends Saga>...) - Constructor for class org.axonframework.saga.AbstractSagaManager
-
- AbstractSagaManager(SagaRepository, SagaFactory, Class<? extends Saga>...) - Constructor for class org.axonframework.saga.AbstractSagaManager
-
Initializes the SagaManager with the given sagaRepository
.
- AbstractSagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
Abstract SagaManager parser that parses common properties for all SagaManager implementations.
- AbstractSagaManagerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
-
- AbstractSagaRepository - Class in org.axonframework.saga.repository
-
Abstract implementation for saga repositories.
- AbstractSagaRepository() - Constructor for class org.axonframework.saga.repository.AbstractSagaRepository
-
- AbstractSingleEntryUpcaster<T> - Class in org.axonframework.upcasting
-
Abstract implementation of an upcaster that only needs to convert one serialized object to another using the same
representation.
- AbstractSingleEntryUpcaster() - Constructor for class org.axonframework.upcasting.AbstractSingleEntryUpcaster
-
- AbstractSnapshotter - Class in org.axonframework.eventsourcing
-
Abstract implementation of the
Snapshotter
that uses a task executor to
creates snapshots.
- AbstractSnapshotter() - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
-
- AbstractUpcasterChain - Class in org.axonframework.upcasting
-
Abstract implementation of the UpcasterChain interface.
- AbstractUpcasterChain(List<Upcaster>) - Constructor for class org.axonframework.upcasting.AbstractUpcasterChain
-
- AbstractUpcasterChain(ConverterFactory, List<Upcaster>) - Constructor for class org.axonframework.upcasting.AbstractUpcasterChain
-
Initializes the UpcasterChain with given converterFactory
and upcasters
.
- AbstractXStreamSerializer - Class in org.axonframework.serializer
-
Abstract implementation for XStream based serializers.
- AbstractXStreamSerializer(XStream) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
-
Initialize a generic serializer using the UTF-8 character set.
- AbstractXStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
-
Initialize a generic serializer using the UTF-8 character set.
- AbstractXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
-
Initialize the serializer using the given charset
and xStream
instance.
- AbstractXStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
-
Initialize the serializer using the given charset
and xStream
instance.
- AbstractXStreamSerializer(Charset, XStream, RevisionResolver, ConverterFactory) - Constructor for class org.axonframework.serializer.AbstractXStreamSerializer
-
Initialize the serializer using the given charset
, xStream
instance,
revisionResolver
and converterFactory
.
- AcceptAllConflictResolver - Class in org.axonframework.eventsourcing.conflictresolvers
-
Implementation of the conflict resolver that will accept all changes made to an aggregate, even if the aggregate
contains changes that were not expected by the command handler.
- AcceptAllConflictResolver() - Constructor for class org.axonframework.eventsourcing.conflictresolvers.AcceptAllConflictResolver
-
- add(T) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
- add(T) - Method in class org.axonframework.repository.AbstractRepository
-
Adds the given aggregate
to the repository.
- add(T) - Method in class org.axonframework.repository.LockingRepository
-
- add(T) - Method in interface org.axonframework.repository.Repository
-
Adds the given aggregate
to the repository.
- add(AssociationValue) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- add(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues
-
Adds the given associationValue
, if it has not been previously added.
- add(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
-
- add(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AssociationValueMap
-
Adds an association between the given associationValue
and sagaIdentifier
.
- add(Saga) - Method in class org.axonframework.saga.repository.CachingSagaRepository
-
- add(Saga) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
-
- add(Saga) - Method in interface org.axonframework.saga.SagaRepository
-
Registers a newly created Saga with the Repository.
- add(UnitOfWorkListener) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
-
Adds a listener to the collection.
- addAlias(String, Class) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Adds an alias to use instead of the fully qualified class name.
- addedAssociations() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- addedAssociations() - Method in interface org.axonframework.saga.AssociationValues
-
- addEvent(MetaData, T) - Method in class org.axonframework.domain.EventContainer
-
Add an event to this container.
- addEvent(DomainEventMessage<T>) - Method in class org.axonframework.domain.EventContainer
-
Add an event to this container.
- addEventRegistrationCallback(EventRegistrationCallback) - Method in class org.axonframework.domain.AbstractAggregateRoot
-
- addEventRegistrationCallback(EventRegistrationCallback) - Method in interface org.axonframework.domain.AggregateRoot
-
Adds an EventRegistrationCallback, which is notified when the aggregate registers an Event for publication.
- addEventRegistrationCallback(EventRegistrationCallback) - Method in class org.axonframework.domain.EventContainer
-
Adds an EventRegistrationCallback, which is invoked when the aggregate owning this container registers an Event.
- addFieldAlias(String, Class, String) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Adds an alias to use for a given field in the given class.
- addPackageAlias(String, String) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Add an alias for a package.
- AFTER_REPLAY_TIMEOUT - Static variable in class org.axonframework.eventhandling.replay.ReplayingCluster
-
The key to use in Cluster MetaData that indicates how long the replaying cluster should wait for all events to
be processed, before invoking the afterReplay on all methods.
- afterCommit(UnitOfWork) - Method in class org.axonframework.auditing.AuditingUnitOfWorkListener
-
- afterCommit(UnitOfWork) - Method in interface org.axonframework.unitofwork.UnitOfWorkListener
-
Invoked when the UnitOfWork is committed.
- afterCommit(UnitOfWork) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerAdapter
-
Invoked when the UnitOfWork is committed.
- afterCommit(UnitOfWork) - Method in class org.axonframework.unitofwork.UnitOfWorkListenerCollection
-
Invoked when the UnitOfWork is committed.
- afterPropertiesSet() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
-
- afterPropertiesSet() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
-
- afterPropertiesSet() - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
- afterReplay() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
-
- afterReplay() - Method in interface org.axonframework.eventhandling.replay.ReplayAware
-
Invoked when a replay has finished.
- afterReplay() - Method in class org.axonframework.saga.AbstractReplayAwareSagaManager
-
- afterShutdown(EventProcessor) - Method in interface org.axonframework.eventhandling.async.EventProcessor.ShutdownCallback
-
Called when event processing is complete.
- AggregateAnnotationCommandHandler<T extends AggregateRoot> - Class in org.axonframework.commandhandling.annotation
-
Command handler that handles commands based on
CommandHandler
annotations on an aggregate.
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType
, using the
given repository
to add and load aggregate instances.
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandTargetResolver) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType
, using the
given repository
to add and load aggregate instances and the default ParameterResolverFactory.
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandTargetResolver, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType
, using the
given repository
to add and load aggregate instances and the given
parameterResolverFactory
.
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandBus) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandBus, CommandTargetResolver) - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
- AggregateAnnotationCommandHandlerFactoryBean<T extends AggregateRoot<?>> - Class in org.axonframework.commandhandling.annotation
-
Spring FactoryBean that creates an AggregateAnnotationCommandHandler instance.
- AggregateAnnotationCommandHandlerFactoryBean() - Constructor for class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
- AggregateAnnotationInspector - Class in org.axonframework.eventsourcing.annotation
-
- AggregateBlacklistedException - Exception in org.axonframework.commandhandling.disruptor
-
Exception indicating that an aggregate has been blacklisted by the DisruptorCommandBus.
- AggregateBlacklistedException(Object, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateBlacklistedException
-
Initializes the exception with given aggregateIdentifier
, given explanatory message
and cause
.
- AggregateCommandHandlerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
Bean Definition parser that parses AggregateAnnotationCommandHandler type beans (aggregate-command-handler element).
- AggregateCommandHandlerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AggregateCommandHandlerBeanDefinitionParser
-
- AggregateCommandHandlerInspector<T extends AggregateRoot> - Class in org.axonframework.commandhandling.annotation
-
Handler inspector that finds annotated constructors and methods on a given aggregate type and provides handlers for
those methods.
- AggregateCommandHandlerInspector(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
-
Initialize an MethodMessageHandlerInspector, where the given annotationType
is used to annotate the
Event Handler methods.
- AggregateDeletedException - Exception in org.axonframework.eventsourcing
-
Special case of the
AggregateNotFoundException
that indicates that historic
information of an aggregate was found, but the aggregate has been deleted.
- AggregateDeletedException(Object, String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
-
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier
and
given message
.
- AggregateDeletedException(Object) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
-
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier
and
a default message
.
- AggregateFactory<T extends EventSourcedAggregateRoot> - Interface in org.axonframework.eventsourcing
-
Interface describing objects capable of creating instances of aggregates to be initialized with an event stream.
- AggregateIdentifier - Annotation Type in org.axonframework.eventsourcing.annotation
-
Field annotation that indicates the field contains the identifier of the Aggregate.
- AggregateIdentifierNotInitializedException - Exception in org.axonframework.domain
-
Exception indicating that an AggregateRoot instance has failed to provide a valid aggregate identifier in time.
- AggregateIdentifierNotInitializedException(String) - Constructor for exception org.axonframework.domain.AggregateIdentifierNotInitializedException
-
Initialize the exception with the given message
- AggregateNotFoundException - Exception in org.axonframework.repository
-
Exception indicating that the an aggregate could not be found in the repository.
- AggregateNotFoundException(Object, String) - Constructor for exception org.axonframework.repository.AggregateNotFoundException
-
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier
and given message
.
- AggregateNotFoundException(Object, String, Throwable) - Constructor for exception org.axonframework.repository.AggregateNotFoundException
-
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier
and
with the given message
and cause
.
- AggregateRoot<I> - Interface in org.axonframework.domain
-
Interface defining a contract for entities that represent the aggregate root.
- AggregateSnapshotter - Class in org.axonframework.eventsourcing
-
Implementation of a snapshotter that uses the actual aggregate and its state to create a snapshot event.
- AggregateSnapshotter() - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
-
- AggregateStateCorruptedException - Exception in org.axonframework.commandhandling.disruptor
-
Exception indicating that the changes in an aggregate (generated events) are ignored by the DisruptorCommandBus,
because it cannot guarantee that these changes have been applied to an aggregate instance with the correct state.
- AggregateStateCorruptedException(Object, String) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
-
Initializes the exception with given aggregateIdentifier
and given explanatory
message
.
- AggregateStateCorruptedException(Object, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
-
Initializes the exception with given aggregateIdentifier
, given explanatory message
and cause
.
- and(Criteria) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcCriteria
-
- and(Criteria) - Method in class org.axonframework.eventstore.jpa.criteria.JpaCriteria
-
- and(Criteria) - Method in interface org.axonframework.eventstore.management.Criteria
-
Returns a criteria instance where both this
and given criteria
must match.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandMessage
-
Returns a copy of this CommandMessage with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.DomainEventMessage
-
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.EventMessage
-
Returns a copy of this EventMessage with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericDomainEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.domain.GenericMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.domain.Message
-
Returns a copy of this Message with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.serializer.SerializedMessage
-
- 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
-
- AnnotatedSagaManager(SagaRepository, SagaFactory, EventBus, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
-
- AnnotatedSagaManager(SagaRepository, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
-
Initialize the AnnotatedSagaManager using given repository
to load sagas and supporting given
annotated sagaClasses
.
- AnnotatedSagaManager(SagaRepository, ParameterResolverFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
-
Initialize the AnnotatedSagaManager using given repository
to load sagas and supporting given
annotated sagaClasses
.
- AnnotatedSagaManager(SagaRepository, SagaFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
-
Initialize the AnnotatedSagaManager using the given resources.
- AnnotatedSagaManager(SagaRepository, SagaFactory, ParameterResolverFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AnnotatedSagaManager
-
Initialize the AnnotatedSagaManager using the given resources.
- AnnotationClusterSelector - Class in org.axonframework.eventhandling
-
Cluster Selector implementation that selects a cluster if an Annotation is present on the Event Listener class.
- AnnotationClusterSelector(Class<? extends Annotation>, Cluster) - Constructor for class org.axonframework.eventhandling.AnnotationClusterSelector
-
Initializes a ClusterSelector instance that selects the given cluster
for Event Listeners that are
annotated with the given annotationType
.
- AnnotationClusterSelector(Class<? extends Annotation>, Cluster, boolean) - Constructor for class org.axonframework.eventhandling.AnnotationClusterSelector
-
Initializes a ClusterSelector instance that selects the given cluster
for Event Listeners that are
annotated with the given annotationType
.
- AnnotationCommandHandlerAdapter - Class in org.axonframework.commandhandling.annotation
-
- AnnotationCommandHandlerAdapter(Object, CommandBus) - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
-
- AnnotationCommandHandlerAdapter(Object) - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
-
Wraps the given annotatedCommandHandler
, allowing it to be subscribed to a Command Bus.
- AnnotationCommandHandlerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
-
Wraps the given annotatedCommandHandler
, allowing it to be subscribed to a Command Bus.
- AnnotationCommandHandlerBeanPostProcessor - Class in org.axonframework.commandhandling.annotation
-
Spring Bean post processor that automatically generates an adapter for each bean containing
CommandHandler
annotated methods.
- AnnotationCommandHandlerBeanPostProcessor() - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
-
- AnnotationCommandTargetResolver - Class in org.axonframework.commandhandling.annotation
-
CommandTargetResolver that uses annotations on the command to identify the methods that provide the
Aggregate Identifier of the targeted Aggregate and optionally the expected version of the aggregate.
- AnnotationCommandTargetResolver() - Constructor for class org.axonframework.commandhandling.annotation.AnnotationCommandTargetResolver
-
- AnnotationConfigurationBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
The AnnotationConfigurationBeanDefinitionParser is responsible for parsing the annotation-config element from the
Axon namespace.
- AnnotationConfigurationBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
-
- AnnotationDriven - Annotation Type in org.axonframework.contextsupport.spring
-
Annotation for
@Configuration
that will automatically
subscribe
@CommandHandler
and
@EventHandler
annotated beans with the CommandBus and
EventBus, respectively.
- AnnotationDrivenConfiguration - Class in org.axonframework.contextsupport.spring
-
Spring @Configuration related class that adds Axon Annotation PostProcessors to the BeanDefinitionRegistry.
- AnnotationDrivenConfiguration() - Constructor for class org.axonframework.contextsupport.spring.AnnotationDrivenConfiguration
-
- AnnotationEventListenerAdapter - Class in org.axonframework.eventhandling.annotation
-
- AnnotationEventListenerAdapter(Object) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
-
Wraps the given annotatedEventListener
, allowing it to be subscribed to an Event Bus.
- AnnotationEventListenerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
-
Wraps the given annotatedEventListener
, allowing it to be subscribed to an Event Bus.
- AnnotationEventListenerAdapter(Object, EventBus) - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
-
- AnnotationEventListenerBeanPostProcessor - Class in org.axonframework.eventhandling.annotation
-
Spring Bean post processor that automatically generates an adapter for each bean containing
EventHandler
annotated methods.
- AnnotationEventListenerBeanPostProcessor() - Constructor for class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
-
- AnnotationRevisionResolver - Class in org.axonframework.serializer
-
Revision Resolver implementation that checks for the presence of an
@Revision
annotation.
- AnnotationRevisionResolver() - Constructor for class org.axonframework.serializer.AnnotationRevisionResolver
-
- appendEvents(String, DomainEventStream) - Method in interface org.axonframework.eventstore.EventStore
-
Append the events in the given
stream
to the event store.
- appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
-
Append the events in the given
stream
to the event store.
- appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
Append the events in the given
stream
to the event store.
- appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
Append the events in the given
stream
to the event store.
- appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.supporting.SequenceEventStore
-
- appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
-
- appendEvents(String, DomainEventStream) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
-
- appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
-
Append the given snapshotEvent
to the snapshot event log for the given type type
.
- appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
Append the given snapshotEvent
to the snapshot event log for the given type type
.
- appendSnapshotEvent(String, DomainEventMessage) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
Append the given snapshotEvent
to the snapshot event log for the given type type
.
- appendSnapshotEvent(String, DomainEventMessage) - Method in interface org.axonframework.eventstore.SnapshotEventStore
-
Append the given snapshotEvent
to the snapshot event log for the given type type
.
- ApplicationContextLookupParameterResolverFactory - Class in org.axonframework.contextsupport.spring
-
FactoryBean implementation that create a ParameterResolverFactory, which auto-detects beans implementing
ParameterResolverFactory beans in the application context.
- ApplicationContextLookupParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
-
Creates an instance, using the given defaultFactories
.
- apply(Object) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
-
Apply the provided event.
- apply(Object, MetaData) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
-
Apply the provided event.
- apply(Object) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
-
Apply the provided event.
- apply(Object, MetaData) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
-
Apply the provided event and attaching the given metaData
.
- asCommandMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandMessage
-
Returns the given command as a CommandMessage.
- asEventMessage(Object) - Static method in class org.axonframework.domain.GenericEventMessage
-
Returns the given event as an EventMessage.
- Assert - Class in org.axonframework.common
-
Utility class (inspired by Springs Assert class) for doing assertions on parameters and object state.
- asSet() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- asSet() - Method in interface org.axonframework.saga.AssociationValues
-
Returns this instance as a Set of Association Values.
- assignMetaData(EventMessage, List<EventMessage>, int) - Method in class org.axonframework.unitofwork.MetaDataMutatingUnitOfWorkListenerAdapter
-
Defines the additional meta data to assign to the given event
.
- associateWith(AssociationValue) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Registers a AssociationValue with the given saga.
- associateWith(String, String) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Registers a AssociationValue with the given saga.
- associateWith(String, Number) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Registers a AssociationValue with the given saga.
- AssociationValue - Class in org.axonframework.saga
-
A combination of key and value by which a Saga can be found.
- AssociationValue(String, String) - Constructor for class org.axonframework.saga.AssociationValue
-
Creates a Association Value instance with the given key
and value
.
- AssociationValueEntry - Class in org.axonframework.saga.repository.jpa
-
JPA wrapper around an Association Value.
- AssociationValueEntry(String, String, AssociationValue) - Constructor for class org.axonframework.saga.repository.jpa.AssociationValueEntry
-
Initialize a new AssociationValueEntry for a saga with given sagaIdentifier
and
associationValue
.
- AssociationValueEntry() - Constructor for class org.axonframework.saga.repository.jpa.AssociationValueEntry
-
Constructor required by JPA.
- AssociationValueMap - Class in org.axonframework.saga.repository
-
In-memory storage for AssociationValue to Saga mappings.
- AssociationValueMap() - Constructor for class org.axonframework.saga.repository.AssociationValueMap
-
Initializes a new and empty AssociationValueMap.
- AssociationValueResolver - Interface in org.axonframework.saga
-
Interface describing the mechanism that resolves Association Values from events.
- AssociationValues - Interface in org.axonframework.saga
-
- AssociationValuesImpl - Class in org.axonframework.saga.annotation
-
Default implementation of the AssociationValues interface.
- AssociationValuesImpl() - Constructor for class org.axonframework.saga.annotation.AssociationValuesImpl
-
- assocValueEntryTable() - Method in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
-
- AsyncAnnotatedSagaManager - Class in org.axonframework.saga.annotation
-
A SagaManager implementation that processes Sagas asynchronously.
- AsyncAnnotatedSagaManager(EventBus, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
- AsyncAnnotatedSagaManager(Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Initializes an Asynchronous Saga Manager using default values for the given sagaTypes
.
- AsyncAnnotatedSagaManager(ParameterResolverFactory, Class<? extends AbstractAnnotatedSaga>...) - Constructor for class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Initializes an Asynchronous Saga Manager using default values for the given sagaTypes
.
- AsynchronousCluster - Class in org.axonframework.eventhandling.async
-
Cluster implementation that publishes events to the subscribed Event Listeners asynchronously from the publishing
thread.
- AsynchronousCluster(String, Executor, TransactionManager, SequencingPolicy<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
-
Creates an AsynchronousCluster implementation using the given executor
,
transactionManager
and sequencingPolicy
.
- AsynchronousCluster(String, Executor, SequencingPolicy<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
-
Creates an AsynchronousCluster implementation using the given executor
and
sequencingPolicy
.
- AsynchronousCluster(String, Executor, TransactionManager, SequencingPolicy<? super EventMessage<?>>, ErrorHandler) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
-
Creates an AsynchronousCluster implementation using the given executor
,
transactionManager
and sequencingPolicy
.
- AsynchronousCluster(String, Executor, UnitOfWorkFactory, SequencingPolicy<? super EventMessage<?>>, ErrorHandler) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
-
Creates an AsynchronousCluster implementation using the given executor
,
unitOfWorkFactory
and sequencingPolicy
.
- AsynchronousCluster(String, Executor, UnitOfWorkFactory, SequencingPolicy<? super EventMessage<?>>, ErrorHandler, OrderResolver) - Constructor for class org.axonframework.eventhandling.async.AsynchronousCluster
-
Creates an AsynchronousCluster implementation using the given executor
,
unitOfWorkFactory
and sequencingPolicy
.
- AsynchronousCommandBus - Class in org.axonframework.commandhandling
-
Specialization of the SimpleCommandBus that processed Commands asynchronously from the calling thread.
- AsynchronousCommandBus() - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
-
Initialize the AsynchronousCommandBus, using a Cached Thread Pool.
- AsynchronousCommandBus(Executor) - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
-
Initialize the AsynchronousCommandBus using the given executor
.
- AsyncSagaCreationElector - Class in org.axonframework.saga.annotation
-
Manages the election of which asynchronous saga event processor is responsible for creating a new Saga instance,
when necessary.
- AsyncSagaCreationElector() - Constructor for class org.axonframework.saga.annotation.AsyncSagaCreationElector
-
- AsyncSagaEventProcessor - Class in org.axonframework.saga.annotation
-
Processes events by forwarding it to Saga instances "owned" by each processor.
- AsyncSagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
BeanDefinitionParser that parses saga-manager elements in the application context.
- AsyncSagaManagerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
-
- AsyncSagaProcessingEvent - Class in org.axonframework.saga.annotation
-
Placeholder for information required by the AsyncSagaEventProcessor for processing Events.
- AsyncSagaProcessingEvent() - Constructor for class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
- attachInheritedResources(UnitOfWork) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- attachInheritedResources(UnitOfWork) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- attachInheritedResources(UnitOfWork) - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Attach all inherited resources to the given unitOfWork
.
- attachResource(String, Object) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- attachResource(String, Object, boolean) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- attachResource(String, Object) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- attachResource(String, Object, boolean) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- attachResource(String, Object) - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Attaches the given resource
to this Unit of Work under the given name
.
- attachResource(String, Object, boolean) - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Attaches the given resource
to this Unit of Work under the given name
.
- AuditDataProvider - Interface in org.axonframework.auditing
-
Interface describing the instance that provides the relevant information for auditing purposes.
- AuditingInterceptor - Class in org.axonframework.auditing
-
Interceptor that keeps track of commands and the events that were dispatched as a result of handling that command.
- AuditingInterceptor() - Constructor for class org.axonframework.auditing.AuditingInterceptor
-
- AuditingUnitOfWorkListener - Class in org.axonframework.auditing
-
Listener implementation that adds auditing information to events being tracked by the unit of work this listener is
registered to.
- AuditingUnitOfWorkListener(CommandMessage<?>, AuditDataProvider, AuditLogger) - Constructor for class org.axonframework.auditing.AuditingUnitOfWorkListener
-
Initialize a listener for the given command
.
- AuditLogger - Interface in org.axonframework.auditing
-
Interface describing a component capable of writing auditing entries to a log.
- AutowiredBean - Class in org.axonframework.contextsupport.spring
-
Special type of BeanDefinition that references can be use to explicitly define a property as being autowired.
- AutowiredDependencyFactoryBean - Class in org.axonframework.contextsupport.spring
-
Convenience factory bean that locates a bean of a number of given types.
- AutowiredDependencyFactoryBean(Class<?>...) - Constructor for class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
-
Creates a factory bean that automatically resolved to a bean of one of the given beanTypes
.
- AutowiredDependencyFactoryBean(Object, Class<?>...) - Constructor for class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
-
Creates a factory bean that automatically resolved to a bean of one of the given beanTypes
,
reverting to the given defaultBean
if no candidates are found.
- AutowiringClusterSelector - Class in org.axonframework.eventhandling
-
Cluster selector implementation that uses a Spring Application Context to find all selector beans available.
- AutowiringClusterSelector() - Constructor for class org.axonframework.eventhandling.AutowiringClusterSelector
-
- awaitCompletion(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Wait for completion of the command, or for the timeout to expire.
- AxonConfigurationException - Exception in org.axonframework.common
-
Exception indicating that a configuration error has been made in the Axon configuration.
- AxonConfigurationException(String) - Constructor for exception org.axonframework.common.AxonConfigurationException
-
Initializes the exception using the given message
.
- AxonConfigurationException(String, Throwable) - Constructor for exception org.axonframework.common.AxonConfigurationException
-
Initializes the exception using the given message
and cause
.
- AxonException - Exception in org.axonframework.common
-
Base exception of all Axon Framework related exceptions.
- AxonException(String) - Constructor for exception org.axonframework.common.AxonException
-
Initializes the exception using the given message
.
- AxonException(String, Throwable) - Constructor for exception org.axonframework.common.AxonException
-
Initializes the exception using the given message
and cause
.
- AxonNamespaceHandler - Class in org.axonframework.contextsupport.spring
-
The Axon namespace handler is responsible for parsing the elements of the Axon namespace and adjusting the Spring
context configuration accordingly.
- AxonNamespaceHandler() - Constructor for class org.axonframework.contextsupport.spring.AxonNamespaceHandler
-
- AxonNonTransientException - Exception in org.axonframework.common
-
Exception indicating an error has been cause that cannot be resolved without intervention.
- AxonNonTransientException(String) - Constructor for exception org.axonframework.common.AxonNonTransientException
-
Initializes the exception using the given message
.
- AxonNonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonNonTransientException
-
Initializes the exception using the given message
and cause
.
- AxonThreadFactory - Class in org.axonframework.common
-
Thread factory that created threads in a given group.
- AxonThreadFactory(String) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that creates each thread in a group with given groupName
with
default priority.
- AxonThreadFactory(ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that create each thread in the given group
with default
priority.
- AxonThreadFactory(int, ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that create each thread in the given group
with given
priority
.
- AxonTransientException - Exception in org.axonframework.common
-
Exception indicating an error occurred that might be resolved by retrying the operation that caused the exception.
- AxonTransientException(String) - Constructor for exception org.axonframework.common.AxonTransientException
-
Initializes the exception using the given message
.
- AxonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonTransientException
-
Initializes the exception using the given message
and cause
.
- Cache - Interface in org.axonframework.cache
-
Abstraction for a Caching mechanism.
- Cache.EntryListener - Interface in org.axonframework.cache
-
Interface describing callback methods, which are invoked when changes are made in the underlying cache.
- Cache.EntryListenerAdapter - Class in org.axonframework.cache
-
Adapter implementation for the EntryListener, allowing for overriding only specific callback methods.
- Cache.EntryListenerAdapter() - Constructor for class org.axonframework.cache.Cache.EntryListenerAdapter
-
- CachingEventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
-
Implementation of the event sourcing repository that uses a cache to improve loading performance.
- CachingEventSourcingRepository(AggregateFactory<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Initializes a repository with a the given aggregateFactory
and a pessimistic locking strategy.
- CachingEventSourcingRepository(AggregateFactory<T>, EventStore, LockManager) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Initializes a repository with a the given aggregateFactory
and a pessimistic locking strategy.
- CachingSagaRepository - Class in org.axonframework.saga.repository
-
Saga Repository implementation that adds caching behavior to the repository it wraps.
- CachingSagaRepository(SagaRepository, Cache, Cache) - Constructor for class org.axonframework.saga.repository.CachingSagaRepository
-
Initializes an instance delegating to the given delegate
, storing associations in the given
associationsCache
and Saga instances in the given sagaCache
.
- calculateChain(Class<S>, Class<T>, Collection<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serializer.ChainedConverter
-
Returns a converter that can convert an IntermediateRepresentation from the given sourceType
to the
given targetType
using a chain formed with given candidates
.
- 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<S>, Class<T>, List<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serializer.ChainedConverter
-
Indicates whether this converter is capable of converting the given sourceContentType
into
targetContentType
, using the given converters
.
- CannotConvertBetweenTypesException - Exception in org.axonframework.serializer
-
Exception indicating that a conversion is required between to upcasters, but there is no converter capable of doing
the conversion.
- CannotConvertBetweenTypesException(String) - Constructor for exception org.axonframework.serializer.CannotConvertBetweenTypesException
-
Initializes the exception with the given message
.
- CannotConvertBetweenTypesException(String, Throwable) - Constructor for exception org.axonframework.serializer.CannotConvertBetweenTypesException
-
Initializing the exception with given message
and cause
.
- canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.JavaSerializer
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.json.JacksonSerializer
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
-
- canSerializeTo(Class<T>) - Method in interface org.axonframework.serializer.Serializer
-
Indicates whether this Serializer is capable of serializing to the given expectedRepresentation
.
- canUpcast(SerializedType) - Method in interface org.axonframework.upcasting.Upcaster
-
Indicates whether this upcaster is capable of upcasting the given type
.
- CapturingEventVisitor - Class in org.axonframework.eventstore.supporting
-
- CapturingEventVisitor() - Constructor for class org.axonframework.eventstore.supporting.CapturingEventVisitor
-
- ChainedConverter<S,T> - Class in org.axonframework.serializer
-
A converter that delegates to a chain of other ContentTypeConverters to convert from a source to a target for which
there is not necessarily a single converter available.
- ChainedConverter(List<ContentTypeConverter>) - Constructor for class org.axonframework.serializer.ChainedConverter
-
Creates a new instance that uses the given delegates
to form a chain of converters.
- ChainingConverterFactory - Class in org.axonframework.serializer
-
ConverterFactory implementation that will combine converters to form chains of converters to be able to convert
from one type to another, for which there is no suitable single converter.
- ChainingConverterFactory() - Constructor for class org.axonframework.serializer.ChainingConverterFactory
-
Initialize a new ChainingConverterFactory.
- classForType(SerializedType) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Returns the class for the given type identifier.
- classForType(SerializedType) - Method in class org.axonframework.serializer.JavaSerializer
-
- classForType(SerializedType) - Method in class org.axonframework.serializer.json.JacksonSerializer
-
- classForType(SerializedType) - Method in class org.axonframework.serializer.MessageSerializer
-
- classForType(SerializedType) - Method in interface org.axonframework.serializer.Serializer
-
Returns the class for the given type identifier.
- ClassNamePatternClusterSelector - Class in org.axonframework.eventhandling
-
ClusterSelector implementation that chooses a Cluster based on whether the Listener's Class Name matches a given
Pattern.
- ClassNamePatternClusterSelector(Pattern, Cluster) - Constructor for class org.axonframework.eventhandling.ClassNamePatternClusterSelector
-
Initializes the ClassNamePrefixClusterSelector using the given mappings
.
- ClassNamePrefixClusterSelector - Class in org.axonframework.eventhandling
-
ClusterSelector implementation that chooses a Cluster based on a mapping of the Listener's Class Name.
- ClassNamePrefixClusterSelector(String, Cluster) - Constructor for class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
-
Initializes the ClassNamePrefixClusterSelector where classes starting with the given prefix
will be
mapped to the given cluster
.
- ClassNamePrefixClusterSelector(Map<String, Cluster>) - Constructor for class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
-
Initializes the ClassNamePrefixClusterSelector using the given mappings
.
- ClassNamePrefixClusterSelector(Map<String, Cluster>, Cluster) - Constructor for class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
-
Initializes the ClassNamePrefixClusterSelector using the given mappings
.
- ClasspathParameterResolverFactory - Class in org.axonframework.common.annotation
-
ParameterResolverFactory instance that locates other ParameterResolverFactory instances on the class path.
- ClasspathParameterResolverFactory() - Constructor for class org.axonframework.common.annotation.ClasspathParameterResolverFactory
-
- clear() - Static method in class org.axonframework.correlation.CorrelationDataHolder
-
Clears the correlation data from the current thread.
- clear() - Method in class org.axonframework.domain.MetaData
-
This operation is not supported.
- clear() - Method in class org.axonframework.saga.annotation.AsyncSagaCreationElector
-
Clears the voting counts for a new round.
- clear() - Method in class org.axonframework.saga.repository.AssociationValueMap
-
Clears all the associations.
- clear(UnitOfWork) - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
-
Clears the UnitOfWork currently bound to the current thread, if that UnitOfWork is the given
unitOfWork
.
- clearCache() - Static method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
-
Clears the cached message handlers.
- clone() - Method in interface org.axonframework.cache.Cache.EntryListener
-
Clone operation used by some Cache implementations.
- clone() - Method in class org.axonframework.cache.Cache.EntryListenerAdapter
-
- close(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
-
Close the given connection
, which was wrapped by the ConnectionWrapperFactory.
- close(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
-
- close() - Method in class org.axonframework.eventstore.fs.FileSystemBufferedReaderDomainEventStream
-
- close() - Method in class org.axonframework.eventstore.fs.FileSystemEventMessageReader
-
- closeIfCloseable(Object) - Static method in class org.axonframework.common.io.IOUtils
-
Close the given
closeable
if it implements the
Closeable
interface.
- closeQuietly(Closeable) - Static method in class org.axonframework.common.io.IOUtils
-
Closes any Closable object, while suppressing any IOExceptions it will generate.
- closeQuietly(ResultSet) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given resultSet
, if possible.
- closeQuietly(Statement) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given statement
, if possible.
- closeQuietly(Connection) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given connection
, if possible.
- closeQuietlyIfCloseable(Object) - Static method in class org.axonframework.common.io.IOUtils
-
Closes any object if that object implements
Closeable
, while suppressing any IOExceptions it will
generate.
- Cluster - Interface in org.axonframework.eventhandling
-
A cluster represents a group of Event Listeners that are treated as a single group by the
ClusteringEventBus
.
- ClusterBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
BeanDefinitionParser implementation that parses "cluster" elements.
- ClusterBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.ClusterBeanDefinitionParser
-
- ClusteringEventBus - Class in org.axonframework.eventhandling
-
EventBus
implementation that supports clustering of Event Listeners.
- ClusteringEventBus() - Constructor for class org.axonframework.eventhandling.ClusteringEventBus
-
- ClusteringEventBus(EventBusTerminal) - Constructor for class org.axonframework.eventhandling.ClusteringEventBus
-
- 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.
- CollectionOperator - Class in org.axonframework.eventstore.jdbc.criteria
-
Abstract implementation to use for testing whether an item is present in a collection or not.
- CollectionOperator(JdbcProperty, String, Object) - Constructor for class org.axonframework.eventstore.jdbc.criteria.CollectionOperator
-
Initializes the operator matching given property
against the given expression
using
the given operator
.
- CollectionOperator - Class in org.axonframework.eventstore.jpa.criteria
-
Abstract implementation to use for testing whether an item is present in a collection or not.
- CollectionOperator(JpaProperty, String, Object) - Constructor for class org.axonframework.eventstore.jpa.criteria.CollectionOperator
-
Initializes the operator matching given property
against the given expression
using
the given operator
.
- CollectionUtils - Class in org.axonframework.common
-
Utility methods for operations on collections.
- CommandBus - Interface in org.axonframework.commandhandling
-
The mechanism that dispatches Command objects to their appropriate CommandHandler.
- CommandCallback<R> - Interface in org.axonframework.commandhandling
-
Interface describing a callback that is invoked when command handler execution has finished.
- CommandDispatchInterceptor - Interface in org.axonframework.commandhandling
-
Interceptor that allows commands to be intercepted and modified before they are dispatched by the Command Bus.
- CommandExecutionException - Exception in org.axonframework.commandhandling
-
Indicates that an exception has occurred while handling a command.
- CommandExecutionException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
-
Initializes the exception with given message
and cause
.
- CommandGateway - Interface in org.axonframework.commandhandling.gateway
-
Interface towards the Command Handling components of an application.
- CommandGatewayFactoryBean<T> - Class in org.axonframework.commandhandling.gateway
-
FactoryBean that creates a gateway instance for any given (compatible) interface.
- CommandGatewayFactoryBean() - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
- CommandHandler - Annotation Type in org.axonframework.commandhandling.annotation
-
Marker annotation to mark any method on an object as being a CommandHandler.
- CommandHandler<T> - Interface in org.axonframework.commandhandling
-
Marks an instance that is capable of handling commands.
- CommandHandlerInterceptor - Interface in org.axonframework.commandhandling
-
Workflow interface that allows for customized command handler invocation chains.
- CommandHandlerInvoker - Class in org.axonframework.commandhandling.disruptor
-
Component of the DisruptorCommandBus that invokes the command handler.
- CommandHandlerInvoker(EventStore, Cache, int) - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
-
Create an aggregate invoker instance that uses the given eventStore
and cache
to
retrieve aggregate instances.
- CommandHandlingEntry - Class in org.axonframework.commandhandling.disruptor
-
DataHolder for the DisruptorCommandBus.
- CommandHandlingEntry(boolean) - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Initializes the CommandHandlingEntry
- CommandHandlingEntry.Factory - Class in org.axonframework.commandhandling.disruptor
-
Factory class for CommandHandlingEntry instances.
- CommandHandlingEntry.Factory(boolean) - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlingEntry.Factory
-
Initialize the factory with given transactional
flag
- CommandHandlingMember - Annotation Type in org.axonframework.commandhandling.annotation
-
Marker annotation for field that contain an Entity capable of handling Commands on behalf of the aggregate.
- CommandHandlingMemberCollection - Annotation Type in org.axonframework.commandhandling.annotation
-
Marker annotation for field that contain an Entity capable of handling Commands on behalf of the aggregate.
- CommandHandlingMemberMap - Annotation Type in org.axonframework.commandhandling.annotation
-
Marker annotation for fields that contain a
Map
of Entities capable of handling Commands on behalf
of the aggregate.
- CommandMessage<T> - Interface in org.axonframework.commandhandling
-
Represents a Message carrying a command as its payload.
- CommandMessageHandlerUtils - Class in org.axonframework.commandhandling.annotation
-
Utility class that resolves the name of a Command accepted by a given handler.
- CommandMessageHandlerUtils() - Constructor for class org.axonframework.commandhandling.annotation.CommandMessageHandlerUtils
-
- CommandMetaDataProvider - Class in org.axonframework.auditing
-
AuditDataProvider implementation that attaches a Command's MetaData to each event generated as result of that
command.
- CommandMetaDataProvider() - Constructor for class org.axonframework.auditing.CommandMetaDataProvider
-
- 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.
- commit() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- commit(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
-
Commits the underlying transaction
- commit(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
-
- commit() - Method in class org.axonframework.domain.EventContainer
-
Clears the events in this container.
- commit(Saga) - Method in class org.axonframework.saga.AbstractSagaManager
-
Commits the given saga
to the registered repository.
- commit() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- commit() - Method in interface org.axonframework.saga.AssociationValues
-
Resets the tracked changes.
- commit(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
-
- commit(Saga) - Method in class org.axonframework.saga.repository.CachingSagaRepository
-
- commit(Saga) - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
-
- commit(Saga) - Method in interface org.axonframework.saga.SagaRepository
-
Commits the changes made to the Saga instance.
- commit() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
-
Commits the current UnitOfWork.
- commit() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- commit() - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Commits the UnitOfWork.
- commitEvents() - Method in class org.axonframework.domain.AbstractAggregateRoot
-
- commitEvents() - Method in interface org.axonframework.domain.AggregateRoot
-
- commitEvents() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
-
- commitInnerUnitOfWork() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
Commit all registered inner units of work.
- commitTransaction(Object) - Method in class org.axonframework.unitofwork.NoTransactionManager
-
- commitTransaction(TransactionStatus) - Method in class org.axonframework.unitofwork.SpringTransactionManager
-
- commitTransaction(T) - Method in interface org.axonframework.unitofwork.TransactionManager
-
Commits the transaction identifier by given transactionStatus
.
- CompactDriver - Class in org.axonframework.serializer.xml
-
XStream HierarchicalStreamDriver implementation that uses a CompactWriter to write XML without newlines and
indentation, while writing it using the (default) XPPReader.
- CompactDriver() - Constructor for class org.axonframework.serializer.xml.CompactDriver
-
- compare(T, T) - Method in class org.axonframework.common.annotation.PriorityAnnotationComparator
-
- compare(EventListener, EventListener) - Method in class org.axonframework.eventhandling.EventListenerOrderComparator
-
- compareTo(AbstractMessageHandler) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
-
- compareTo(PropertyAccessStrategy) - Method in class org.axonframework.common.property.PropertyAccessStrategy
-
- compareTo(SagaMethodMessageHandler) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
-
- CompositeClusterSelector - Class in org.axonframework.eventhandling
-
ClusterSelector implementation that delegates the selection to a list of other ClusterSelectors.
- CompositeClusterSelector(List<ClusterSelector>) - Constructor for class org.axonframework.eventhandling.CompositeClusterSelector
-
Initializes the CompositeClusterSelector with the given List of delegates
.
- CompositeEventStreamDecorator - Class in org.axonframework.eventsourcing
-
EventStreamDecorator implementation that delegates to several other decorator instances.
- CompositeEventStreamDecorator(Collection<EventStreamDecorator>) - Constructor for class org.axonframework.eventsourcing.CompositeEventStreamDecorator
-
Initialize the decorator, delegating to the given eventStreamDecorators
.
- ConcurrencyException - Exception in org.axonframework.repository
-
Exception indicating that concurrent access to a repository was detected.
- ConcurrencyException(String) - Constructor for exception org.axonframework.repository.ConcurrencyException
-
Initialize a ConcurrencyException with the given message
.
- ConcurrencyException(String, Throwable) - Constructor for exception org.axonframework.repository.ConcurrencyException
-
Initialize a ConcurrencyException with the given message
and cause
.
- ConflictingAggregateVersionException - Exception in org.axonframework.repository
-
Exception indicating that the (actual) version of a loaded aggregate did not match the given expected version number.
- ConflictingAggregateVersionException(Object, long, long) - Constructor for exception org.axonframework.repository.ConflictingAggregateVersionException
-
Initializes the exception using the given message
.
- ConflictingAggregateVersionException(Object, long, long, Throwable) - Constructor for exception org.axonframework.repository.ConflictingAggregateVersionException
-
Initializes the exception using the given message
and cause
.
- ConflictingModificationException - Exception in org.axonframework.repository
-
Root of a hierarchy of exceptions indicating the detection of conflicting concurrent modifications.
- ConflictingModificationException(String) - Constructor for exception org.axonframework.repository.ConflictingModificationException
-
Initializes the exception using the given message
.
- ConflictingModificationException(String, Throwable) - Constructor for exception org.axonframework.repository.ConflictingModificationException
-
Initializes the exception using the given message
and cause
.
- ConflictResolver - Interface in org.axonframework.eventsourcing
-
Interface describing an object that is capable of detecting conflicts between changes applied to an aggregate, and
unseen changes made to the aggregate.
- ConnectionProvider - Interface in org.axonframework.common.jdbc
-
Interface towards a mechanism that provides access to a JDBC Connection.
- ConnectionWrapperFactory - Class in org.axonframework.common.jdbc
-
Factory for creating wrappers around a Connection, allowing one to override the behavior of the
Connection.close()
method.
- ConnectionWrapperFactory.ConnectionCloseHandler - Interface in org.axonframework.common.jdbc
-
Interface defining an operation to close the wrapped connection
- ConnectionWrapperFactory.NoOpCloseHandler - Class in org.axonframework.common.jdbc
-
Implementation of ConnectionCloseHandler that does nothing on close.
- ConnectionWrapperFactory.NoOpCloseHandler() - Constructor for class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
-
- ConstructorCommandMessageHandler<T extends AggregateRoot> - Class in org.axonframework.commandhandling.annotation
-
Command Handler that creates a new aggregate instance by invoking that aggregate's constructor.
- ContainerManagedEntityManagerProvider - Class in org.axonframework.common.jpa
-
EntityManagerProvider implementation that expects the container to inject the default container managed
EntityManager
instance.
- ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
-
- contains(AssociationValue) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- contains(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues
-
Indicates whether this instance contains the given associationValue
.
- containsKey(K) - Method in interface org.axonframework.cache.Cache
-
Indicates whether there is an item stored under given key
.
- containsKey(K) - Method in class org.axonframework.cache.EhCacheAdapter
-
- containsKey(K) - Method in class org.axonframework.cache.JCacheAdapter
-
- containsKey(Object) - Method in class org.axonframework.cache.NoCache
-
- containsKey(K) - Method in class org.axonframework.cache.WeakReferenceCache
-
- containsKey(Object) - Method in class org.axonframework.domain.MetaData
-
- containsValue(Object) - Method in class org.axonframework.domain.MetaData
-
- ContentTypeConverter<S,T> - Interface in org.axonframework.serializer
-
Interface describing a mechanism that converts the data type of IntermediateRepresentations of SerializedObjects for
Upcasters.
- convert(SerializedObject<S>) - Method in class org.axonframework.serializer.AbstractContentTypeConverter
-
- convert(Class<S>, Class<T>, S) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Convert the given source
, of type sourceType
to the given targetType
.
- convert(SerializedObject<S>) - Method in class org.axonframework.serializer.ChainedConverter
-
- convert(S) - Method in class org.axonframework.serializer.ChainedConverter
-
- convert(SerializedObject<S>) - Method in interface org.axonframework.serializer.ContentTypeConverter
-
Converts the data format of the given original
IntermediateRepresentation to the target data type.
- convert(S) - Method in interface org.axonframework.serializer.ContentTypeConverter
-
Converts the given object into another.
- convert(Blob) - Method in class org.axonframework.serializer.converters.BlobToInputStreamConverter
-
- convert(byte[]) - Method in class org.axonframework.serializer.converters.ByteArrayToInputStreamConverter
-
- convert(byte[]) - Method in class org.axonframework.serializer.converters.ByteArrayToStringConverter
-
- convert(InputStream) - Method in class org.axonframework.serializer.converters.InputStreamToByteArrayConverter
-
- convert(String) - Method in class org.axonframework.serializer.converters.StringToByteArrayConverter
-
- convert(byte[]) - Method in class org.axonframework.serializer.json.ByteArrayToJsonNodeConverter
-
- convert(JsonNode) - Method in class org.axonframework.serializer.json.JsonNodeToByteArrayConverter
-
- convert(Document) - Method in class org.axonframework.serializer.xml.Dom4JToByteArrayConverter
-
- convert(InputStream) - Method in class org.axonframework.serializer.xml.InputStreamToDom4jConverter
-
- convert(InputStream) - Method in class org.axonframework.serializer.xml.InputStreamToXomConverter
-
- convert(Document) - Method in class org.axonframework.serializer.xml.XomToStringConverter
-
- ConverterFactory - Interface in org.axonframework.serializer
-
Interface describing a mechanism that provides instances of ContentTypeConverter for a given source and target data
type.
- CorrelationAuditDataProvider - Class in org.axonframework.auditing
-
AuditDataProvider implementation that attaches the command identifier to each Event generated as result of that
Command.
- CorrelationAuditDataProvider() - Constructor for class org.axonframework.auditing.CorrelationAuditDataProvider
-
Initializes the CorrelationAuditDataProvider which attaches the Command Identifier to an Event's MetaData using
the default key ("
"command-identifier"").
- CorrelationAuditDataProvider(String) - Constructor for class org.axonframework.auditing.CorrelationAuditDataProvider
-
Initializes the CorrelationAuditDataProvider which attaches the Command Identifier to an Event's MetaData using
the given correlationIdKey
.
- correlationDataFor(T) - Method in interface org.axonframework.correlation.CorrelationDataProvider
-
Provides a map with the entries to attach as correlation data to generated messages while processing given
message
.
- correlationDataFor(T) - Method in class org.axonframework.correlation.MultiCorrelationDataProvider
-
- correlationDataFor(Message) - Method in class org.axonframework.correlation.SimpleCorrelationDataProvider
-
- CorrelationDataHolder - Class in org.axonframework.correlation
-
DataHolder for meta data entries that need to be attached to messages being generated by this thread.
- CorrelationDataProvider<T extends Message> - Interface in org.axonframework.correlation
-
Object defining the the data from a Message that should be attached as correlation data to messages generated as
result of the processing of that message.
- count() - Method in class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
-
- createAggregate(Object, DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
- createAggregate(Object, DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.AggregateFactory
-
Instantiate the aggregate using the given aggregate identifier and first event.
- createAutowiredBean(Class<?>...) - Static method in class org.axonframework.contextsupport.spring.AutowiredBean
-
Creates an autowired dependency on the given autowiredTypes
.
- createAutowiredBeanWithFallback(Object, Class<?>...) - Static method in class org.axonframework.contextsupport.spring.AutowiredBean
-
Creates an autowired dependency on the given autowiredTypes
.
- createDomainEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
- createDomainEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
Allows for customization of the DomainEventEntry to store.
- createDomainEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
-
Creates an entity representing a Domain Event, which contains the data provided in the parameters, which can be
stored using the JPA Entity Manager configured on the JpaEventStore using this factory.
- createEventHandlerInvoker(Object) - Method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
-
Creates a new MessageHandlerInvoker that invokes methods on the given instance
.
- createFor(Method, Class<?>, ParameterResolverFactory) - Static method in class org.axonframework.common.annotation.MethodMessageHandler
-
Creates a MethodMessageHandler for the given method
, using given explicitPayloadType
(if not null
) defining the payload of the message it supports.
- createGateway(Class<T>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
-
Creates a gateway instance for the given gatewayInterface
.
- createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.commandhandling.annotation.CurrentUnitOfWorkParameterResolverFactory
-
- createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.DefaultParameterResolverFactory
-
- createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.MultiParameterResolverFactory
-
- createInstance(Annotation[], Class<?>, Annotation[]) - Method in interface org.axonframework.common.annotation.ParameterResolverFactory
-
If available, creates a ParameterResolver instance that can provide a parameter of type
parameterType
for a given message.
- createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.SimpleResourceParameterResolverFactory
-
- createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.common.annotation.SpringBeanParameterResolverFactory
-
- createInstance(Annotation[], Class<?>, Annotation[]) - Method in class org.axonframework.eventhandling.annotation.AbstractAnnotatedParameterResolverFactory
-
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.cache.AbstractCacheAdapter
-
Creates an adapter for the given cacheEntryListener
.
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.cache.EhCacheAdapter
-
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.cache.JCacheAdapter
-
- createParameterResolverFactory() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
-
Creates (or returns) a ParameterResolverFactory which is used by this aggregate root to resolve the parameters
for @EventSourcingHandler annotated methods.
- createParameterResolverFactory() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
-
Creates (or returns) a ParameterResolverFactory which is used by this aggregate root to resolve the parameters
for @EventSourcingHandler annotated methods.
- createReader(Reader) - Method in class org.axonframework.serializer.xml.CompactDriver
-
- createReader(InputStream) - Method in class org.axonframework.serializer.xml.CompactDriver
-
- createReader(URL) - Method in class org.axonframework.serializer.xml.CompactDriver
-
- createReader(File) - Method in class org.axonframework.serializer.xml.CompactDriver
-
- createRepository(AggregateFactory<T>, EventStreamDecorator) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
-
Create a repository instance for an aggregate created by the given aggregateFactory
.
- createRepository(AggregateFactory<T>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
.
- createRepository(AggregateFactory<T>, EventStreamDecorator) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
.
- createRepositoryDefinition(Element, String, ParserContext, PropertyValue) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser
-
- createSaga(Class<T>) - Method in class org.axonframework.saga.GenericSagaFactory
-
- createSaga(Class<T>) - Method in interface org.axonframework.saga.SagaFactory
-
Create a new instance of a Saga of given type.
- createSchema() - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
-
Performs the DDL queries to create the schema necessary for this EventEntryStore implementation.
- createSchema() - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
-
Creates the SQL Schema required to store Sagas and their associations,.
- createSerializedDomainEventData(ResultSet) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Reads the current entry of the ResultSet into a SerializedDomainEventData.
- createSerializedDomainEventData(ResultSet) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- createSnapshot(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Creates a snapshot event for an aggregate of the given typeIdentifier
of which passed events are
available in the given eventStream
.
- createSnapshot(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-
- createSnapshotEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
- createSnapshotEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
Allows for customization of the SnapshotEventEntry to store.
- createSnapshotEventEntry(String, DomainEventMessage, SerializedObject<T>, SerializedObject<T>) - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
-
Creates an entity representing a Snapshot Event, which contains the data provided in the parameters, which can
be stored using the JPA Entity Manager configured on the JpaEventStore using this factory.
- createSnapshotterTask(String, Object) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Creates an instance of a task that contains the actual snapshot creation logic.
- createUnitOfWork() - Method in class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
-
- createUnitOfWork() - Method in interface org.axonframework.unitofwork.UnitOfWorkFactory
-
Creates a new UnitOfWork instance.
- createWriter(Writer) - Method in class org.axonframework.serializer.xml.CompactDriver
-
- createWriter(OutputStream) - Method in class org.axonframework.serializer.xml.CompactDriver
-
- Criteria - Interface in org.axonframework.eventstore.management
-
Interface describing the criteria that DomainEvent entries must match against.
- CriteriaBuilder - Interface in org.axonframework.eventstore.management
-
Interface providing access to the criteria API of an Event Store.
- CurrentUnitOfWork - Class in org.axonframework.unitofwork
-
Default entry point to gain access to the current UnitOfWork.
- CurrentUnitOfWorkParameterResolverFactory - Class in org.axonframework.commandhandling.annotation
-
ParameterResolverFactory that add support for the UnitOfWork parameter type in annotated handlers.
- CurrentUnitOfWorkParameterResolverFactory() - Constructor for class org.axonframework.commandhandling.annotation.CurrentUnitOfWorkParameterResolverFactory
-
- cutoff(DateTime) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
-
- DataSourceConnectionProvider - Class in org.axonframework.common.jdbc
-
ConnectionProvider implementation that obtains a connection from a given DataSource.
- DataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.common.jdbc.DataSourceConnectionProvider
-
Initialize the Connection Provider, using given dataSource
to obtain new connections.
- DeadlockException - Exception in org.axonframework.common.lock
-
Exception indicating that a deadlock has been detected while a thread was attempting to acquire a lock.
- DeadlockException(String) - Constructor for exception org.axonframework.common.lock.DeadlockException
-
Initializes the exception with given message
.
- declaringClass(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns the class on which the method with name "getter
" and parameters of type
parameterTypes
is declared.
- decorateForAppend(String, EventSourcedAggregateRoot, DomainEventStream) - Method in class org.axonframework.eventsourcing.CompositeEventStreamDecorator
-
- decorateForAppend(String, EventSourcedAggregateRoot, DomainEventStream) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
-
- decorateForAppend(String, EventSourcedAggregateRoot, DomainEventStream) - Method in interface org.axonframework.eventsourcing.EventStreamDecorator
-
Called when an event stream is appended to the event store.
- decorateForRead(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.CompositeEventStreamDecorator
-
- decorateForRead(String, Object, DomainEventStream) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
-
- decorateForRead(String, Object, DomainEventStream) - Method in interface org.axonframework.eventsourcing.EventStreamDecorator
-
Called when an event stream is read from the event store.
- DEFAULT_ASSOC_VALUE_ENTRY_TABLE - Static variable in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
-
- DEFAULT_BUFFER_SIZE - Static variable in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
The default size of the buffer in this configuration
- DEFAULT_CORRELATION_KEY - Static variable in class org.axonframework.auditing.CorrelationAuditDataProvider
-
The default meta-data key, which is used when an instance is created using the default constructor
- DEFAULT_DOMAINEVENT_TABLE - Static variable in class org.axonframework.eventstore.jdbc.SchemaConfiguration
-
- DEFAULT_SAGA_ENTRY_TABLE - Static variable in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
-
- DEFAULT_SNAPSHOTEVENT_TABLE - Static variable in class org.axonframework.eventstore.jdbc.SchemaConfiguration
-
- DefaultClusterMetaData - Class in org.axonframework.eventhandling
-
Default implementation of ClusterMetaData.
- DefaultClusterMetaData() - Constructor for class org.axonframework.eventhandling.DefaultClusterMetaData
-
- DefaultClusterSelector - Class in org.axonframework.eventhandling
-
ClusterSelector implementation that always selects the same cluster.
- DefaultClusterSelector() - Constructor for class org.axonframework.eventhandling.DefaultClusterSelector
-
Initializes the DefaultClusterSelector using a
SimpleCluster
with
identifier "default", to which this instance will assign all Event Listeners.
- DefaultClusterSelector(Cluster) - Constructor for class org.axonframework.eventhandling.DefaultClusterSelector
-
Initializes the DefaultClusterSelector to assign the given defaultCluster
to each listener.
- DefaultCommandGateway - Class in org.axonframework.commandhandling.gateway
-
Default implementation of the CommandGateway interface.
- DefaultCommandGateway(CommandBus, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Initializes a command gateway that dispatches commands to the given commandBus
after they have been
handles by the given commandDispatchInterceptors
.
- DefaultCommandGateway(CommandBus, RetryScheduler, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Initializes a command gateway that dispatches commands to the given commandBus
after they have been
handles by the given commandDispatchInterceptors
.
- DefaultCommandGateway(CommandBus, RetryScheduler, List<CommandDispatchInterceptor>) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Initializes a command gateway that dispatches commands to the given commandBus
after they have been
handles by the given commandDispatchInterceptors
.
- DefaultErrorHandler - Class in org.axonframework.eventhandling.async
-
An ErrorHandler implementation that returns a fixed RetryPolicy instance when an error occurs.
- DefaultErrorHandler(RetryPolicy) - Constructor for class org.axonframework.eventhandling.async.DefaultErrorHandler
-
Initializes the ErrorHandler, making it return the given retryPolicy
when an error occurs.
- DefaultEventEntryFactory - Class in org.axonframework.eventstore.jpa
-
Implementation of the EventEntryFactory that provides the default Axon entities, which store payload and meta data
of Events as byte arrays.
- DefaultEventEntryFactory() - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
Creates a new instance of the factory which stores the timestamps with the original timezone of the event
messages.
- DefaultEventEntryFactory(boolean) - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
Creates a new instance of the factory which, when forceUtc
true
, stores the timestamps
converted to UTC timezone.
- DefaultEventEntryStore<T> - Class in org.axonframework.eventstore.jdbc
-
Implementation of the EventEntryStore that stores events in DomainEventEntry table and snapshot events in
SnapshotEventEntry table.
- DefaultEventEntryStore(DataSource, EventSqlSchema<T>) - Constructor for class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
-
Initialize the EventEntryStore, fetching connections from the given dataSource
and executing SQL
statements using given sqlSchema
.
- DefaultEventEntryStore(ConnectionProvider, EventSqlSchema<T>) - Constructor for class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
-
Initialize the EventEntryStore, fetching connections from the given connectionProvider
and
executing
SQL
statements using given sqlSchema
.
- DefaultEventEntryStore(ConnectionProvider) - Constructor for class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
-
Initialize the EventEntryStore using a Generic SQL Schema, and given connectionProvider
to obtain
connections.
- DefaultEventEntryStore<T> - Class in org.axonframework.eventstore.jpa
-
Implementation of the EventEntryStore that stores events in DomainEventEntry entities and snapshot events in
SnapshotEventEntry entities.
- DefaultEventEntryStore() - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
Initialize the Event Entry Store, storing timestamps in the system timezone and storing serialized data as byte
arrays.
- DefaultEventEntryStore(boolean) - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
Initializes the EventEntryStore, storing serialized data as byte arrays, with the possibility to force
timestamps to be stored in UTC timezone.
- DefaultEventEntryStore(EventEntryFactory<T>) - Constructor for class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
Initializes the EventEntryStore, using the given eventEntryFactory
to provide instances of the
JPA entities to use for persistence.
- DefaultIdentifierFactory - Class in org.axonframework.domain
-
Default IdentifierFactory implementation that uses generates random java.util.UUID
based identifiers.
- DefaultIdentifierFactory() - Constructor for class org.axonframework.domain.DefaultIdentifierFactory
-
- DefaultInterceptorChain - Class in org.axonframework.commandhandling
-
Mechanism that takes care of interceptor and event handler execution.
- DefaultInterceptorChain(CommandMessage<?>, UnitOfWork, CommandHandler<?>, Iterable<? extends CommandHandlerInterceptor>) - Constructor for class org.axonframework.commandhandling.DefaultInterceptorChain
-
Initialize the default interceptor chain to dispatch the given command
, through the
chain
, to the handler
.
- DefaultParameterResolverFactory - Class in org.axonframework.common.annotation
-
Factory for the default parameter resolvers.
- DefaultParameterResolverFactory() - Constructor for class org.axonframework.common.annotation.DefaultParameterResolverFactory
-
- DefaultUnitOfWork - Class in org.axonframework.unitofwork
-
Implementation of the UnitOfWork that buffers all published events until it is committed.
- DefaultUnitOfWork() - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWork
-
Initializes a Unit of Work (without starting it) that is not bound to any transaction.
- DefaultUnitOfWork(TransactionManager<?>) - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWork
-
Initializes a Unit of Work (without starting it) that is binds to the transaction created by the given
transactionManager
when the Unit of Work starts.
- DefaultUnitOfWorkFactory - Class in org.axonframework.unitofwork
-
- DefaultUnitOfWorkFactory() - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
-
Initializes the Unit of Work Factory to create Unit of Work that are not bound to any transaction.
- DefaultUnitOfWorkFactory(TransactionManager) - Constructor for class org.axonframework.unitofwork.DefaultUnitOfWorkFactory
-
Initializes the factory to create Unit of Work bound to transactions managed by the given
transactionManager
- deleteSaga(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
-
Remove the given saga as well as all known association values pointing to it from the repository.
- deleteSaga(Saga) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
-
- deleteSaga(Saga) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
-
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Deserializes the first object read from the given bytes
.
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.JavaSerializer
-
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.json.JacksonSerializer
-
- deserialize(JsonParser, DeserializationContext) - Method in class org.axonframework.serializer.json.JodaDeserializer
-
- deserialize(JsonParser, DeserializationContext) - Method in class org.axonframework.serializer.json.MetaDataDeserializer
-
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serializer.MessageSerializer
-
- deserialize(SerializedObject<S>) - Method in interface org.axonframework.serializer.Serializer
-
Deserializes the first object read from the given bytes
.
- destroy() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- Digester - Class in org.axonframework.common.digest
-
Utility class for generating hashes for values using several algorithms.
- digestHex() - Method in class org.axonframework.common.digest.Digester
-
Returns the hex representation of the digest of all data that has been provided so far.
- DirectExecutor - Class in org.axonframework.common
-
Simple executor implementation that runs a given Runnable immediately in the calling thread.
- DirectExecutor() - Constructor for class org.axonframework.common.DirectExecutor
-
- DiscardingIncomingMessageHandler - Class in org.axonframework.eventhandling.replay
-
IncomingMessageHandler implementation that simply discards all messages dispatch during a replay process.
- DiscardingIncomingMessageHandler() - Constructor for class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
-
- dispatch(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.CommandBus
-
Dispatch the given command
to the CommandHandler subscribed to that type of command
.
- dispatch(CommandMessage<?>, CommandCallback<R>) - Method in interface org.axonframework.commandhandling.CommandBus
-
Dispatch the given command
to the CommandHandler subscribed to that type of command
.
- dispatch(CommandMessage<?>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
- dispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
- dispatch(CommandMessage<?>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
- dispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
- DisruptorCommandBus - Class in org.axonframework.commandhandling.disruptor
-
Asynchronous CommandBus implementation with very high performance characteristics.
- DisruptorCommandBus(EventStore, EventBus) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Initialize the DisruptorCommandBus with given resources, using default configuration settings.
- DisruptorCommandBus(EventStore, EventBus, DisruptorConfiguration) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Initialize the DisruptorCommandBus with given resources and settings.
- DisruptorCommandBusBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
BeanDefinitionParser that parses <disruptor-command-bus>
elements in the Spring context
- DisruptorCommandBusBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.DisruptorCommandBusBeanDefinitionParser
-
- DisruptorConfiguration - Class in org.axonframework.commandhandling.disruptor
-
Configuration object for the DisruptorCommandBus.
- DisruptorConfiguration() - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Initializes a configuration instance with default settings: ring-buffer size: 4096, blocking wait strategy and
multi-threaded producer type.
- DisruptorRepositoryBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
Bean Definition parsers that parses disruptor-repository elements.
- DisruptorRepositoryBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser
-
- DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean - Class in org.axonframework.contextsupport.spring
-
FactoryBean to create repository instances for use with the DisruptorCommandBus
- DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean() - Constructor for class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
-
- DisruptorUnitOfWork - Class in org.axonframework.commandhandling.disruptor
-
Specialized UnitOfWork instance for the DisruptorCommandBus.
- DisruptorUnitOfWork(boolean) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Creates a new Unit of Work for use in the DisruptorCommandBus.
- doCommit() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- doCommit() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
Executes the logic required to commit this unit of work.
- doCreateAggregate(Object, DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
Create an uninitialized Aggregate instance with the given aggregateIdentifier
.
- doCreateAggregate(Object, DomainEventMessage) - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
-
Create an uninitialized Aggregate instance with the given aggregateIdentifier
.
- doCreateAggregate(Object, DomainEventMessage) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
- doDelete(T) - Method in class org.axonframework.repository.AbstractRepository
-
Removes the aggregate from the repository.
- doDelete(T) - Method in class org.axonframework.repository.LockingRepository
-
- doDeleteWithLock(T) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
- doDeleteWithLock(T) - Method in class org.axonframework.eventsourcing.HybridJpaRepository
-
- doDeleteWithLock(T) - Method in class org.axonframework.repository.GenericJpaRepository
-
- doDeleteWithLock(T) - Method in class org.axonframework.repository.LockingRepository
-
Perform the actual deleting of the aggregate.
- doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Deserialize the given serializedObject
.
- doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serializer.xml.XStreamSerializer
-
Deserialize the given serializedObject
.
- doDispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
-
- doDispatch(CommandMessage, CommandCallback<R>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Forces a dispatch of a command.
- doDispatch(CommandMessage<?>, CommandCallback<R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Performs the actual dispatching logic.
- doHandle(EventMessage<?>) - Method in class org.axonframework.eventhandling.async.EventProcessor
-
Does the actual processing of the event.
- doInsertEventEntry(String, Connection, String, String, long, DateTime, String, String, T, T, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
Creates a statement to insert an entry with given attributes in the given tableName
.
- doLoad(Object, Long) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Perform the actual loading of an aggregate.
- doLoad(Object, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Perform the actual loading of an aggregate.
- doLoad(Object, Long) - Method in class org.axonframework.repository.AbstractRepository
-
Loads and initialized the aggregate with the given aggregateIdentifier.
- doLoad(Object, Long) - Method in class org.axonframework.repository.GenericJpaRepository
-
- doLoad(Object, Long) - Method in class org.axonframework.repository.LockingRepository
-
Perform the actual loading of an aggregate.
- Dom4JToByteArrayConverter - Class in org.axonframework.serializer.xml
-
Converter that converts Dom4j Document instances to a byte array.
- Dom4JToByteArrayConverter() - Constructor for class org.axonframework.serializer.xml.Dom4JToByteArrayConverter
-
- DomainEventEntry - Class in org.axonframework.eventstore.jpa
-
JPA compliant wrapper around a DomainEvent.
- DomainEventEntry() - Constructor for class org.axonframework.eventstore.jpa.DomainEventEntry
-
Default constructor, as required by JPA specification.
- DomainEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.DomainEventEntry
-
Initialize an Event entry for the given event
.
- DomainEventEntry(String, DomainEventMessage, DateTime, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.DomainEventEntry
-
Initialize an Event entry for the given event
.
- domainEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
The name of the DomainEventEntry entity to use when querying for domain events.
- domainEventEntryTable() - Method in class org.axonframework.eventstore.jdbc.SchemaConfiguration
-
- DomainEventMessage<T> - Interface in org.axonframework.domain
-
Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain.
- DomainEventStream - Interface in org.axonframework.domain
-
The DomainEventStream represents a stream of historical domain events.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.JdbcEventStoreBeanDefinitionParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
- doParse(Element, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.JpaRepositoryBeanDefinitionParser
-
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
-
- doPublish(List<EventMessage>, Set<EventListener>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.AbstractCluster
-
Publish the given list of events
to the given set of eventListeners
, and notify the
given eventProcessingMonitor
after completion.
- doPublish(List<EventMessage>, Set<EventListener>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.async.AsynchronousCluster
-
- doPublish(List<EventMessage>, Set<EventListener>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.SimpleCluster
-
- doRegisterListener(L) - Method in class org.axonframework.cache.AbstractCacheAdapter
-
Registers the given listener with the cache implementation
- doRegisterListener(CacheEventListener) - Method in class org.axonframework.cache.EhCacheAdapter
-
- doRegisterListener(CacheEntryListenerConfiguration) - Method in class org.axonframework.cache.JCacheAdapter
-
- doRollback(Throwable) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- doRollback(Throwable) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
Executes the logic required to commit this unit of work.
- doSave(T) - Method in class org.axonframework.repository.AbstractRepository
-
Performs the actual saving of the aggregate.
- doSave(T) - Method in class org.axonframework.repository.LockingRepository
-
- doSaveWithLock(T) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Perform the actual saving of the aggregate.
- doSaveWithLock(T) - Method in class org.axonframework.eventsourcing.HybridJpaRepository
-
- doSaveWithLock(T) - Method in class org.axonframework.repository.GenericJpaRepository
-
- doSaveWithLock(T) - Method in class org.axonframework.repository.LockingRepository
-
Perform the actual saving of the aggregate.
- doSelectCluster(EventListener, Class<?>) - Method in class org.axonframework.eventhandling.AbstractClusterSelector
-
Select a cluster for the given eventListener
, which has the actual class listenerType
.
- doSelectCluster(EventListener, Class<?>) - Method in class org.axonframework.eventhandling.AnnotationClusterSelector
-
- doSelectCluster(EventListener, Class) - Method in class org.axonframework.eventhandling.ClassNamePatternClusterSelector
-
- doSelectCluster(EventListener, Class<?>) - Method in class org.axonframework.eventhandling.ClassNamePrefixClusterSelector
-
- doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Serialize the given object
to the given expectedFormat
.
- doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serializer.xml.XStreamSerializer
-
- doStart() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- doStart() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
Performs logic required when starting this UnitOfWork instance.
- doUnregisterListener(L) - Method in class org.axonframework.cache.AbstractCacheAdapter
-
Unregisters the given listener
with the cache
- doUnregisterListener(CacheEventListener) - Method in class org.axonframework.cache.EhCacheAdapter
-
- doUnregisterListener(CacheEntryListenerConfiguration) - Method in class org.axonframework.cache.JCacheAdapter
-
- doUpcast(SerializedObject<T>, UpcastingContext) - Method in class org.axonframework.upcasting.AbstractSingleEntryUpcaster
-
Upcasts the given intermediateRepresentation
into zero or more other representations.
- doUpcast(SerializedType) - Method in class org.axonframework.upcasting.AbstractSingleEntryUpcaster
-
Upcast the given serializedType
into its new format.
- doUpcast(Upcaster<T>, SerializedObject<?>, List<SerializedType>, UpcastingContext) - Method in class org.axonframework.upcasting.AbstractUpcasterChain
-
Performs the actual upcasting by the given upcaster
on the given sourceObject
.
- doUpcast(Upcaster<T>, SerializedObject<?>, List<SerializedType>, UpcastingContext) - Method in class org.axonframework.upcasting.LazyUpcasterChain
-
- doUpcast(Upcaster<T>, SerializedObject<?>, List<SerializedType>, UpcastingContext) - Method in class org.axonframework.upcasting.SimpleUpcasterChain
-
- doWithEvent(DomainEventMessage) - Method in interface org.axonframework.eventstore.EventVisitor
-
Called for each event loaded by the event store.
- doWithEvent(DomainEventMessage) - Method in class org.axonframework.eventstore.supporting.CapturingEventVisitor
-
- EhCacheAdapter - Class in org.axonframework.cache
-
Cache implementation that delegates all calls to an EhCache instance.
- EhCacheAdapter(Ehcache) - Constructor for class org.axonframework.cache.EhCacheAdapter
-
Initialize the adapter to forward all call to the given ehCache
instance
- EMPTY - Static variable in class org.axonframework.upcasting.SimpleUpcasterChain
-
Represents an empty UpcasterChain.
- EmptyDataProvider - Class in org.axonframework.auditing
-
- EmptyDataProvider() - Constructor for class org.axonframework.auditing.EmptyDataProvider
-
- emptyInstance() - Static method in class org.axonframework.domain.MetaData
-
Returns an empty MetaData instance.
- 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(T) - Static method in class org.axonframework.common.ReflectionUtils
-
Makes the given member
accessible via reflection if it is not the case already.
- ensureCorrectContentType(SerializedObject<S>, Class<T>) - Method in class org.axonframework.upcasting.AbstractUpcasterChain
-
Converts, if necessary, the given serializedObject
, and returns a SerializedObject with given
expectedContentType
.
- EntityManagerProvider - Interface in org.axonframework.common.jpa
-
Provides components with an EntityManager to access the persistence mechanism.
- entrySet() - Method in class org.axonframework.domain.MetaData
-
- equals(Object) - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
-
- equals(Object) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
-
- equals(Object) - Method in class org.axonframework.common.annotation.MethodMessageHandler
-
- equals(Object) - Method in class org.axonframework.domain.MetaData
-
- Equals - Class in org.axonframework.eventstore.jdbc.criteria
-
Implementation of the EQUALS operator for a Jdbc Event Store.
- Equals(JdbcProperty, Object) - Constructor for class org.axonframework.eventstore.jdbc.criteria.Equals
-
Initializes an Equals operator matching the given property
against the given
expression
.
- equals(Object) - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData.PK
-
- Equals - Class in org.axonframework.eventstore.jpa.criteria
-
Implementation of the EQUALS operator for a JPA Event Store.
- Equals(JpaProperty, Object) - Constructor for class org.axonframework.eventstore.jpa.criteria.Equals
-
Initializes an Equals operator matching the given property
against the given
expression
.
- equals(Object) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
-
- equals(Object) - Method in class org.axonframework.saga.AssociationValue
-
- equals(Object) - Method in class org.axonframework.serializer.SerializedMetaData
-
- equals(Object) - Method in class org.axonframework.serializer.SimpleSerializedObject
-
- equals(Object) - Method in class org.axonframework.serializer.SimpleSerializedType
-
- ErrorHandler - Interface in org.axonframework.eventhandling.async
-
Interface describing a mechanism that decides what should happen when an asynchronously handled event raises an
error.
- ErrorHandler - Interface in org.axonframework.saga.annotation
-
Defines the behavior of a component when an error occurs during Event Processing in a Saga.
- EVENT_BUS_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
-
The key used to locate the Event Bus in the scheduler context.
- EVENT_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
-
The key used to locate the event in the JobExecutionContext.
- EventBus - Interface in org.axonframework.eventhandling
-
Specification of the mechanism on which the Event Listeners can subscribe for events and event publishers can
publish
their events.
- EventBusBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
The EventBusBeanDefinitionParser is responsible for parsing the eventBus
element from the Axon
namespace.
- EventBusBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.EventBusBeanDefinitionParser
-
- EventBusTerminal - Interface in org.axonframework.eventhandling
-
Interface describing a mechanism that connects Event Bus clusters.
- EventContainer - Class in org.axonframework.domain
-
Container for events related to a single aggregate.
- EventContainer(Object) - Constructor for class org.axonframework.domain.EventContainer
-
Initialize an EventContainer for an aggregate with the given aggregateIdentifier
.
- EventCountSnapshotterTrigger - Class in org.axonframework.eventsourcing
-
Snapshotter trigger mechanism that counts the number of events to decide when to create a snapshot.
- EventCountSnapshotterTrigger() - Constructor for class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
-
- EventEntryFactory<T> - Interface in org.axonframework.eventstore.jpa
-
Interface describing a factory that creates Entities for the JpaEventStore to persist.
- EventEntryStore<T> - Interface in org.axonframework.eventstore.jdbc
-
Interface describing the mechanism that stores Events into the backing data store.
- EventEntryStore<T> - Interface in org.axonframework.eventstore.jpa
-
Interface describing the mechanism that stores Events into the backing data store.
- eventFileExists(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
-
Indicates whether there is a file containing (regular) events for the given aggregateIdentifier
of
given type
.
- eventFileExists(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
-
- EventFileResolver - Interface in org.axonframework.eventstore.fs
-
Interface that allows basic access to InputStreams and appending OutputStreams to event logs for aggregates.
- EventHandler - Annotation Type in org.axonframework.eventhandling.annotation
-
Annotation to be placed on methods that can handle events.
- EventListener - Interface in org.axonframework.eventhandling
-
Interface to be implemented by classes that can handle events.
- EventListenerOrderComparator - Class in org.axonframework.eventhandling
-
Comparator implementation that uses an
OrderResolver
instance to define the expected order of two
candidates.
- EventListenerOrderComparator(OrderResolver) - Constructor for class org.axonframework.eventhandling.EventListenerOrderComparator
-
Creates a comparator using given orderResolver
to resolve the "order" value.
- EventListenerProxy - Interface in org.axonframework.eventhandling
-
Specialist interface for implementations of an event listener that redirect actual processing to another instance.
- EventListenerSubscriptionFailedException - Exception in org.axonframework.eventhandling
-
Exception indicating that the subscription of an Event Listener has not succeeded.
- EventListenerSubscriptionFailedException(String) - Constructor for exception org.axonframework.eventhandling.EventListenerSubscriptionFailedException
-
Initializes the exception with given descriptive message
.
- EventListenerSubscriptionFailedException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.EventListenerSubscriptionFailedException
-
Initializes the exception with given descriptive message
and originating cause
.
- EventMessage<T> - Interface in org.axonframework.domain
-
Represents a Message wrapping an Event, which is represented by its payload.
- EventMessageReader - Class in org.axonframework.eventhandling.io
-
Reader that reads EventMessage instances written to the underlying input.
- EventMessageReader(DataInputStream, Serializer) - Constructor for class org.axonframework.eventhandling.io.EventMessageReader
-
Creates a new EventMessageReader that reads the data from the given input
and deserializes payload
and meta data using the given serializer
.
- EventMessageType - Enum in org.axonframework.eventhandling.io
-
- EventMessageWriter - Class in org.axonframework.eventhandling.io
-
Writer that writes Event Messages onto a an OutputStream.
- EventMessageWriter(DataOutput, Serializer) - Constructor for class org.axonframework.eventhandling.io.EventMessageWriter
-
Creates a new EventMessageWriter writing data to the specified underlying output
.
- EventProcessingMonitor - Interface in org.axonframework.eventhandling
-
Interface describing a mechanism that listens for the results of events being processed.
- EventProcessingMonitorCollection - Class in org.axonframework.eventhandling
-
Implementation of the EventProcessingMonitor that delegates to all registered EventProcessingMonitor instances.
- EventProcessingMonitorCollection() - Constructor for class org.axonframework.eventhandling.EventProcessingMonitorCollection
-
- EventProcessingMonitorSupport - Interface in org.axonframework.eventhandling
-
Interface indicating that the implementing class is capable of notifying monitors when event processing completes.
- EventProcessor - Class in org.axonframework.eventhandling.async
-
Scheduler that keeps track of (Event processing) tasks that need to be executed sequentially.
- EventProcessor(Executor, EventProcessor.ShutdownCallback, ErrorHandler, UnitOfWorkFactory, Set<EventListener>, MultiplexingEventProcessingMonitor) - Constructor for class org.axonframework.eventhandling.async.EventProcessor
-
Initialize a scheduler using the given executor
.
- EventProcessor.ProcessingResult - Class in org.axonframework.eventhandling.async
-
Class indicating the result of Event Processing and the policy for resuming or retrying in case of errors.
- EventProcessor.ProcessingResult(RetryPolicy, Throwable) - Constructor for class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
-
Creates an instance requiring the given retryPolicy
and reporting the given (optional)
error
to indicate a failure.
- EventProcessor.ShutdownCallback - Interface in org.axonframework.eventhandling.async
-
Callback that allows the SequenceManager to receive a notification when this scheduler finishes processing
events.
- EventPublisher - Class in org.axonframework.commandhandling.disruptor
-
Component of the DisruptorCommandBus that stores and publishes events generated by the command's execution.
- EventPublisher(EventStore, EventBus, Executor, TransactionManager, RollbackConfiguration, int) - Constructor for class org.axonframework.commandhandling.disruptor.EventPublisher
-
Initializes the EventPublisher to publish Events to the given eventStore
and eventBus
for aggregate of given aggregateType
.
- EventRegistrationCallback - Interface in org.axonframework.domain
-
Callback that allows components to be notified of an event being registered with an Aggregate.
- EventReplayUnsupportedException - Exception in org.axonframework.eventhandling.replay
-
Exception that indicates that event replays are not supported by a component.
- EventReplayUnsupportedException(String) - Constructor for exception org.axonframework.eventhandling.replay.EventReplayUnsupportedException
-
Initialize the exception with the given message
.
- EventScheduler - Interface in org.axonframework.eventhandling.scheduling
-
Interface towards a mechanism capable of scheduling the publication of events.
- EventSourcedAggregateRoot<I> - Interface in org.axonframework.eventsourcing
-
- EventSourcedEntity - Interface in org.axonframework.eventsourcing
-
Interface towards an Event Sourced Entity that is part of an aggregate, but not its root.
- EventSourcedMember - Annotation Type in org.axonframework.eventsourcing.annotation
-
Field-level annotation that indicates the objects referred to in the field are a child of the current entity.
- EventSourcingHandler - Annotation Type in org.axonframework.eventsourcing.annotation
-
Annotation that marks a method in an Aggregate (either the root, or an entity) as a handler for Events generated by
that aggregate.
- EventSourcingRepository<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
-
Abstract repository implementation that allows easy implementation of an Event Sourcing mechanism.
- EventSourcingRepository(Class<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initializes a repository with the default locking strategy, using a GenericAggregateFactory to create new
aggregate instances of given aggregateType
.
- EventSourcingRepository(AggregateFactory<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initializes a repository with the default locking strategy, using the given aggregateFactory
to
create new aggregate instances.
- EventSourcingRepository(AggregateFactory<T>, EventStore, LockManager) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initialize a repository with the given locking strategy.
- EventSourcingRepository(Class<T>, EventStore, LockManager) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initialize a repository with the given locking strategy, using a GenericAggregateFactory to create new aggregate
instances.
- EventSqlSchema<T> - Interface in org.axonframework.eventstore.jdbc
-
Interface describing the operations that the JDBC Event Store needs to do on a backing database.
- EventStore - Interface in org.axonframework.eventstore
-
Abstraction of the event storage mechanism.
- EventStoreException - Exception in org.axonframework.eventstore
-
Indicates that the given events stream could not be stored or read due to an underlying exception.
- EventStoreException(String) - Constructor for exception org.axonframework.eventstore.EventStoreException
-
Initialize the exception with the given message
.
- EventStoreException(String, Throwable) - Constructor for exception org.axonframework.eventstore.EventStoreException
-
Initialize the exception with the given message
and cause
- EventStoreManagement - Interface in org.axonframework.eventstore.management
-
Interface describing operations useful for management purposes.
- EventStreamDecorator - Interface in org.axonframework.eventsourcing
-
Interface describing a class that can decorates DomainEventStreams when events for aggregates are read or appended.
- EventStreamNotFoundException - Exception in org.axonframework.eventstore
-
Exception indicating that the event store could not find an event stream for a given aggregate type and identifier.
- EventStreamNotFoundException(String) - Constructor for exception org.axonframework.eventstore.EventStreamNotFoundException
-
Initialize the exception with the given message
.
- EventStreamNotFoundException(String, Object) - Constructor for exception org.axonframework.eventstore.EventStreamNotFoundException
-
Initialize the exception with a default message for a given aggregate identifier
of given
type
.
- EventStreamNotFoundException(String, Throwable) - Constructor for exception org.axonframework.eventstore.EventStreamNotFoundException
-
Initialize the exception with the given message
and cause
.
- EventTemplate - Class in org.axonframework.eventhandling
-
Template class that dispatches Events to an
EventBus
, taking active
UnitOfWork into account.
- EventTemplate(EventBus) - Constructor for class org.axonframework.eventhandling.EventTemplate
-
Initialize the template to publish Events through the given eventBus
.
- EventTemplate(EventBus, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.EventTemplate
-
Initialize the template to publish Events through the given eventBus
.
- EventVisitor - Interface in org.axonframework.eventstore
-
Interface describing an instance of a visitor that receives events for processing.
- execute(Runnable) - Method in class org.axonframework.common.DirectExecutor
-
Executes the given command
immediately in the current thread.
- execute(JobExecutionContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
-
- expectedRepresentationType() - Method in interface org.axonframework.upcasting.Upcaster
-
Returns the type of intermediate representation this upcaster expects.
- expectedSourceType() - Method in class org.axonframework.serializer.ChainedConverter
-
- expectedSourceType() - Method in interface org.axonframework.serializer.ContentTypeConverter
-
The expected type of input data.
- expectedSourceType() - Method in class org.axonframework.serializer.converters.BlobToInputStreamConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.converters.ByteArrayToInputStreamConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.converters.ByteArrayToStringConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.converters.InputStreamToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.converters.StringToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.json.ByteArrayToJsonNodeConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.json.JsonNodeToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.xml.Dom4JToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.xml.InputStreamToDom4jConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.xml.InputStreamToXomConverter
-
- expectedSourceType() - Method in class org.axonframework.serializer.xml.XomToStringConverter
-
- explicitlyUnequal(Object, Object) - Static method in class org.axonframework.common.ReflectionUtils
-
Indicates whether the two given objects are
not the same, override an equals method that indicates
they are
not equal, or implements
Comparable
which indicates the two are not equal.
- ExtendedUpcaster<T> - Interface in org.axonframework.upcasting
-
Extension of the Upcaster interface that allows type upcasting to be based on the contents of the
serialized object.
- extractAssociationValues(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.AbstractSagaManager
-
Extracts the AssociationValues from the given event
as relevant for a Saga of given
sagaType
.
- extractAssociationValues(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
-
- extractAssociationValues(EventMessage) - Method in interface org.axonframework.saga.AssociationValueResolver
-
Extracts an Association Value from the given event
.
- extractAssociationValues(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.SimpleSagaManager
-
- GatewayProxyFactory - Class in org.axonframework.commandhandling.gateway
-
Factory that creates Gateway implementations from custom interface definitions.
- GatewayProxyFactory(CommandBus, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.GatewayProxyFactory
-
Initialize the factory sending Commands to the given commandBus
, optionally intercepting them with
given dispatchInterceptors
.
- GatewayProxyFactory(CommandBus, RetryScheduler, CommandDispatchInterceptor...) - Constructor for class org.axonframework.commandhandling.gateway.GatewayProxyFactory
-
Initialize the factory sending Commands to the given commandBus
, optionally intercepting them with
given dispatchInterceptors
.
- GatewayProxyFactory(CommandBus, RetryScheduler, List<CommandDispatchInterceptor>) - Constructor for class org.axonframework.commandhandling.gateway.GatewayProxyFactory
-
Initialize the factory sending Commands to the given commandBus
, optionally intercepting them with
given dispatchInterceptors
.
- GatewayProxyFactory.InvocationHandler<R> - Interface in org.axonframework.commandhandling.gateway
-
Interface towards the mechanism that handles a method call on a gateway interface method.
- generateIdentifier() - Method in class org.axonframework.domain.DefaultIdentifierFactory
-
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
- generateIdentifier() - Method in class org.axonframework.domain.IdentifierFactory
-
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
- GenericAggregateFactory<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
-
Aggregate factory that uses a convention to create instances of aggregates.
- GenericAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
-
Initialize the AggregateFactory for creating instances of the given aggregateType
.
- GenericAggregateFactory(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
-
Initialize the AggregateFactory for creating instances of the given aggregateType
and using the
given parameterResolverFactory
to resolve parameters of annotated event handler methods.
- GenericCommandMessage<T> - Class in org.axonframework.commandhandling
-
Implementation of the CommandMessage that takes all properties as constructor parameters.
- GenericCommandMessage(T) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload and empty metaData
- GenericCommandMessage(T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload.
- GenericCommandMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload.
- GenericCommandMessage(String, String, T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload and a custom chosen
identifier
.
- GenericCommandMessage(GenericCommandMessage<T>, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Copy constructor that allows creation of a new GenericCommandMessage with modified metaData.
- GenericDomainEventMessage<T> - Class in org.axonframework.domain
-
Generic implementation of the DomainEventMessage interface.
- GenericDomainEventMessage(Object, long, T) - Constructor for class org.axonframework.domain.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
and payload
.
- GenericDomainEventMessage(Object, long, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
, metaData
and payload
.
- GenericDomainEventMessage(String, DateTime, Object, long, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericDomainEventMessage
-
Constructor to reconstruct a DomainEventMessage using existing data.
- GenericEventMessage<T> - Class in org.axonframework.domain
-
Generic implementation of the EventMessage interface.
- GenericEventMessage(T) - Constructor for class org.axonframework.domain.GenericEventMessage
-
Creates a GenericEventMessage with given payload
, and an empty MetaData.
- GenericEventMessage(T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericEventMessage
-
Creates a GenericEventMessage with given payload
and given metaData
.
- GenericEventMessage(String, DateTime, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericEventMessage
-
Constructor to reconstruct an EventMessage using existing data.
- GenericEventSqlSchema<T> - Class in org.axonframework.eventstore.jdbc
-
- GenericEventSqlSchema() - Constructor for class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
Initialize a GenericEventSqlSchema using default settings.
- GenericEventSqlSchema(Class<T>) - Constructor for class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
Initialize a GenericEventSqlSchema.
- GenericEventSqlSchema(Class<T>, SchemaConfiguration) - Constructor for class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
Initialize a GenericEventSqlSchema.
- GenericJpaRepository<T extends AggregateRoot> - Class in org.axonframework.repository
-
Generic repository implementation that stores JPA annotated aggregates.
- GenericJpaRepository(EntityManagerProvider, Class<T>) - Constructor for class org.axonframework.repository.GenericJpaRepository
-
Initialize a repository for storing aggregates of the given aggregateType
.
- GenericJpaRepository(EntityManagerProvider, Class<T>, LockManager) - Constructor for class org.axonframework.repository.GenericJpaRepository
-
Initialize a repository for storing aggregates of the given aggregateType
with an additional
lockManager
.
- GenericMessage<T> - Class in org.axonframework.domain
-
Generic implementation of the Message interface.
- GenericMessage(T) - Constructor for class org.axonframework.domain.GenericMessage
-
Constructs a Message for the given payload
using empty meta data.
- GenericMessage(T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericMessage
-
Constructs a Message for the given payload
and meta data
.
- GenericMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.domain.GenericMessage
-
Constructor to reconstruct a Message using existing data.
- GenericSagaFactory - Class in org.axonframework.saga
-
SagaFactory implementation that uses the default (no-arg) constructor on the saga to initialize.
- GenericSagaFactory() - Constructor for class org.axonframework.saga.GenericSagaFactory
-
- GenericSagaSqlSchema - Class in org.axonframework.saga.repository.jdbc
-
Generic SagaSqlSchema implementation, for use in most databases.
- GenericSagaSqlSchema() - Constructor for class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
Initialize a GenericSagaSqlSchema using default settings.
- GenericSagaSqlSchema(SchemaConfiguration) - Constructor for class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
Initialize a GenericSagaSqlSchema.
- get(K) - Method in interface org.axonframework.cache.Cache
-
Returns an item from the cache, or null
if no item was stored under that key
- get(K) - Method in class org.axonframework.cache.EhCacheAdapter
-
- get(K) - Method in class org.axonframework.cache.JCacheAdapter
-
- get(K) - Method in class org.axonframework.cache.NoCache
-
- get(K) - Method in class org.axonframework.cache.WeakReferenceCache
-
- get() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for the command handling to complete, and then returns its result.
- get(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for at most the given time for the command handling to complete, and then retrieves its
result, if available.
- get(Object) - Method in class org.axonframework.domain.MetaData
-
- get() - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
-
Gets the UnitOfWork bound to the current thread.
- getActualVersion() - Method in exception org.axonframework.repository.ConflictingAggregateVersionException
-
Returns the actual version of the aggregate, as loaded by the repository.
- getAdapterInterface() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
-
- getAdapterInterface() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
Returns the interface that the adapter implements to connect the annotated method to the actual interface
definition.
- getAdapterInterface() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
-
- getAfterReplayTimeout() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
- getAggregate() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Returns the identifier of the aggregate modified in this UnitOfWork.
- getAggregateFactory() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Returns the factory used by this repository.
- getAggregateIdentifier() - Method in exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
-
Returns the identifier of the blacklisted aggregate.
- getAggregateIdentifier() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the identifier of the aggregate to recover.
- getAggregateIdentifier() - Method in interface org.axonframework.domain.DomainEventMessage
-
Returns the identifier of the Aggregate that generated this DomainEvent.
- getAggregateIdentifier() - Method in class org.axonframework.domain.EventContainer
-
Returns the aggregate identifier assigned to this container.
- getAggregateIdentifier() - Method in class org.axonframework.domain.GenericDomainEventMessage
-
- getAggregateIdentifier() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
Returns the Aggregate Identifier of the associated event.
- getAggregateIdentifier() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
- getAggregateIdentifier() - Method in exception org.axonframework.repository.AggregateNotFoundException
-
Returns the identifier of the aggregate that could not be found.
- getAggregateIdentifier() - Method in exception org.axonframework.repository.ConflictingAggregateVersionException
-
Returns the identifier of the aggregate which version is not as expected.
- getAggregateIdentifier() - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
-
- getAggregateIdentifier() - Method in interface org.axonframework.serializer.SerializedDomainEventData
-
Returns the Identifier of the Aggregate to which the Event was applied.
- getAggregateIdentifier() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- getAggregateIdentifier() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
-
- getAggregateIdentifier() - Method in interface org.axonframework.upcasting.UpcastingContext
-
Returns the Identifier of the Aggregate to which the Event owning the object to upcast, was applied.
- getAggregateIdentifier() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
-
- getAggregateRoot() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
-
Returns the reference to the root of the aggregate this entity is a member of.
- getAggregateType() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Returns the type identifier of the aggregate handled in this unit of work.
- getAggregateType() - Method in interface org.axonframework.eventsourcing.AggregateFactory
-
Returns the type of aggregate this factory creates.
- getAggregateType() - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
-
- getAggregateType() - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
- getAggregateType() - Method in class org.axonframework.repository.AbstractRepository
-
Returns the aggregate type stored by this repository.
- getAnnotation(Class<A>) - Method in class org.axonframework.commandhandling.annotation.ConstructorCommandMessageHandler
-
- getAnnotation(Class<T>) - Method in class org.axonframework.common.annotation.AbstractMessageHandler
-
Returns the member-level annotation of given annotationType
, or null
if no such
annotation is present.
- getAnnotation(Class<T>) - Method in class org.axonframework.common.annotation.MethodMessageHandler
-
- getAnnotation(Annotation[], Class<T>) - Static method in class org.axonframework.common.CollectionUtils
-
Finds an annotation of given annotationType
from the given annotations
.
- getApplicationContext() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
Returns the ApplicationContext this Bean Post Processor is registered in.
- getAssociationValue(EventMessage) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
-
The AssociationValue to find the saga instance with, or null
if no AssociationValue can be found on
the given eventMessage
.
- getAssociationValue() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
-
Returns the association value contained in this entry.
- getAssociationValues() - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
- getAssociationValues() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Returns all association values that could potentially link a saga instance with the incoming event.
- getAssociationValues() - Method in interface org.axonframework.saga.Saga
-
Returns a view on the Association Values for this saga instance.
- getBeanClass() - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
-
Returns the type of bean to be created by this BeanDefinitionParser.
- getBeanClass() - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
-
- getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
- getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.JdbcEventStoreBeanDefinitionParser
-
- getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
- getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.JpaRepositoryBeanDefinitionParser
-
- getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
- getBeanClass(Element) - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
-
- getBeanClass() - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
-
- getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.contextsupport.spring.SpringContextParameterResolverFactoryBuilder
-
Create, if necessary, a bean definition for a ParameterResolverFactory and returns the reference to bean for use
in other Bean Definitions.
- getBufferSize() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the buffer size to use.
- getCache() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the cache used to store Aggregates loaded by the DisruptorCommandBus.
- getCallback() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the CommandCallback instance for the executed command.
- getCharset() - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Returns the character set used to convert character to bytes and vice versa.
- getChildEntities() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedAggregateRoot
-
Returns a collection of event sourced entities directly referenced by this entity.
- getChildEntities() - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
-
Returns a collection of event sourced entities directly referenced by this entity.
- getChildEntities() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
-
- getChildEntities() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedEntity
-
- getChildEntities(Object) - Method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
-
Returns the child entities of given instance
.
- getCommand() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the CommandMessage to be executed.
- getCommandHandlerCount() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
-
Returns the amount of registered handlers.
- getCommandHandlerCount() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
-
Returns the amount of registered handlers.
- getCommandName() - Method in interface org.axonframework.commandhandling.CommandMessage
-
Returns the name of the command to execute.
- getCommandName() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- getCommandTargetResolver() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the CommandTargetResolver that is used to find out which Aggregate is to be invoked for a given Command.
- getConnection() - Method in interface org.axonframework.common.jdbc.ConnectionProvider
-
Returns a connection, ready for use.
- getConnection() - Method in class org.axonframework.common.jdbc.DataSourceConnectionProvider
-
- getConnection() - Method in class org.axonframework.common.jdbc.SpringDataSourceConnectionProvider
-
- getConnection() - Method in class org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper
-
- getConstructorHandlers() - Method in class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
-
Returns a list of constructor handlers on the given aggregate type.
- getContentType() - Method in class org.axonframework.serializer.SerializedMetaData
-
- getContentType() - Method in interface org.axonframework.serializer.SerializedObject
-
Returns the type of this representation's data.
- getContentType() - Method in class org.axonframework.serializer.SimpleSerializedObject
-
- getConverter(Class<S>, Class<T>) - Method in class org.axonframework.serializer.ChainingConverterFactory
-
- getConverter(Class<S>, Class<T>) - Method in interface org.axonframework.serializer.ConverterFactory
-
Returns a converter that is capable of converting IntermediateRepresentation object containing the given
sourceContentType
to the given targetContentType
.
- getConverterFactory() - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Returns the ConverterFactory used by this serialized.
- getConverterFactory() - Method in class org.axonframework.serializer.JavaSerializer
-
- getConverterFactory() - Method in class org.axonframework.serializer.json.JacksonSerializer
-
- getConverterFactory() - Method in class org.axonframework.serializer.MessageSerializer
-
- getConverterFactory() - Method in interface org.axonframework.serializer.Serializer
-
Returns the converter factory used by this Serializer to convert between serialized representations.
- getCoolingDownPeriod() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the cooling down period for the shutdown of the DisruptorCommandBus, in milliseconds.
- getCorrelationData() - Static method in class org.axonframework.correlation.CorrelationDataHolder
-
Returns the correlation data attached to the current thread.
- getCreationHandler() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Returns the event handler which is used to create a new saga instance based on the incoming event.
- getCreationPolicy() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
-
Returns the creation policy of the inspected method.
- getCreationPolicy() - Method in class org.axonframework.saga.SagaInitializationPolicy
-
Returns the creation policy
- getData() - Method in class org.axonframework.serializer.SerializedMetaData
-
- getData() - Method in interface org.axonframework.serializer.SerializedObject
-
The actual data of the serialized object.
- getData() - Method in class org.axonframework.serializer.SimpleSerializedObject
-
- getDataType() - Method in class org.axonframework.eventstore.jdbc.DefaultEventEntryStore
-
- getDataType() - Method in interface org.axonframework.eventstore.jdbc.EventEntryStore
-
Returns the type used to store serialized payloads.
- getDataType() - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Returns the type used to store serialized payloads.
- getDataType() - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- getDataType() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
- getDataType() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
- getDataType() - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
-
Returns the type used to store serialized payloads.
- getDataType() - Method in interface org.axonframework.eventstore.jpa.EventEntryStore
-
Returns the type used to store serialized payloads.
- getDefinedPayload(T) - Method in class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
-
Returns the payload type configured on the given annotated method.
- getDelegates() - Method in class org.axonframework.common.annotation.MultiParameterResolverFactory
-
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
- getDispatchInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the dispatch interceptors for the DisruptorCommandBus.
- getDomainEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
- getDomainEventEntryEntityName() - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
-
Returns the entity name of the Domain Event Entry provided by this factory.
- getEntityManager() - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
-
- getEntityManager() - Method in interface org.axonframework.common.jpa.EntityManagerProvider
-
Returns the EntityManager instance to use.
- getEntityManager() - Method in class org.axonframework.common.jpa.SimpleEntityManagerProvider
-
- getError() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
-
Returns the exception that caused the processing to fail
- getEventIdentifier() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
- getEventIdentifier() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
- getEventIdentifier() - Method in interface org.axonframework.serializer.SerializedDomainEventData
-
Returns the identifier of the serialized event.
- getEventIdentifier() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
-
- getEventList() - Method in class org.axonframework.domain.EventContainer
-
Returns an unmodifiable version of the backing list of events.
- getEventsToPublish() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Returns the events that need to be published as part of this Unit of Work.
- getEventStore() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Returns the event store this snapshotter uses to load domain events and store snapshot events.
- getEventsToStore() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Returns the events that need to be stored as part of this Unit of Work.
- getEventStream() - Method in class org.axonframework.domain.EventContainer
-
- getExceptionResult() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the exception that occurred while processing the incoming command, or null
if
processing did not result in an exception or if execution is not yet finished.
- getExecutor() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the Executor providing the processing resources (Threads) for the DisruptorCommandBus.
- getExecutor() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Returns the executor that executes snapshot taking tasks.
- getExpectedVersion() - Method in exception org.axonframework.repository.ConflictingAggregateVersionException
-
Returns the version expected by the component loading the aggregate.
- getFieldValue(Field, Object) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns the value of the given field
in the given object
.
- getGroupIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
-
Returns the Quartz group identifier.
- getHandlers() - Method in class org.axonframework.commandhandling.annotation.AggregateCommandHandlerInspector
-
Returns the list of handlers found on target type.
- getHandlers() - Method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
-
Returns the list of handlers found on target type.
- getHandlers() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Returns the handler that can process the published Event.
- getHandlerTypes() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
-
Returns a list with the names of the types of the registered handlers.
- getHandlerTypes() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
-
Returns a list with names of the registered handlers.
- getId() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
-
The unique identifier of this entry.
- getIdentifier() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- getIdentifier() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
-
Returns the identifier of the targeted Aggregate.
- getIdentifier() - Method in interface org.axonframework.domain.AggregateRoot
-
Returns the identifier of this aggregate.
- getIdentifier() - Method in interface org.axonframework.domain.EventMessage
-
Returns the identifier of this event.
- getIdentifier() - Method in class org.axonframework.domain.GenericMessage
-
- getIdentifier() - Method in interface org.axonframework.domain.Message
-
Returns the identifier of this message.
- getIdentifier() - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
-
- getIdentifier(AbstractAnnotatedAggregateRoot<I>) - Method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
-
Returns the identifier of the given aggregateRoot
.
- getIdentifier() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- getIdentifier() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- getIdentifier() - Method in class org.axonframework.serializer.SerializedEventMessage
-
- getIdentifier() - Method in class org.axonframework.serializer.SerializedMessage
-
- getInitialAssociationValue() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Returns the association to assign to an event when handling an incoming event that creates a Saga.
- getInitialAssociationValue() - Method in class org.axonframework.saga.SagaInitializationPolicy
-
Returns the initial association value for a newly created saga.
- getInspector(Class<?>, ParameterResolverFactory) - Static method in class org.axonframework.eventsourcing.annotation.AggregateAnnotationInspector
-
Returns (or creates) an inspector for the given entityType
.
- getInstance(Class<?>, Class<T>, ParameterResolverFactory, boolean) - Static method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
-
Returns a MethodMessageHandlerInspector for the given handlerClass
that contains handler methods
annotated with the given annotationType
.
- getInstance(Class<?>, ParameterResolverFactory, boolean, HandlerDefinition<? super Method>) - Static method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
-
Returns a MethodMessageHandlerInspector for the given handlerClass
that contains handler methods
annotated with the given annotationType
.
- getInstance() - Static method in class org.axonframework.common.annotation.PriorityAnnotationComparator
-
Returns the instance of the comparator.
- getInstance() - Static method in class org.axonframework.common.IdentifierValidator
-
Returns the singleton instance of the IdentifierValidator.
- getInstance() - Static method in class org.axonframework.domain.IdentifierFactory
-
Returns an instance of the IdentifierFactory discovered on the classpath.
- getInstance(MethodMessageHandler) - Static method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
-
Create a SagaMethodMessageHandler for the given methodHandler
.
- getInstance(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
-
Returns a SagaMethodMessageHandlerInspector for the given sagaType
.
- getInvocationInterceptorChain() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the InterceptorChain for the invocation process registered with this entry, or null
if none
is available.
- getInvokerId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the Identifier of the invoker that is chosen to handle this entry.
- getInvokerInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the interceptors for the DisruptorCommandBus.
- getInvokerThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the number of threads to use for Command Handler invocation.
- getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
-
Returns the Quartz job identifier.
- getKey() - Method in class org.axonframework.saga.AssociationValue
-
Returns the key of this association value.
- getLastCommittedEventSequenceNumber() - Method in class org.axonframework.domain.AbstractAggregateRoot
-
Returns the sequence number of the last committed event, or null
if no events have been committed
before.
- getLastCommittedSequenceNumber() - Method in class org.axonframework.domain.EventContainer
-
Returns the sequence number of the last committed event, or null
if no events have been committed.
- getLastSequenceNumber() - Method in class org.axonframework.domain.EventContainer
-
Returns the sequence number of the event last added to this container.
- getListenerCount() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
-
Returns the amount of registered listeners.
- getListenerCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
-
Returns the amount of registered listeners.
- getListenerTypes() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
-
Returns the list of names of the registered listeners.
- getListenerTypes() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
-
Returns a list of simple class names (class name without its package) of the registered listeners.
- getLockManagerType() - Method in enum org.axonframework.contextsupport.spring.LockingStrategy
-
Returns the type of LockManager that belongs to this strategy.
- getManagedSagaTypes() - Method in class org.axonframework.saga.AbstractSagaManager
-
Returns the set of Saga types managed by this instance.
- getMembers() - Method in class org.axonframework.eventhandling.AbstractCluster
-
Returns a read-only view on the members in the cluster.
- getMembers() - Method in interface org.axonframework.eventhandling.Cluster
-
Returns a read-only view on the members in the cluster.
- getMembers() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
- getMessageHandlers(EventMessage) - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
-
Find the configuration for the handlers for the given event
.
- getMessageIdentifier() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
-
- getMessageIdentifier() - Method in interface org.axonframework.upcasting.UpcastingContext
-
Returns the identifier of the message wrapping the object to upcast.
- getMetaData() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- getMetaData() - Method in class org.axonframework.domain.GenericMessage
-
- getMetaData() - Method in interface org.axonframework.domain.Message
-
Returns the meta data for this event.
- getMetaData() - Method in class org.axonframework.eventhandling.AbstractCluster
-
- getMetaData() - Method in interface org.axonframework.eventhandling.Cluster
-
Returns the MetaData of this Cluster.
- getMetaData() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
- getMetaData() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntry
-
- getMetaData() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
- getMetaData() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- getMetaData() - Method in interface org.axonframework.serializer.SerializedDomainEventData
-
Returns the serialized data of the MetaData of the serialized Event.
- getMetaData() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- getMetaData() - Method in class org.axonframework.serializer.SerializedEventMessage
-
- getMetaData() - Method in class org.axonframework.serializer.SerializedMessage
-
- getMetaData() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
-
- getMetaData() - Method in interface org.axonframework.upcasting.UpcastingContext
-
Returns the meta data of the message wrapping the object being upcast.
- getMetaData() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
-
- getMethod() - Method in class org.axonframework.common.annotation.MethodMessageHandler
-
Returns the Method backing this handler.
- getMethodName() - Method in class org.axonframework.common.annotation.MethodMessageHandler
-
Returns the name of the method backing this handler.
- getName() - Method in class org.axonframework.eventhandling.AbstractCluster
-
- getName() - Method in interface org.axonframework.eventhandling.Cluster
-
Returns the name of this cluster.
- getName() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
- getName() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandler
-
Returns the name of the handler.
- getName() - Method in interface org.axonframework.serializer.SerializedType
-
Returns the name of the serialized type.
- getName() - Method in class org.axonframework.serializer.SimpleSerializedType
-
- getNewSaga() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Returns the new Saga instance that should be used when processing an Event that creates a new Saga instance
- getObject() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
- getObject() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
- getObject() - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
-
- getObject() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
-
- getObject() - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
-
- getObject() - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
-
- getObject() - Method in class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
-
- getObject() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- getObject() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- getObject() - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
-
- getObject() - Method in class org.axonframework.serializer.LazyDeserializingObject
-
De-serializes the object and returns the result.
- getObjectMapper() - Method in class org.axonframework.serializer.json.JacksonSerializer
-
Returns the ObjectMapper used by this serializer, allowing for configuration of the serialization settings.
- getObjectType() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
- getObjectType() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
- getObjectType() - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
-
- getObjectType() - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
-
- getObjectType() - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
-
- getObjectType() - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
-
- getObjectType() - Method in class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
-
- getObjectType() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- getObjectType() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- getObjectType() - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
-
- getParameterResolverFactory() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
-
Returns the ParameterResolverFactory used by this inspector to resolve values for handler parameters
- getParameters() - Method in class org.axonframework.eventstore.jdbc.criteria.ParameterRegistry
-
Returns a map containing the key-value pairs, where each key is the parameter name, and the value the expression
to be inserted as parameter.
- getParameters() - Method in class org.axonframework.eventstore.jpa.criteria.ParameterRegistry
-
Returns a map containing the key-value pairs, where each key is the parameter name, and the value the expression
to be inserted as parameter.
- getParameterValueResolvers() - Method in class org.axonframework.common.annotation.AbstractMessageHandler
-
Returns the parameter resolvers provided at construction time.
- getPayload() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- getPayload() - Method in class org.axonframework.domain.GenericMessage
-
- getPayload() - Method in interface org.axonframework.domain.Message
-
Returns the payload of this Event.
- getPayload() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntry
-
- getPayload() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
- getPayload() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- getPayload() - Method in interface org.axonframework.serializer.SerializedDomainEventData
-
Returns the serialized data of the Event Message's payload.
- getPayload() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- getPayload() - Method in class org.axonframework.serializer.SerializedEventMessage
-
- getPayload() - Method in class org.axonframework.serializer.SerializedMessage
-
- getPayload() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
-
- getPayloadType() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- getPayloadType() - Method in class org.axonframework.common.annotation.AbstractMessageHandler
-
Returns the type of payload this handler expects.
- getPayloadType() - Method in class org.axonframework.domain.GenericMessage
-
- getPayloadType() - Method in interface org.axonframework.domain.Message
-
Returns the type of the payload.
- getPayloadType() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
Returns the payload type of the event message stored in this entry.
- getPayloadType() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- getPayloadType() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- getPayloadType() - Method in class org.axonframework.serializer.SerializedEventMessage
-
- getPayloadType() - Method in class org.axonframework.serializer.SerializedMessage
-
- getPhase() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
- getPhase() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
-
- getPriority() - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-
- getPriority() - Method in class org.axonframework.common.property.PropertyAccessStrategy
-
The priority of this strategy.
- getPriority() - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-
- getProducerType() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the producer type to use.
- getProperty(Class<T>, String) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
-
Iterates over all known PropertyAccessStrategy implementations to create a
Property
instance for the
given parameters.
- getProperty(String) - Method in interface org.axonframework.eventhandling.ClusterMetaData
-
Returns the property stored using the given key
.
- getProperty(String) - Method in class org.axonframework.eventhandling.DefaultClusterMetaData
-
- getPublishedEvent() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Returns the event that has been published on the EventBus.
- getPublisherId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the Identifier of the publisher that is chosen to handle this entry.
- getPublisherInterceptorChain() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the InterceptorChain for the publication process registered with this entry, or null
if
none
is available.
- getPublisherInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the interceptors for the DisruptorCommandBus.
- getPublisherThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the number of threads to use for storing and publication of generated Events.
- getReader(Class<?>) - Method in class org.axonframework.serializer.json.JacksonSerializer
-
Provides the ObjectReader, with which objects are read from the JSON form.
- getReceivedCommandCount() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
-
Returns the amount of received commands from the beginning of starting up or after the last reset.
- getReceivedCommandCount() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
-
Returns the amount of received commands.
- getReceivedEventsCount() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
-
Returns the amount of received events, from the beginning or after the last reset.
- getReceivedEventsCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
-
Returns the amount of received events.
- getRepository(String) - Static method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
-
Returns the Repository instance for Aggregate with given typeIdentifier
used by the
CommandHandlerInvoker that is running on the current thread.
- getRescheduleCommandsOnCorruptState() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Indicates whether commands that failed due to potentially corrupt Aggregate state should be automatically
rescheduled for processing.
- getResolver() - Method in class org.axonframework.eventhandling.annotation.AbstractAnnotatedParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.eventhandling.annotation.SequenceNumberParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.eventhandling.annotation.TimestampParameterResolverFactory
-
- getResource(String) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- getResource(String) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- getResource(String) - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Returns the resource previously attached under given name
, or null
if no such resource
is available.
- getResult() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for the command handling to complete, and then returns its result.
- getResult(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for at most the given time for the command handling to complete, and then retrieves its
result, if available.
- getResult() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the result of the command's execution, or null
if the command is not yet executed or
resulted in an exception.
- getRevision() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
-
Returns the revision of the serialized saga
- getRevision() - Method in interface org.axonframework.serializer.SerializedType
-
Returns the revision identifier of the serialized object.
- getRevision() - Method in class org.axonframework.serializer.SimpleSerializedType
-
- getRollbackConfiguration() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the RollbackConfiguration indicating for which Exceptions the DisruptorCommandBus should perform a
rollback, and which exceptions should result in a Commit.
- getSaga(Serializer) - Method in class org.axonframework.saga.repository.jpa.SagaEntry
-
Returns the Saga instance stored in this entry.
- getSagaCreationPolicy(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.AbstractSagaManager
-
Returns the Saga Initialization Policy for a Saga of the given sagaType
and event
.
- getSagaCreationPolicy(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
-
- getSagaCreationPolicy(Class<? extends Saga>, EventMessage) - Method in class org.axonframework.saga.SimpleSagaManager
-
- getSagaId() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
-
Returns the identifier of the saga contained in this entry
- getSagaIdentifier() - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
- getSagaIdentifier() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
-
Returns the Saga Identifier contained in this entry.
- getSagaIdentifier() - Method in interface org.axonframework.saga.Saga
-
Returns the unique identifier of this saga.
- getSagaType() - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Returns the type of Saga being processed.
- getSagaType() - Method in class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
-
Returns the type of saga this inspector handles.
- getSagaType() - Method in class org.axonframework.saga.repository.jpa.AssociationValueEntry
-
Returns the type (fully qualified class name) of the Saga this association value belongs to
- getSagaType() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
-
Returns the type identifier of the serialized saga
- getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.FullConcurrencyPolicy
-
Returns the sequence identifier for the given event
.
- getSequenceIdentifierFor(T) - Method in interface org.axonframework.eventhandling.async.SequencingPolicy
-
Returns the sequence identifier for the given event
.
- getSequenceIdentifierFor(EventMessage) - Method in class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-
Returns the sequence identifier for the given event
.
- getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.SequentialPolicy
-
Returns the sequence identifier for the given event
.
- getSequenceNumber() - Method in interface org.axonframework.domain.DomainEventMessage
-
Returns the sequence number that allows DomainEvents originating from the same Aggregate to be placed in the
order of generation.
- getSequenceNumber() - Method in class org.axonframework.domain.GenericDomainEventMessage
-
- getSequenceNumber() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
Returns the sequence number of the associated event.
- getSequenceNumber() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
- getSequenceNumber() - Method in class org.axonframework.serializer.SerializationAwareDomainEventMessage
-
- getSequenceNumber() - Method in interface org.axonframework.serializer.SerializedDomainEventData
-
Returns the sequence number of the event in the aggregate.
- getSequenceNumber() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- getSequenceNumber() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
-
- getSequenceNumber() - Method in interface org.axonframework.upcasting.UpcastingContext
-
Returns the sequence number of the event in the aggregate, or null
if the message wrapping the
object being upcast does not contain a sequence number.
- getSequenceNumber() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
-
- getSerializedMetaData() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
-
Returns the wrapper containing the serialized MetaData.
- getSerializedObject() - Method in class org.axonframework.serializer.LazyDeserializingObject
-
Returns the serialized object to deserialize upon request
- getSerializedRepresentation() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the type of data the serialized object should be represented in.
- getSerializedSaga() - Method in class org.axonframework.saga.repository.jpa.SagaEntry
-
Returns the serialized form of the Saga.
- getSerializer() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the serializer to perform pre-serialization with, or null
if no pre-serialization should be
done.
- getSerializer() - Method in class org.axonframework.serializer.LazyDeserializingObject
-
Returns the serializer to deserialize this object
- getSerializerSegmentId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the Segment ID that identifies the serializer thread to process this entry
- getSerializerThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the configured number of threads that should perform the pre-serialization step.
- getSnapshotEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
- getSnapshotEventEntryEntityName() - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
-
Returns the entity name of the Snapshot Event Entry provided by this factory.
- getTargetType() - Method in class org.axonframework.common.annotation.MessageHandlerInvoker
-
Returns the targetType on which handler methods are invoked.
- getTargetType() - Method in class org.axonframework.common.annotation.MethodMessageHandlerInspector
-
Returns the targetType on which handler methods are invoked.
- getTargetType() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
-
- getTargetType() - Method in interface org.axonframework.eventhandling.EventListenerProxy
-
Returns the instance type that this proxy delegates all event handling to.
- getTargetType() - Method in class org.axonframework.saga.annotation.AnnotatedSagaManager
-
- getTargetType() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
- getTargetType() - Method in class org.axonframework.saga.SimpleSagaManager
-
- getterName(String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-
Returns the name of the method that is used to access the property.
- getterName(String) - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-
- getterName(String) - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-
- getTimestamp() - Method in interface org.axonframework.domain.EventMessage
-
Returns the timestamp of this event.
- getTimestamp() - Method in class org.axonframework.domain.GenericEventMessage
-
- getTimestamp() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
Returns the time stamp of the associated event.
- getTimestamp() - Method in class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
- getTimestamp() - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- getTimestamp() - Method in interface org.axonframework.serializer.SerializedDomainEventData
-
Returns the timestamp at which the event was first created.
- getTimestamp() - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- getTimestamp() - Method in class org.axonframework.serializer.SerializedEventMessage
-
- getTimestamp() - Method in class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
-
- getTimestamp() - Method in interface org.axonframework.upcasting.UpcastingContext
-
Returns the timestamp at which the event was first created.
- getTimestamp() - Method in class org.axonframework.upcasting.UpcastSerializedDomainEventData
-
- getTokenId() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
-
Returns the identifier of the scheduled task.
- getTransactionManager() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the transaction manager to use to manage a transaction around the storage and publication of events.
- getType() - Method in class org.axonframework.eventstore.jpa.AbstractEventEntryData
-
Returns the type identifier of the aggregate.
- getType() - Method in class org.axonframework.serializer.LazyDeserializingObject
-
Returns the class of the serialized object.
- getType() - Method in class org.axonframework.serializer.SerializedMetaData
-
- getType() - Method in interface org.axonframework.serializer.SerializedObject
-
Returns the description of the type of object contained in the data.
- getType() - Method in class org.axonframework.serializer.SimpleSerializedObject
-
- getTypeByte() - Method in enum org.axonframework.eventhandling.io.EventMessageType
-
Returns the Type Byte for this EventMessageType.
- getTypeIdentifier() - Method in interface org.axonframework.eventsourcing.AggregateFactory
-
Returns the type identifier for this aggregate factory.
- getTypeIdentifier() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Return the type identifier belonging to the AggregateFactory of this repository.
- getTypeIdentifier() - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
-
- getTypeIdentifier() - Method in class org.axonframework.eventsourcing.HybridJpaRepository
-
Returns the type identifier to use when appending events in the event store.
- getTypeIdentifier() - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
- getUncommittedEventCount() - Method in class org.axonframework.domain.AbstractAggregateRoot
-
Returns the number of uncommitted events currently available in the aggregate.
- getUncommittedEventCount() - Method in interface org.axonframework.domain.AggregateRoot
-
Returns the number of uncommitted events currently available in the aggregate.
- getUncommittedEvents() - Method in class org.axonframework.domain.AbstractAggregateRoot
-
Returns a DomainEventStream to the events in the aggregate that have been raised since creation or the last
commit.
- getUncommittedEvents() - Method in interface org.axonframework.domain.AggregateRoot
-
Returns a DomainEventStream to the events in the aggregate that have been raised since creation or the last
commit.
- getUnitOfWork() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the UnitOfWork for the command execution.
- getValue(T) - Method in class org.axonframework.common.property.MethodAccessedProperty
-
- getValue(T) - Method in interface org.axonframework.common.property.Property
-
Returns the value of the property on given target
.
- getValue() - Method in class org.axonframework.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.common.annotation.UnsupportedHandlerException
-
A reference to the method that violated the event handler rules.
- getViolations() - Method in exception org.axonframework.commandhandling.interceptors.JSR303ViolationException
-
Returns the violations that were detected when this exception was thrown.
- getWaitStrategy() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the WaitStrategy currently configured.
- getWriter() - Method in class org.axonframework.serializer.json.JacksonSerializer
-
Provides the ObjectWriter, with which objects are serialized to JSON form.
- getXStream() - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Returns a reference to the underlying XStream
instance, that does the actual
serialization.
- greaterThan(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
-
- greaterThan(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
-
- greaterThan(Object) - Method in interface org.axonframework.eventstore.management.Property
-
Returns a criteria instance where the property must be "greater than" the given expression
.
- greaterThanEquals(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.JdbcProperty
-
- greaterThanEquals(Object) - Method in class org.axonframework.eventstore.jpa.criteria.JpaProperty
-
- greaterThanEquals(Object) - Method in interface org.axonframework.eventstore.management.Property
-
Returns a criteria instance where the property must be "greater than" or "equal to" the given
expression
.
- readEventMessage() - Method in class org.axonframework.eventhandling.io.EventMessageReader
-
Reads an EventMessage from the underlying input.
- readEventMessage() - Method in class org.axonframework.eventstore.fs.FileSystemEventMessageReader
-
Reads the next event from the input.
- readEvents(String, Object) - Method in interface org.axonframework.eventstore.EventStore
-
Read the events of the aggregate identified by the given type and identifier that allow the current aggregate
state to be rebuilt.
- readEvents(String, Object) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
-
- readEvents(String, Object) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
Read the events of the aggregate identified by the given type and identifier that allow the current aggregate
state to be rebuilt.
- readEvents(String, Object, long) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
- readEvents(String, Object, long, long) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
- readEvents(String, Object) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
Read the events of the aggregate identified by the given type and identifier that allow the current aggregate
state to be rebuilt.
- readEvents(String, Object, long) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
- readEvents(String, Object, long, long) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
- readEvents(String, Object, long) - Method in interface org.axonframework.eventstore.PartialStreamSupport
-
Returns a Stream containing events for the aggregate identified by the given type
and identifier
, starting at the event with the given firstSequenceNumber
(included).
- readEvents(String, Object, long, long) - Method in interface org.axonframework.eventstore.PartialStreamSupport
-
Returns a Stream containing events for the aggregate identified by the given type
and identifier
, starting at the event with the given firstSequenceNumber
(included) up to and including the
event with given lastSequenceNumber
.
- readEvents(String, Object) - Method in class org.axonframework.eventstore.supporting.SequenceEventStore
-
- readEvents(String, Object) - Method in class org.axonframework.eventstore.supporting.TimestampCutoffReadonlyEventStore
-
- readEvents(String, Object) - Method in class org.axonframework.eventstore.supporting.VolatileEventStore
-
- readPayload(ResultSet, int) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
Reads a serialized object from the given resultSet
at given columnIndex
.
- readResolve() - Method in class org.axonframework.domain.MetaData
-
Java Serialization specification method that will ensure that deserialization will maintain a single instance of
empty MetaData.
- readSerializedSaga(ResultSet) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- readSerializedSaga(ResultSet) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
- readSnapshotEvent(String, Object) - Method in class org.axonframework.eventstore.fs.FileSystemSnapshotEventReader
-
Reads the latest snapshot of the given aggregate identifier.
- readTimeStamp(ResultSet, int) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
Reads a timestamp from the given resultSet
at given columnIndex
.
- ReflectionUtils - Class in org.axonframework.common
-
Utility class for working with Java Reflection API.
- register(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
-
Registers a PropertyAccessStrategy implementation at runtime.
- register(Object) - Method in class org.axonframework.eventstore.jdbc.criteria.ParameterRegistry
-
Registers the given expression
as parameter and returns the value to use to refer to this
expression.
- register(Object) - Method in class org.axonframework.eventstore.jpa.criteria.ParameterRegistry
-
Registers the given expression
as parameter and returns the value to use to refer to this
expression.
- registerAggregate(T, EventBus, SaveAggregateCallback<T>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- registerAggregate(T, EventBus, SaveAggregateCallback<T>) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- registerAggregate(T, EventBus, SaveAggregateCallback<T>) - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Register an aggregate with this UnitOfWork.
- registerAggregateRoot(AbstractEventSourcedAggregateRoot) - Method in class org.axonframework.eventsourcing.AbstractEventSourcedEntity
-
- registerAggregateRoot(AbstractEventSourcedAggregateRoot) - Method in interface org.axonframework.eventsourcing.EventSourcedEntity
-
Register the aggregate root with this entity.
- registerAnnotationCommandHandlerBeanPostProcessor(String, String, String, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
-
- registerAnnotationEventListenerBeanPostProcessor(String, String, String, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.AnnotationConfigurationBeanDefinitionParser
-
- registerBean(Object, Class<?>) - Method in class org.axonframework.monitoring.MonitorRegistry
-
Registers the bean with the Registry.
- registerBeanDefinition(BeanDefinitionHolder, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser
-
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.contextsupport.spring.AnnotationDrivenConfiguration
-
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.AbstractCacheAdapter
-
- registerCacheEntryListener(Cache.EntryListener) - Method in interface org.axonframework.cache.Cache
-
Registers the given cacheEntryListener
to listen for Cache changes.
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.NoCache
-
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.cache.WeakReferenceCache
-
- registerCommandCallback(CommandCallback<R>) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
-
Registers the callback
, which is invoked for each sent command, unless Axon is able to detect that
the result of the command does not match the type accepted by the callback.
- registerConverter(ContentTypeConverter) - Method in class org.axonframework.serializer.ChainingConverterFactory
-
Registers the given converter
with this factory.
- registerConverter(Class<? extends ContentTypeConverter>) - Method in class org.axonframework.serializer.ChainingConverterFactory
-
Registers a convert of the given converterType
with this factory, only if initialization of such a
converter is possible.
- registerConverters(ChainingConverterFactory) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Registers any converters that are specific to the type of content written by this serializer.
- registerConverters(ChainingConverterFactory) - Method in class org.axonframework.serializer.json.JacksonSerializer
-
Registers converters with the given converterFactory
which depend on the actual contents of the
serialized for to represent a JSON format.
- registerConverters(ChainingConverterFactory) - Method in class org.axonframework.serializer.xml.XStreamSerializer
-
- registerDispatchInterceptor(CommandDispatchInterceptor) - Method in class org.axonframework.commandhandling.gateway.GatewayProxyFactory
-
Registers the given dispatchInterceptor
which is invoked for each Command dispatched through the
Command Gateways created by this factory.
- registerEvent(T) - Method in class org.axonframework.domain.AbstractAggregateRoot
-
Registers an event to be published when the aggregate is saved, containing the given payload
and no
(additional) meta-data.
- registerEvent(MetaData, T) - Method in class org.axonframework.domain.AbstractAggregateRoot
-
Registers an event to be published when the aggregate is saved.
- registerEventMessage(DomainEventMessage<T>) - Method in class org.axonframework.domain.AbstractAggregateRoot
-
Registers an event message to be published when the aggregate is saved.
- registerForPublication(EventMessage<?>, EventBus, boolean) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- registerForPublication(EventMessage<?>, EventBus, boolean) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
Register the given event
for publication on the given eventBus
when the unit of work
is committed.
- registerListener(UnitOfWorkListener) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- registerListener(UnitOfWorkListener) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- registerListener(UnitOfWorkListener) - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Register a listener that listens to state changes in this UnitOfWork.
- registerMonitoringBean(Object, Class<?>) - Static method in class org.axonframework.monitoring.MonitorRegistry
-
Register the given monitoringBean
with the registries on the classpath.
- registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.annotation.AbstractAnnotatedAggregateRoot
-
Registers the given parameterResolverFactory
with this aggregate instance.
- registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Sets the ParameterResolverFactory for this instance to use.
- registerSagaFactory(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
-
Registers the given sagaFactoryDefinition
in the given sagaManagerDefinition
.
- registerSagaFactory(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
-
- registerSagaFactory(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
-
- registerSagaRepository(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
-
Registers the given sagaRepositoryDefinition
in the given sagaManagerDefinition
.
- registerSagaRepository(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
-
- registerSagaRepository(Object, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
-
- registerScheduledEvents(UnitOfWork) - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- registerScheduledEvents(UnitOfWork) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
Invokes when a child Unit of Work should register its scheduled events with the given unitOfWork
.
- registerSpecificProperties(Element, ParserContext, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
-
Registers any implementation specific properties found in the given element
in the given
sagaManagerDefinition
.
- registerSpecificProperties(Element, ParserContext, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
-
- registerSpecificProperties(Element, ParserContext, GenericBeanDefinition) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
-
- registerTypes(String[], GenericBeanDefinition, RuntimeBeanReference) - Method in class org.axonframework.contextsupport.spring.AbstractSagaManagerBeanDefinitionParser
-
Registers the given Saga types
in the given sagaManagerDefinition
.
- registerTypes(String[], GenericBeanDefinition, RuntimeBeanReference) - Method in class org.axonframework.contextsupport.spring.AsyncSagaManagerBeanDefinitionParser
-
- registerTypes(String[], GenericBeanDefinition, RuntimeBeanReference) - Method in class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
-
- REGULAR - Static variable in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
-
Instance indicating processing was successful and should proceed normally.
- releaseLock(String) - Method in class org.axonframework.common.lock.IdentifierBasedLock
-
Release the lock held on the given identifier
.
- releaseLock(Object) - Method in interface org.axonframework.repository.LockManager
-
Release the lock held for an aggregate with the given aggregateIdentifier
.
- releaseLock(Object) - Method in class org.axonframework.repository.NullLockManager
-
Release the lock held for an aggregate with the given aggregateIdentifier
.
- releaseLock(Object) - Method in class org.axonframework.repository.OptimisticLockManager
-
Release the lock held for an aggregate with the given aggregateIdentifier
.
- releaseLock(Object) - Method in class org.axonframework.repository.PessimisticLockManager
-
Release the lock held on the aggregate.
- releaseMessage(Cluster, DomainEventMessage) - Method in class org.axonframework.eventhandling.replay.BackloggingIncomingMessageHandler
-
- releaseMessage(Cluster, DomainEventMessage) - Method in class org.axonframework.eventhandling.replay.DiscardingIncomingMessageHandler
-
- releaseMessage(Cluster, DomainEventMessage) - Method in interface org.axonframework.eventhandling.replay.IncomingMessageHandler
-
Invoked when a message has been replayed from the event store.
- remove(K) - Method in interface org.axonframework.cache.Cache
-
Removes the entry stored under given key
.
- remove(K) - Method in class org.axonframework.cache.EhCacheAdapter
-
- remove(K) - Method in class org.axonframework.cache.JCacheAdapter
-
- remove(Object) - Method in class org.axonframework.cache.NoCache
-
- remove(K) - Method in class org.axonframework.cache.WeakReferenceCache
-
- remove(Object) - Method in class org.axonframework.domain.MetaData
-
This operation is not supported.
- remove(AssociationValue) - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- remove(AssociationValue) - Method in interface org.axonframework.saga.AssociationValues
-
Removes the given associationValue
, if it is contained by this instance.
- remove(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AssociationValueMap
-
Removes an association between the given associationValue
and sagaIdentifier
.
- removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
-
Removes the association value that has been associated with Saga, identified with the given
sagaIdentifier
.
- removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
-
- removeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
-
- removeAssociationWith(AssociationValue) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Removes the given association from this Saga.
- removeAssociationWith(String, String) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Removes the given association from this Saga.
- removeAssociationWith(String, Number) - Method in class org.axonframework.saga.annotation.AbstractAnnotatedSaga
-
Removes the given association from this Saga.
- removedAssociations() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- removedAssociations() - Method in interface org.axonframework.saga.AssociationValues
-
- removeProperty(String) - Method in interface org.axonframework.eventhandling.ClusterMetaData
-
Removes the value store under the given key
.
- removeProperty(String) - Method in class org.axonframework.eventhandling.DefaultClusterMetaData
-
- ReplayAware - Interface in org.axonframework.eventhandling.replay
-
Interface indicating a component is aware of "replays".
- ReplayFailedException - Exception in org.axonframework.eventhandling.replay
-
Exception indicating that a replay task has failed.
- ReplayFailedException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.replay.ReplayFailedException
-
Initialize the exception with given message
and cause
- ReplayingCluster - Class in org.axonframework.eventhandling.replay
-
Cluster implementation that wraps another Cluster, adding the capability to replay events from an Event Store.
- ReplayingCluster(Cluster, EventStoreManagement, TransactionManager, int, IncomingMessageHandler) - Constructor for class org.axonframework.eventhandling.replay.ReplayingCluster
-
Initializes a ReplayingCluster that wraps the given delegate
, to allow it to replay event from the
given eventStore
.
- Repository<T> - Interface in org.axonframework.repository
-
The repository provides an abstraction of the storage of aggregates.
- RepositoryBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
The RepositoryBeanDefinitionParser is responsible for parsing the repository
element from the Axon
namespace.
- RepositoryBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.RepositoryBeanDefinitionParser
-
- requiresRescheduleEvent() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
-
- requiresRescheduleEvent() - Method in class org.axonframework.eventhandling.async.RetryPolicy
-
Indicates whether the scheduler should reschedule the failed event.
- requiresRollback() - Method in class org.axonframework.eventhandling.async.EventProcessor.ProcessingResult
-
- requiresRollback() - Method in class org.axonframework.eventhandling.async.RetryPolicy
-
Indicates whether the scheduler should rollback the Unit of Work wrapping the event handling.
- reset(CommandMessage<?>, CommandHandler, int, int, int, BlacklistDetectingCallback, List<CommandHandlerInterceptor>, List<CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Resets this entry, preparing it for use for another command.
- reset(EventMessage, Class<? extends AbstractAnnotatedSaga>, List<SagaMethodMessageHandler>, AbstractAnnotatedSaga) - Method in class org.axonframework.saga.annotation.AsyncSagaProcessingEvent
-
Reset this entry for processing a new EventMessage
- resetAsRecoverEntry(Object) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Resets this entry, preparing it for use as a recovery entry.
- resetReceivedCommandsCounter() - Method in class org.axonframework.commandhandling.SimpleCommandBusStatistics
-
Resets the received command counter.
- resetReceivedCommandsCounter() - Method in interface org.axonframework.commandhandling.SimpleCommandBusStatisticsMXBean
-
Reset the amount of commands received counter.
- resetReceivedEventsCount() - Method in class org.axonframework.eventhandling.SimpleEventBusStatistics
-
Reset the amount of events that was received.
- resetReceivedEventsCount() - Method in interface org.axonframework.eventhandling.SimpleEventBusStatisticsMXBean
-
resets the amount of events received.
- resolveAcceptedCommandName(AbstractMessageHandler) - Static method in class org.axonframework.commandhandling.annotation.CommandMessageHandlerUtils
-
Returns the name of the Command accepted by the given handler
.
- resolveClassName(SerializedType) - Method in class org.axonframework.serializer.json.JacksonSerializer
-
Resolve the class name from the given serializedType
.
- resolveConflicts(List<DomainEventMessage>, List<DomainEventMessage>) - Method in interface org.axonframework.eventsourcing.ConflictResolver
-
Checks the given list of appliedChanges
and committedChanges
for any conflicting
changes.
- resolveConflicts(List<DomainEventMessage>, List<DomainEventMessage>) - Method in class org.axonframework.eventsourcing.conflictresolvers.AcceptAllConflictResolver
-
Checks the given list of appliedChanges
and committedChanges
for any conflicting
changes.
- resolveConflicts(T, DomainEventStream) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Resolve (potential) conflicts for the given aggregate
, where given unseenEvents
may
have been concurrently applied.
- resolveDateTimeValue(DateTime) - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryFactory
-
Returns the representation used for the given dateTime
in the event entry.
- resolveDateTimeValue(DateTime) - Method in interface org.axonframework.eventstore.jpa.EventEntryFactory
-
Returns the representation used for the given dateTime
in the event entry.
- resolveParameterValue(Message) - Method in class org.axonframework.commandhandling.annotation.CurrentUnitOfWorkParameterResolverFactory
-
- resolveParameterValue(Message) - Method in class org.axonframework.common.annotation.FixedValueParameterResolver
-
- resolveParameterValue(Message) - Method in interface org.axonframework.common.annotation.ParameterResolver
-
Resolves the parameter value to use for the given message
, or null
if no suitable
parameter value can be resolved.
- resolvePayloadFor(AccessibleObject) - Method in class org.axonframework.common.annotation.AbstractAnnotatedHandlerDefinition
-
- resolvePayloadFor(T) - Method in interface org.axonframework.common.annotation.HandlerDefinition
-
Returns the explicitly defined payload of supported messages on the given member
- resolvePrimitiveWrapperType(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns the boxed wrapper type for the given primitiveType
.
- resolveReturnValue(CommandMessage<?>, T) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Resolves the value to return when the given command
has created the given aggregate
.
- resolveTarget(CommandMessage<?>) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandTargetResolver
-
- resolveTarget(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.CommandTargetResolver
-
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given command
should be executed.
- resolveTarget(CommandMessage<?>) - Method in class org.axonframework.commandhandling.MetaDataCommandTargetResolver
-
- ResourceInjector - Interface in org.axonframework.saga
-
Interface describing a mechanism to inject resources into Saga instances.
- retryAfter(long, TimeUnit) - Static method in class org.axonframework.eventhandling.async.RetryPolicy
-
This policy will roll back the Unit of Work (and the transaction), if any) and reschedule the event for
processing.
- RetryingCallback<R> - Class in org.axonframework.commandhandling.gateway
-
Callback implementation that will invoke a retry scheduler if a command results in a runtime exception.
- RetryingCallback(CommandCallback<R>, CommandMessage, RetryScheduler, CommandBus) - Constructor for class org.axonframework.commandhandling.gateway.RetryingCallback
-
Initialize the RetryingCallback with the given delegate
, representing the actual callback passed as
a parameter to dispatch, the given commandMessage
, retryScheduler
and
commandBus
.
- RetryingErrorHandler - Class in org.axonframework.saga.annotation
-
ErrorHandler implementation that retries Events on non-transient exceptions.
- RetryingErrorHandler() - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler
-
Initialize an instance of the RetryingErrorHandler that indefinitely retries each 2 seconds.
- RetryingErrorHandler(RetryingErrorHandler.TimeoutConfiguration...) - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler
-
Initialize an instance of the RetryingErrorHandler that uses the given TimeoutConfiguration
s that
describe which retry timeout should be used for each number of retries.
- RetryingErrorHandler.TimeoutConfiguration - Class in org.axonframework.saga.annotation
-
Definition of a timeout to use for a specific range of retries
- RetryingErrorHandler.TimeoutConfiguration(long, TimeUnit) - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
-
Initialize a configuration to indefinitely retry, applying the given timeout
between retries.
- RetryingErrorHandler.TimeoutConfiguration(int, long, TimeUnit) - Constructor for class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
-
Initialize a configuration to apply the given timeout
between retries for the given
count
number of retries.
- RetryPolicy - Class in org.axonframework.eventhandling.async
-
This policy tells the EventProcessor how it should deal with failed transactions.
- RetryPolicy() - Constructor for class org.axonframework.eventhandling.async.RetryPolicy
-
- retryPolicy() - Method in class org.axonframework.saga.annotation.RetryingErrorHandler.TimeoutConfiguration
-
The retry policy to use between retries
- RetryScheduler - Interface in org.axonframework.commandhandling.gateway
-
Interface towards a mechanism that decides whether to schedule a command for execution when a previous attempts
resulted in an exception.
- Revision - Annotation Type in org.axonframework.serializer
-
Annotation that attaches revision information to a Serializable object.
- revisionOf(Class<?>) - Method in class org.axonframework.serializer.AnnotationRevisionResolver
-
- revisionOf(Class<?>) - Method in class org.axonframework.serializer.FixedValueRevisionResolver
-
- revisionOf(Class<?>) - Method in class org.axonframework.serializer.MavenArtifactRevisionResolver
-
- revisionOf(Class<?>) - Method in interface org.axonframework.serializer.RevisionResolver
-
Returns the revision for the given payloadType
.
- revisionOf(Class<?>) - Method in class org.axonframework.serializer.SerialVersionUIDRevisionResolver
-
- RevisionResolver - Interface in org.axonframework.serializer
-
Interface towards a mechanism that resolves the revision of a given payload type.
- rollback() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- rollback(Throwable) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- rollback() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- rollback(Throwable) - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- rollback() - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Clear the UnitOfWork of any buffered changes.
- rollback(Throwable) - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Clear the UnitOfWork of any buffered changes.
- RollbackConfiguration - Interface in org.axonframework.commandhandling
-
The RollbackConfiguration defines when a UnitOfWork should be rolled back when the command handler or any
interceptors
reported a failure.
- rollBackOn(Throwable) - Method in interface org.axonframework.commandhandling.RollbackConfiguration
-
Decides whether the given throwable
should trigger a rollback.
- rollBackOn(Throwable) - Method in class org.axonframework.commandhandling.RollbackOnAllExceptionsConfiguration
-
- rollBackOn(Throwable) - Method in class org.axonframework.commandhandling.RollbackOnUncheckedExceptionConfiguration
-
- RollbackOnAllExceptionsConfiguration - Class in org.axonframework.commandhandling
-
The default implementation of the RollbackConfiguration interface.
- RollbackOnAllExceptionsConfiguration() - Constructor for class org.axonframework.commandhandling.RollbackOnAllExceptionsConfiguration
-
- RollbackOnUncheckedExceptionConfiguration - Class in org.axonframework.commandhandling
-
RollbackConfiguration that indicates a rollback should be triggered for all but checked exceptions.
- RollbackOnUncheckedExceptionConfiguration() - Constructor for class org.axonframework.commandhandling.RollbackOnUncheckedExceptionConfiguration
-
- rollbackTransaction(Object) - Method in class org.axonframework.unitofwork.NoTransactionManager
-
- rollbackTransaction(TransactionStatus) - Method in class org.axonframework.unitofwork.SpringTransactionManager
-
- rollbackTransaction(T) - Method in interface org.axonframework.unitofwork.TransactionManager
-
Rolls back the transaction identifier by given transactionStatus
.
- run() - Method in class org.axonframework.common.MemberAccessibilityCallback
- run() - Method in class org.axonframework.eventhandling.async.EventProcessor
- Saga - Interface in org.axonframework.saga
-
Interface describing an implementation of a Saga.
- SagaCreationPolicy - Enum in org.axonframework.saga
-
Enumeration containing the possible Creation Policies for Sagas.
- SagaEntry - Class in org.axonframework.saga.repository.jpa
-
Java Persistence Entity allowing sagas to be stored in a relational database.
- SagaEntry(Saga, Serializer) - Constructor for class org.axonframework.saga.repository.jpa.SagaEntry
-
Constructs a new SagaEntry for the given saga
.
- SagaEntry() - Constructor for class org.axonframework.saga.repository.jpa.SagaEntry
-
Constructor required by JPA.
- sagaEntryTable() - Method in class org.axonframework.saga.repository.jdbc.SchemaConfiguration
-
- SagaEventHandler - Annotation Type in org.axonframework.saga.annotation
-
Method-level annotation indicating that the annotated method i an event handler method for the saga instance.
- SagaFactory - Interface in org.axonframework.saga
-
Interface describing a mechanism that creates implementations of a Saga.
- SagaInitializationPolicy - Class in org.axonframework.saga
-
Describes the conditions under which a Saga should be created, and which AssociationValue it should be initialized
with.
- SagaInitializationPolicy(SagaCreationPolicy, AssociationValue) - Constructor for class org.axonframework.saga.SagaInitializationPolicy
-
Creates an instance using the given creationPolicy
and initialAssociationValue
.
- SagaManager - Interface in org.axonframework.saga
-
Interface toward the Manager of one or more types of Saga.
- SagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
Parses the saga-manager element.
- SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager - Class in org.axonframework.contextsupport.spring
-
Manages the subscription of a SagaManager with an Event Bus.
- SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager() - Constructor for class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
-
- SagaMethodMessageHandler - Class in org.axonframework.saga.annotation
-
- SagaMethodMessageHandler(SagaCreationPolicy, MethodMessageHandler, String, String, Property) - Constructor for class org.axonframework.saga.annotation.SagaMethodMessageHandler
-
Creates a SagaMethodMessageHandler.
- SagaMethodMessageHandlerInspector<T extends AbstractAnnotatedSaga> - Class in org.axonframework.saga.annotation
-
Utility class that inspects annotation on a Saga instance and returns the relevant configuration for its Event
Handlers.
- SagaMethodMessageHandlerInspector(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.saga.annotation.SagaMethodMessageHandlerInspector
-
Initialize the inspector to handle events for the given sagaType
.
- SagaRepository - Interface in org.axonframework.saga
-
Interface towards the storage mechanism of Saga instances.
- SagaSqlSchema - Interface in org.axonframework.saga.repository.jdbc
-
Interface describing the SQL statements that the JdbcSagaRepository needs to execute against the underlying
database.
- SagaStorageException - Exception in org.axonframework.saga
-
Exception indicating that an error has occurred while storing a Saga.
- SagaStorageException(String) - Constructor for exception org.axonframework.saga.SagaStorageException
-
Initialize a SagaStorageException with the given descriptive message
.
- SagaStorageException(String, Throwable) - Constructor for exception org.axonframework.saga.SagaStorageException
-
Initialize a SagaStorageException with the given descriptive message
and cause
.
- save(T) - Method in interface org.axonframework.unitofwork.SaveAggregateCallback
-
Invoked when the UnitOfWork wishes to store an aggregate.
- SaveAggregateCallback<T extends AggregateRoot> - Interface in org.axonframework.unitofwork
-
Callback used by UnitOfWork instances to be invoked when the UnitOfWork wishes to store an aggregate.
- saveAggregates() - Method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
- saveAggregates() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
Saves all registered aggregates by calling their respective callbacks.
- schedule(EventMessage<?>, MultiplexingEventProcessingMonitor) - Method in class org.axonframework.eventhandling.async.AsynchronousCluster
-
Schedules this task for execution when all pre-conditions have been met.
- schedule(DateTime, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Schedule the given event
for publication at the given triggerDateTime
.
- schedule(Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Schedule the given event
for publication after the given triggerDuration
.
- schedule(DateTime, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- schedule(DateTime, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- scheduleEvent(EventMessage<?>) - Method in class org.axonframework.eventhandling.async.EventProcessor
-
Schedules an event for processing.
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
-
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in interface org.axonframework.commandhandling.gateway.RetryScheduler
-
Inspect the given commandMessage
that failed with given lastFailure
.
- scheduleSnapshot(String, Object) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
- scheduleSnapshot(String, Object) - Method in interface org.axonframework.eventsourcing.Snapshotter
-
Schedules snapshot taking for an aggregate with given typeIdentifier
and
aggregateIdentifier
.
- ScheduleToken - Interface in org.axonframework.eventhandling.scheduling
-
Token that identifies a single scheduled Event.
- SchedulingException - Exception in org.axonframework.eventhandling.scheduling
-
Exception indicating a problem in the Event Scheduling mechanism.
- SchedulingException(String) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
-
Initialize a SchedulingException with the given message
.
- SchedulingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
-
Initialize a SchedulingException with the given message
and cause
.
- schemaConfiguration - Variable in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- SchemaConfiguration - Class in org.axonframework.eventstore.jdbc
-
SchemaConfiguration allows specification of custom storage locations for domain event
and snapshot event entries.
- SchemaConfiguration() - Constructor for class org.axonframework.eventstore.jdbc.SchemaConfiguration
-
Initialize SchemaConfiguration with default values.
- SchemaConfiguration(String, String) - Constructor for class org.axonframework.eventstore.jdbc.SchemaConfiguration
-
Initialize SchemaConfiguration with custom locations for event entry tables.
- schemaConfiguration - Variable in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- SchemaConfiguration - Class in org.axonframework.saga.repository.jdbc
-
SchemaConfiguration allows specification of custom storage locations for the saga repositories.
- SchemaConfiguration() - Constructor for class org.axonframework.saga.repository.jdbc.SchemaConfiguration
-
Initialize SchemaConfiguration with default values.
- SchemaConfiguration(String, String) - Constructor for class org.axonframework.saga.repository.jdbc.SchemaConfiguration
-
Initialize SchemaConfiguration with custom locations for event entry tables.
- selectCluster(EventListener) - Method in class org.axonframework.eventhandling.AbstractClusterSelector
-
- selectCluster(EventListener) - Method in class org.axonframework.eventhandling.AutowiringClusterSelector
-
- selectCluster(EventListener) - Method in interface org.axonframework.eventhandling.ClusterSelector
-
Selects the cluster instance that the given eventListener
should be member of.
- selectCluster(EventListener) - Method in class org.axonframework.eventhandling.CompositeClusterSelector
-
- selectCluster(EventListener) - Method in class org.axonframework.eventhandling.DefaultClusterSelector
-
Selects the cluster instance that the given eventListener
should be member of.
- send(Object, CommandCallback<R>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Sends the given command
, and invokes the callback
when the command is processed.
- send(Object, CommandCallback<R>) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
, and have the result of the command's execution reported to the given
callback
.
- send(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and returns immediately, without waiting for the command to execute.
- send(Object, CommandCallback<R>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
- send(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Sends the given command
and returns immediately.
- sendAndForget(Object) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Dispatches a command without callback.
- sendAndWait(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and wait for it to execute.
- sendAndWait(Object, long, TimeUnit) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and wait for it to execute.
- sendAndWait(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Sends the given command
and waits for its execution to complete, or until the waiting thread is
interrupted.
- sendAndWait(Object, long, TimeUnit) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Sends the given command
and waits for its execution to complete, or until the given
timeout
has expired, or the waiting thread is interrupted.
- SequenceEventStore - Class in org.axonframework.eventstore.supporting
-
- SequenceEventStore(EventStore, EventStoreManagement, EventStore, EventStoreManagement) - Constructor for class org.axonframework.eventstore.supporting.SequenceEventStore
-
- SequenceNumber - Annotation Type in org.axonframework.eventhandling.annotation
-
Annotation indication that a parameter on an Event Handler method should be injected with the SequenceNumber of
a DomainEventMessage.
- SequenceNumberParameterResolverFactory - Class in org.axonframework.eventhandling.annotation
-
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a
Long
type
annotated with the
SequenceNumber
annotation and assigns the sequenceNumber of the DomainEventMessage.
- SequenceNumberParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.annotation.SequenceNumberParameterResolverFactory
-
- SequencingPolicy<T> - Interface in org.axonframework.eventhandling.async
-
Interface to a policy definition for concurrent processing, for example event handling.
- SequentialPerAggregatePolicy - Class in org.axonframework.eventhandling.async
-
Concurrency policy that requires sequential processing of events raised by the same aggregate.
- SequentialPerAggregatePolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-
- SequentialPolicy - Class in org.axonframework.eventhandling.async
-
SequencingPolicy that requires serialized handling of all events delivered to an event handler.
- SequentialPolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPolicy
-
- SerializationAware - Interface in org.axonframework.serializer
-
Marker interface for messages that have special serialization awareness.
- SerializationAwareDomainEventMessage<T> - Class in org.axonframework.serializer
-
Wrapper around a DomainEventMessage that adds "Serialization Awareness" to the message it wraps.
- SerializationAwareDomainEventMessage(DomainEventMessage<T>) - Constructor for class org.axonframework.serializer.SerializationAwareDomainEventMessage
-
Initialize a new wrapper for the given message
.
- SerializationAwareEventMessage<T> - Class in org.axonframework.serializer
-
Wrapper around am EventMessage that adds "Serialization Awareness" to the message it wraps.
- SerializationAwareEventMessage(EventMessage<T>) - Constructor for class org.axonframework.serializer.SerializationAwareEventMessage
-
Initializes a new wrapper for the given eventMessage
.
- SerializationException - Exception in org.axonframework.serializer
-
Indicates that an exception occurred while serializing or deserializing an object.
- SerializationException(String) - Constructor for exception org.axonframework.serializer.SerializationException
-
Initializes the exception using the given message
.
- SerializationException(String, Throwable) - Constructor for exception org.axonframework.serializer.SerializationException
-
Initializes the exception using the given message
and cause
.
- SerializationOptimizingInterceptor - Class in org.axonframework.commandhandling.interceptors
-
Interceptor that register a unit of work listener that wraps each EventMessage in a SerializationAware message.
- SerializationOptimizingInterceptor() - Constructor for class org.axonframework.commandhandling.interceptors.SerializationOptimizingInterceptor
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serializer.AbstractXStreamSerializer
-
Serialize the given object
into a Serialized Object containing the given
expectedRepresentation
.
- serialize(Object, Class<T>) - Method in class org.axonframework.serializer.JavaSerializer
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serializer.json.JacksonSerializer
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
-
- serialize(Object, Class<T>) - Method in interface org.axonframework.serializer.Serializer
-
Serialize the given object
into a Serialized Object containing the given
expectedRepresentation
.
- SerializedDomainEventData<T> - Interface in org.axonframework.serializer
-
Interface describing the properties of serialized Domain Event Messages.
- SerializedDomainEventMessage<T> - Class in org.axonframework.serializer
-
DomainEventMessage implementation that is optimized to cope with serialized Payload and MetaData.
- SerializedDomainEventMessage(SerializedDomainEventData, Serializer) - Constructor for class org.axonframework.serializer.SerializedDomainEventMessage
-
Reconstructs a DomainEventMessage using the given domainEventData
, containing data to be
deserialized using the given serializer
.
- SerializedDomainEventMessage(SerializedEventMessage<T>, Object, long) - Constructor for class org.axonframework.serializer.SerializedDomainEventMessage
-
Wrapper constructor for wrapping a SerializedEventMessage as a SerializedDomainEventMessage, using given
aggregateIdentifier
and sequenceNumber
.
- SerializedDomainEventUpcastingContext - Class in org.axonframework.upcasting
-
Implementation of UpcastingContext that builds a context based on the information of a serialized domain event
- SerializedDomainEventUpcastingContext(SerializedDomainEventData, Serializer) - Constructor for class org.axonframework.upcasting.SerializedDomainEventUpcastingContext
-
Initializes the UpcastingContext using given serialized domainEventData
.
- SerializedEventMessage<T> - Class in org.axonframework.serializer
-
EventMessage implementation that is optimized to cope with serialized Payload and MetaData.
- SerializedEventMessage(String, DateTime, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serializer.SerializedEventMessage
-
Constructor to reconstruct an EventMessage using serialized data
- SerializedMessage<T> - Class in org.axonframework.serializer
-
Message implementation that is optimized to cope with serialized Payload and MetaData.
- SerializedMessage(String, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serializer.SerializedMessage
-
Reconstructs a Message using the given identifier
, serializedPayload
,
serializedMetaData
and serializer
.
- SerializedMetaData<T> - Class in org.axonframework.serializer
-
Represents the serialized form of a
MetaData
instance.
- SerializedMetaData(T, Class<T>) - Constructor for class org.axonframework.serializer.SerializedMetaData
-
Construct an instance with given
bytes
representing the serialized form of a
MetaData
instance.
- SerializedObject<T> - Interface in org.axonframework.serializer
-
Interface describing the structure of a serialized object.
- SerializedObjectHolder - Class in org.axonframework.serializer
-
Holder that keeps references to serialized representations of a payload and meta data of a specific message.
- SerializedObjectHolder(Message) - Constructor for class org.axonframework.serializer.SerializedObjectHolder
-
Initialize the holder for the serialized representations of the payload and meta data of given
message
- SerializedSaga - Class in org.axonframework.saga.repository.jpa
-
Specialization of the SerializedObject for Sagas represented as byte array.
- SerializedSaga(byte[], String, String) - Constructor for class org.axonframework.saga.repository.jpa.SerializedSaga
-
Initialize a SerializedSaga instance with given data
, of given type
and
revision
.
- SerializedType - Interface in org.axonframework.serializer
-
Describes the type of a serialized object.
- serializeMetaData(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serializer.MessageSerializer
-
Utility method that serializes the meta data of the given message
using given
serializer
and expectedRepresentation
.
- serializeMetaData(Message<?>, Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
-
Serialize the meta data of given message
to the given expectedRepresentation
.
- serializeMetaData(Serializer, Class<T>) - Method in interface org.axonframework.serializer.SerializationAware
-
Serialize the meta data of this message using given serializer
, using given
expectedRepresentation
.
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedEventMessage
-
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedMessage
-
- serializeMetaData(Serializer, Class<T>) - Method in class org.axonframework.serializer.SerializedObjectHolder
-
- serializePayload(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serializer.MessageSerializer
-
Utility method that serializes the payload of the given message
using given serializer
and expectedRepresentation
.
- serializePayload(Message<?>, Class<T>) - Method in class org.axonframework.serializer.MessageSerializer
-
Serialize the payload of given message
to the given expectedRepresentation
.
- serializePayload(Serializer, Class<T>) - Method in interface org.axonframework.serializer.SerializationAware
-
Serialize the payload of this message using given serializer
, using given
expectedRepresentation
.
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializationAwareEventMessage
-
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedDomainEventMessage
-
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedEventMessage
-
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serializer.SerializedMessage
-
- serializePayload(Serializer, Class<T>) - Method in class org.axonframework.serializer.SerializedObjectHolder
-
- Serializer - Interface in org.axonframework.serializer
-
Interface describing a serialization mechanism.
- SerializerHandler - Class in org.axonframework.commandhandling.disruptor
-
Disruptor Event Handler that serializes EventMessage implementations that are also SerializationAware.
- SerializerHandler(Serializer, int, Class<?>) - Constructor for class org.axonframework.commandhandling.disruptor.SerializerHandler
-
Initialize the handler using given serializer
and processing the segment Id with given
serializerId
(in case of multiple serializer threads).
- SerialVersionUIDRevisionResolver - Class in org.axonframework.serializer
-
RevisionResolver implementation that returns the (String representation of the) serialVersionUID of a class.
- SerialVersionUIDRevisionResolver() - Constructor for class org.axonframework.serializer.SerialVersionUIDRevisionResolver
-
- set(UnitOfWork) - Static method in class org.axonframework.unitofwork.CurrentUnitOfWork
-
Binds the given unitOfWork
to the current thread.
- setAdditionalConverters(List<ContentTypeConverter>) - Method in class org.axonframework.serializer.ChainingConverterFactory
-
Setter for dependency injection frameworks that require property methods.
- setAdditionalFactories(List<ParameterResolverFactory>) - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
-
Defines any additional parameter resovler factories that need to be use to resolve parameters.
- setAggregateCache(Cache) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
-
Sets the Cache instance used be Caching repositories.
- setAggregateCaches(List<Cache>) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
-
Sets the Cache instances used be Caching repositories.
- setAggregateFactories(List<AggregateFactory<?>>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-
Sets the aggregate factory to use.
- setAggregateFactories(List<AggregateFactory<?>>) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
-
Optionally sets the aggregate factories to use.
- setAggregateFactory(AggregateFactory<? extends EventSourcedAggregateRoot>) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
-
Sets the aggregate factory used to create instances for the repository to create.
- setAggregateType(Class<T>) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
Sets the type of aggregate to inspect for annotations.
- setAggregateType(String) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Sets the type identifier of the aggregate handled in this unit of work
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.common.annotation.SpringBeanParameterResolverFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.contextsupport.spring.ApplicationContextLookupParameterResolverFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.contextsupport.spring.AutowiredDependencyFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.AutowiringClusterSelector
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.saga.spring.SpringResourceInjector
-
- 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.
- setBatchSize(int) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
Sets the number of events that should be read at each database access.
- setBatchSize(int) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
Sets the number of events that should be read at each database access.
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
-
- setBeanName(String) - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
-
- setBeanName(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
- setBufferSize(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the buffer size to use.
- setBufferSize(int) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the size of the processing buffer.
- setCache(Cache) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the cache in which loaded aggregates will be stored.
- setCache(Cache) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Set the cache to use for this repository.
- 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.AggregateAnnotationCommandHandlerFactoryBean
-
Sets the CommandBus to subscribe the handler to
- setCommandBus(CommandBus) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
-
Sets the event bus to which detected event listeners should be subscribed.
- setCommandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
Sets the command bus on which the Gateway must dispatch commands.
- setCommandBus(DisruptorCommandBus) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
-
The DisruptorCommandBus instance to create the repository from.
- setCommandCallbacks(List<CommandCallback<?>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
Registers the commandCallbacks
, which are invoked for each sent command, unless Axon is able to detect
that the result of the command does not match the type accepted by that callback.
- setCommandDispatchInterceptors(CommandDispatchInterceptor...) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
Sets the interceptors that should be invoked before a command is dispatched the the Command Bus.
- setCommandDispatchInterceptors(List<CommandDispatchInterceptor>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
Sets the interceptors that should be invoked before a command is dispatched the the Command Bus.
- setCommandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
The resolver providing the identifier (and version) of the aggregate a command targets.
- setCommandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the CommandTargetResolver that must be used to indicate which Aggregate instance will be invoked by an
incoming command.
- setConflictResolver(ConflictResolver) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Sets the conflict resolver to use for this repository.
- setCoolingDownPeriod(long) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the cooling down period in milliseconds.
- setCorrelationData(Map<String, ?>) - Static method in class org.axonframework.correlation.CorrelationDataHolder
-
Attaches the given data
as correlation data to the current thread.
- setCorrelationDataProvider(CorrelationDataProvider<? super EventMessage>) - Method in class org.axonframework.saga.AbstractSagaManager
-
Sets the correlation data provider for this SagaManager.
- setCorrelationDataProvider(CorrelationDataProvider<? super EventMessage>) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the CorrelationDataProvider which provides the Meta Data to assign to messages generated by the Sagas that
are managed by this SagaManager instance.
- setCorrelationDataProviders(List<? extends CorrelationDataProvider<? super EventMessage>>) - Method in class org.axonframework.saga.AbstractSagaManager
-
Sets the given correlationDataProviders
.
- setCorrelationDataProviders(List<? extends CorrelationDataProvider<? super EventMessage>>) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the CorrelationDataProviders which provide the Meta Data to assign to messages generated by the Sagas that
are managed by this SagaManager instance.
- setDataSource(DataSource) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
Registers the data source that allows the EventStore to detect the database type and define the error codes that
represent concurrent access failures.
- setDispatchInterceptors(List<CommandDispatchInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Configures the CommandDispatchInterceptor to use with the DisruptorCommandBus when commands are dispatched.
- setDispatchInterceptors(List<? extends CommandDispatchInterceptor>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Registers the given list of dispatch interceptors to the command bus.
- setEntityManager(EntityManager) - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
-
Sets the container managed entityManager to use.
- setErrorHandler(ErrorHandler) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the ErrorHandler instance, which defines the behavior in case an error occurs while loading or invoking
Sagas for an incoming Event.
- setEventBus(EventBus) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
-
Sets the event bus to which the SagaManager should be subscribed
- setEventBus(EventBus) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
-
Sets the event bus to which detected event listeners should be subscribed.
- setEventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
Sets the eventBus that scheduled events should be published to.
- setEventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the event bus to which scheduled events need to be published.
- setEventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the event bus to which scheduled events need to be published.
- setEventBus(EventBus) - Method in class org.axonframework.repository.AbstractRepository
-
Sets the event bus to which newly stored events should be published.
- setEventsToAlwaysCreateNewSagasFor(List<Class<?>>) - Method in class org.axonframework.saga.SimpleSagaManager
-
Sets the types of Events that should cause the creation of a new Saga instance, even if one already exists.
- setEventsToOptionallyCreateNewSagasFor(List<Class<?>>) - Method in class org.axonframework.saga.SimpleSagaManager
-
Sets the types of Events that should cause the creation of a new Saga instance if one does not already exist.
- setEventStore(SnapshotEventStore) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Sets the event store where the snapshotter can load domain events and store its snapshot events.
- setEventStore(EventStore) - Method in class org.axonframework.eventsourcing.HybridJpaRepository
-
The event store to which events are appended.
- setEventStreamDecorator(EventStreamDecorator) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Registers the EventStreamDecorator for events as part of this unit of work
- setEventStreamDecorators(List<EventStreamDecorator>) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
-
Sets the (additional) decorators to use when loading and storing events from/to the Event Store.
- setEventStreamDecorators(List<? extends EventStreamDecorator>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Sets the Event Stream Decorators that will process the event in the DomainEventStream when read, or written to
the event store.
- setExceptionResult(Throwable) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Registers the exception that occurred while processing the incoming command.
- setExecutor(Executor) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the Executor that provides the processing resources (Threads) for the components of the
DisruptorCommandBus.
- setExecutor(Executor) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Sets the executor that should process actual snapshot taking.
- setExecutor(Executor) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the executor that provides the threads for the processors.
- setExecutorService(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
Sets the ExecutorService implementation that monitors the triggers and provides the Threads to publish events.
- setForceFlushOnSave(boolean) - Method in class org.axonframework.repository.GenericJpaRepository
-
Indicates whether the EntityManager's state should be flushed each time an aggregate is saved.
- setForceUtc(boolean) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
Control if date time in the SQL scheme
should use UTC time zone or system local time zone.
- setGatewayInterface(Class<T>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
Sets the interface that describes the gateway instance to describe.
- setGroupIdentifier(String) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the group identifier to use when scheduling jobs with Quartz.
- setGroupIdentifier(String) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the group identifier to use when scheduling jobs with Quartz.
- setHandlerInterceptors(List<? extends CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Registers the given list of interceptors to the command bus.
- setInvokerInterceptors(List<CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during in the invocation thread.
- setInvokerThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the number of Threads that should be used to invoke the Command Handlers.
- setMaxSnapshotsArchived(int) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
Sets the maximum number of snapshots to archive for an aggregate.
- setMaxSnapshotsArchived(int) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
Sets the maximum number of snapshots to archive for an aggregate.
- setMetaDataValues(Map<String, Object>) - Method in class org.axonframework.eventhandling.SimpleClusterFactoryBean
-
Sets the given metaDataValues
in the Cluster.
- setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
Sets the ParameterResolverFactory to create parameter resolver instances with.
- setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
Sets the ParameterResolverFactory to create the Parameter Resolvers with that provide the parameter values for
the handler methods.
- setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
Sets the parameter resolver with which parameters of annotated event handlers in the aggregae are resolved.
- setPersistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
Sets the persistenceExceptionResolver that will help detect concurrency exceptions from the backing database.
- setPersistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
Sets the persistenceExceptionResolver that will help detect concurrency exceptions from the backing database.
- setPhase(int) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
Sets the phase in which handlers are subscribed and unsubscribed.
- setProcessorCount(int) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the number of processors (threads) to process events with.
- setProducerType(ProducerType) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the producer type to use.
- setProperty(String, Object) - Method in interface org.axonframework.eventhandling.ClusterMetaData
-
Stores a property value
under the given key
.
- setProperty(String, Object) - Method in class org.axonframework.eventhandling.DefaultClusterMetaData
-
- setPrototypeBeanName(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
Sets the name of the prototype bean this repository serves.
- setPublisherInterceptors(List<CommandHandlerInterceptor>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during the publication of changes.
- setPublisherThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the number of Threads that should be used to store and publish the generated Events.
- setReplayable(boolean) - Method in class org.axonframework.saga.AbstractReplayAwareSagaManager
-
Sets whether or not to allow event replay on managed Sagas.
- setRepository(Repository<T>) - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandlerFactoryBean
-
The repository from which to load aggregate instances.
- setRescheduleCommandsOnCorruptState(boolean) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Indicates whether commands that failed because they were executed against potentially corrupted aggregate state
should be automatically rescheduled.
- setResourceInjector(ResourceInjector) - Method in class org.axonframework.saga.GenericSagaFactory
-
Sets the resource injector that provides the resources needed by the Sagas created by this factory.
- setResourceInjector(ResourceInjector) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
-
Sets the ResourceInjector to use to inject Saga instances with any (temporary) resources they might need.
- setResourceInjector(ResourceInjector) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
-
Sets the ResourceInjector to use to inject Saga instances with any (temporary) resources they might need.
- setResult(Object) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Registers the result of the command's execution, if successful.
- setRetryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactoryBean
-
Sets the RetryScheduler that will be invoked when a command fails execution.
- setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the rollback configuration for the DisruptorCommandBus to use.
- setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Sets the RollbackConfiguration that allows you to change when the UnitOfWork is committed.
- setSagaFactory(SagaFactory) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the SagaFactory responsible for creating new Saga instances when required.
- setSagaManager(SagaManager) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
-
Sets the SagaManager instance to subscribe to the Event Bus
- setSagaRepository(SagaRepository) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the saga repository to store and load Sagas from.
- setScheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the backing Quartz Scheduler for this timer.
- setScheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the backing Quartz Scheduler for this timer.
- setSerializedRepresentation(Class<?>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the type of data the serialized object should be represented in.
- setSerializer(Serializer) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the serializer to perform pre-serialization with, or null
if no pre-serialization should be
done.
- setSerializer(Serializer) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
-
Sets the Serializer instance to serialize Sagas with.
- setSerializer(Serializer) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
-
Sets the Serializer instance to serialize Sagas with.
- setSerializerThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the number of threads that should perform the pre-serialization step.
- setSnapshotter(Snapshotter) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
-
Sets the snapshotter to notify when a snapshot needs to be taken.
- setSnapshotterTrigger(SnapshotterTrigger) - Method in class org.axonframework.contextsupport.spring.DisruptorRepositoryBeanDefinitionParser.RepositoryFactoryBean
-
The snapshotter trigger instance that will decide when to trigger a snapshot
- setSnapshotterTrigger(SnapshotterTrigger) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Sets the snapshotter trigger for this repository.
- setStartTimeout(long) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the amount of time (in milliseconds) the AsyncSagaManager will wait for the async processors to be assigned
a thread from the executor.
- setSubscriptions(Map<?, ?>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Convenience method that allows you to register command handlers using a Dependency Injection framework.
- setSuppressExceptions(boolean) - Method in class org.axonframework.saga.AbstractSagaManager
-
Sets whether or not to suppress any exceptions that are cause by invoking Sagas.
- setSynchronizeSagaAccess(boolean) - Method in class org.axonframework.saga.AbstractSagaManager
-
Sets whether of not access to Saga's Event Handler should by synchronized.
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
The TransactionDefinition to use by the transaction manager.
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
The TransactionDefinition to use by the transaction manager.
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
-
Optionally sets the transaction definition to use.
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.unitofwork.SpringTransactionManager
-
The TransactionDefinition to use by the transaction manager.
- setTransactionManager(TransactionManager) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the transaction manager to use to manage a transaction around the storage and publication of events.
- setTransactionManager(TransactionManager) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Sets the transaction manager that manages the transaction around command handling.
- setTransactionManager(Object) - Method in class org.axonframework.contextsupport.spring.TransactionManagerFactoryBean
-
Sets the actual transaction manager.
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
Sets the transaction manager that manages the transaction around the publication of an event.
- setTransactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the transaction manager that manages a transaction around the publication of an event.
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the transaction manager that manages the transaction around the publication of an event.
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.eventsourcing.SpringAggregateSnapshotter
-
Sets the transaction manager to manager underlying transaction with.
- setTransactionManager(TransactionManager) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the TransactionManager used to manage any transactions required by the underlying storage mechanism.
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.unitofwork.SpringTransactionManager
-
The PlatformTransactionManager that manages the transactions with the underlying data source.
- setTrigger(int) - Method in class org.axonframework.eventsourcing.EventCountSnapshotterTrigger
-
Sets the number of events that will trigger the creation of a snapshot events.
- setTxManager(TransactionManager<?>) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Sets the transactionManager that wraps the snapshot creation in a transaction.
- setTypeIdentifier(String) - Method in class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
Sets the type identifier of the aggregate served by this repository.
- setUnitOfWorkFactory(UnitOfWorkFactory) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Sets the UnitOfWorkFactory that provides the UnitOfWork instances for handling incoming commands.
- setUnitOfWorkFactory(UnitOfWorkFactory) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the Unit of Work Factory instance which provides the UnitOfWork that manages the publication of the
scheduled event.
- setUnsubscribeOnShutdown(boolean) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
Indicates whether handlers should be unsubscribed on shutdown.
- setUpcasterChain(UpcasterChain) - Method in class org.axonframework.eventstore.fs.FileSystemEventStore
-
- setUpcasterChain(UpcasterChain) - Method in class org.axonframework.eventstore.jdbc.JdbcEventStore
-
- setUpcasterChain(UpcasterChain) - Method in class org.axonframework.eventstore.jpa.JpaEventStore
-
- setUpcasterChain(UpcasterChain) - Method in interface org.axonframework.upcasting.UpcasterAware
-
Sets the UpcasterChain which allow older revisions of serialized objects to be deserialized.
- 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.
- setWaitStrategy(WaitStrategy) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the WaitStrategy
, which used to make dependent threads wait for tasks to be completed.
- setWaitStrategy(WaitStrategy) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Sets the WaitStrategy to use when event processors need to wait for incoming events.
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.AggregateCommandHandlerBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.DisruptorCommandBusBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.EventBusBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.FileSystemEventStoreBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JdbcEventStoreBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JdbcSagaRepositoryBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JpaEventStoreBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JpaRepositoryBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.JpaSagaRepositoryBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.RepositoryBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SimpleCommandBusBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
-
- shouldGenerateIdAsFallback() - Method in class org.axonframework.contextsupport.spring.SnapshotterTriggerBeanDefinitionParser
-
- shutdown() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
-
Shuts down the Executor used to asynchronously dispatch incoming commands.
- SimpleCluster - Class in org.axonframework.eventhandling
-
A simple Cluster implementation that invokes each of the members of a cluster when an Event is published.
- SimpleCluster(String) - Constructor for class org.axonframework.eventhandling.SimpleCluster
-
Initializes the cluster with given name
.
- SimpleCluster(String, OrderResolver) - Constructor for class org.axonframework.eventhandling.SimpleCluster
-
Initializes the cluster with given name
, using given orderResolver
to define the
order in which listeners need to be invoked.
- SimpleClusterFactoryBean - Class in org.axonframework.eventhandling
-
FactoryBean that creates an instance of a SimpleCluster, allowing easier access to the MetaData.
- SimpleClusterFactoryBean() - Constructor for class org.axonframework.eventhandling.SimpleClusterFactoryBean
-
- SimpleCommandBus - Class in org.axonframework.commandhandling
-
Implementation of the CommandBus that dispatches commands to the handlers subscribed to that specific type of
command.
- SimpleCommandBus() - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
-
Initializes the SimpleCommandBus.
- SimpleCommandBusBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
The SimpleCommandBusBeanDefinitionParser does the actual work of parsing the commandBus
element from
the
Axon namespace.
- SimpleCommandBusBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SimpleCommandBusBeanDefinitionParser
-
- SimpleCommandBusStatistics - Class in org.axonframework.commandhandling
-
Statistics object to store information about the internals of the SimpleCommandBus
.
- SimpleCommandBusStatistics() - Constructor for class org.axonframework.commandhandling.SimpleCommandBusStatistics
-
Creates an instance of this statistics MBean.
- SimpleCommandBusStatisticsMXBean - Interface in org.axonframework.commandhandling
-
Management interface for the SimpleCommandBus monitor
As required by the JMX specification.
- SimpleCorrelationDataProvider - Class in org.axonframework.correlation
-
CorrelationDataProvider implementation defines correlation headers by the header names.
- SimpleCorrelationDataProvider(String...) - Constructor for class org.axonframework.correlation.SimpleCorrelationDataProvider
-
Initializes the CorrelationDataProvider to return the meta data of messages with given metaDataKeys
as correlation data.
- SimpleDomainEventStream - Class in org.axonframework.domain
-
Creates a DomainEventStream that streams the contents of a list.
- SimpleDomainEventStream(Collection<? extends DomainEventMessage>) - Constructor for class org.axonframework.domain.SimpleDomainEventStream
-
Initialize the event stream using the given List of DomainEvent and aggregate identifier.
- SimpleDomainEventStream(DomainEventMessage...) - Constructor for class org.axonframework.domain.SimpleDomainEventStream
-
- SimpleEntityManagerProvider - Class in org.axonframework.common.jpa
-
Simple implementation of the EntityManagerProvider that returns the EntityManager instance provided at construction
time.
- SimpleEntityManagerProvider(EntityManager) - Constructor for class org.axonframework.common.jpa.SimpleEntityManagerProvider
-
Initializes an instance that always returns the given entityManager
.
- SimpleEventBus - Class in org.axonframework.eventhandling
-
Implementation of the
EventBus
that directly forwards all published events (in the callers' thread) to all
subscribed listeners.
- SimpleEventBus() - Constructor for class org.axonframework.eventhandling.SimpleEventBus
-
Initializes the SimpleEventBus and registers the mbeans for management information.
- SimpleEventBusStatistics - Class in org.axonframework.eventhandling
-
Statistics object to store information about the internal of the SimpleEventBus
.
- SimpleEventBusStatisticsMXBean - Interface in org.axonframework.eventhandling
-
Management interface the SimpleEventBus monitor.
- SimpleEventFileResolver - Class in org.axonframework.eventstore.fs
-
Very straightforward implementation of the EventFileResolver that stores files in a directory structure underneath a
given base directory.
- SimpleEventFileResolver(File) - Constructor for class org.axonframework.eventstore.fs.SimpleEventFileResolver
-
Initialize the SimpleEventFileResolver with the given baseDir
.
- SimpleEventScheduler - Class in org.axonframework.eventhandling.scheduling.java
-
An
EventScheduler
implementation that uses Java's ScheduledExecutorService as scheduling and triggering
mechanism.
- SimpleEventScheduler(ScheduledExecutorService, EventBus) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
Initialize the SimpleEventScheduler using the given executorService
as trigger and execution
mechanism, and publishes events to the given eventBus
.
- SimpleEventScheduler(ScheduledExecutorService, EventBus, UnitOfWorkFactory) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
Initialize the SimpleEventScheduler using the given executorService
as trigger and execution
mechanism, and publishes events to the given eventBus
.
- SimpleEventSchedulerFactoryBean - Class in org.axonframework.eventhandling.scheduling.java
-
Spring FactoryBean that creates a SimpleEventScheduler instance using resources found in the Spring Application
Context.
- SimpleEventSchedulerFactoryBean() - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- SimpleOperator - Class in org.axonframework.eventstore.jdbc.criteria
-
Implementation of all simple operators (i.e.
- SimpleOperator(JdbcProperty, String, Object) - Constructor for class org.axonframework.eventstore.jdbc.criteria.SimpleOperator
-
Initializes a simple operator where the given property
, operator
and
expression
match.
- SimpleOperator - Class in org.axonframework.eventstore.jpa.criteria
-
Implementation of all simple operators (i.e.
- SimpleOperator(JpaProperty, String, Object) - Constructor for class org.axonframework.eventstore.jpa.criteria.SimpleOperator
-
Initializes a simple operator where the given property
, operator
and
expression
match.
- SimpleResourceInjector - Class in org.axonframework.saga
-
Resource injector that uses setter methods to inject resources.
- SimpleResourceInjector(Object...) - Constructor for class org.axonframework.saga.SimpleResourceInjector
-
Initializes the resource injector to inject to given resources
.
- SimpleResourceInjector(Collection<?>) - Constructor for class org.axonframework.saga.SimpleResourceInjector
-
Initializes the resource injector to inject to given resources
.
- SimpleResourceParameterResolverFactory - Class in org.axonframework.common.annotation
-
ParameterResolverFactory implementation that resolves parameters for a specific given Resource.
- SimpleResourceParameterResolverFactory(Object) - Constructor for class org.axonframework.common.annotation.SimpleResourceParameterResolverFactory
-
Initialize the ParameterResolverFactory to inject the given resource
in applicable parameters.
- SimpleSagaManager - Class in org.axonframework.saga
-
Simple SagaManager implementation.
- SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, EventBus) - Constructor for class org.axonframework.saga.SimpleSagaManager
-
- SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, SagaFactory, EventBus) - Constructor for class org.axonframework.saga.SimpleSagaManager
-
- SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver) - Constructor for class org.axonframework.saga.SimpleSagaManager
-
Initialize a SimpleSagaManager backed by the given resources, using a GenericSagaFactory.
- SimpleSagaManager(Class<? extends Saga>, SagaRepository, AssociationValueResolver, SagaFactory) - Constructor for class org.axonframework.saga.SimpleSagaManager
-
Initialize a SimpleSagaManager backed by the given resources.
- SimpleScheduleToken - Class in org.axonframework.eventhandling.scheduling.java
-
ScheduleToken for tasks event scheduled using the SimpleEventScheduler.
- SimpleScheduleToken(String) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
-
Creates a SimpleScheduleToken with the given tokenId
.
- SimpleSerializedDomainEventData<T> - Class in org.axonframework.eventstore.jpa
-
Simple implementation of the
SerializedDomainEventData
class, used to reduce memory consumptions by queries
accessing Event Entries.
- SimpleSerializedDomainEventData(String, String, long, Object, String, String, T, T) - Constructor for class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
Initialize an instance using given properties.
- SimpleSerializedDomainEventData(String, String, long, Object, SerializedObject<T>, SerializedObject<T>) - Constructor for class org.axonframework.eventstore.jpa.SimpleSerializedDomainEventData
-
Initialize an instance using given properties.
- SimpleSerializedObject<T> - Class in org.axonframework.serializer
-
SerializedObject implementation that takes all properties as constructor parameters.
- SimpleSerializedObject(T, Class<T>, SerializedType) - Constructor for class org.axonframework.serializer.SimpleSerializedObject
-
Initializes a SimpleSerializedObject using given data
and serializedType
.
- SimpleSerializedObject(T, Class<T>, String, String) - Constructor for class org.axonframework.serializer.SimpleSerializedObject
-
Initializes a SimpleSerializedObject using given data
and a serialized type identified by given
type
and revision
.
- SimpleSerializedType - Class in org.axonframework.serializer
-
SerializedType implementation that takes its properties as constructor parameters.
- SimpleSerializedType(String, String) - Constructor for class org.axonframework.serializer.SimpleSerializedType
-
Initialize with given objectType
and revisionNumber
- SimpleUpcasterChain - Class in org.axonframework.upcasting
-
Represents a series of upcasters which are combined to upcast a
SerializedObject
to the most recent revision of that payload.
- SimpleUpcasterChain(List<Upcaster>) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
-
- SimpleUpcasterChain(Serializer, List<Upcaster>) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
-
Initializes the UpcasterChain with given serializer
and upcasters
.
- SimpleUpcasterChain(ConverterFactory, List<Upcaster>) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
-
Initializes the UpcasterChain with given converterFactory
and upcasters
.
- SimpleUpcasterChain(ConverterFactory, Upcaster...) - Constructor for class org.axonframework.upcasting.SimpleUpcasterChain
-
Initialize a chain of the given upcasters
and using the given converterFactory
to
create converters for the intermediate representations used by the upcasters.
- size() - Method in class org.axonframework.domain.EventContainer
-
Returns the number of events currently inside this container.
- size() - Method in class org.axonframework.domain.MetaData
-
- size() - Method in class org.axonframework.saga.annotation.AssociationValuesImpl
-
- size() - Method in interface org.axonframework.saga.AssociationValues
-
Returns the number of AssociationValue instances available in this container
- size() - Method in class org.axonframework.saga.repository.AssociationValueMap
-
Returns an approximation of the size of this map.
- size() - Method in class org.axonframework.saga.repository.inmemory.InMemorySagaRepository
-
Returns the number of Sagas currently contained in this repository.
- skip() - Static method in class org.axonframework.eventhandling.async.RetryPolicy
-
This policy will roll back the Unit of Work (and the transaction) and skip the event altogether.
- snapshotEntryTable() - Method in class org.axonframework.eventstore.jdbc.SchemaConfiguration
-
- SnapshotEventEntry - Class in org.axonframework.eventstore.jpa
-
JPA compatible entry that stores data required for the use of snapshot events.
- SnapshotEventEntry() - Constructor for class org.axonframework.eventstore.jpa.SnapshotEventEntry
-
Default constructor, as required by JPA specification.
- SnapshotEventEntry(String, DomainEventMessage, SerializedObject<byte[]>, SerializedObject<byte[]>) - Constructor for class org.axonframework.eventstore.jpa.SnapshotEventEntry
-
Initialize an Event entry for the given event
.
- snapshotEventEntryEntityName() - Method in class org.axonframework.eventstore.jpa.DefaultEventEntryStore
-
The name of the SnapshotEventEntry entity to use when querying for snapshot events.
- SnapshotEventStore - Interface in org.axonframework.eventstore
-
Interface describing an event store that is able to store snapshot events.
- snapshotFileExists(String, Object) - Method in interface org.axonframework.eventstore.fs.EventFileResolver
-
Indicates whether there is a file containing snapshot events for the given aggregateIdentifier
of
given type
.
- snapshotFileExists(String, Object) - Method in class org.axonframework.eventstore.fs.SimpleEventFileResolver
-
- Snapshotter - Interface in org.axonframework.eventsourcing
-
Interface describing instances that are capable of creating snapshot events for aggregates.
- SnapshotterBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
The SnapshotterBeanDefinitionParser is responsible for parsing the snapshotter
element form the Axon
namespace.
- SnapshotterBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SnapshotterBeanDefinitionParser
-
- SnapshotterTrigger - Interface in org.axonframework.eventsourcing
-
- 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
-
- SpringAnnotationOrderResolver - Class in org.axonframework.eventhandling
-
OrderResolver implementation that checks for @Order
annotations on the type level.
- SpringAnnotationOrderResolver() - Constructor for class org.axonframework.eventhandling.SpringAnnotationOrderResolver
-
- SpringBeanParameterResolverFactory - Class in org.axonframework.common.annotation
-
ParameterResolverFactory implementation that resolves parameters in the Spring Application Context.
- SpringBeanParameterResolverFactory() - Constructor for class org.axonframework.common.annotation.SpringBeanParameterResolverFactory
-
- SpringContextParameterResolverFactoryBuilder - Class in org.axonframework.contextsupport.spring
-
Creates and registers a bean definition for a Spring Context aware ParameterResolverFactory.
- SpringDataSourceConnectionProvider - Class in org.axonframework.common.jdbc
-
ConnectionProvider implementation that is aware of Transaction Managers and provides the connection attached to an
active transaction manager, instead of asking a Data Source directly.
- SpringDataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.common.jdbc.SpringDataSourceConnectionProvider
-
Initialize the connection provider, using given dataSource
to obtain a connection, when required.
- SpringParameterResolverFactoryBean - Class in org.axonframework.contextsupport.spring
-
Spring factory bean that creates a ParameterResolverFactory instance that is capable of resolving parameter values
as Spring Beans, in addition to the default behavior defined by Axon.
- SpringParameterResolverFactoryBean() - Constructor for class org.axonframework.contextsupport.spring.SpringParameterResolverFactoryBean
-
- SpringPrototypeAggregateFactory<T extends EventSourcedAggregateRoot> - Class in org.axonframework.eventsourcing
-
AggregateFactory implementation that uses Spring prototype beans to create new uninitialized instances of
Aggregates.
- SpringPrototypeAggregateFactory() - Constructor for class org.axonframework.eventsourcing.SpringPrototypeAggregateFactory
-
- SpringResourceInjector - Class in org.axonframework.saga.spring
-
ResourceInjector implementation that injects Saga instances with resources available from the Spring Application
context the injector is registered in.
- SpringResourceInjector() - Constructor for class org.axonframework.saga.spring.SpringResourceInjector
-
- SpringTransactionManager - Class in org.axonframework.unitofwork
-
TransactionManager implementation that uses a PlatformTransactionManager
as
underlying transaction manager.
- SpringTransactionManager(PlatformTransactionManager, TransactionDefinition) - Constructor for class org.axonframework.unitofwork.SpringTransactionManager
-
- SpringTransactionManager(PlatformTransactionManager) - Constructor for class org.axonframework.unitofwork.SpringTransactionManager
-
Initializes the SpringTransactionManager with the given transactionManager
and the default
transaction definition.
- SpringTransactionManager() - Constructor for class org.axonframework.unitofwork.SpringTransactionManager
-
Default constructor.
- sql_createDomainEventEntryTable(Connection) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates a PreparedStatement that allows for the creation of the table to store Event entries.
- sql_createDomainEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_createDomainEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.PostgresEventSqlSchema
-
- sql_createSnapshotEventEntryTable(Connection) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates a PreparedStatement that allows for the creation of the table to store Snapshots.
- sql_createSnapshotEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_createSnapshotEventEntryTable(Connection) - Method in class org.axonframework.eventstore.jdbc.PostgresEventSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.HsqlSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.PostgresSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that creates the table for storing Association Values for Sagas.
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.saga.repository.jdbc.PostgresSagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that creates the table for storing Sagas.
- sql_dateTime(DateTime) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Converts a DateTime
to a data value suitable for the database scheme.
- sql_dateTime(DateTime) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_deleteAssociationEntries(Connection, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_deleteAssociationEntries(Connection, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that deletes all association entries for a Saga with given
sagaIdentifier
.
- sql_deleteSagaEntry(Connection, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_deleteSagaEntry(Connection, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that deletes a Saga with given sagaIdentifier
.
- sql_fetchFromSequenceNumber(Connection, String, Object, long) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates a PreparedStatement that fetches event data for an aggregate with given type
and
identifier
, starting at the given firstSequenceNumber
.
- sql_fetchFromSequenceNumber(Connection, String, Object, long) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that finds identifiers of Sagas of given sagaType
associated with the
given association key
and value
.
- sql_findSnapshotSequenceNumbers(Connection, String, Object) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates a PreparedStatement that returns the sequence numbers of snapshots for an aggregate of given
type
and aggregateIdentifier
.
- sql_findSnapshotSequenceNumbers(Connection, String, Object) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_getFetchAll(Connection, String, Object[]) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates a PreparedStatement that fetches all event messages matching the given whereClause
.
- sql_getFetchAll(Connection, String, Object[]) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_insertDomainEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates the PreparedStatement for inserting a DomainEvent in the Event Store, using given attributes.
- sql_insertDomainEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_insertSnapshotEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates the PreparedStatement for inserting a Snapshot Event in the Event Store, using given attributes.
- sql_insertSnapshotEventEntry(Connection, String, String, long, DateTime, String, String, T, T, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_loadLastSnapshot(Connection, Object, String) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates the PreparedStatement for loading the last snapshot event for an aggregate with given
identifier
and of given aggregateType
.
- sql_loadLastSnapshot(Connection, Object, String) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_loadSaga(Connection, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_loadSaga(Connection, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that loads a single Saga, with given sagaId
.
- sql_pruneSnapshots(Connection, String, Object, long) - Method in interface org.axonframework.eventstore.jdbc.EventSqlSchema
-
Creates a PreparedStatement that deletes all snapshots with a sequence identifier equal or lower to the given
sequenceOfFirstSnapshotToPrune
, for an aggregate of given type
and
aggregateIdentifier
.
- sql_pruneSnapshots(Connection, String, Object, long) - Method in class org.axonframework.eventstore.jdbc.GenericEventSqlSchema
-
- sql_removeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_removeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that removes an association value for given sagaIdentifier
, where the
association is identified with given key
and value
.
- sql_storeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_storeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that stores an association with given key
and value
, for a
Saga of given type
and identifier
.
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that inserts a Saga entry, of given sagaType
and with given
sagaIdentifier
.
- sql_updateSaga(Connection, String, byte[], String, String) - Method in class org.axonframework.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_updateSaga(Connection, String, byte[], String, String) - Method in interface org.axonframework.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that updates the serialized form of an existing Saga entry, of given
sagaType
and with given sagaIdentifier
.
- SQLErrorCodesResolver - Class in org.axonframework.eventstore.jpa
-
SQLErrorCodesResolver is an implementation of PersistenceExceptionResolver used to resolve sql error codes to see if
it is an duplicate key constraint violation.
- SQLErrorCodesResolver(List<Integer>) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
-
Initializes the SQLErrorCodesResolver using the given list of SQL Codes representing Key Constraint Violations.
- SQLErrorCodesResolver(DataSource) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(String) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(Properties, String) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(Properties, DataSource) - Constructor for class org.axonframework.eventstore.jpa.SQLErrorCodesResolver
-
Initialize the SQLErrorCodesResolver with the given properties
and use the dataSource
to automatically retrieve the database product name.
- SQLStateResolver - Class in org.axonframework.eventstore.jpa
-
SQLStateResolver is an implementation of PersistenceExceptionResolver used to resolve sql state values to see if
it violates a unique key constraint.
- SQLStateResolver() - Constructor for class org.axonframework.eventstore.jpa.SQLStateResolver
-
Constructor that uses the standard SQL state category for the check.
- SQLStateResolver(String) - Constructor for class org.axonframework.eventstore.jpa.SQLStateResolver
-
Constructor that can be used to supply a specific SQL state code for the check.
- start() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- start() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
- start() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
-
- start() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Starts the Saga Manager by starting the processor threads and subscribes it with the eventBus
.
- start() - Method in class org.axonframework.unitofwork.NestableUnitOfWork
-
- start() - Method in interface org.axonframework.unitofwork.UnitOfWork
-
Starts the current unit of work, preparing it for aggregate registration.
- startAndGet() - Static method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork.
- startAndGet(TransactionManager<?>) - Static method in class org.axonframework.unitofwork.DefaultUnitOfWork
-
Starts a new DefaultUnitOfWork instance using the given transactionManager
to provide a backing
transaction, registering it a CurrentUnitOfWork.
- startReplay() - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
Starts a replay process on the current thread.
- startReplay(Criteria) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
Start a replay process on the current thread, only reading events matching the given criteria
.
- startReplay(Executor) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
Starts a replay process using the given executor
.
- startReplay(Executor, Criteria) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
Starts a replay process using the given executor
, only reading events matching the given
criteria
.
- StartSaga - Annotation Type in org.axonframework.saga.annotation
-
Indicates that the annotated
SagaEventHandler
method can trigger the
creation of a new Saga instance.
- startTransaction() - Method in class org.axonframework.unitofwork.NoTransactionManager
-
- startTransaction() - Method in class org.axonframework.unitofwork.SpringTransactionManager
-
- startTransaction() - Method in interface org.axonframework.unitofwork.TransactionManager
-
Starts a transaction.
- state(boolean, String) - Static method in class org.axonframework.common.Assert
-
Asserts that the value of state
is true.
- stop() - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Shuts down the command bus.
- stop(Runnable) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
- stop() - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
- stop() - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
-
- stop(Runnable) - Method in class org.axonframework.contextsupport.spring.SagaManagerBeanDefinitionParser.SagaManagerLifecycleManager
-
- stop() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
Unsubscribes this Saga Manager from the event bus and stops accepting new events.
- storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
-
Store the given associationValue
, which has been associated with given sagaIdentifier
.
- storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
-
- storeAssociationValue(AssociationValue, String, String) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
-
- storeSaga(Saga) - Method in class org.axonframework.saga.repository.AbstractSagaRepository
-
Stores a newly created Saga instance.
- storeSaga(Saga) - Method in class org.axonframework.saga.repository.jdbc.JdbcSagaRepository
-
- storeSaga(Saga) - Method in class org.axonframework.saga.repository.jpa.JpaSagaRepository
-
- StringToByteArrayConverter - Class in org.axonframework.serializer.converters
-
ContentTypeConverter that converts String into byte arrays.
- StringToByteArrayConverter() - Constructor for class org.axonframework.serializer.converters.StringToByteArrayConverter
-
- 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.common
-
Deprecated.
as of 2.1. This interface will be removed in future versions. Self subscribing components give problems
when wrapping components (using compositions or proxies). Therefore, subscriptions should be managed by
the creating component.
- subscribe(Class<T>, Repository<T>, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Subscribe a handler for the given aggregate type to the given command bus.
- subscribe(Class<T>, Repository<T>, CommandBus, CommandTargetResolver) - Static method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Subscribe a handler for the given aggregate type to the given command bus.
- subscribe(AggregateAnnotationCommandHandler<?>, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Subscribe the given aggregateAnnotationCommandHandler
to the given commandBus
.
- subscribe() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
- subscribe(Object, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
-
Subscribe the annotated command handler to the given command bus.
- subscribe(AnnotationCommandHandlerAdapter, CommandBus) - Static method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
-
Subscribe the given annotationCommandHandler
to the given commandBus
.
- subscribe() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
-
- subscribe(CommandHandler, AnnotationCommandHandlerAdapter) - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerBeanPostProcessor
-
- subscribe(String, CommandHandler<? super C>) - Method in interface org.axonframework.commandhandling.CommandBus
-
Subscribe the given handler
to commands of type commandType
.
- subscribe(String, CommandHandler<? super C>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
- subscribe(String, CommandHandler<? super T>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Subscribe the given handler
to commands of type commandType
.
- subscribe(I, T) - Method in class org.axonframework.common.annotation.AbstractAnnotationHandlerBeanPostProcessor
-
Subscribe the given proxy bean
(with its annotated methods managed by given adapter
)
to the messaging infrastructure.
- subscribe() - Method in interface org.axonframework.common.Subscribable
-
Deprecated.
Subscribe this instance with its configured component.
- subscribe(EventListener) - Method in class org.axonframework.eventhandling.AbstractCluster
-
- subscribe(Object, EventBus) - Static method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
-
Subscribe the given annotatedEventListener
to the given eventBus
.
- subscribe() - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerAdapter
-
- subscribe(EventListener, AnnotationEventListenerAdapter) - Method in class org.axonframework.eventhandling.annotation.AnnotationEventListenerBeanPostProcessor
-
- subscribe(EventListener) - Method in interface org.axonframework.eventhandling.Cluster
-
Subscribe the given eventListener
to this cluster.
- subscribe(EventListener) - Method in class org.axonframework.eventhandling.ClusteringEventBus
-
- subscribe(EventListener) - Method in interface org.axonframework.eventhandling.EventBus
-
Subscribe the given eventListener
to this bus.
- subscribe(EventListener) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
Subscribe the given eventListener
to this cluster.
- subscribe(EventListener) - Method in class org.axonframework.eventhandling.SimpleEventBus
-
Subscribe the given eventListener
to this bus.
- subscribe() - Method in class org.axonframework.saga.AbstractSagaManager
-
- subscribe() - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
- subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.AbstractCluster
-
- subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.EventProcessingMonitorCollection
-
- subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in interface org.axonframework.eventhandling.EventProcessingMonitorSupport
-
Subscribes the given monitor
.
- subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.eventhandling.replay.ReplayingCluster
-
- subscribeEventProcessingMonitor(EventProcessingMonitor) - Method in class org.axonframework.saga.annotation.AsyncAnnotatedSagaManager
-
- supportedCommands() - Method in class org.axonframework.commandhandling.annotation.AggregateAnnotationCommandHandler
-
Returns the set of commands supported by the annotated command handler managed by this adapter.
- supportedCommands() - Method in class org.axonframework.commandhandling.annotation.AnnotationCommandHandlerAdapter
-
Returns the set of commands supported by the annotated command handler managed by this adapter.
- supports(Class<? extends Saga>) - Method in class org.axonframework.saga.GenericSagaFactory
-
Indicates whether or not this factory can create instances of the given sagaType
.
- supports(Class<? extends Saga>) - Method in interface org.axonframework.saga.SagaFactory
-
Indicates whether or not this factory can create instances of the given sagaType
.
- SyncSagaManagerBeanDefinitionParser - Class in org.axonframework.contextsupport.spring
-
BeanDefinitionParser that parses saga-manager elements in the application context.
- SyncSagaManagerBeanDefinitionParser() - Constructor for class org.axonframework.contextsupport.spring.SyncSagaManagerBeanDefinitionParser
-