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

A

AbstractAggregateFactory<T> - Class in org.axonframework.eventsourcing
Abstract AggregateFactory implementation that is aware of snapshot events.
AbstractAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
Initialize an aggregateFactory for the given aggregateBaseType.
AbstractAnnotatedParameterResolverFactory<A extends Annotation,P> - Class in org.axonframework.messaging.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.messaging.annotation.AbstractAnnotatedParameterResolverFactory
Initialize a ParameterResolverFactory instance that resolves parameters of type declaredParameterType annotated with the given annotationType.
AbstractAnnotationHandlerBeanPostProcessor<I,T extends I> - Class in org.axonframework.spring.config
Abstract bean post processor that finds candidates for proxying.
AbstractAnnotationHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
 
AbstractCacheAdapter<L> - Class in org.axonframework.common.caching
Abstract implementation of the Cache interface which makes it easier to implement Adapters.
AbstractCacheAdapter() - Constructor for class org.axonframework.common.caching.AbstractCacheAdapter
 
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<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Constructor for class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Initialize the AbstractCommandGateway with given commandBus, retryScheduler and commandDispatchInterceptors.
AbstractDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
Abstract base class of a serialized domain event.
AbstractDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
Construct a new event entry from a published domain event message to enable storing the event or sending it to a remote location.
AbstractDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
Reconstruct an event entry from a stored object.
AbstractDomainEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
Default constructor required by JPA
AbstractEventBus - Class in org.axonframework.eventhandling
Base class for the Event Bus.
AbstractEventBus() - Constructor for class org.axonframework.eventhandling.AbstractEventBus
Initializes an event bus with a NoOpMessageMonitor.
AbstractEventBus(MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.AbstractEventBus
Initializes an event bus.
AbstractEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
Abstract base class of a serialized event.
AbstractEventEntry(EventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
Construct a new event entry from a published event message to enable storing the event or sending it to a remote location.
AbstractEventEntry(String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
Reconstruct an event entry from a stored object.
AbstractEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
Default constructor required by JPA
AbstractEventProcessor - Class in org.axonframework.eventhandling
Abstract implementation of an EventProcessor.
AbstractEventProcessor(String, EventHandlerInvoker, RollbackConfiguration, ErrorHandler, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.AbstractEventProcessor
Initializes an event processor with given name.
AbstractEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
Abstract event storage implementation that takes care of event serialization and upcasting.
AbstractEventStorageEngine(Serializer, EventUpcaster, PersistenceExceptionResolver) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Initializes an EventStorageEngine with given serializer, upcasterChain and persistenceExceptionResolver.
AbstractEventStore - Class in org.axonframework.eventsourcing.eventstore
Abstract implementation of an EventStore that uses a EventStorageEngine to store and load events.
AbstractEventStore(EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Initializes an event store with given storageEngine and NoOpMessageMonitor.
AbstractEventStore(EventStorageEngine, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Initializes an event store with given storageEngine and messageMonitor.
AbstractEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
Abstract implementation of an EventTableFactory that provides Jdbc "create table" statements compatible with most databases.
AbstractEventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
 
AbstractMessage<T> - Class in org.axonframework.messaging
Abstract base class for Messages.
AbstractMessage(String) - Constructor for class org.axonframework.messaging.AbstractMessage
Initializes a new message with given identifier.
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
 
AbstractMongoEventStorageStrategy - Class in org.axonframework.mongo.eventsourcing.eventstore
Abstract implementation of a Mongo StorageStrategy.
AbstractMongoEventStorageStrategy(EventEntryConfiguration, Duration) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
Initializes a new StorageStrategy for a EventStorageEngine that uses Mongo.
AbstractMongoTemplate - Class in org.axonframework.mongo
Abstract implementation for Mongo templates.
AbstractMongoTemplate(MongoClient) - Constructor for class org.axonframework.mongo.AbstractMongoTemplate
Initializes the MongoTemplate to connect using the given mongo instance and a database with default name "axonframework".
AbstractMongoTemplate(MongoClient, String) - Constructor for class org.axonframework.mongo.AbstractMongoTemplate
Initializes the MongoTemplate to connect using the given mongo instance and the database with given databaseName.
AbstractRepository<T,A extends Aggregate<T>> - Class in org.axonframework.commandhandling.model
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.commandhandling.model.AbstractRepository
Initializes a repository that stores aggregate of the given aggregateType.
AbstractRepository(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.model.AbstractRepository
Initializes a repository that stores aggregate of the given aggregateType.
AbstractResourceInjector - Class in org.axonframework.eventhandling.saga
Abstract implementation of a ResourceInjector for sagas that injects field and method resources.
AbstractResourceInjector() - Constructor for class org.axonframework.eventhandling.saga.AbstractResourceInjector
 
AbstractRoutingStrategy - Class in org.axonframework.commandhandling.distributed
Abstract implementation of the RoutingStrategy interface that uses a policy to prescribe what happens when a routing cannot be resolved.
AbstractRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
Initializes the strategy using given unresolvedRoutingKeyPolicy prescribing what happens when a routing key cannot be resolved.
AbstractSagaEntry<T> - Class in org.axonframework.eventhandling.saga.repository.jpa
Java Persistence Entity allowing sagas to be stored in a relational database.
AbstractSagaEntry(Object, String, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
Constructs a new SagaEntry for the given saga.
AbstractSagaEntry() - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
Default constructor required by JPA.
AbstractSagaManager<T> - Class in org.axonframework.eventhandling.saga
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager implementations.
AbstractSagaManager(Class<T>, SagaRepository<T>, Supplier<T>) - Constructor for class org.axonframework.eventhandling.saga.AbstractSagaManager
Initializes the SagaManager with the given sagaRepository.
AbstractSequencedDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
Abstract base class of a serialized domain event.
AbstractSequencedDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSequencedDomainEventEntry
Construct a new default domain event entry from a published domain event message to enable storing the event or sending it to a remote location.
AbstractSequencedDomainEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSequencedDomainEventEntry
Default constructor required by JPA
AbstractSnapshotEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
Abstract base class of a serialized snapshot event storing the state of an aggregate.
AbstractSnapshotEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
Construct a new event entry from a published domain event message to enable storing the event or sending it to a remote location.
AbstractSnapshotEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
Reconstruct an event entry from a stored object.
AbstractSnapshotEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
Default constructor required by JPA
AbstractSnapshotEventEntry.PK - Class in org.axonframework.eventsourcing.eventstore
Primary key definition of the AbstractEventEntry class.
AbstractSnapshotter - Class in org.axonframework.eventsourcing
Abstract implementation of the Snapshotter that uses a task executor to creates snapshots.
AbstractSnapshotter(EventStore) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
Initializes the Snapshotter to append snapshots in the given eventStore.
AbstractSnapshotter(EventStore, TransactionManager) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
Initializes the Snapshotter to append snapshots in the given eventStore.
AbstractSnapshotter(EventStore, Executor, TransactionManager) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
Initializes the Snapshotter to append snapshots in the given eventStore.
AbstractTokenEntry<T> - Class in org.axonframework.eventhandling.tokenstore
Abstract base class of a JPA entry containing a serialized tracking token belonging to a given process.
AbstractTokenEntry(TrackingToken, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Initializes a new token entry for given token, process and segment.
AbstractTokenEntry(T, String, String, String) - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Initializes a token entry from existing data.
AbstractTokenEntry() - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Default constructor required for JPA
AbstractUnitOfWork<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
Abstract implementation of the Unit of Work.
AbstractUnitOfWork() - Constructor for class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
AbstractXStreamSerializer - Class in org.axonframework.serialization
Abstract implementation for XStream based serializers.
AbstractXStreamSerializer(XStream) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
AbstractXStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
AbstractXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
AbstractXStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
AbstractXStreamSerializer(Charset, XStream, RevisionResolver, Converter) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
Initialize the serializer using the given charset, xStream instance, revisionResolver and converter.
accept(T) - Method in interface org.axonframework.test.eventscheduler.EventConsumer
Performs this operation on the given argument.
accept(Field) - Method in class org.axonframework.test.matchers.AllFieldsFilter
 
accept(Field) - Method in interface org.axonframework.test.matchers.FieldFilter
Indicates whether the given field should be accepted for processing, or skipped/ignored.
accept(Field) - Method in class org.axonframework.test.matchers.IgnoreField
 
accept(Field) - Method in class org.axonframework.test.matchers.MatchAllFieldFilter
 
accept(Field) - Method in class org.axonframework.test.matchers.NonTransientFieldsFilter
 
AcceptAll - Enum in org.axonframework.commandhandling.distributed.commandfilter
A command filter that accepts all CommandMessages
activeProcessorThreads() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Returns an approximation of the number of threads currently processing events.
add(AssociationValue) - Method in interface org.axonframework.eventhandling.saga.AssociationValues
Adds the given associationValue, if it has not been previously added.
add(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
add(AssociationValue, String, String) - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
Adds an association between the given associationValue and sagaIdentifier.
addAlias(String, Class) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Adds an alias to use instead of the fully qualified class name.
addAttribute(String, String) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
addCachedAssociations(Iterable<AssociationValue>, String, Class<?>) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
Registers the associations of a saga with given sagaIdentifier and given sagaType with the associations cache.
addChildNode(String) - Method in class org.axonframework.mongo.serialization.BSONNode
Adds a child node to the current node.
addCommandDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>>) - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
Add an interceptor that should be invoked before a command is dispatched the the Command Bus.
addedAssociations() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
Returns the Set of association values that have been added since the last AssociationValues.commit().
addedAssociations() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
addFieldAlias(String, Class, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Adds an alias to use for a given field in the given class.
addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
Register the given handler with the Unit of Work.
addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
 
addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Adds a handler to the collection.
addPackageAlias(String, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Add an alias for a package.
advanceTimeBy(Duration, EventConsumer<EventMessage<?>>) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Advance time by the given duration and invokes the given eventConsumer for each event scheduled for publication until that time.
advanceTimeTo(Instant, EventConsumer<EventMessage<?>>) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Advance time to the given newDateTime and invokes the given eventConsumer for each event scheduled for publication until that time.
advanceTo(long, int) - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
advanceTo(long, int, boolean) - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
Returns a new GapAwareTrackingToken instance based on this token but which has advanced to given index.
advanceTo(Instant, String, Duration) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
Returns a new MongoTrackingToken instance based on this token but which has advanced to the event with given timestamp, eventIdentifier and sequenceNumber.
advanceToNextTrigger() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Advances the "current time" of the scheduler to the next scheduled Event, and returns that event.
afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
Process given events after the Unit of Work has been committed.
afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.SimpleEventBus
 
afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
 
afterCommit(Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
afterCommit(Consumer<UnitOfWork<T>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Register given handler with the Unit of Work.
afterPropertiesSet() - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
 
afterPropertiesSet() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.AxonConfiguration
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
 
afterPropertiesSet() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
 
afterPropertiesSet() - Method in class org.axonframework.spring.messaging.ApplicationContextEventPublisher
 
afterPropertiesSet() - Method in class org.axonframework.spring.messaging.OutboundEventMessageChannelAdapter
Subscribes this event listener to the event bus.
afterShutdown(EventProcessorTask) - Method in interface org.axonframework.eventhandling.async.EventProcessorTask.ShutdownCallback
Called when event processing is complete.
Aggregate<T> - Interface in org.axonframework.commandhandling.model
Interface that describes an aggregate.
Aggregate - Annotation Type in org.axonframework.spring.stereotype
Annotation that informs Axon's auto configurer for Spring that a given Component is an aggregate instance.
AggregateAnnotationCommandHandler<T> - Class in org.axonframework.commandhandling
Command handler that handles commands based on CommandHandler annotations on an aggregate.
AggregateAnnotationCommandHandler(Class<T>, Repository<T>) - Constructor for class org.axonframework.commandhandling.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.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.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(Repository<T>, CommandTargetResolver, AggregateModel<T>) - Constructor for class org.axonframework.commandhandling.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.
AggregateBlacklistedException - Exception in org.axonframework.commandhandling.disruptor
Exception indicating that an aggregate has been blacklisted by the DisruptorCommandBus.
AggregateBlacklistedException(String, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateBlacklistedException
Initializes the exception with given aggregateIdentifier, given explanatory message and cause.
AggregateConfiguration<A> - Interface in org.axonframework.config
Specialization of the Module Configuration for modules that define an Aggregate Configuration.
AggregateConfigurer<A> - Class in org.axonframework.config
Axon Configuration API extension that allows the definition of an Aggregate.
AggregateConfigurer(Class<A>) - Constructor for class org.axonframework.config.AggregateConfigurer
Creates a default configuration as described in AggregateConfigurer.defaultConfiguration(Class).
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(String, String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier and given message.
AggregateDeletedException(String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier and a default message.
AggregateFactory<T> - 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.commandhandling.model
Field annotation that identifies the field containing the identifier of the Aggregate.
aggregateIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the aggregate identifier of the event.
aggregateIdentifierProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the aggregate identifier of the event.
AggregateInvocationException - Exception in org.axonframework.commandhandling.model
Exception thrown when an invocation on a method of an aggregate gives rise to an exception.
AggregateInvocationException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.AggregateInvocationException
Initializes the exception using the given message and cause.
AggregateLifecycle - Class in org.axonframework.commandhandling.model
Abstract base class of a component that models an aggregate's life cycle.
AggregateLifecycle() - Constructor for class org.axonframework.commandhandling.model.AggregateLifecycle
 
AggregateMember - Annotation Type in org.axonframework.commandhandling.model
Marker annotation for a field that references one or more Entities capable of handling Commands or Events.
AggregateMemberAnnotatedChildEntityCollectionDefinition - Class in org.axonframework.commandhandling.model.inspection
Implementation of a ChildEntityDefinition that is used to detect Collections of entities (field type assignable to Iterable) annotated with AggregateMember.
AggregateMemberAnnotatedChildEntityCollectionDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
 
AggregateMemberAnnotatedChildEntityDefinition - Class in org.axonframework.commandhandling.model.inspection
Implementation of a ChildEntityDefinition that is used to detect single entities annotated with AggregateMember.
AggregateMemberAnnotatedChildEntityDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityDefinition
 
AggregateMemberAnnotatedChildEntityMapDefinition - Class in org.axonframework.commandhandling.model.inspection
Implementation of a ChildEntityDefinition that is used to detect Maps with entities as values annotated with AggregateMember.
AggregateMemberAnnotatedChildEntityMapDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
 
aggregateModel() - Method in class org.axonframework.commandhandling.model.AbstractRepository
Returns the aggregate model stored by this repository.
AggregateModel<T> - Interface in org.axonframework.commandhandling.model.inspection
Specialized EntityModel that describes the capabilities and properties of an aggregate root of type T.
AggregateNotFoundException - Exception in org.axonframework.commandhandling.model
Exception indicating that the an aggregate could not be found in the repository.
AggregateNotFoundException(String, String) - Constructor for exception org.axonframework.commandhandling.model.AggregateNotFoundException
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier and given message.
AggregateNotFoundException(String, String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.AggregateNotFoundException
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier and with the given message and cause.
AggregateRolledBackException - Exception in org.axonframework.commandhandling.model
Exception indicating that an aggregate has been part of a Unit of Work that was rolled back and that the validity of its state cannot be guaranteed.
AggregateRolledBackException(String) - Constructor for exception org.axonframework.commandhandling.model.AggregateRolledBackException
Initialize the exception for an aggregate with given aggregateIdentifier.
AggregateRoot - Annotation Type in org.axonframework.commandhandling.model
Annotation placed on types that should be treated as the root of an aggregate.
AggregateSnapshotter - Class in org.axonframework.eventsourcing
Implementation of a snapshotter that uses the actual aggregate and its state to create a snapshot event.
AggregateSnapshotter(EventStore, AggregateFactory<?>...) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
Initializes a snapshotter using the ParameterResolverFactory instances available on the classpath.
AggregateSnapshotter(EventStore, List<AggregateFactory<?>>) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
Initializes a snapshotter using the ParameterResolverFactory instances available on the classpath.
AggregateSnapshotter(EventStore, List<AggregateFactory<?>>, ParameterResolverFactory) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
Initializes a snapshotter using the given parameterResolverFactory.
AggregateSnapshotter(EventStore, List<AggregateFactory<?>>, ParameterResolverFactory, Executor, TransactionManager) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
Initializes a snapshotter that stores snapshots using the given executor.
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(String, String) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
Initializes the exception with given aggregateIdentifier and given explanatory message.
AggregateStateCorruptedException(String, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
Initializes the exception with given aggregateIdentifier, given explanatory message and cause.
AggregateTestFixture<T> - Class in org.axonframework.test.aggregate
A test fixture that allows the execution of given-when-then style test cases.
AggregateTestFixture(Class<T>) - Constructor for class org.axonframework.test.aggregate.AggregateTestFixture
Initializes a new given-when-then style test fixture for the given aggregateType.
aggregateType() - Method in interface org.axonframework.config.AggregateConfiguration
Returns the type of Aggregate defined in this Configuration.
aggregateType() - Method in class org.axonframework.config.AggregateConfigurer
 
AggregateVersion - Annotation Type in org.axonframework.commandhandling.model
Field annotation that indicates the field contains the value that represents the version of the Aggregate, used for optimistic locking, as well as state validation for commands.
AllFieldsFilter - Class in org.axonframework.test.matchers
FieldFilter implementation that accepts all Fields.
AMQPAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
AMQPAutoConfiguration() - Constructor for class org.axonframework.boot.autoconfig.AMQPAutoConfiguration
 
amqpBridge(EventBus, ConnectionFactory, AMQPMessageConverter) - Method in class org.axonframework.boot.autoconfig.AMQPAutoConfiguration
 
AMQPMessage - Class in org.axonframework.amqp.eventhandling
Representation of an AMQP Message.
AMQPMessage(byte[], String) - Constructor for class org.axonframework.amqp.eventhandling.AMQPMessage
Creates an AMQP Message with given body and routingKey, which is not mandatory and non-immediate and has no additional properties.
AMQPMessage(byte[], String, AMQP.BasicProperties, boolean, boolean) - Constructor for class org.axonframework.amqp.eventhandling.AMQPMessage
Creates an AMQPMessage.
AMQPMessageConverter - Interface in org.axonframework.amqp.eventhandling
Interface describing a mechanism that converts AMQP Messages from an Axon Messages and vice versa.
amqpMessageConverter(Serializer, RoutingKeyResolver) - Method in class org.axonframework.boot.autoconfig.AMQPAutoConfiguration
 
AMQPProperties - Class in org.axonframework.boot
 
AMQPProperties() - Constructor for class org.axonframework.boot.AMQPProperties
 
AMQPProperties.TransactionMode - Enum in org.axonframework.boot
 
and(Predicate<? super CommandMessage<?>>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
and(Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
and(Predicate<? super CommandMessage<?>>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
and(Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
and(String, Object) - Method in class org.axonframework.messaging.MetaData
Returns a MetaData instances containing the current entries, and the given key and given value.
andIfNotPresent(String, Supplier<Object>) - Method in class org.axonframework.messaging.MetaData
Returns a MetaData instances containing the current entries, and the given key if it was not yet present in this MetaData.
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.eventhandling.EventMessage
Returns a copy of this EventMessage with it MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericEventMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventsourcing.DomainEventMessage
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.AbstractMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.Message
Returns a copy of this Message with it MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.serialization.SerializedMessage
 
andNoMore() - Static method in class org.axonframework.test.matchers.Matchers
Matches against null or void.
andThen(Runnable) - Method in interface org.axonframework.commandhandling.model.ApplyMore
Execute the given runnable after applying the previous event.
andThen(Runnable) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
andThenAggregate(String) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Use this method to indicate that an aggregate with given identifier published certain events.
andThenAggregate(String) - Method in class org.axonframework.test.saga.SagaTestFixture
 
andThenApply(Supplier<?>) - Method in interface org.axonframework.commandhandling.model.ApplyMore
Apply a subsequent event to the aggregate after applying another event.
andThenApply(Supplier<?>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
andThenAPublished(Object) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Indicates that the given event has been published in the past.
andThenAPublished(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
 
andThenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Simulate time shifts in the current given state.
andThenTimeAdvancesTo(Instant) - Method in class org.axonframework.test.saga.SagaTestFixture
 
andThenTimeElapses(Duration) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Simulate time shifts in the current given state.
andThenTimeElapses(Duration) - Method in class org.axonframework.test.saga.SagaTestFixture
 
AnnotatedAggregate<T> - Class in org.axonframework.commandhandling.model.inspection
Implementation of the Aggregate interface that allows for an aggregate root to be a POJO with annotations on its Command and Event Handler methods.
AnnotatedAggregate(T, AggregateModel<T>, EventBus) - Constructor for class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Initialize an Aggregate instance for the given aggregateRoot, described by the given aggregateModel that will publish events to the given eventBus.
AnnotatedAggregate(AggregateModel<T>, EventBus) - Constructor for class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Initialize an Aggregate instance for the given aggregateRoot, described by the given aggregateModel that will publish events to the given eventBus.
AnnotatedChildEntity<P,C> - Class in org.axonframework.commandhandling.model.inspection
Implementation of a ChildEntity that uses annotations on a target entity to resolve event and command handlers.
AnnotatedChildEntity(EntityModel<C>, boolean, boolean, BiFunction<CommandMessage<?>, P, C>, BiFunction<EventMessage<?>, P, Iterable<C>>) - Constructor for class org.axonframework.commandhandling.model.inspection.AnnotatedChildEntity
Initiates a new AnnotatedChildEntity instance that uses the provided entityModel to delegate command and event handling to an annotated child entity.
AnnotatedHandlerInspector<T> - Class in org.axonframework.messaging.annotation
Inspector for a message handling target of type T that uses annotations on the target to inspect the capabilities of the target.
AnnotatedMessageHandlingMember<T> - Class in org.axonframework.messaging.annotation
Implementation of a MessageHandlingMember that is used to invoke message handler methods on the target type.
AnnotatedMessageHandlingMember(Executable, Class<? extends Message>, Class<?>, ParameterResolverFactory) - Constructor for class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
Initializes a new instance that will invoke the given executable (method) on a target to handle a message of the given messageType.
AnnotatedMessageHandlingMemberDefinition - Class in org.axonframework.messaging.annotation
The default HandlerDefinition implementation in Axon.
AnnotatedMessageHandlingMemberDefinition() - Constructor for class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
 
AnnotatedSaga<T> - Class in org.axonframework.eventhandling.saga
Implementation of the interface that allows for a POJO instance with annotated message handlers to act as a Saga.
AnnotatedSaga(String, Set<AssociationValue>, T, TrackingToken, SagaModel<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSaga
Creates an AnnotatedSaga instance to wrap the given annotatedSaga, identifier with the given sagaId and associated with the given associationValues.
AnnotatedSagaManager<T> - Class in org.axonframework.eventhandling.saga
Implementation of the SagaManager that uses annotations on the Sagas to describe the lifecycle management.
AnnotatedSagaManager(Class<T>, SagaRepository<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using given repository to load sagas.
AnnotatedSagaManager(Class<T>, SagaRepository<T>, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using given repository to load sagas.
AnnotatedSagaManager(Class<T>, SagaRepository<T>, Supplier<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using given repository to load sagas and sagaFactory to create new sagas.
AnnotatedSagaManager(Class<T>, SagaRepository<T>, Supplier<T>, SagaModel<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSagaManager
Initialize the AnnotatedSagaManager using given repository to load sagas, the sagaFactory to create new sagas and the sagaMetaModel to delegate messages to the saga instances.
AnnotatedSagaRepository<T> - Class in org.axonframework.eventhandling.saga.repository
Abstract implementation for saga repositories.
AnnotatedSagaRepository(Class<T>, SagaStore<? super T>) - Constructor for class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Initializes an AnnotatedSagaRepository for given sagaType that stores sagas in the given sagaStore.
AnnotatedSagaRepository(Class<T>, SagaStore<? super T>, ResourceInjector) - Constructor for class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Initializes an AnnotatedSagaRepository for given sagaType that stores sagas in the given sagaStore.
AnnotatedSagaRepository(Class<T>, SagaStore<? super T>, ResourceInjector, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Initializes an AnnotatedSagaRepository for given sagaType that stores sagas in the given sagaStore.
AnnotatedSagaRepository(Class<T>, SagaStore<? super T>, SagaModel<T>, ResourceInjector, LockFactory) - Constructor for class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Initializes an AnnotatedSagaRepository for given sagaType that stores sagas in the given sagaStore.
annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
annotationAttributes(Class<? extends Annotation>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Get the attributes of an annotation of given annotationType on the method of the target entity.
annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
AnnotationCommandHandlerAdapter - Class in org.axonframework.commandhandling
Adapter that turns any @CommandHandler annotated bean into a MessageHandler implementation.
AnnotationCommandHandlerAdapter(Object) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
Wraps the given annotatedCommandHandler, allowing it to be subscribed to a Command Bus.
AnnotationCommandHandlerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
Wraps the given annotatedCommandHandler, allowing it to be subscribed to a Command Bus.
AnnotationCommandHandlerBeanPostProcessor - Class in org.axonframework.spring.config.annotation
Spring Bean post processor that automatically generates an adapter for each bean containing CommandHandler annotated methods.
AnnotationCommandHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
 
AnnotationCommandTargetResolver - Class in org.axonframework.commandhandling
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.AnnotationCommandTargetResolver
 
AnnotationDriven - Annotation Type in org.axonframework.spring.config
Annotation for @Configuration that will automatically subscribe @CommandHandler and @EventHandler annotated beans with the CommandBus and EventBus, respectively.
AnnotationDrivenRegistrar - Class in org.axonframework.spring.config
Spring @Configuration related class that adds Axon Annotation PostProcessors to the BeanDefinitionRegistry.
AnnotationDrivenRegistrar() - Constructor for class org.axonframework.spring.config.AnnotationDrivenRegistrar
 
AnnotationEventListenerAdapter - Class in org.axonframework.eventhandling
Adapter that turns any bean with EventHandler annotated methods into an EventListener.
AnnotationEventListenerAdapter(Object) - Constructor for class org.axonframework.eventhandling.AnnotationEventListenerAdapter
Wraps the given annotatedEventListener, allowing it to be subscribed to an Event Bus.
AnnotationEventListenerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.AnnotationEventListenerAdapter
Wraps the given annotatedEventListener, allowing it to be subscribed to an Event Bus.
AnnotationRevisionResolver - Class in org.axonframework.serialization
Revision Resolver implementation that checks for the presence of an @Revision annotation.
AnnotationRevisionResolver() - Constructor for class org.axonframework.serialization.AnnotationRevisionResolver
 
AnnotationRoutingStrategy - Class in org.axonframework.commandhandling.distributed
RoutingStrategy that expects an TargetAggregateIdentifier annotation on the command message's payload.
AnnotationRoutingStrategy() - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that fails when an incoming command does not define an AggregateIdentifier to base the routing key on.
AnnotationRoutingStrategy(Class<? extends Annotation>) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier.
AnnotationRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that uses the given unresolvedRoutingKeyPolicy when an incoming command does not define an AggregateIdentifier to base the routing key on.
AnnotationRoutingStrategy(Class<? extends Annotation>, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier and the given unresolvedRoutingKeyPolicy when an incoming command does not define an AggregateIdentifier to base the routing key on.
AnnotationUtils - Class in org.axonframework.common.annotation
Utility class for locating annotations and attribute values on elements.
appendErrors(ErrorWriter) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
 
appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Append given events to the backing database.
appendEvents(EventMessage<?>...) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Append one or more events to the event storage.
appendEvents(List<? extends EventMessage<?>>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Append a list of events to the event storage.
appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
appendEvents(MongoCollection<Document>, List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
 
appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
 
appendEvents(MongoCollection<Document>, List<? extends EventMessage<?>>, Serializer) - Method in interface org.axonframework.mongo.eventsourcing.eventstore.StorageStrategy
Appends the given list of events to the given eventCollection.
appendSnapshot(Connection, DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to append the given snapshot to the event storage using given connection to the database.
appendSnapshot(MongoCollection<Document>, DomainEventMessage<?>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
 
appendSnapshot(MongoCollection<Document>, DomainEventMessage<?>, Serializer) - Method in interface org.axonframework.mongo.eventsourcing.eventstore.StorageStrategy
Append the given aggregate snapshot to the snapshotCollection.
ApplicationContextEventPublisher - Class in org.axonframework.spring.messaging
Component that forward events received from a SubscribableMessageSource as Spring ApplicationEvent to the ApplicationContext.
ApplicationContextEventPublisher(SubscribableMessageSource<? extends EventMessage<?>>) - Constructor for class org.axonframework.spring.messaging.ApplicationContextEventPublisher
Initialize the publisher to forward events received from the given messageSource to the application context that this bean is part of.
ApplicationContextLookupParameterResolverFactory - Class in org.axonframework.spring.config
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.spring.config.ApplicationContextLookupParameterResolverFactory
Creates an instance, using the given defaultFactories.
apply(Object, MetaData) - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
Apply a DomainEventMessage with given payload and metadata (metadata from interceptors will be combined with the provided metadata).
apply(Object) - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
Apply a DomainEventMessage with given payload without metadata (though interceptors can also be used to provide metadata).
apply(Connection) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlFunction
Create a new PreparedStatement using the given connection.
apply(ResultSet) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlResultConverter
Convert the given resultSet to a result of type R.
applyMessageOrPayload(Object) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Apply a new event message to the aggregate and then publish this message to external systems.
ApplyMore - Interface in org.axonframework.commandhandling.model
Interface that describes a mechanism that enables the application of an additional event after another event is applied.
asCommandMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandMessage
Returns the given command as a CommandMessage.
asDBObject() - Method in class org.axonframework.mongo.serialization.BSONNode
Returns the current BSON structure as DBObject.
asDocument() - Method in class org.axonframework.mongo.eventhandling.saga.repository.SagaEntry
Returns the Mongo Document representing the Saga provided in this entry.
asDocument(CommitEntryConfiguration, EventEntryConfiguration) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntry
Returns the current CommitEntry as a mongo Document.
asDocument(EventEntryConfiguration) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
Returns the current entry as a mongo Document.
asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
Convert a plain EventMessage to a DomainEventMessage.
asEventMessage(Object) - Static method in class org.axonframework.eventhandling.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.
assertActiveSagas(int) - Method in class org.axonframework.test.saga.RepositoryContentValidator
Asserts that the repsitory contains the given expected amount of active sagas.
assertAssociationPresent(String, String) - Method in class org.axonframework.test.saga.RepositoryContentValidator
Asserts that an association is present for the given associationKey and associationValue.
assertDispatchedEqualTo(Object...) - Method in class org.axonframework.test.saga.CommandValidator
Assert that the given commands have been dispatched in the exact sequence provided.
assertDispatchedMatching(Matcher<?>) - Method in class org.axonframework.test.saga.CommandValidator
Assert that commands matching the given matcher has been dispatched on the command bus.
assertNoAssociationPresent(String, String) - Method in class org.axonframework.test.saga.RepositoryContentValidator
Asserts that no association is present for the given associationKey and associationValue.
assertNoScheduledEvents() - Method in class org.axonframework.test.saga.EventSchedulerValidator
Asserts that no events are scheduled for publication.
assertPublishedEvents(Object...) - Method in class org.axonframework.test.saga.EventValidator
Assert that the given expected events have been published.
assertPublishedEventsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.saga.EventValidator
Asserts that events have been published matching the given matcher.
assertScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.saga.EventSchedulerValidator
Asserts that an event matching the given matcher is scheduled for publication after the given duration.
assertScheduledEventMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.saga.EventSchedulerValidator
Asserts that an event matching the given matcher is scheduled for publication at the given scheduledTime.
assertValidRecording() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
Makes sure the execution phase has finishes without any Errors ir FixtureExecutionExceptions.
asSet() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
Returns this instance as a Set of Association Values.
asSet() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
assignHandlersMatching(String, Predicate<Object>) - Method in class org.axonframework.config.EventHandlingConfiguration
Configures a rule to assign Event Handler beans that match the given criteria to the Event Processor with given name, with neutral priority (value 0).
assignHandlersMatching(String, int, Predicate<Object>) - Method in class org.axonframework.config.EventHandlingConfiguration
Configures a rule to assign Event Handler beans that match the given criteria to the Event Processor with given name, with given priority.
associateWith(String, String) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
Registers a AssociationValue with the currently active saga.
associateWith(String, Number) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
Registers a AssociationValue with the currently active saga.
associateWith(AssociationValue) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
Registers a AssociationValue with the currently active saga.
AssociationValue - Class in org.axonframework.eventhandling.saga
A combination of key and value by which a Saga can be found.
AssociationValue(String, String) - Constructor for class org.axonframework.eventhandling.saga.AssociationValue
Creates a Association Value instance with the given key and value.
AssociationValueEntry - Class in org.axonframework.eventhandling.saga.repository.jpa
JPA wrapper around an Association Value.
AssociationValueEntry(String, String, AssociationValue) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
Initialize a new AssociationValueEntry for a saga with given sagaIdentifier and associationValue.
AssociationValueEntry() - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
Constructor required by JPA.
associationValueEntryTable() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
Returns the name of the associationValueEntry table
AssociationValueMap - Class in org.axonframework.eventhandling.saga.repository
In-memory storage for AssociationValue to Saga mappings.
AssociationValueMap() - Constructor for class org.axonframework.eventhandling.saga.repository.AssociationValueMap
Initializes a new and empty AssociationValueMap.
AssociationValues - Interface in org.axonframework.eventhandling.saga
Interface describing a container of Association Values for a single Saga instance.
associationValues() - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore.Entry
Returns the Set of association values of the fetched Saga entry.
AssociationValuesImpl - Class in org.axonframework.eventhandling.saga
Default implementation of the AssociationValues interface.
AssociationValuesImpl() - Constructor for class org.axonframework.eventhandling.saga.AssociationValuesImpl
Initializes a new AssociationValues object without initial associations.
AssociationValuesImpl(Set<AssociationValue>) - Constructor for class org.axonframework.eventhandling.saga.AssociationValuesImpl
Initializes a new AssociationValues object with given initial associations.
asStream() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Returns this DomainEventStream as a Stream of DomainEventMessages.
asStream(DomainEventStream) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
Convert the given domainEventStream to a regular java Stream of domain event messages.
asStream() - Method in interface org.axonframework.messaging.MessageStream
Returns this MessageStream as a Stream of Messages.
asStream(MessageStream<M>) - Static method in class org.axonframework.messaging.StreamUtils
Convert the given messageStream to a regular java Stream of messages.
asTrackedEventMessage(EventMessage<T>, TrackingToken) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
Convert an EventMessage to a TrackedEventMessage using the given trackingToken.
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.
AsynchronousEventProcessingStrategy - Class in org.axonframework.eventhandling.async
Implementation of a EventProcessingStrategy that creates event processing tasks for asynchronous execution.
AsynchronousEventProcessingStrategy(Executor, SequencingPolicy<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
Initializes a new AsynchronousEventProcessingStrategy that uses the given executor to execute event processing tasks and sequencingPolicy that determines if an event may be processed in sequence or in parallel.
attributes() - Method in class org.axonframework.mongo.serialization.BSONNode
Returns a map containing the attributes of the current node.
AutowiredResourceInjector - Class in org.axonframework.test.utils
Resource injector that uses setter methods to inject resources.
AutowiredResourceInjector(Iterable<?>) - Constructor for class org.axonframework.test.utils.AutowiredResourceInjector
Initializes the resource injector to inject to given resources.
awaitCompletion(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Wait for completion of the command, or for the timeout to expire.
awaitJoined() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
this method blocks until this member has successfully joined the other members, until the thread is interrupted, or when joining has failed.
awaitJoined(long, TimeUnit) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
this method blocks until this member has successfully joined the other members, until the thread is interrupted, when the given number of milliseconds have passed, or when joining has failed.
AXON_CONFIGURATION_BEAN - Static variable in class org.axonframework.spring.config.SpringAxonAutoConfigurer
Name of the AxonConfiguration bean.
AXON_CONFIGURER_BEAN - Static variable in class org.axonframework.spring.config.SpringAxonAutoConfigurer
Name of the Configurer bean.
AxonAssertionError - Error in org.axonframework.test
Error indication that an Assertion failed during a test case.
AxonAssertionError(String) - Constructor for error org.axonframework.test.AxonAssertionError
Create a new error instance using the given detailMessage.
AxonAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
AxonAutoConfiguration(EventProcessorProperties) - Constructor for class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
AxonConfiguration - Class in org.axonframework.spring.config
Spring Configuration class that defines a number of conditional beans.
AxonConfiguration(Configurer) - Constructor for class org.axonframework.spring.config.AxonConfiguration
Initializes a new AxonConfiguration that uses the given configurer to build the configuration.
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.
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.
axonTransactionManager() - Method in class org.axonframework.boot.autoconfig.NoOpTransactionAutoConfiguration
 
axonTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.boot.autoconfig.TransactionAutoConfiguration
 
AxonTransientException - Exception in org.axonframework.common
Exception indicating an error occurred that might be resolved by retrying the operation that caused the exception.
AxonTransientException(String) - Constructor for exception org.axonframework.common.AxonTransientException
Initializes the exception using the given message.
AxonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonTransientException
Initializes the exception using the given message and cause.

B

BatchingEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
Abstract EventStorageEngine implementation that fetches events in batches from the backing database.
BatchingEventStorageEngine(Serializer, EventUpcaster, PersistenceExceptionResolver, Integer) - Constructor for class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Initializes an EventStorageEngine with given serializer, upcasterChain and persistenceExceptionResolver.
BatchingUnitOfWork<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
Unit of Work implementation that is able to process a batch of Messages instead of just a single Message.
BatchingUnitOfWork(T...) - Constructor for class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Initializes a BatchingUnitOfWork for processing the given batch of messages.
BatchingUnitOfWork(List<T>) - Constructor for class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Initializes a BatchingUnitOfWork for processing the given list of messages.
batchSize() - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Returns the maximum number of event entries to be fetched per batch.
BeanPropertyAccessStrategy - Class in org.axonframework.common.property
BeanPropertyAccessStrategy implementation that uses JavaBean style property access.
BeanPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.BeanPropertyAccessStrategy
 
BeanValidationInterceptor<T extends Message<?>> - Class in org.axonframework.messaging.interceptors
Interceptor that applies JSR303 bean validation on incoming messages.
BeanValidationInterceptor() - Constructor for class org.axonframework.messaging.interceptors.BeanValidationInterceptor
Initializes a validation interceptor using a default ValidatorFactory (see Validation.buildDefaultValidatorFactory()).
BeanValidationInterceptor(ValidatorFactory) - Constructor for class org.axonframework.messaging.interceptors.BeanValidationInterceptor
Initializes a validation interceptor using the given ValidatorFactory.
BlacklistDetectingCallback<C,R> - Class in org.axonframework.commandhandling.disruptor
Wrapper for command handler Callbacks that detects blacklisted aggregates and starts a cleanup process when an aggregate is blacklisted.
BlacklistDetectingCallback(CommandCallback<? super C, R>, RingBuffer<CommandHandlingEntry>, BiConsumer<CommandMessage<? extends C>, CommandCallback<? super C, R>>, boolean) - Constructor for class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
Initializes the callback which allows the given command to be rescheduled on the given ringBuffer if it failed due to a corrupt state.
BlobToInputStreamConverter - Class in org.axonframework.serialization.converters
 
BlobToInputStreamConverter() - Constructor for class org.axonframework.serialization.converters.BlobToInputStreamConverter
 
block() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
broadCastMembership() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
Send the local membership details (load factor and supported Command types) to other member nodes of this cluster.
BSONNode - Class in org.axonframework.mongo.serialization
Represents a node in a BSON structure.
BSONNode(String) - Constructor for class org.axonframework.mongo.serialization.BSONNode
Creates a node with given "code" name.
build() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Builds a new TokenSchema from builder values.
build() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Builds a new EventSchema from builder values.
build() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
buildConfiguration() - Method in interface org.axonframework.config.Configurer
Returns the completely initialized Configuration built using this configurer.
buildConfiguration() - Method in class org.axonframework.config.DefaultConfigurer
 
builder() - Static method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns a new TokenSchema.Builder initialized with default settings.
Builder() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
 
builder() - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Returns a new EventSchema.Builder initialized with default settings.
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
 
builder() - Static method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntryConfiguration
Returns a new builder that is initialized with default values.
builder() - Static method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Returns a new Builder for an EventEntryConfiguration initialized with default settings.
Builder() - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
buildJobDetail(EventMessage, JobKey) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Builds the JobDetail instance for Quartz, which defines the Job that needs to be executed when the trigger fires.
buildTrigger(Instant, JobKey) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Builds a Trigger which fires the Job identified by jobKey at (or around) the given triggerDateTime.
byDefaultAssignTo(String) - Method in class org.axonframework.config.EventHandlingConfiguration
Registers the Event Processor name to assign Event Handler beans to when no other, more explicit, rule matches.
byDefaultAssignTo(Function<Object, String>) - Method in class org.axonframework.config.EventHandlingConfiguration
Registers a function that defines the Event Processor name to assign Event Handler beans to when no other rule matches.
ByteArrayToInputStreamConverter - Class in org.axonframework.serialization.converters
ContentTypeConverter that converts byte arrays into InputStream.
ByteArrayToInputStreamConverter() - Constructor for class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
 
ByteArrayToJsonNodeConverter - Class in org.axonframework.serialization.json
ContentTypeConverter implementation that converts byte[] containing UTF8 encoded JSON string to a Jackson JsonNode.
ByteArrayToJsonNodeConverter(ObjectMapper) - Constructor for class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
Initialize the Converter, using given objectMapper to parse the binary contents
ByteArrayToStringConverter - Class in org.axonframework.serialization.converters
ContentTypeConverter that converts byte arrays into Strings.
ByteArrayToStringConverter() - Constructor for class org.axonframework.serialization.converters.ByteArrayToStringConverter
 

C

Cache - Interface in org.axonframework.common.caching
Abstraction for a Caching mechanism.
Cache.EntryListener - Interface in org.axonframework.common.caching
Interface describing callback methods, which are invoked when changes are made in the underlying cache.
Cache.EntryListenerAdapter - Class in org.axonframework.common.caching
Adapter implementation for the EntryListener, allowing for overriding only specific callback methods.
CachingEventSourcingRepository<T> - Class in org.axonframework.eventsourcing
Implementation of the event sourcing repository that uses a cache to improve loading performance.
CachingEventSourcingRepository(AggregateFactory<T>, EventStore, Cache) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Initializes a repository with a the given aggregateFactory and a pessimistic locking strategy.
CachingEventSourcingRepository(AggregateFactory<T>, EventStore, Cache, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Initializes a repository with a the given aggregateFactory and a pessimistic locking strategy.
CachingEventSourcingRepository(AggregateFactory<T>, EventStore, LockFactory, Cache, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Initializes a repository with a the given aggregateFactory and a pessimistic locking strategy.
CachingEventSourcingRepository(AggregateFactory<T>, EventStore, LockFactory, Cache, ParameterResolverFactory, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Initializes a repository with a the given aggregateFactory and a pessimistic locking strategy.
CachingSagaStore<T> - Class in org.axonframework.eventhandling.saga.repository
Saga Repository implementation that adds caching behavior to the repository it wraps.
CachingSagaStore(SagaStore<T>, Cache, Cache) - Constructor for class org.axonframework.eventhandling.saga.repository.CachingSagaStore
Initializes an instance delegating to the given delegate, storing associations in the given associationsCache and Saga instances in the given sagaCache.
CachingSupplier<T> - Class in org.axonframework.serialization
A Supplier that caches its result, useful if the supplier operation is expensive and expected to always yield the same result.
calculateChain(Class<S>, Class<T>, Collection<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serialization.ChainedConverter
Returns a converter that can convert an IntermediateRepresentation from the given sourceType to the given targetType using a chain formed with given candidates.
CallbackBehavior - Interface in org.axonframework.test.utils
Interface towards a mechanism that replicates the behavior of a Command Handling component.
callbacks() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
Returns the callbacks mapped by callback identifier.
cancel() - Method in interface org.axonframework.common.Registration
Cancels this Registration.
cancelCallbacks(A) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
Removes all callbacks for a given channel.
cancelSchedule(ScheduleToken) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Cancel the publication of a scheduled event.
cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
cancelSchedule(ScheduleToken) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
canConvert(Class<S>, Class<T>, List<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serialization.ChainedConverter
Indicates whether this converter is capable of converting the given sourceContentType into targetContentType, using the given converters.
canConvert(Class<?>, Class<?>) - Method in class org.axonframework.serialization.ChainingConverter
 
canConvert(Class<?>, Class<?>) - Method in interface org.axonframework.serialization.Converter
Indicates whether this converter is capable of converting the given sourceType to the targetType.
canHandle(Message<?>) - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
canHandle(EventMessage<?>) - Method in class org.axonframework.eventhandling.AnnotationEventListenerAdapter
 
canHandle(Message<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
canHandle(Message<?>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Checks if this handler is capable of handling the given message.
canHandle(Message<?>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
CannotConvertBetweenTypesException - Exception in org.axonframework.serialization
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.serialization.CannotConvertBetweenTypesException
Initializes the exception with the given message.
CannotConvertBetweenTypesException(String, Throwable) - Constructor for exception org.axonframework.serialization.CannotConvertBetweenTypesException
Initializing the exception with given message and cause.
canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.MessageSerializer
 
canSerializeTo(Class<T>) - Method in interface org.axonframework.serialization.Serializer
Indicates whether this Serializer is capable of serializing to the given expectedRepresentation.
canUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
Checks if this upcaster can upcast the given intermediateRepresentation.
canUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryUpcaster
Checks if this upcaster can upcast the given intermediateRepresentation.
CapacityMonitor - Class in org.axonframework.metrics
Calculates capacity by tracking, within the configured time window, the average message processing time and multiplying that by the amount of messages processed.
CapacityMonitor() - Constructor for class org.axonframework.metrics.CapacityMonitor
Creates a capacity monitor with the default time window 10 minutes
CapacityMonitor(long, TimeUnit) - Constructor for class org.axonframework.metrics.CapacityMonitor
Creates a capacity monitor with the default time window 10 minutes
CapacityMonitor(long, TimeUnit, Clock) - Constructor for class org.axonframework.metrics.CapacityMonitor
Creates a capacity monitor with the given time window.
ChainedConverter<S,T> - Class in org.axonframework.serialization
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.serialization.ChainedConverter
Creates a new instance that uses the given delegates to form a chain of converters.
ChainingConverter - Class in org.axonframework.serialization
Converter 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.
ChainingConverter() - Constructor for class org.axonframework.serialization.ChainingConverter
Initialize a new ChainingConverter with the context ClassLoader for this thread.
ChainingConverter(ClassLoader) - Constructor for class org.axonframework.serialization.ChainingConverter
Initialize a new ChainingConverter.
changePhase(UnitOfWork.Phase...) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
Ask the unit of work to transition to the given phases sequentially.
ChildEntity<T> - Interface in org.axonframework.commandhandling.model.inspection
Interface describing en entity that is a child of another entity.
ChildEntityDefinition - Interface in org.axonframework.commandhandling.model.inspection
Interface describing the definition of a Child Entity.
ChildForwardingCommandMessageHandlingMember<P,C> - Class in org.axonframework.commandhandling.model.inspection
Implementation of a CommandMessageHandlingMember that forwards commands to a child entity.
ChildForwardingCommandMessageHandlingMember(MessageHandlingMember<? super C>, BiFunction<CommandMessage<?>, P, C>) - Constructor for class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
Initializes a ChildForwardingCommandMessageHandlingMember that routes commands to a compatible child entity.
children() - Method in class org.axonframework.mongo.serialization.BSONNode
Returns an iterator providing access to the child nodes of the current node.
claim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Attempt to claim ownership of this token.
claimToken(ResultSet, AbstractTokenEntry<?>) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Tries to claim the given token entry.
classForType(SerializedType) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
classForType(SerializedType) - Method in class org.axonframework.serialization.JavaSerializer
 
classForType(SerializedType) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
classForType(SerializedType) - Method in class org.axonframework.serialization.MessageSerializer
 
classForType(SerializedType) - Method in interface org.axonframework.serialization.Serializer
Returns the class for the given type identifier.
ClasspathParameterResolverFactory - Class in org.axonframework.messaging.annotation
ParameterResolverFactory instance that locates other ParameterResolverFactory instances on the class path.
clear() - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
Clears all the associations.
clear() - Method in class org.axonframework.messaging.MetaData
This operation is not supported.
clear(UnitOfWork<?>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
Clears the UnitOfWork currently bound to the current thread, if that UnitOfWork is the given unitOfWork.
clearCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
Clears all the commands recorded by this Command Bus.
clearSubscriptions() - Method in class org.axonframework.test.utils.RecordingCommandBus
Clears all subscribed handlers on this command bus.
clock - Static variable in class org.axonframework.eventhandling.GenericEventMessage
Clock instance used to set the time on new events.
clock - Static variable in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
The clock used to persist timestamps in this entry.
clone() - Method in interface org.axonframework.common.caching.Cache.EntryListener
Clone operation used by some Cache implementations.
clone() - Method in class org.axonframework.common.caching.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 interface org.axonframework.common.lock.Lock
Releases this lock.
close() - Method in interface org.axonframework.common.Registration
Cancels this Registration.
close() - Method in interface org.axonframework.messaging.MessageStream
 
close() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
close() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
closeQuietly(AutoCloseable) - Static method in class org.axonframework.common.io.IOUtils
Closes any AutoCloseable 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.
CollectionUtils - Class in org.axonframework.common
Utility methods for operations on collections.
commandBus(TransactionManager, AxonConfiguration) - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
CommandBus - Interface in org.axonframework.commandhandling
The mechanism that dispatches Command objects to their appropriate CommandHandler.
commandBus() - Method in interface org.axonframework.config.Configuration
Returns the Command Bus defined in this Configuration.
commandBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
CommandBusConnector - Interface in org.axonframework.commandhandling.distributed
Interface describing the component that remotely connects multiple CommandBus instances.
CommandBusConnectorCommunicationException - Exception in org.axonframework.commandhandling.distributed
Exception thrown when the CommandBusConnector has a communication failure
CommandBusConnectorCommunicationException(String) - Constructor for exception org.axonframework.commandhandling.distributed.CommandBusConnectorCommunicationException
Initializes the CommandBusConnectorCommunicationException
CommandBusConnectorCommunicationException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.CommandBusConnectorCommunicationException
Initializes the CommandBusConnectorCommunicationException
CommandCallback<C,R> - Interface in org.axonframework.commandhandling
Interface describing a callback that is invoked when command handler execution has finished.
CommandCallbackRepository<A> - Class in org.axonframework.commandhandling.distributed
This class retains a list of callbacks for CommandCallbackConnectors to use.
CommandCallbackRepository() - Constructor for class org.axonframework.commandhandling.distributed.CommandCallbackRepository
 
CommandCallbackWrapper<A,C,R> - Class in org.axonframework.commandhandling.distributed
Wrapper for a Command callback.
CommandCallbackWrapper(A, CommandMessage<C>, CommandCallback<? super C, R>) - Constructor for class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
Initializes a CommandCallbackWrapper which wraps the original callback and holds on to the command message and channelId of the channel on which the message is sent.
CommandDispatchException - Exception in org.axonframework.commandhandling.distributed
Exception indicating that an error has occurred while trying to dispatch a command to another (potentially remote) segment of the CommandBus.
CommandDispatchException(String) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
Initializes the exception using the given message.
CommandDispatchException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
Initializes the exception using the given message and cause.
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(CommandBus) - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
CommandGateway - Interface in org.axonframework.commandhandling.gateway
Interface towards the Command Handling components of an application.
commandGateway() - Method in interface org.axonframework.config.Configuration
Returns the Command Gateway defined in this Configuration.
commandGateway(CommandBus) - Method in class org.axonframework.spring.config.AxonConfiguration
Returns the CommandGateway used to send commands to command handlers.
CommandGatewayFactory - Class in org.axonframework.commandhandling.gateway
Factory that creates Gateway implementations from custom interface definitions.
CommandGatewayFactory(CommandBus, MessageDispatchInterceptor<CommandMessage<?>>...) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Initialize the factory sending Commands to the given commandBus, optionally intercepting them with given dispatchInterceptors.
CommandGatewayFactory(CommandBus, RetryScheduler, MessageDispatchInterceptor<CommandMessage<?>>...) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Initialize the factory sending Commands to the given commandBus, optionally intercepting them with given dispatchInterceptors.
CommandGatewayFactory(CommandBus, RetryScheduler, List<MessageDispatchInterceptor<CommandMessage<?>>>) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Initialize the factory sending Commands to the given commandBus, optionally intercepting them with given dispatchInterceptors.
CommandGatewayFactory.InvocationHandler<R> - Interface in org.axonframework.commandhandling.gateway
Interface towards the mechanism that handles a method call on a gateway interface method.
CommandGatewayFactoryBean<T> - Class in org.axonframework.spring.commandhandling.gateway
FactoryBean that creates a gateway instance for any given (compatible) interface.
CommandGatewayFactoryBean() - Constructor for class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
 
CommandHandler - Annotation Type in org.axonframework.commandhandling
Marker annotation to mark any method on an object as being a CommandHandler.
commandHandler(String) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
Get the MessageHandlingMember capable of handling commands with given commandName (see CommandMessage.getCommandName()).
commandHandler(String) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
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.
commandHandlers() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedChildEntity
 
commandHandlers() - Method in interface org.axonframework.commandhandling.model.inspection.ChildEntity
Returns the commands and their respective handler that this entity declares
commandHandlers() - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
Get a mapping of MessageHandlingMember to command name (obtained via CommandMessage.getCommandName()).
commandHandlers() - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
CommandHandlerSubscriber - Class in org.axonframework.spring.config
Registers Spring beans that implement both MessageHandler and SupportedCommandNamesAware with the command bus.
CommandHandlerSubscriber() - Constructor for class org.axonframework.spring.config.CommandHandlerSubscriber
 
CommandHandlingEntry - Class in org.axonframework.commandhandling.disruptor
DataHolder for the DisruptorCommandBus.
CommandHandlingEntry() - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Initializes the CommandHandlingEntry
commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
CommandMessage<T> - Interface in org.axonframework.commandhandling
Represents a Message carrying a command as its payload.
CommandMessageHandlingMember<T> - Interface in org.axonframework.commandhandling.model.inspection
Interface describing a message handler capable of handling a specific command.
commandName - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
commandName() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
commandName() - Method in interface org.axonframework.commandhandling.model.inspection.CommandMessageHandlingMember
Returns the name of the command that can be handled.
CommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
A filter for CommandMessages which filters CommandMessages by a Command Name.
CommandNameFilter(Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
Initializes a CommandNameFilter for the given set of commandNames.
CommandNameFilter(String) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
Initializes a CommandNameFilter for a single command name.
CommandResponseProcessingFailedException - Exception in org.axonframework.jgroups.commandhandling
Exception indicating that a failure occurred during processing of a command response.
CommandResponseProcessingFailedException(String) - Constructor for exception org.axonframework.jgroups.commandhandling.CommandResponseProcessingFailedException
Initializes the exception using the given message.
CommandResponseProcessingFailedException(String, Throwable) - Constructor for exception org.axonframework.jgroups.commandhandling.CommandResponseProcessingFailedException
Initializes the exception using the given message and cause.
CommandRouter - Interface in org.axonframework.commandhandling.distributed
Interface describing a mechanism used to find a suitable member of a cluster capable of handling given command message.
CommandTargetResolver - Interface in org.axonframework.commandhandling
Interface towards a mechanism that is capable of extracting an Aggregate Identifier and Version form a command that identifies the aggregate instance the command should be invoked on.
CommandValidator - Class in org.axonframework.test.saga
Helper class for validation of dispatched commands.
CommandValidator(RecordingCommandBus, FieldFilter) - Constructor for class org.axonframework.test.saga.CommandValidator
Creates a validator which monitors the given commandBus.
commit(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 interface org.axonframework.common.transaction.Transaction
Commit this transaction.
commit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
Process given events while the Unit of Work root is being committed.
commit() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
Resets the tracked changes.
commit() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
commit(AnnotatedSaga<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Commits the given modified saga to the underlying saga store.
commit() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
commit() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
Commits the current UnitOfWork.
commit() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Commits the Unit of Work.
CommitEntry - Class in org.axonframework.mongo.eventsourcing.eventstore.documentpercommit
Mongo event storage entry containing an array of event entries that are part of the same UnitOfWork commit.
CommitEntry(List<? extends DomainEventMessage<?>>, Serializer) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntry
Constructor used to create a new event entry to store in Mongo.
CommitEntry(Document, CommitEntryConfiguration, EventEntryConfiguration) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntry
Creates a new CommitEntry based on data provided by Mongo.
CommitEntryConfiguration - Class in org.axonframework.mongo.eventsourcing.eventstore.documentpercommit
Configuration for a mongo event store entry that contains an array of event entries that are part of the same UnitOfWork commit.
commitTransaction(TransactionStatus) - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
Commits the transaction with given status if the transaction is new and not completed.
CompactDriver - Class in org.axonframework.serialization.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.serialization.xml.CompactDriver
 
compare(T, T) - Method in class org.axonframework.common.annotation.PriorityAnnotationComparator
 
compareTo(PropertyAccessStrategy) - Method in class org.axonframework.common.property.PropertyAccessStrategy
 
compareTo(GlobalSequenceTrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
 
compareTo(StubScheduleToken) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
Component<B> - Class in org.axonframework.config
A Component used in the Axon Configurer.
Component(Configuration, String, Function<Configuration, ? extends B>) - Constructor for class org.axonframework.config.Component
Creates a component for the given config with given name created by the given builderFunction.
Component(Supplier<Configuration>, String, Function<Configuration, ? extends B>) - Constructor for class org.axonframework.config.Component
Creates a component for the given config with given name created by the given builderFunction.
concat(DomainEventStream, DomainEventStream) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Concatenate two DomainEventStreams.
ConcludesBatch - Annotation Type in org.axonframework.eventhandling
Annotation indication that a parameter on an EventHandler method should be injected with a value that informs whether the event is the last event of a processed batch of events.
ConcludesBatchParameterResolverFactory - Class in org.axonframework.eventhandling
Paramater resolver factory for boolean event handler parameters annotated with ConcludesBatch.
ConcludesBatchParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
Initialize a ConcludesBatchParameterResolverFactory.
ConcurrencyException - Exception in org.axonframework.commandhandling.model
Exception indicating that concurrent access to a repository was detected.
ConcurrencyException(String) - Constructor for exception org.axonframework.commandhandling.model.ConcurrencyException
Initialize a ConcurrencyException with the given message.
ConcurrencyException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.ConcurrencyException
Initialize a ConcurrencyException with the given message and cause.
Configuration - Interface in org.axonframework.config
Interface describing the Global Configuration for Axon components.
ConfigurationParameterResolverFactory - Class in org.axonframework.config
ParameterResolverFactory implementation that resolves parameters from available components in the Configuration instance it was configured with.
ConfigurationParameterResolverFactory(Configuration) - Constructor for class org.axonframework.config.ConfigurationParameterResolverFactory
Initialize an instance using given configuration to supply the value to resolve parameters with
ConfigurationResourceInjector - Class in org.axonframework.config
ResourceInjector implementation that injects resources defined in the Axon Configuration.
ConfigurationResourceInjector(Configuration) - Constructor for class org.axonframework.config.ConfigurationResourceInjector
Initializes the ResourceInjector to inject the resources found in the given configuration.
configureAggregate(AggregateConfiguration<A>) - Method in interface org.axonframework.config.Configurer
Configures an Aggregate in this configuration based on the given aggregateConfiguration.
configureAggregate(Class<A>) - Method in interface org.axonframework.config.Configurer
Configures an Aggregate using default settings.
configureAggregate(AggregateConfiguration<A>) - Method in class org.axonframework.config.DefaultConfigurer
 
configureAggregateFactory(Function<Configuration, AggregateFactory<A>>) - Method in class org.axonframework.config.AggregateConfigurer
Defines the factory to use to to create new Aggregates instances of the type under configuration.
configureCommandBus(Function<Configuration, CommandBus>) - Method in interface org.axonframework.config.Configurer
Configure the given Command Bus to use in this configuration.
configureCommandHandler(Function<Configuration, AggregateAnnotationCommandHandler>) - Method in class org.axonframework.config.AggregateConfigurer
Defines the AggregateAnnotationCommandHandler instance to use.
configureCommandTargetResolver(Function<Configuration, CommandTargetResolver>) - Method in class org.axonframework.config.AggregateConfigurer
Defines the CommandTargetResolver to use for the Aggregate type under configuration.
configureCorrelationDataProviders(Function<Configuration, List<CorrelationDataProvider>>) - Method in interface org.axonframework.config.Configurer
Configures the CorrelationDataProviders that Message processing components should use to attach correlation data to outgoing messages.
configureCorrelationDataProviders(Function<Configuration, List<CorrelationDataProvider>>) - Method in class org.axonframework.config.DefaultConfigurer
 
configureEmbeddedEventStore(Function<Configuration, EventStorageEngine>) - Method in interface org.axonframework.config.Configurer
Configure an Embedded Event Store which uses the given Event Storage Engine to store its events.
configureEmbeddedEventStore(Function<Configuration, EventStorageEngine>) - Method in class org.axonframework.config.DefaultConfigurer
 
configureEventBus(Function<Configuration, EventBus>) - Method in interface org.axonframework.config.Configurer
Configure the given Event Bus to use in this configuration.
configureEventHandling(EventHandlingConfiguration, ApplicationContext) - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
configureEventStore(Function<Configuration, EventStore>) - Method in interface org.axonframework.config.Configurer
Configure the given Event Store to use in this configuration.
configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in interface org.axonframework.config.Configurer
Configure the Message Monitor to use for the Message processing components in this configuration.
configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in class org.axonframework.config.DefaultConfigurer
 
Configurer - Interface in org.axonframework.config
Entry point of the Axon Configuration API.
configureRepository(Function<Configuration, Repository<A>>) - Method in class org.axonframework.config.AggregateConfigurer
Defines the repository to use to load and store Aggregates of this type.
configureResourceInjector(Function<Configuration, ResourceInjector>) - Method in interface org.axonframework.config.Configurer
Configure the given Resource Injector to use for Sagas in this configuration.
configureSagaStore(Function<Configuration, SagaStore<? super S>>) - Method in class org.axonframework.config.SagaConfiguration
Configures the Saga Store to use to store Saga instances of this type.
configureSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
Configure the given Serializer to use in this configuration.
configureTransactionManager(Function<Configuration, TransactionManager>) - Method in interface org.axonframework.config.Configurer
Configure the given Transaction Manager to use in this configuration.
ConflictExceptionSupplier<T extends Exception> - Interface in org.axonframework.commandhandling.conflictresolution
Interface describing a factory for exceptions that indicate an unresolved conflict in an aggregate instance.
ConflictingAggregateVersionException - Exception in org.axonframework.commandhandling.model
Exception indicating that the (actual) version of a loaded aggregate did not match the given expected version number.
ConflictingAggregateVersionException(String, long, long) - Constructor for exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
Initializes the exception using the given message.
ConflictingAggregateVersionException(String, long, long, Throwable) - Constructor for exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
Initializes the exception using the given message and cause.
ConflictingModificationException - Exception in org.axonframework.commandhandling.model
Root of a hierarchy of exceptions indicating the detection of conflicting concurrent modifications.
ConflictingModificationException(String) - Constructor for exception org.axonframework.commandhandling.model.ConflictingModificationException
Initializes the exception using the given message.
ConflictingModificationException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.ConflictingModificationException
Initializes the exception using the given message and cause.
ConflictResolution - Class in org.axonframework.commandhandling.conflictresolution
ParameterResolverFactory that add support for the ConflictResolver parameter type in annotated handlers.
ConflictResolution() - Constructor for class org.axonframework.commandhandling.conflictresolution.ConflictResolution
 
ConflictResolver - Interface in org.axonframework.commandhandling.conflictresolution
Interface describing an object that is capable of detecting conflicts between changes to be applied to an aggregate, and unseen changes made to the aggregate.
Conflicts - Class in org.axonframework.commandhandling.conflictresolution
Utility class providing common Predicates used to detect conflicts between the actual state of an event sourced aggregate and the expected state of the aggregate.
connect() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
Connects this Node to the cluster and shares membership details about this node with the other nodes in the cluster.
ConnectionFailedException - Exception in org.axonframework.jgroups.commandhandling
Exception indicating that a CommandBusConnector failed to connect to other instances.
ConnectionFailedException(String) - Constructor for exception org.axonframework.jgroups.commandhandling.ConnectionFailedException
Initializes the exception using the given message.
ConnectionFailedException(String, Throwable) - Constructor for exception org.axonframework.jgroups.commandhandling.ConnectionFailedException
Initializes the exception using the given message and cause.
ConnectionProvider - Interface in org.axonframework.common.jdbc
Interface towards a mechanism that provides access to a JDBC Connection.
ConnectionWrapperFactory - Class in org.axonframework.common.jdbc
Factory for creating wrappers around a Connection, allowing one to override the behavior of the Connection.close() method.
ConnectionWrapperFactory.ConnectionCloseHandler - Interface in org.axonframework.common.jdbc
Interface defining an operation to close the wrapped connection
ConnectionWrapperFactory.NoOpCloseHandler - Class in org.axonframework.common.jdbc
Implementation of ConnectionCloseHandler that does nothing on close.
ConsistentHash - Class in org.axonframework.commandhandling.distributed
Component used by command routers to find members capable of handling a given command.
ConsistentHash() - Constructor for class org.axonframework.commandhandling.distributed.ConsistentHash
Initializes a new ConsistentHash.
ConsistentHash.ConsistentHashMember - Class in org.axonframework.commandhandling.distributed
Member implementation used by a ConsistentHash registry.
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 interface org.axonframework.eventhandling.saga.AssociationValues
Indicates whether this instance contains the given associationValue.
contains(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
containsKey(K) - Method in interface org.axonframework.common.caching.Cache
Indicates whether there is an item stored under given key.
containsKey(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
containsKey(K) - Method in class org.axonframework.common.caching.JCacheAdapter
 
containsKey(Object) - Method in class org.axonframework.common.caching.NoCache
 
containsKey(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
containsKey(Object) - Method in class org.axonframework.messaging.MetaData
 
containsValue(Object) - Method in class org.axonframework.messaging.MetaData
 
ContentTypeConverter<S,T> - Interface in org.axonframework.serialization
Interface describing a mechanism that converts the data type of IntermediateRepresentations of SerializedObjects for Upcasters.
ContinuedGivenState - Interface in org.axonframework.test.saga
Interface describing methods that can be executed after the first "given" state has been supplied.
convert(Set<ConstraintViolation<Object>>) - Static method in exception org.axonframework.messaging.interceptors.JSR303ViolationException
Convert the violations to a human readable format, sorted by class and property e.g.
convert(DBObject) - Method in class org.axonframework.mongo.serialization.DBObjectToStringContentTypeConverter
 
convert(Document) - Method in class org.axonframework.mongo.serialization.DocumentToStringContentTypeConverter
 
convert(String) - Method in class org.axonframework.mongo.serialization.StringToDBObjectContentTypeConverter
 
convert(S, Class<S>, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Convert the given source, of type sourceType to the given targetType.
convert(S) - Method in class org.axonframework.serialization.ChainedConverter
 
convert(Object, Class<?>, Class<T>) - Method in class org.axonframework.serialization.ChainingConverter
 
convert(S) - Method in interface org.axonframework.serialization.ContentTypeConverter
Converts the given object into another.
convert(Object, Class<T>) - Method in interface org.axonframework.serialization.Converter
Converts the given object into another.
convert(Object, Class<?>, Class<T>) - Method in interface org.axonframework.serialization.Converter
Converts the given object into another using the source type to find the conversion path.
convert(SerializedObject<?>, Class<T>) - Method in interface org.axonframework.serialization.Converter
Converts the data format of the given original IntermediateRepresentation to the target data type.
convert(Blob) - Method in class org.axonframework.serialization.converters.BlobToInputStreamConverter
 
convert(byte[]) - Method in class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
 
convert(byte[]) - Method in class org.axonframework.serialization.converters.ByteArrayToStringConverter
 
convert(InputStream) - Method in class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
 
convert(String) - Method in class org.axonframework.serialization.converters.StringToByteArrayConverter
 
convert(byte[]) - Method in class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
 
convert(JsonNode) - Method in class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
 
convert(Document) - Method in class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
 
convert(InputStream) - Method in class org.axonframework.serialization.xml.InputStreamToDom4jConverter
 
convert(InputStream) - Method in class org.axonframework.serialization.xml.InputStreamToXomConverter
 
convert(Document) - Method in class org.axonframework.serialization.xml.XomToStringConverter
 
convert(EventMessage<?>) - Method in class org.axonframework.spring.messaging.ApplicationContextEventPublisher
Converts the given Axon eventMessage to a Spring ApplicationEvent.
Converter - Interface in org.axonframework.serialization
Interface describing a mechanism that can convert data from one to another type.
convertFromInboundMessage(Message<T>) - Method in class org.axonframework.spring.messaging.DefaultEventMessageConverter
 
convertFromInboundMessage(Message<T>) - Method in interface org.axonframework.spring.messaging.EventMessageConverter
Converts a Spring inbound message into an Axon event Message
convertToOutboundMessage(EventMessage<T>) - Method in class org.axonframework.spring.messaging.DefaultEventMessageConverter
 
convertToOutboundMessage(EventMessage<T>) - Method in interface org.axonframework.spring.messaging.EventMessageConverter
Converts Axon event into Spring message.
correlationData() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
Returns the Correlation Data attached to the current Unit of Work, or an empty MetaData instance if no Unit of Work is started.
correlationDataFor(Message<?>) - Method in interface org.axonframework.messaging.correlation.CorrelationDataProvider
Provides a map with the entries to attach as correlation data to generated messages while processing given message.
correlationDataFor(Message<?>) - Method in class org.axonframework.messaging.correlation.MessageOriginProvider
 
correlationDataFor(Message<?>) - Method in class org.axonframework.messaging.correlation.MultiCorrelationDataProvider
 
correlationDataFor(Message<?>) - Method in class org.axonframework.messaging.correlation.SimpleCorrelationDataProvider
 
CorrelationDataInterceptor<T extends Message<?>> - Class in org.axonframework.messaging.interceptors
Message interceptor that registers CorrelationDataProviders with the Unit of Work.
CorrelationDataInterceptor(Collection<CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
Initializes the interceptor that registers given correlationDataProvider with the current Unit of Work.
CorrelationDataProvider - Interface in org.axonframework.messaging.correlation
Object defining the data from a Message that should be attached as correlation data to messages generated as result of the processing of that message.
correlationDataProviders() - Method in interface org.axonframework.config.Configuration
Returns the Correlation Data Providers defined in this Configuration.
correlationDataProviders() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
Provides the collection of registered Correlation Data Providers of this Unit of Work.
correlationDataProviders() - Method in class org.axonframework.spring.config.AxonConfiguration
 
createAggregateRoot(String, DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
 
createAggregateRoot(String, DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.AggregateFactory
Instantiate the aggregate root using the given aggregate identifier and first event.
createAggregateRoot(String, DomainEventMessage<?>) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
 
createAMQPMessage(EventMessage<?>) - Method in interface org.axonframework.amqp.eventhandling.AMQPMessageConverter
Creates an AMQPMessage from given eventMessage.
createAMQPMessage(EventMessage<?>) - Method in class org.axonframework.amqp.eventhandling.DefaultAMQPMessageConverter
 
createAMQPMessage(EventMessage) - Method in class org.axonframework.amqp.eventhandling.legacy.JavaSerializationAMQPMessageConverter
 
createChannel() - Method in interface org.axonframework.jgroups.commandhandling.JChannelFactory
Creates a JChannel instance, which is fully configured, but not connected.
createChannel() - Method in class org.axonframework.jgroups.commandhandling.JGroupsXmlConfigurationChannelFactory
 
createChildDefinition(Field, EntityModel<T>) - Method in class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
 
createChildDefinition(Field, EntityModel<T>) - Method in class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityDefinition
 
createChildDefinition(Field, EntityModel<T>) - Method in class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
 
createChildDefinition(Field, EntityModel<T>) - Method in interface org.axonframework.commandhandling.model.inspection.ChildEntityDefinition
Inspect the given field, which is declared on the given declaringEntity for the presence of a Child Entity.
createDomainEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
 
createDomainEventTable(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory
Creates a PreparedStatement that allows for the creation of the table to store Event entries.
createDomainEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
 
createEventDocuments(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
Returns a stream of Mongo documents that represent the given batch of events.
createEventDocuments(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
 
createEventDocuments(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.DocumentPerEventStorageStrategy
 
createEventEntity(EventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Returns a Jpa event entity for given eventMessage.
createEventProcessor(Configuration, String, List<?>) - Method in interface org.axonframework.config.EventHandlingConfiguration.EventProcessorBuilder
Builder function for an Event Processor.
createGateway(Class<T>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Creates a gateway instance for the given gatewayInterface.
createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
 
createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in interface org.axonframework.messaging.annotation.HandlerDefinition
Create a MessageHandlingMember for the given executable method.
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.config.ConfigurationParameterResolverFactory
 
createInstance(String, Supplier<T>) - Method in class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
Creates a new Saga instance.
createInstance(String, Supplier<T>) - Method in interface org.axonframework.eventhandling.saga.SagaRepository
Creates a new Saga instance.
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventsourcing.eventstore.TrackingTokenParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.DefaultParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in interface org.axonframework.messaging.annotation.ParameterResolverFactory
If available, creates a ParameterResolver instance that can provide a parameter of type parameterType for a given message.
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.test.FixtureResourceParameterResolverFactory
 
createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
Creates an adapter for the given cacheEntryListener.
createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.JCacheAdapter
 
createMessage(P, MetaData) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Creates an EventMessage with given payload and metaData.
createMessage(P, MetaData) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
createMongo() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoFactory
Creates a mongo instance based on the provided configuration.
createMongoOptions() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Uses the configured parameters to create a MongoOptions instance.
createNullStatement(Connection) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
Creates a prepared statement that acts as a null object.
createReader(Reader) - Method in class org.axonframework.serialization.xml.CompactDriver
 
createReader(InputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
 
createReader(URL) - Method in class org.axonframework.serialization.xml.CompactDriver
 
createReader(File) - Method in class org.axonframework.serialization.xml.CompactDriver
 
createRepository(AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - 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>, SnapshotTriggerDefinition) - 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>, ParameterResolverFactory) - 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>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate that is created by the given aggregateFactory.
createSagaEntry(Object, String, Serializer) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Intended for clients to override.
createSchema() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
Creates the SQL Schema required to store Sagas and their associations,.
createSchema(TokenTableFactory) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Performs the DDL queries to create the schema necessary for this token store implementation.
createSchema(EventTableFactory) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Performs the DDL queries to create the schema necessary for this storage engine implementation.
createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Creates a snapshot event for an aggregate of which passed events are available in the given eventStream.
createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
 
createSnapshotDocument(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
Returns a Mongo document for given snapshot event.
createSnapshotDocument(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
 
createSnapshotDocument(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.DocumentPerEventStorageStrategy
 
createSnapshotEntity(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Returns a Jpa snapshot entity for given snapshot of an aggregate.
createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
 
createSnapshotEventTable(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory
Creates a PreparedStatement that allows for the creation of the table to store Snapshots.
createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
 
createSnapshotterTask(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Creates an instance of a task that contains the actual snapshot creation logic.
createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
 
createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory
 
createTable(Connection, TokenSchema) - Method in interface org.axonframework.eventhandling.tokenstore.jdbc.TokenTableFactory
Creates a PreparedStatement that allows for the creation of the table to store tracking token entries.
createWriter(Writer) - Method in class org.axonframework.serialization.xml.CompactDriver
 
createWriter(OutputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
 
currentTime() - Method in interface org.axonframework.test.saga.FixtureConfiguration
Returns the time as "known" by the fixture.
currentTime() - Method in class org.axonframework.test.saga.SagaTestFixture
 
CurrentUnitOfWork - Class in org.axonframework.messaging.unitofwork
Default entry point to gain access to the current UnitOfWork.
CurrentUnitOfWorkParameterResolverFactory - Class in org.axonframework.commandhandling
ParameterResolverFactory that add support for the UnitOfWork parameter type in annotated handlers.
CurrentUnitOfWorkParameterResolverFactory() - Constructor for class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
 

D

database() - Method in class org.axonframework.mongo.AbstractMongoTemplate
Returns a reference to the Database with the configured database name.
DataSourceConnectionProvider - Class in org.axonframework.common.jdbc
ConnectionProvider implementation that obtains a connection from a given DataSource.
DataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.common.jdbc.DataSourceConnectionProvider
Initialize the Connection Provider, using given dataSource to obtain new connections.
dataSourcePersistenceExceptionResolver(DataSource) - Method in class org.axonframework.boot.autoconfig.JpaAutoConfiguration
 
DateTimeUtils - Class in org.axonframework.common
Some utility methods regarding Date and Time.
DBObjectHierarchicalStreamReader - Class in org.axonframework.mongo.serialization
HierarchicalStreamReader implementation that reads from a Mongo DBObject structure that has been created using the DBObjectHierarchicalStreamWriter.
DBObjectHierarchicalStreamReader(DBObject) - Constructor for class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
Initialize the reader to read the structure of the given root DBObject.
DBObjectHierarchicalStreamWriter - Class in org.axonframework.mongo.serialization
HierarchicalStreamWriter implementation that writes objects into a MongoDB DBObject structure.
DBObjectHierarchicalStreamWriter(DBObject) - Constructor for class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
Initialize the writer to write the object structure to the given root DBObject.
DBObjectToStringContentTypeConverter - Class in org.axonframework.mongo.serialization
ContentTypeConverter implementation that converts a DBObject structure into a String containing its Binary JSON representation.
DBObjectToStringContentTypeConverter() - Constructor for class org.axonframework.mongo.serialization.DBObjectToStringContentTypeConverter
 
DBObjectXStreamSerializer - Class in org.axonframework.mongo.serialization
XStream based serializer implementation that serializes objects into a Binary JSON structure.
DBObjectXStreamSerializer() - Constructor for class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
Initialize the serializer with UTF-8 character set and a default XStream serializer.
DBObjectXStreamSerializer(XStream) - Constructor for class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
Initialize the serializer using the UTF-8 character set.
DBObjectXStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
Initialize the serializer using the UTF-8 character set.
DBObjectXStreamSerializer(Charset) - Constructor for class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
Initialize the serializer using the given charset.
DBObjectXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
DBObjectXStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
Initialize the serializer using the given charset, xStream and revisionResolver instance.
DBObjectXStreamSerializer(Charset, XStream, RevisionResolver, Converter) - Constructor for class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
Initialize the serializer using the given charset and xStream instance.
DeadlockException - Exception in org.axonframework.common.lock
Exception indicating that a deadlock has been detected while a thread was attempting to acquire a lock.
DeadlockException(String) - Constructor for exception org.axonframework.common.lock.DeadlockException
Initializes the exception with given message.
declaringClass(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
Returns the class on which the method with name "getter" and parameters of type parameterTypes is declared.
DEFAULT_BUFFER_SIZE - Static variable in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
The default size of the buffer in this configuration
DefaultAMQPMessageConverter - Class in org.axonframework.amqp.eventhandling
Default implementation of the AMQPMessageConverter interface.
DefaultAMQPMessageConverter(Serializer) - Constructor for class org.axonframework.amqp.eventhandling.DefaultAMQPMessageConverter
Initializes the AMQPMessageConverter with the given serializer, using a PackageRoutingKeyResolver and requesting durable dispatching.
DefaultAMQPMessageConverter(Serializer, RoutingKeyResolver, boolean) - Constructor for class org.axonframework.amqp.eventhandling.DefaultAMQPMessageConverter
Initializes the AMQPMessageConverter with the given serializer, routingKeyResolver and requesting durable dispatching when durable is true.
DefaultCallbackBehavior - Class in org.axonframework.test.utils
Default implementation of the CallbackBehavior interface.
DefaultCallbackBehavior() - Constructor for class org.axonframework.test.utils.DefaultCallbackBehavior
 
defaultCommandBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default CommandBus implementation.
defaultCommandBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
DefaultCommandGateway - Class in org.axonframework.commandhandling.gateway
Default implementation of the CommandGateway interface.
DefaultCommandGateway(CommandBus, MessageDispatchInterceptor<? super CommandMessage<?>>...) - 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, MessageDispatchInterceptor<? super CommandMessage<?>>...) - 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<MessageDispatchInterceptor<? super CommandMessage<?>>>) - 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(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Returns a DefaultCommandGateway that will use the configuration's CommandBus to dispatch commands.
defaultConfiguration(Class<A>) - Static method in class org.axonframework.config.AggregateConfigurer
Creates a default Configuration for an aggregate of the given aggregateType.
defaultConfiguration() - Static method in class org.axonframework.config.DefaultConfigurer
Returns a Configurer instance with default components configured, such as a SimpleCommandBus and SimpleEventBus.
DefaultConfigurer - Class in org.axonframework.config
Entry point of the Axon Configuration API.
DefaultConfigurer() - Constructor for class org.axonframework.config.DefaultConfigurer
Initialize the Configurer
DefaultConflictResolver - Class in org.axonframework.commandhandling.conflictresolution
Implementation of a ConflictResolver that fetches any unseen changes from the EventStore.
DefaultConflictResolver(EventStore, String, long, long) - Constructor for class org.axonframework.commandhandling.conflictresolution.DefaultConflictResolver
Initializes a DefaultConflictResolver using the given eventStore to load unseen events since given expectedVersion.
DefaultEntityRegistrar - Class in org.axonframework.boot
 
DefaultEntityRegistrar() - Constructor for class org.axonframework.boot.DefaultEntityRegistrar
 
defaultEventBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default EventBus implementation.
defaultEventBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
DefaultEventMessageConverter - Class in org.axonframework.spring.messaging
An EventMessageConverter that will convert an Axon event message into a Spring message by: - Copying axon event payload into Spring message payload - Copying axon event metadata into Spring message headers - Adding axon event message specific attributes - that are not part of axon metadata - to the Spring message Headers.
DefaultEventMessageConverter() - Constructor for class org.axonframework.spring.messaging.DefaultEventMessageConverter
 
DefaultIdentifierFactory - Class in org.axonframework.common
Default IdentifierFactory implementation that uses generates random java.util.UUID based identifiers.
DefaultIdentifierFactory() - Constructor for class org.axonframework.common.DefaultIdentifierFactory
 
DefaultInterceptorChain<T extends Message<?>> - Class in org.axonframework.messaging
Mechanism that takes care of interceptor and handler execution.
DefaultInterceptorChain(UnitOfWork<? extends T>, Iterable<? extends MessageHandlerInterceptor<? super T>>, MessageHandler<? super T>) - Constructor for class org.axonframework.messaging.DefaultInterceptorChain
Initialize the default interceptor chain to dispatch the given message, through the chain, to the handler.
DefaultMongoTemplate - Class in org.axonframework.mongo.eventhandling.saga.repository
MongoTemplate instance providing access to the MongoDB Collection containing stored Sagas.
DefaultMongoTemplate(MongoClient) - Constructor for class org.axonframework.mongo.eventhandling.saga.repository.DefaultMongoTemplate
Initialize a template for the given mongoDb instance, using default database name ("axonframework") and collection name ("sagas").
DefaultMongoTemplate(MongoClient, String, String) - Constructor for class org.axonframework.mongo.eventhandling.saga.repository.DefaultMongoTemplate
Creates a template connecting to given mongo instance, and loads sagas in the collection with given sagasCollectionName, in a database with given databaseName.
DefaultMongoTemplate - Class in org.axonframework.mongo.eventsourcing.eventstore
Default implementation for the MongoTemplate.
DefaultMongoTemplate(MongoClient) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.DefaultMongoTemplate
Initializes the MongoTemplate using the given mongo for database access, using default database and collection names.
DefaultMongoTemplate(MongoClient, String, String, String) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.DefaultMongoTemplate
Creates a template connecting to given mongo instance, and loads events in the collection with given domainEventsCollectionName and snapshot events from snapshotEventsCollectionName, in a database with given databaseName.
defaultParameterResolverFactory(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default ParameterResolverFactory.
DefaultParameterResolverFactory - Class in org.axonframework.messaging.annotation
Factory for the default parameter resolvers.
DefaultParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.DefaultParameterResolverFactory
 
defaultResourceInjector(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Returns a ConfigurationResourceInjector that injects resources defined in the given config Configuration.
DefaultSagaMetaModelFactory - Class in org.axonframework.eventhandling.saga.metamodel
Default implementation of a SagaMetaModelFactory.
DefaultSagaMetaModelFactory() - Constructor for class org.axonframework.eventhandling.saga.metamodel.DefaultSagaMetaModelFactory
DefaultSagaMetaModelFactory(ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.saga.metamodel.DefaultSagaMetaModelFactory
Initializes a DefaultSagaMetaModelFactory with given parameterResolverFactory.
defaultSerializer(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default Serializer implementation.
DefaultUnitOfWork<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
Implementation of the UnitOfWork that processes a single message.
DefaultUnitOfWork(T) - Constructor for class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
Initializes a Unit of Work (without starting it).
deleteSaga(AnnotatedSaga<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Remove the given saga as well as all known association values pointing to it from the repository.
deleteSaga(Class<? extends T>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
 
deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
 
deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
 
deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
 
deleteSaga(Class<? extends T>, String, Set<AssociationValue>) - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore
Deletes a Saga with given sagaType and sagaIdentifier and all its associations.
deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.mongo.eventhandling.saga.repository.MongoSagaStore
 
deleteSnapshots(Connection, String, long) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to delete all snapshots of the aggregate with given aggregateIdentifier.
deleteSnapshots(String, long) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Deletes all snapshots from the underlying storage with given aggregateIdentifier.
deleteSnapshots(MongoCollection<Document>, String, long) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
 
deleteSnapshots(MongoCollection<Document>, String, long) - Method in interface org.axonframework.mongo.eventsourcing.eventstore.StorageStrategy
Delete all snapshots of the aggregate with given aggregateIdentifier from the given snapshotCollection, whose sequence number is lower than the given sequenceNumber.
DenyAll - Enum in org.axonframework.commandhandling.distributed.commandfilter
A Command Message predicate that denies all CommandMessages
DenyCommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
A Predicate for CommandMessage's that can deny commands based on their name.
DenyCommandNameFilter(Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
Initializes a DenyCommandNameFilter from the given set of commandNames.
DenyCommandNameFilter(String) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
Initializes a DenyCommandNameFilter for a single commandName.
describe(List<?>, Description) - Static method in class org.axonframework.test.saga.DescriptionUtils
Describe the contents of the given list in the given description.
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ExactSequenceMatcher
 
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListMatcher
Describes the type of collection expected.
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListWithAllOfMatcher
 
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
describeCollectionType(Description) - Method in class org.axonframework.test.matchers.SequenceMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.EmptyCollectionMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.ListMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.NullOrVoidMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.PayloadMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.PayloadsMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.PredicateMatcher
 
DescriptionUtils - Class in org.axonframework.test.saga
Utility class for creating a description.
deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.JavaSerializer
 
deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.axonframework.serialization.json.MetaDataDeserializer
 
deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.MessageSerializer
 
deserialize(SerializedObject<S>) - Method in interface org.axonframework.serialization.Serializer
Deserializes the first object read from the given bytes.
deserializeWithType(JsonParser, DeserializationContext, TypeDeserializer) - Method in class org.axonframework.serialization.json.MetaDataDeserializer
 
destroy() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in interface org.axonframework.commandhandling.conflictresolution.ConflictResolver
Resolve conflicts between unseen changes made to the aggregate and new changes that are about to be made.
detectConflicts(Predicate<List<DomainEventMessage<?>>>) - Method in interface org.axonframework.commandhandling.conflictresolution.ConflictResolver
Resolve conflicts between changes to be applied to the aggregate and unseen changes made to the aggregate.
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in class org.axonframework.commandhandling.conflictresolution.DefaultConflictResolver
 
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in enum org.axonframework.commandhandling.conflictresolution.NoConflictResolver
 
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.
DirectEventJobDataBinder() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
 
DirectEventProcessingStrategy - Enum in org.axonframework.eventhandling
Event processing strategy that directly initiates event processing.
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
 
DirectlyAccessedProperty<T> - Class in org.axonframework.common.property
Property implementation that accesses public field to obtain a value of a property for a given instance.
DirectlyAccessedProperty(Field, String) - Constructor for class org.axonframework.common.property.DirectlyAccessedProperty
 
DirectPropertyAccessStrategy - Class in org.axonframework.common.property
Implementation of PropertyAccessStrategy that scans class hierarchy to get public field named "property"
DirectPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.DirectPropertyAccessStrategy
 
disconnect() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
Disconnects from the Cluster, preventing any Commands from being routed to this node.
dispatch(CommandMessage<C>) - Method in interface org.axonframework.commandhandling.CommandBus
Dispatch the given command to the CommandHandler subscribed to the given command's name.
dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in interface org.axonframework.commandhandling.CommandBus
Dispatch the given command to the CommandHandler subscribed to the given command's name.
dispatch(CommandMessage<C>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
 
dispatch(CommandMessage<C>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Dispatch the given command to the CommandHandler subscribed to the given command's name.
dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
 
dispatch(CommandMessage<C>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
DispatchMessage - Class in org.axonframework.commandhandling.distributed
Base class for dispatch messages which may be used in the CommandBusConnector upon dispatching a command to other nodes.
DispatchMessage() - Constructor for class org.axonframework.commandhandling.distributed.DispatchMessage
Default constructor required for de-/serialization of extending classes.
DispatchMessage(CommandMessage<?>, Serializer, boolean) - Constructor for class org.axonframework.commandhandling.distributed.DispatchMessage
Initialized a DispatchMessage for the given commandMessage, which uses the given serializer to deserialize its contents.
DisruptorCommandBus - Class in org.axonframework.commandhandling.disruptor
Asynchronous CommandBus implementation with very high performance characteristics.
DisruptorCommandBus(EventStore) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Initialize the DisruptorCommandBus with given resources, using default configuration settings.
DisruptorCommandBus(EventStore, DisruptorConfiguration) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Initialize the DisruptorCommandBus with given resources and settings.
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.
DisruptorUnitOfWork<T extends Message<?>> - Class in org.axonframework.commandhandling.disruptor
Specialized UnitOfWork instance for the DisruptorCommandBus.
DisruptorUnitOfWork() - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
DistributedAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
DistributedAutoConfiguration() - Constructor for class org.axonframework.boot.autoconfig.DistributedAutoConfiguration
 
distributedCommandBus(CommandRouter, CommandBusConnector, DistributedCommandBusProperties) - Method in class org.axonframework.boot.autoconfig.DistributedAutoConfiguration
 
DistributedCommandBus - Class in org.axonframework.commandhandling.distributed
Implementation of a CommandBus that is aware of multiple instances of a CommandBus working together to spread load.
DistributedCommandBus(CommandRouter, CommandBusConnector) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
Initializes the command bus with the given commandRouter and connector.
DistributedCommandBus(CommandRouter, CommandBusConnector, MessageMonitor<? super CommandMessage<?>>) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
Initializes the command bus with the given commandRouter, connector and messageMonitor.
DistributedCommandBusProperties - Class in org.axonframework.boot
 
DistributedCommandBusProperties() - Constructor for class org.axonframework.boot.DistributedCommandBusProperties
 
DistributedCommandBusProperties.JGroupsProperties - Class in org.axonframework.boot
 
DistributedCommandBusProperties.JGroupsProperties.Gossip - Class in org.axonframework.boot
 
doApply(T, MetaData) - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
Apply a DomainEventMessage with given payload and metadata (metadata from interceptors will be combined with the provided metadata).
doApply(P, MetaData) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
doApply(P, MetaData) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
doAssociateWith(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
Registers a AssociationValue with the given saga.
doAssociateWith(AssociationValue) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
SagaLifecycle instance method to register the given associationValue.
doCreateAggregate(String, DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
Create an uninitialized Aggregate instance with the given aggregateIdentifier.
doCreateAggregate(String, DomainEventMessage) - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
Create an uninitialized Aggregate instance with the given aggregateIdentifier.
doCreateInstance(String, Supplier<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
 
doCreateInstance(String, Supplier<T>) - Method in class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
Creates a new Saga instance.
doCreateNew(Callable<T>) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Creates a new aggregate instance using the given factoryMethod.
doCreateNew(Callable<T>) - Method in class org.axonframework.commandhandling.model.LockingRepository
 
doCreateNewForLock(Callable<T>) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
 
doCreateNewForLock(Callable<T>) - Method in class org.axonframework.commandhandling.model.LockingRepository
Creates a new aggregate instance using the given factoryMethod.
doCreateNewForLock(Callable<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
doCreateNewForLock(Callable<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
DocumentPerCommitStorageStrategy - Class in org.axonframework.mongo.eventsourcing.eventstore.documentpercommit
Implementation of a Mongo StorageStrategy that stores one Document per commit of a batch of events.
DocumentPerCommitStorageStrategy() - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
Initializes a DocumentPerCommitStorageStrategy with default event entry and commit entry configuration.
DocumentPerCommitStorageStrategy(CommitEntryConfiguration) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
Initializes a DocumentPerCommitStorageStrategy with default event entry and given commitEntryConfiguration.
DocumentPerCommitStorageStrategy(EventEntryConfiguration, CommitEntryConfiguration, Duration) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
Initializes a DocumentPerCommitStorageStrategy with given eventConfiguration and commitEntryConfiguration.
DocumentPerEventStorageStrategy - Class in org.axonframework.mongo.eventsourcing.eventstore.documentperevent
Implementation of a StorageStrategy that stores one Document per EventMessage.
DocumentPerEventStorageStrategy() - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.DocumentPerEventStorageStrategy
Initializes a DocumentPerEventStorageStrategy with default configuration.
DocumentPerEventStorageStrategy(EventEntryConfiguration, Duration) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.DocumentPerEventStorageStrategy
Initializes a DocumentPerEventStorageStrategy with given eventConfiguration.
DocumentToStringContentTypeConverter - Class in org.axonframework.mongo.serialization
ContentTypeConverter implementation that converts a BSON Document structure into a String containing its JSON representation.
DocumentToStringContentTypeConverter() - Constructor for class org.axonframework.mongo.serialization.DocumentToStringContentTypeConverter
 
doDelete(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Removes the aggregate from the repository.
doDelete(LockAwareAggregate<T, A>) - Method in class org.axonframework.commandhandling.model.LockingRepository
Verifies whether all locks are valid and delegates to LockingRepository.doDeleteWithLock(Aggregate) to perform actual deleting.
doDeleteWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
 
doDeleteWithLock(A) - Method in class org.axonframework.commandhandling.model.LockingRepository
Perform the actual deleting of the aggregate.
doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
 
doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Deserialize the given serializedObject.
doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serialization.xml.XStreamSerializer
 
doDispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
 
doDispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Performs the actual dispatching logic.
doEnd() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
Marks the saga as ended.
doEnd() - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
SagaLifecycle instance method to mark the current saga as ended.
doLoad(String, Long) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Loads and initialized the aggregate with the given aggregateIdentifier.
doLoad(String, Long) - Method in class org.axonframework.commandhandling.model.LockingRepository
Perform the actual loading of an aggregate.
doLoad(String) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
 
doLoad(String) - Method in class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
Loads a known Saga instance by its unique identifier.
doLoadSaga(String) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Loads the saga with given sagaIdentifier from the underlying saga store and returns it as a AnnotatedSaga.
doLoadWithLock(String, Long) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
 
doLoadWithLock(String, Long) - Method in class org.axonframework.commandhandling.model.LockingRepository
Loads the aggregate with the given aggregateIdentifier.
doLoadWithLock(String, Long) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
Perform the actual loading of an aggregate.
doLoadWithLock(String, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Perform the actual loading of an aggregate.
Dom4JToByteArrayConverter - Class in org.axonframework.serialization.xml
Converter that converts Dom4j Document instances to a byte array.
Dom4JToByteArrayConverter() - Constructor for class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
 
DomainEventData<T> - Interface in org.axonframework.eventsourcing.eventstore
Interface describing the properties of serialized Domain Event Messages.
DomainEventEntry - Class in org.axonframework.eventsourcing.eventstore.jpa
Default implementation of a tracked domain event entry.
DomainEventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.DomainEventEntry
Construct a new default domain event entry from a published domain event message to enable storing the event or sending it to a remote location.
DomainEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.DomainEventEntry
Default constructor required by JPA
domainEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Returns the name of the Jpa event entity.
domainEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Returns a comma separated list of domain event column names to select from an event or snapshot entry.
DomainEventMessage<T> - Interface in org.axonframework.eventsourcing
Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain.
DomainEventStream - Interface in org.axonframework.eventsourcing.eventstore
The DomainEventStream represents a stream of historical events published by an Aggregate.
domainEventTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Returns the name of the domain event table.
doMarkDeleted() - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
Marks this aggregate as deleted.
doMarkDeleted() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
doRegisterListener(L) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
Registers the given listener with the cache implementation
doRegisterListener(CacheEventListener) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
doRegisterListener(CacheEntryListenerConfiguration) - Method in class org.axonframework.common.caching.JCacheAdapter
 
doRemoveAssociation(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
Removes the given association from this Saga.
doRemoveAssociation(AssociationValue) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
SagaLifecycle instance method to remove the given associationValue.
doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
Resolve the Routing Key for the given command.
doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
 
doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
 
doSave(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Performs the actual saving of the aggregate.
doSave(LockAwareAggregate<T, A>) - Method in class org.axonframework.commandhandling.model.LockingRepository
Verifies whether all locks are valid and delegates to LockingRepository.doSaveWithLock(Aggregate) to perform actual storage.
doSaveWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
 
doSaveWithLock(A) - Method in class org.axonframework.commandhandling.model.LockingRepository
Perform the actual saving of the aggregate.
doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
doSendMessage(Channel, AMQPMessage) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Does the actual publishing of the given body on the given channel.
doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
 
doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Serialize the given object to the given expectedFormat.
doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serialization.xml.XStreamSerializer
 
doUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
Upcasts the given intermediateRepresentation.
doUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryUpcaster
Upcasts the given intermediateRepresentation.

E

EhCacheAdapter - Class in org.axonframework.common.caching
Cache implementation that delegates all calls to an EhCache instance.
EhCacheAdapter(Ehcache) - Constructor for class org.axonframework.common.caching.EhCacheAdapter
Initialize the adapter to forward all call to the given ehCache instance
EmbeddedEventStore - Class in org.axonframework.eventsourcing.eventstore
Implementation of an EventStore that stores and fetches events using an EventStorageEngine.
EmbeddedEventStore(EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
Initializes an EmbeddedEventStore with given storageEngine and default settings.
EmbeddedEventStore(EventStorageEngine, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
Initializes an EmbeddedEventStore with given storageEngine and monitor and default settings.
EmbeddedEventStore(EventStorageEngine, MessageMonitor<? super EventMessage<?>>, int, long, long, TimeUnit) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
Initializes an EmbeddedEventStore with given storageEngine and monitor and custom settings.
empty() - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Create an empty DomainEventStream.
EmptyCollectionMatcher<T> - Class in org.axonframework.test.matchers
Matches any empty collection.
EmptyCollectionMatcher(String) - Constructor for class org.axonframework.test.matchers.EmptyCollectionMatcher
Creates a matcher of a list of empty items.
emptyInstance() - Static method in class org.axonframework.messaging.MetaData
Returns an empty MetaData instance.
EnableAxon - Annotation Type in org.axonframework.spring.config
Annotation that enables Axon Configuration API for Spring.
end() - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
Marks the saga as ended.
endNode() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
endpoint() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
Returns this Member's endpoint.
EndSaga - Annotation Type in org.axonframework.eventhandling.saga
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.
ensureConflictsResolved() - Method in class org.axonframework.commandhandling.conflictresolution.DefaultConflictResolver
ensureIndexes(MongoCollection<Document>, MongoCollection<Document>) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
 
ensureIndexes(MongoCollection<Document>, MongoCollection<Document>) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
 
ensureIndexes() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
Make sure an index is created on the collection that stores domain events.
ensureIndexes(MongoCollection<Document>, MongoCollection<Document>) - Method in interface org.axonframework.mongo.eventsourcing.eventstore.StorageStrategy
Ensure that the correct indexes are in place.
ensureSagaManagerInitialized() - Method in class org.axonframework.test.saga.SagaTestFixture
Initializes the SagaManager if it hasn't already done so.
EntityId - Annotation Type in org.axonframework.commandhandling.model
Field annotation that marks the field containing the identifier of an Entity.
entityManager() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Provides an EntityManager instance for storing and fetching event data.
entityManagerProvider() - Method in class org.axonframework.boot.autoconfig.JpaAutoConfiguration
 
EntityManagerProvider - Interface in org.axonframework.common.jpa
Provides components with an EntityManager to access the persistence mechanism.
EntityModel<T> - Interface in org.axonframework.commandhandling.model.inspection
Interface of an entity model that describes the properties and capabilities of an entity of type T.
EntryListenerAdapter() - Constructor for class org.axonframework.common.caching.Cache.EntryListenerAdapter
 
entrySet() - Method in class org.axonframework.messaging.MetaData
 
EqualFieldsMatcher<T> - Class in org.axonframework.test.matchers
Matcher that will match an Object if all the fields on that Object contain values equal to the same field in the expected instance.
EqualFieldsMatcher(T) - Constructor for class org.axonframework.test.matchers.EqualFieldsMatcher
Initializes an EqualFieldsMatcher that will match an object with equal properties as the given expected object.
EqualFieldsMatcher(T, FieldFilter) - Constructor for class org.axonframework.test.matchers.EqualFieldsMatcher
Initializes an EqualFieldsMatcher that will match an object with equal properties as the given expected object.
equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.SimpleMember
 
equals(Object) - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
 
equals(Object) - Method in class org.axonframework.eventhandling.saga.AssociationValue
 
equals(Object) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
 
equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
 
equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
 
equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
 
equals(Object) - Method in class org.axonframework.messaging.MetaData
 
equals(Object) - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
 
equals(Object) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
 
equals(Object) - Method in class org.axonframework.serialization.SerializedMetaData
 
equals(Object) - Method in class org.axonframework.serialization.SimpleSerializedObject
 
equals(Object) - Method in class org.axonframework.serialization.SimpleSerializedType
 
equals(Object) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
equalTo(T) - Static method in class org.axonframework.test.matchers.Matchers
Matches against each event of the same runtime type that has all field values equal to the fields in the expected event.
equalTo(T, FieldFilter) - Static method in class org.axonframework.test.matchers.Matchers
Matches against each event of the same runtime type that has all field values equal to the fields in the expected event.
error() - Method in class org.axonframework.eventhandling.ErrorContext
Returns the error that was raised in the processor
ErrorContext - Class in org.axonframework.eventhandling
Describes the context of an error.
ErrorContext(String, Exception, List<? extends EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.ErrorContext
 
ErrorHandler - Interface in org.axonframework.eventhandling
Interface of the error handler that will be invoked if event processing fails.
EVENT_BUS_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the Event Bus in the scheduler context.
EVENT_JOB_DATA_BINDER_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the EventJobDataBinder in the scheduler context.
EVENT_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
The key used to locate the event in the JobDataMap.
eventBus(AxonConfiguration) - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
eventBus() - Method in interface org.axonframework.config.Configuration
Retrieves the Event Bus defined in this Configuration.
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.
eventBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
eventCollection() - Method in class org.axonframework.mongo.eventsourcing.eventstore.DefaultMongoTemplate
Returns a reference to the collection containing the events.
eventCollection() - Method in interface org.axonframework.mongo.eventsourcing.eventstore.MongoTemplate
Returns a reference to the collection containing the events.
eventConfiguration() - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
Returns the EventEntryConfiguration that configures how event entries are to be stored.
EventConsumer<T> - Interface in org.axonframework.test.eventscheduler
A consumer that allows implementations to throw exceptions.
EventCountSnapshotTriggerDefinition - Class in org.axonframework.eventsourcing
Snapshotter trigger mechanism that counts the number of events to decide when to create a snapshot.
EventCountSnapshotTriggerDefinition(Snapshotter, int) - Constructor for class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
Initialized the SnapshotTriggerDefinition to threshold snapshots using the given snapshotter when threshold events have been applied to an Aggregate instance
EventData<T> - Interface in org.axonframework.eventsourcing.eventstore
Interface describing the properties of serialized Event Messages.
EventEntry - Class in org.axonframework.mongo.eventsourcing.eventstore.documentperevent
Implementation of a serialized event message that can be used to create a Mongo document.
EventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
Constructor used to create a new event entry to store in Mongo.
EventEntry(Document, EventEntryConfiguration) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
Creates a new EventEntry based on data provided by Mongo.
EventEntryConfiguration - Class in org.axonframework.mongo.eventsourcing.eventstore.documentperevent
Implementation of a StorageStrategy that stores one Document per commit of a list of events.
EventEntryConfiguration.Builder - Class in org.axonframework.mongo.eventsourcing.eventstore.documentperevent
 
eventHandled(EventMessage<?>) - Method in interface org.axonframework.eventsourcing.SnapshotTrigger
Invoked when an event is handled by an aggregate.
EventHandler - Annotation Type in org.axonframework.eventhandling
Annotation to be placed on methods that can handle events.
EventHandlerInvoker - Interface in org.axonframework.eventhandling
Interface for an event message handler that defers handling to one or more other handlers.
EventHandlerRegistrar - Class in org.axonframework.spring.config
Spring Bean that registers Event Handler beans with the EventHandlingConfiguration.
EventHandlerRegistrar(AxonConfiguration, EventHandlingConfiguration) - Constructor for class org.axonframework.spring.config.EventHandlerRegistrar
Initialize the registrar to register beans discovered with the given eventHandlingConfiguration.
EventHandlingConfiguration - Class in org.axonframework.config
Module Configuration implementation that defines an Event Handling component.
EventHandlingConfiguration() - Constructor for class org.axonframework.config.EventHandlingConfiguration
Creates a default configuration for an Event Handling module that assigns Event Handlers to Subscribing Event Processors based on the package they're in.
EventHandlingConfiguration.EventProcessorBuilder - Interface in org.axonframework.config
Interface describing a Builder function for Event Processors.
eventIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the identifier of the event.
eventIdentifierProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the identifier of the event.
EventJobDataBinder - Interface in org.axonframework.eventhandling.scheduling.quartz
Strategy towards reading/writing an Axon EventMessage from/to a Quartz JobDataMap.
EventListener - Interface in org.axonframework.eventhandling
Interface to be implemented by classes that can handle events.
EventListenerProxy - Interface in org.axonframework.eventhandling
Specialist interface for implementations of an event listener that redirect actual processing to another instance.
EventLoggingInterceptor - Class in org.axonframework.eventhandling.interceptors
Message Dispatch Interceptor that logs published events to a SLF4J logger.
EventLoggingInterceptor() - Constructor for class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
Initialize the LoggingInterceptor with the default logger name, which is the fully qualified class name of this logger.
EventLoggingInterceptor(String) - Constructor for class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
Initialize the interceptor with the given loggerName.
eventMatching(Predicate<? super T>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
Returns a Predicate for a ConflictResolver that responds affirmative if any event in a list of unseen events matches the given messageFilter.
EventMessage<T> - Interface in org.axonframework.eventhandling
Represents a Message wrapping an Event, which is represented by its payload.
EventMessageConverter - Interface in org.axonframework.spring.messaging
Interface describing a mechanism that converts Spring Messages from an Axon Event Messages and vice versa.
EventMessageReader - Class in org.axonframework.amqp.eventhandling.legacy
Reader that reads EventMessage instances written to the underlying input.
EventMessageReader(DataInputStream, Serializer) - Constructor for class org.axonframework.amqp.eventhandling.legacy.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.amqp.eventhandling.legacy
Enumeration of supported Message Types by the EventMessageWriter and EventMessageReader.
EventMessageWriter - Class in org.axonframework.amqp.eventhandling.legacy
Writer that writes Event Messages onto a an OutputStream.
EventMessageWriter(DataOutput, Serializer) - Constructor for class org.axonframework.amqp.eventhandling.legacy.EventMessageWriter
Creates a new EventMessageWriter writing data to the specified underlying output.
EventMultiUpcaster - Class in org.axonframework.serialization.upcasting.event
Abstract implementation of a SingleEntryMultiUpcaster and an EventUpcaster that eases the common process of upcasting one intermediate event representation to several other representations by applying a flat mapping function to the input stream of intermediate representations.
EventMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.EventMultiUpcaster
 
EventProcessingException - Exception in org.axonframework.eventhandling
Exception thrown when an EventProcessor failed to handle a batch of events.
EventProcessingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.EventProcessingException
Initialize the exception with given message and cause.
EventProcessingStrategy - Interface in org.axonframework.eventhandling
Interface describing a strategy for the processing of a batch of events.
eventProcessor() - Method in class org.axonframework.eventhandling.ErrorContext
Returns the name of the Event Processor where the error occurred.
EventProcessor - Interface in org.axonframework.eventhandling
An Event Processor processes event messages from an event queue or event bus.
EventProcessorLatencyMonitor - Class in org.axonframework.metrics
Measures the difference in message timestamps between the last ingested and the last processed message.
EventProcessorLatencyMonitor() - Constructor for class org.axonframework.metrics.EventProcessorLatencyMonitor
 
EventProcessorProperties - Class in org.axonframework.boot
 
EventProcessorProperties() - Constructor for class org.axonframework.boot.EventProcessorProperties
 
EventProcessorProperties.Mode - Enum in org.axonframework.boot
 
EventProcessorProperties.ProcessorSettings - Class in org.axonframework.boot
 
EventProcessorTask - Class in org.axonframework.eventhandling.async
Scheduler that keeps track of (Event processing) tasks that need to be executed sequentially.
EventProcessorTask(Executor, EventProcessorTask.ShutdownCallback) - Constructor for class org.axonframework.eventhandling.async.EventProcessorTask
Initialize a scheduler using the given executor.
EventProcessorTask.ShutdownCallback - Interface in org.axonframework.eventhandling.async
Callback that allows the SequenceManager to receive a notification when this scheduler finishes processing events.
EventPublicationFailedException - Exception in org.axonframework.amqp.eventhandling
Exception indication that an error occurred while publishing an event to an AMQP Broker
EventPublicationFailedException(String, Throwable) - Constructor for exception org.axonframework.amqp.eventhandling.EventPublicationFailedException
Initialize the exception using given descriptive message and cause
EventPublisher - Class in org.axonframework.commandhandling.disruptor
Component of the DisruptorCommandBus that stores and publishes events generated by the command's execution.
EventPublisher(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.
EventScheduler - Interface in org.axonframework.eventhandling.scheduling
Interface towards a mechanism capable of scheduling the publication of events.
EventSchedulerValidator - Class in org.axonframework.test.saga
Helper class for validating evets scheduled in a given event scheduler.
EventSchedulerValidator(StubEventScheduler) - Constructor for class org.axonframework.test.saga.EventSchedulerValidator
Initializes the validator to validate the state of the given eventScheduler.
EventSchema - Class in org.axonframework.eventsourcing.eventstore.jdbc
Schema of an event entry to be stored using Jdbc.
EventSchema() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Initializes the default Event Schema
EventSchema.Builder - Class in org.axonframework.eventsourcing.eventstore.jdbc
Builder for an EventSchema that gets initialized with default values.
EventSourcedAggregate<T> - Class in org.axonframework.eventsourcing
Implementation of an Aggregate that is sourced from events that have been published by the aggregate.
EventSourcedAggregate(T, AggregateModel<T>, EventBus, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
Initializes an Aggregate instance for the given aggregateRoot, based on the given model, which publishes events to the given eventBus.
EventSourcedAggregate(AggregateModel<T>, EventBus, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
Creates a new EventSourcedAggregate instance based on the given model, which publishes events to the given eventBus.
EventSourcingHandler - Annotation Type in org.axonframework.eventsourcing
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> - 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(Class<T>, EventStore, SnapshotTriggerDefinition) - 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, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initializes a repository with the default locking strategy, using the given aggregateFactory to create new aggregate instances and triggering snapshots using the given snapshotTriggerDefinition
EventSourcingRepository(AggregateFactory<T>, EventStore, ParameterResolverFactory, SnapshotTriggerDefinition) - 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, LockFactory, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initialize a repository with the given locking strategy.
EventSourcingRepository(AggregateFactory<T>, EventStore, LockFactory, ParameterResolverFactory, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Initialize a repository with the given locking strategy and parameter resolver factory.
eventsProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntryConfiguration
Returns the name of the property containing the array of event entries.
eventStorageEngine(Serializer, PersistenceExceptionResolver, AxonConfiguration, EntityManagerProvider, TransactionManager) - Method in class org.axonframework.boot.autoconfig.JpaAutoConfiguration
 
EventStorageEngine - Interface in org.axonframework.eventsourcing.eventstore
Provides a mechanism to append as well as retrieve events from an underlying storage like a database.
eventStore(EventStorageEngine, AxonConfiguration) - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
eventStore() - Method in interface org.axonframework.config.Configuration
Returns the Event Store in this Configuration, if it is defined.
EventStore - Interface in org.axonframework.eventsourcing.eventstore
Provides a mechanism to open streams from events in the the underlying event storage.
EventStoreException - Exception in org.axonframework.eventsourcing.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.eventsourcing.eventstore.EventStoreException
Initialize the exception with the given message.
EventStoreException(String, Throwable) - Constructor for exception org.axonframework.eventsourcing.eventstore.EventStoreException
Initialize the exception with the given message and cause
EventTableFactory - Interface in org.axonframework.eventsourcing.eventstore.jdbc
Interface describing a factory for JDBC to create the Domain and Snapshot Event tables.
EventUpcaster - Interface in org.axonframework.serialization.upcasting.event
Interface that is used for upcasters of event data.
EventUpcasterChain - Class in org.axonframework.serialization.upcasting.event
Upcaster chain used to upcast event representations.
EventUpcasterChain(EventUpcaster...) - Constructor for class org.axonframework.serialization.upcasting.event.EventUpcasterChain
Initializes an upcaster chain from one or more upcasters.
EventUpcasterChain(List<? extends EventUpcaster>) - Constructor for class org.axonframework.serialization.upcasting.event.EventUpcasterChain
Initializes an upcaster chain from the given list of upcasters.
EventUtils - Class in org.axonframework.eventsourcing.eventstore
Utility class for dealing with events and event streams.
EventValidator - Class in org.axonframework.test.saga
Helper class for validating events published on a given EventBus.
EventValidator(EventBus, FieldFilter) - Constructor for class org.axonframework.test.saga.EventValidator
Initializes the event validator to monitor the given eventBus.
ExactSequenceMatcher<T> - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers against the event in a list at their respective index.
ExactSequenceMatcher(Matcher<? super T>...) - Constructor for class org.axonframework.test.matchers.ExactSequenceMatcher
Construct a matcher that will return true if all the given matchers match against the event with the same index in a given List if Events.
exactSequenceOf(Matcher<? super T>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a List of Events if each of the given matchers matches against the event at the respective index in the list.
ExceptionUtils - Class in org.axonframework.common
Exception utility methods.
execute(Consumer<T>) - Method in interface org.axonframework.commandhandling.model.Aggregate
Execute a method on the underlying aggregate or one of its instances.
execute(Runnable) - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
Executes the given task.
execute(Consumer<T>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
execute(Consumer<AR>) - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
execute(Runnable) - Method in class org.axonframework.common.DirectExecutor
Executes the given command immediately in the current thread.
execute(Consumer<T>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
 
execute(Consumer<T>) - Method in interface org.axonframework.eventhandling.saga.Saga
Execute the given invocation against the root object of this Saga instance.
execute(Runnable) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
SagaLifecycle instance method to execute given task in the context of this SagaLifeCycle.
execute(JobExecutionContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
 
execute(Runnable) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Execute the given task in the context of this Unit of Work.
execute(Runnable, RollbackConfiguration) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Execute the given task in the context of this Unit of Work.
executeBatch(Connection, JdbcUtils.SqlFunction, Consumer<SQLException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Execute the a batch update or insert statement produced by the given sqlFunction.
executeInTransaction(Runnable) - Method in interface org.axonframework.common.transaction.TransactionManager
Executes the given task in a new Transaction.
executeQuery(Connection, JdbcUtils.SqlFunction, JdbcUtils.SqlResultConverter<R>, Function<SQLException, RuntimeException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Execute the query given by the sqlFunction.
executeUpdates(Connection, Consumer<SQLException>, JdbcUtils.SqlFunction...) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Execute the update statements produced by the given sqlFunctions.
executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Execute the given task in the context of this Unit of Work.
executeWithResult(Callable<V>) - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
Executes the given task and returns the result of the task.
executeWithResult(Callable<V>) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
SagaLifecycle instance method to execute given task in the context of this SagaLifeCycle.
executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Execute the given task in the context of this Unit of Work.
executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
executeWithResult(Callable<R>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Execute the given task in the context of this Unit of Work.
executeWithResult(Callable<R>, RollbackConfiguration) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Execute the given task in the context of this Unit of Work.
ExecutionException - Exception in org.axonframework.messaging
Exception thrown to indicate that execution of a task has failed.
ExecutionException(String, Throwable) - Constructor for exception org.axonframework.messaging.ExecutionException
Initialize an ExecutionException with the given message and cause.
ExecutionResult - Class in org.axonframework.messaging.unitofwork
Class of objects that contain the result of an executed task.
ExecutionResult(Object) - Constructor for class org.axonframework.messaging.unitofwork.ExecutionResult
Initializes an ExecutionResult from the given object.
expectActiveSagas(int) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Expect the given number of Sagas to be active (i.e.
expectActiveSagas(int) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectAssociationWith(String, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that at least one of the active sagas is associated with the given associationKey and associationValue.
expectAssociationWith(String, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectDispatchedCommands(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that the given commands have been dispatched in exactly the order given.
expectDispatchedCommands(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectDispatchedCommandsMatching(Matcher<? extends List<? super CommandMessage<?>>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that the sagas dispatched commands as defined by the given matcher.
expectDispatchedCommandsMatching(Matcher<? extends List<? super CommandMessage<?>>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectedSourceType() - Method in class org.axonframework.mongo.serialization.DBObjectToStringContentTypeConverter
 
expectedSourceType() - Method in class org.axonframework.mongo.serialization.DocumentToStringContentTypeConverter
 
expectedSourceType() - Method in class org.axonframework.mongo.serialization.StringToDBObjectContentTypeConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.ChainedConverter
 
expectedSourceType() - Method in interface org.axonframework.serialization.ContentTypeConverter
The expected type of input data.
expectedSourceType() - Method in class org.axonframework.serialization.converters.BlobToInputStreamConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.converters.ByteArrayToStringConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.converters.StringToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.xml.InputStreamToDom4jConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.xml.InputStreamToXomConverter
 
expectedSourceType() - Method in class org.axonframework.serialization.xml.XomToStringConverter
 
expectEvents(Object...) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the given set of events to have been published.
expectEvents(Object...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the published events to match the given matcher.
expectEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectException(Class<? extends Throwable>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the given expectedException to occur during command handler execution.
expectException(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect an exception to occur during command handler execution that matches with the given matcher.
expectException(Class<? extends Throwable>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectException(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoAssociationWith(String, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that at none of the active sagas is associated with the given associationKey and associationValue.
expectNoAssociationWith(String, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoDispatchedCommands() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that the sagas did not dispatch any commands.
expectNoDispatchedCommands() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoEvents() - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect no events to have been published from the command.
expectNoScheduledEvents() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that no events are scheduled for publication.
expectNoScheduledEvents() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectPublishedEvents(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that the saga published events on the EventBus in the exact sequence of the given expected events.
expectPublishedEvents(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectPublishedEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that the saga published events on the EventBus as defined by the given matcher.
expectPublishedEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectReply - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
expectReturnValue(Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the command handler to return the given expectedReturnValue after execution.
expectReturnValue(Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectReturnValueMatching(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the command handler to return a value that matches the given matcher after execution.
expectReturnValueMatching(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledEvent(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event equal to the given ApplicationEvent has been scheduled for publication after the given duration.
expectScheduledEvent(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event equal to the given ApplicationEvent has been scheduled for publication at the given scheduledTime.
expectScheduledEvent(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEvent(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event matching the given matcher has been scheduled to be published after the given duration.
expectScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event matching the given matcher has been scheduled to be published at the given scheduledTime.
expectScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event of the given eventType has been scheduled for publication after the given duration.
expectScheduledEventOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event of the given eventType has been scheduled for publication at the given scheduledTime.
expectScheduledEventOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEventOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectSuccessfulHandlerExecution() - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect a successful execution of the given command handler, regardless of the actual return value.
expectSuccessfulHandlerExecution() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
explicitlyUnequal(Object, Object) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the two given objects are not the same, override an equals method that indicates they are not equal, or implements Comparable which indicates the two are not equal.
extendClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
extendClaim(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Extends the claim on the current token held by the this node for the given processorName and segment.
extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
Extracts the AssociationValues from the given event as relevant for a Saga of given sagaType.
extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSagaManager
 
extractEvents(Document) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
Retrieves event data from the given Mongo object.
extractEvents(Document) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
 
extractEvents(Document) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.DocumentPerEventStorageStrategy
 
extractSnapshot(Document) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
Retrieves snapshot event data from the given Mongo object.
extractSnapshot(Document) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.DocumentPerCommitStorageStrategy
 
extractSnapshot(Document) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.DocumentPerEventStorageStrategy
 

F

fail(Throwable) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
Invokes CommandCallback.onFailure(CommandMessage, Throwable) with given exception on the wrapped callback.
failedEvents() - Method in class org.axonframework.eventhandling.ErrorContext
The events part of the batch that failed.
failedMatcherMessage() - Method in class org.axonframework.test.matchers.ListMatcher
The message to append behind a failing matcher.
failedMatcherMessage() - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
FailureLoggingCallback<C,R> - Class in org.axonframework.commandhandling.callbacks
A CommandCallback implementation wrapping another, that concisely logs failed commands.
FailureLoggingCallback(CommandCallback<C, R>) - Constructor for class org.axonframework.commandhandling.callbacks.FailureLoggingCallback
Initialize the callback to delegate calls to the given delegate, logging failures on a logger for this class (on warn level).
FailureLoggingCallback(Logger, CommandCallback<C, R>) - Constructor for class org.axonframework.commandhandling.callbacks.FailureLoggingCallback
Initialize the callback to delegate calls to the given delegate, logging failures on the given logger (on warn level).
fetchAndRemove(String) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
Fetches and removes a callback.
fetchDomainEvents(String, long, int) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Returns a batch of events published by an aggregate with given aggregateIdentifier.
fetchDomainEvents(String, long, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
fetchDomainEvents(String, long, int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
fetchDomainEvents(String, long, int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
 
fetchInTransaction(Supplier<T>) - Method in interface org.axonframework.common.transaction.TransactionManager
Invokes the given supplier in a transaction managed by the current TransactionManager.
fetchToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
fetchToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
fetchToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
fetchToken(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Returns the last stored token for the given processorName and segment.
fetchTrackedEvents(TrackingToken, int) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Returns a batch of serialized event data entries in the event storage that have a TrackingToken greater than the given lastToken.
fetchTrackedEvents(TrackingToken, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
fetchTrackedEvents(TrackingToken, int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
fetchTrackedEvents(TrackingToken, int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
 
FieldFilter - Interface in org.axonframework.test.matchers
The FieldFilter indicates whether any given Field should be accepted for processing or not.
fieldsOf(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Returns an Iterable of all the fields declared on the given class and its super classes.
find(AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
 
find(AssociationValue) - Method in interface org.axonframework.eventhandling.saga.SagaRepository
Find saga instances of the given type that have been associated with the given associationValue.
findAnnotation(AnnotatedElement, Class<T>) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Find an annotation of given annotationType on the given element, considering that the given annotationType may be present as a meta annotation on any other annotation on that element.
findAnnotation(AnnotatedElement, String) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Find an annotation of given annotationType as String on the given element, considering that the given annotationType may be present as a meta annotation on any other annotation on that element.
findAnnotationAttributes(AnnotatedElement, String) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Find the attributes of an annotation with given annotationName on the given element.
findAnnotationAttributes(AnnotatedElement, Class<? extends Annotation>) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Find the attributes of an annotation of type annotationType on the given element.
findDestination(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.CommandRouter
Returns the member instance to which the given message should be routed.
findDestination(CommandMessage<?>) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
findDestination(CommandMessage<?>) - Method in class org.axonframework.springcloud.commandhandling.SpringCloudCommandRouter
 
findDomainEvents(MongoCollection<Document>, String, long, int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
 
findDomainEvents(MongoCollection<Document>, String, long, int) - Method in interface org.axonframework.mongo.eventsourcing.eventstore.StorageStrategy
Returns a batch of events for an aggregate with given aggregateIdentifier and a sequence number equal or higher than the given firstSequenceNumber.
findException(Throwable, Predicate<Throwable>) - Static method in class org.axonframework.common.ExceptionUtils
Checks if the given exception matches the given predicate.
findException(Throwable, Class<T>) - Static method in class org.axonframework.common.ExceptionUtils
Checks if the given exception class is an instance of the given exceptionClass.
findHandlerMethods(EventMessage<?>) - Method in interface org.axonframework.eventhandling.saga.metamodel.SagaModel
Returns a List of event handlers that can handle the given event.
findLastSnapshot(MongoCollection<Document>, String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
 
findLastSnapshot(MongoCollection<Document>, String) - Method in interface org.axonframework.mongo.eventsourcing.eventstore.StorageStrategy
Finds the entry containing the last snapshot event for an aggregate with given aggregateIdentifier in the given collection.
findResource(Class<R>) - Method in class org.axonframework.config.ConfigurationResourceInjector
 
findResource(Class<R>) - Method in class org.axonframework.eventhandling.saga.AbstractResourceInjector
Returns a resource of given requiredType or an empty Optional if the resource is not registered with the injector.
findResource(Class<R>) - Method in class org.axonframework.eventhandling.saga.SimpleResourceInjector
 
findResource(Class<R>) - Method in class org.axonframework.test.utils.AutowiredResourceInjector
 
findSagas(String, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
Returns the identifiers of the Sagas that have been associated with the given associationValue.
findSagas(Class<? extends T>, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
 
findSagas(Class<?>, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
 
findSagas(Class<?>, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
 
findSagas(Class<?>, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
 
findSagas(Class<? extends T>, AssociationValue) - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore
Returns identifiers of saga instances of the given sagaType that have been associated with the given associationValue.
findSagas(Class<?>, AssociationValue) - Method in class org.axonframework.mongo.eventhandling.saga.repository.MongoSagaStore
 
findTrackedEvents(MongoCollection<Document>, TrackingToken, int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
 
findTrackedEvents(MongoCollection<Document>, TrackingToken, int) - Method in interface org.axonframework.mongo.eventsourcing.eventstore.StorageStrategy
Returns a batch of tracked events with a tracking token above the given lastToken.
FireEventJob - Class in org.axonframework.eventhandling.scheduling.quartz
Quartz Job that publishes an event on an Event Bus.
FireEventJob() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
 
FIRST - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should be the very first
firstSequenceNumberProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntryConfiguration
Returns the name of the property containing the sequence number of the first event entry.
firstTimestampProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntryConfiguration
Returns the name of the property containing the timestamp of the first event entry of the commit.
FixedValueParameterResolver<T> - Class in org.axonframework.messaging.annotation
ParameterResolver implementation that injects a fixed value.
FixedValueParameterResolver(T) - Constructor for class org.axonframework.messaging.annotation.FixedValueParameterResolver
Initialize the ParameterResolver to inject the given value for each incoming message.
FixedValueRevisionResolver - Class in org.axonframework.serialization
RevisionResolver implementation that returns a fixed value as revision, regardless of the type of serialized object involved.
FixedValueRevisionResolver(String) - Constructor for class org.axonframework.serialization.FixedValueRevisionResolver
Initializes the FixedValueRevisionResolver to always return the given revision, when asked.
FixtureConfiguration<T> - Interface in org.axonframework.test.aggregate
Interface describing the operations available on a test fixture in the configuration stage.
FixtureConfiguration - Interface in org.axonframework.test.saga
Interface describing action to perform on a Saga Test Fixture during the configuration phase.
FixtureExecutionException - Exception in org.axonframework.test
Exception indicating that an error occurred that prevented successful execution of a test fixture.
FixtureExecutionException(String) - Constructor for exception org.axonframework.test.FixtureExecutionException
Construct the exception with the given message.
FixtureExecutionException(String, Throwable) - Constructor for exception org.axonframework.test.FixtureExecutionException
Construct the exception with the given message and cause.
FixtureExecutionResult - Interface in org.axonframework.test.saga
Interface towards an object that contains the results of a Fixture execution.
FixtureExecutionResultImpl<T> - Class in org.axonframework.test.saga
Default implementation of FixtureExecutionResult.
FixtureResourceParameterResolverFactory - Class in org.axonframework.test
ParameterResolverFactory implementation for use in test cases that prevent that all declared resources on message handlers need to be configured.
FixtureResourceParameterResolverFactory() - Constructor for class org.axonframework.test.FixtureResourceParameterResolverFactory
 
flush() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
forClass(Class<?>) - Static method in class org.axonframework.messaging.annotation.ClasspathParameterResolverFactory
Creates an instance for the given clazz.
forClassLoader(ClassLoader) - Static method in class org.axonframework.messaging.annotation.ClasspathParameterResolverFactory
Creates an instance using the given classLoader.
formatInstant(TemporalAccessor) - Static method in class org.axonframework.common.DateTimeUtils
Formats the given instant to ISO8601 format including at least 3 positions for milliseconds.
forMessage(EventMessage) - Static method in enum org.axonframework.amqp.eventhandling.legacy.EventMessageType
Returns the most specific EventMessageType for the given message.
from(Map<String, ?>) - Static method in class org.axonframework.messaging.MetaData
Creates a new MetaData instance from the given metaDataEntries.
fromDBObject(DBObject) - Static method in class org.axonframework.mongo.serialization.BSONNode
Constructrs a BSONNode structure from the given DBObject structure.
fromJobData(JobDataMap) - Method in interface org.axonframework.eventhandling.scheduling.quartz.EventJobDataBinder
Read an EventMessage (or its payload) from the JobDataMap.
fromJobData(JobDataMap) - Method in class org.axonframework.eventhandling.scheduling.quartz.LegacyAwareJobDataBinder
 
fromJobData(JobDataMap) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
 
fromTypeByte(byte) - Static method in enum org.axonframework.amqp.eventhandling.legacy.EventMessageType
Returns the EventMessageType identified by the given typeByte.
FullConcurrencyPolicy - Class in org.axonframework.eventhandling.async
SequencingPolicy that does not enforce any sequencing requirements on event processing.
FullConcurrencyPolicy() - Constructor for class org.axonframework.eventhandling.async.FullConcurrencyPolicy
 
FutureCallback<C,R> - Class in org.axonframework.commandhandling.callbacks
Command Handler Callback that allows the dispatching thread to wait for the result of the callback, using the Future mechanism.
FutureCallback() - Constructor for class org.axonframework.commandhandling.callbacks.FutureCallback
 

G

GapAwareTrackingToken - Class in org.axonframework.eventsourcing.eventstore
Implementation of a TrackingToken that uses the global insertion sequence number of the event to determine tracking order and additionally stores a set of possible gaps that have been detected while tracking the event store.
generateIdentifier() - Method in class org.axonframework.common.DefaultIdentifierFactory
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
generateIdentifier() - Method in class org.axonframework.common.IdentifierFactory
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
GenericAggregateFactory<T> - 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.
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(Message<T>, String) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
Create a CommandMessage from the given delegate message containing payload, metadata and message identifier, and the given commandName.
GenericDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
Generic implementation of a serialized domain event entry.
GenericDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.GenericDomainEventEntry
Reconstruct an event entry from a stored object.
GenericDomainEventMessage<T> - Class in org.axonframework.eventsourcing
Generic implementation of a DomainEventMessage.
GenericDomainEventMessage(String, String, long, T) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier, with given sequenceNumber and payload.
GenericDomainEventMessage(String, String, long, T, Map<String, ?>) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier, with given sequenceNumber and payload and metaData.
GenericDomainEventMessage(String, String, long, T, Map<String, ?>, String, Instant) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate using existing data.
GenericDomainEventMessage(String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate using existing data.
GenericDomainEventMessage(String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier, with given sequenceNumber and payload, metaData and timestamp.
GenericEventMessage<T> - Class in org.axonframework.domain
Deprecated.
this class is available for backward compatibility with instances that were serialized with Axon 2. Use GenericEventMessage instead.
GenericEventMessage() - Constructor for class org.axonframework.domain.GenericEventMessage
Deprecated.
 
GenericEventMessage<T> - Class in org.axonframework.eventhandling
Generic implementation of the EventMessage interface.
GenericEventMessage(T) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
Creates a GenericEventMessage with given payload, and an empty MetaData.
GenericEventMessage(T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
Creates a GenericEventMessage with given payload and given metaData.
GenericEventMessage(String, T, Map<String, ?>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
Constructor to reconstruct an EventMessage using existing data.
GenericEventMessage(Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
Constructor to reconstruct an EventMessage using existing data.
GenericEventMessage(Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
Initializes a GenericEventMessage with given message as delegate and given timestamp.
GenericJpaRepository<T> - Class in org.axonframework.commandhandling.model
Generic repository implementation that stores JPA annotated aggregates.
GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType.
GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus, Function<String, ?>) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType.
GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType.
GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus, LockFactory) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType with an additional LockFactory.
GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus, LockFactory, Function<String, ?>) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType with an additional LockFactory and allowing for a custom identifierConverter to convert a String based identifier to an Identifier Object.
GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus, LockFactory, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType with an additional LockFactory.
GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus, LockFactory, ParameterResolverFactory, Function<String, ?>) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
Initialize a repository for storing aggregates of the given aggregateType with an additional LockFactory and allowing for a custom identifierConverter to convert a String based identifier to an Identifier Object.
GenericMessage<T> - Class in org.axonframework.domain
Deprecated.
this class is available for backward compatibility with instances that were serialized with Axon 2. Use GenericMessage instead.
GenericMessage() - Constructor for class org.axonframework.domain.GenericMessage
Deprecated.
 
GenericMessage<T> - Class in org.axonframework.messaging
Generic implementation of a Message that contains the payload and metadata as unserialized values.
GenericMessage(T) - Constructor for class org.axonframework.messaging.GenericMessage
Constructs a Message for the given payload using the correlation data of the current Unit of Work, if present.
GenericMessage(T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
Constructs a Message for the given payload and meta data.
GenericMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
Constructor to reconstruct a Message using existing data.
GenericSagaSqlSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
Generic SagaSqlSchema implementation, for use in most databases.
GenericSagaSqlSchema() - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
Initialize a GenericSagaSqlSchema using default settings.
GenericSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
Initialize a GenericSagaSqlSchema.
GenericTokenEntry<T> - Class in org.axonframework.eventhandling.tokenstore
Generic implementation of a token entry.
GenericTokenEntry(TrackingToken, Serializer, Class<T>, String, int) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
Initializes a new token entry for given token, process and segment.
GenericTokenEntry(T, String, String, String, String, int, Class<T>) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
Initializes a token entry from existing data.
GenericTokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
Jdbc token entry table factory compatible with most databases.
GenericTokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
 
GenericTrackedDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
Deprecated.
Use TrackedDomainEventData instead, as it uses composition (instead of inheritance)
GenericTrackedDomainEventEntry(TrackingToken, String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.GenericTrackedDomainEventEntry
Deprecated.
Reconstruct an event entry from a stored object.
GenericTrackedDomainEventEntry(long, String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.GenericTrackedDomainEventEntry
Deprecated.
Reconstruct an event entry from a stored object.
GenericTrackedDomainEventMessage<T> - Class in org.axonframework.eventsourcing
Generic implementation of a DomainEventMessage that is also a TrackedEventMessage.
GenericTrackedDomainEventMessage(TrackingToken, DomainEventMessage<T>) - Constructor for class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
Initialize a DomainEventMessage originating from an aggregate.
GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate using existing data.
GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
Initialize a DomainEventMessage originating from an aggregate.
GenericTrackedEventMessage<T> - Class in org.axonframework.eventhandling
Generic implementation of a TrackedEventMessage.
GenericTrackedEventMessage(TrackingToken, EventMessage<T>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
Creates a GenericTrackedEventMessage with given trackingToken and delegate event message.
GenericTrackedEventMessage(TrackingToken, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
Creates a GenericTrackedEventMessage with given trackingToken and delegate event message.
GenericTrackedEventMessage(TrackingToken, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
Initializes a GenericTrackedEventMessage with given message as delegate and given timestamp.
GenericUpcasterChain<T> - Class in org.axonframework.serialization.upcasting
Implementation of an Upcaster that is formed of a chain of other upcasters which are combined to upcast a stream of intermediate objects.
GenericUpcasterChain(Upcaster<T>...) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
Initializes an upcaster chain from one or more upcasters.
GenericUpcasterChain(List<? extends Upcaster<T>>) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
Initializes an upcaster chain from the given list of upcasters.
get(K) - Method in interface org.axonframework.common.caching.Cache
Returns an item from the cache, or null if no item was stored under that key
get(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
get(K) - Method in class org.axonframework.common.caching.JCacheAdapter
 
get(K) - Method in class org.axonframework.common.caching.NoCache
 
get(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
get() - Method in class org.axonframework.config.Component
Retrieves the object contained in this component, triggering the builder function if the component hasn't been built yet.
get(Object) - Method in class org.axonframework.messaging.MetaData
 
get() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
Gets the UnitOfWork bound to the current thread.
get() - Method in class org.axonframework.serialization.CachingSupplier
 
getActualVersion() - Method in exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
Returns the actual version of the aggregate, as loaded by the repository.
getAdapterInterfaces() - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
Returns the interface that the adapter implements to connect the annotated method to the actual interface definition.
getAdapterInterfaces() - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
 
getAggregateFactory(Class<?>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
Returns the AggregateFactory registered for the given aggregateType, or null if no such AggregateFactory is known.
getAggregateFactory() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Returns the factory used by this repository.
getAggregateFactory(Class<?>) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
 
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 exception org.axonframework.commandhandling.model.AggregateNotFoundException
Returns the identifier of the aggregate that could not be found.
getAggregateIdentifier() - Method in exception org.axonframework.commandhandling.model.AggregateRolledBackException
Returns the identifier of the compromised aggregate.
getAggregateIdentifier() - Method in exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
Returns the identifier of the aggregate which version is not as expected.
getAggregateIdentifier() - Method in interface org.axonframework.eventsourcing.DomainEventMessage
Returns the identifier of the Aggregate that generated this DomainEvent.
getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
 
getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
 
getAggregateIdentifier() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventData
Returns the Identifier of the Aggregate to which the Event was applied.
getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
 
getAggregateIdentifier() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
 
getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getAggregateIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the Identifier of the Aggregate to which the Event owning the object to upcast, was applied.
getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getAggregateRoot() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Get the annotated aggregate instance.
getAggregateType() - Method in class org.axonframework.commandhandling.model.AbstractRepository
Returns the aggregate type stored by this repository.
getAggregateType() - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
 
getAggregateType() - Method in interface org.axonframework.eventsourcing.AggregateFactory
Returns the type of aggregate this factory creates.
getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getAggregateType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the Type of the Aggregate to which the Event owning the object to upcast, was applied.
getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getAggregateType() - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
 
getAssociationValue() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
Returns the association value contained in this entry.
getAssociationValue(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
The AssociationValue to find the saga instance with, or null if no AssociationValue can be found on the given eventMessage.
getAssociationValues() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
 
getAssociationValues() - Method in interface org.axonframework.eventhandling.saga.Saga
Returns a view on the Association Values for this saga instance.
getAssociationValues() - Method in class org.axonframework.mongo.eventhandling.saga.repository.SagaEntry
Get a set of all the Saga's associations.
getAttribute(String) - Method in class org.axonframework.mongo.serialization.BSONNode
Returns the value of the attribute with given name.
getAttribute(String) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
getAttribute(int) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
getAttributeCount() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
getAttributeName(int) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
getAttributeNames() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.spring.config.annotation.SpringContextParameterResolverFactoryBuilder
Create, if necessary, a bean definition for a ParameterResolverFactory and returns the reference to bean for use in other Bean Definitions.
getBindAddr() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
getBindPort() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
getBody() - Method in class org.axonframework.amqp.eventhandling.AMQPMessage
Returns the body of this message
getBufferSize() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the buffer size to use.
getCache() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the cache used to store Aggregates loaded by the DisruptorCommandBus.
getCallback() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Returns the CommandCallback instance for the executed command.
getChannelIdentifier() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
Returns the identifier of the channel over which the command message was sent.
getCharset() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Returns the character set used to convert character to bytes and vice versa.
getClusterName() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
getCommandBus() - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Returns the CommandBus used by this gateway.
getCommandBus() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
getCommandBus() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Returns the command bus used by this fixture.
getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the identifier of the command carried by this instance.
getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the identifier of the command for which this message is a reply.
getCommandMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the CommandMessage wrapped in this Message.
getCommandMessage(Serializer) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpDispatchMessage
 
getCommandName() - Method in interface org.axonframework.commandhandling.CommandMessage
Returns the name of the command to execute.
getCommandName() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the command name of the command carried by this instance.
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.
getComponent(Class<T>) - Method in interface org.axonframework.config.Configuration
Returns the Component declared under the given componentType, typically the interface the component implements.
getComponent(Class<T>, Supplier<T>) - Method in interface org.axonframework.config.Configuration
Returns the Component declared under the given componentType, typically the interface the component implements, reverting to the given defaultImpl if no such component is defined.
getComponent(Class<T>, Supplier<T>) - Method in class org.axonframework.spring.config.AxonConfiguration
 
getComponents() - Method in class org.axonframework.config.DefaultConfigurer
Returns a map of all registered components in this configuration.
getConfig() - Method in class org.axonframework.config.DefaultConfigurer
Returns the current Configuration object being built by this Configurer, without initializing it.
getConfigurationFile() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
getConflictResolver() - Static method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
Returns the ConflictResolver instance that can be used to resolve conflicts of an Aggregate that has been previously loaded in this Unit of Work.
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.UnitOfWorkAwareConnectionProviderWrapper
 
getConnection() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Returns a Connection to the database.
getConnection() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Returns a Connection to the database.
getConnection() - Method in class org.axonframework.spring.jdbc.SpringDataSourceConnectionProvider
 
getConnectionEndpoint(Class<T>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
 
getConnectionEndpoint(Class<T>) - Method in interface org.axonframework.commandhandling.distributed.Member
Get the endpoint of this Member given a protocol.
getConnectionEndpoint(Class<T>) - Method in class org.axonframework.commandhandling.distributed.SimpleMember
 
getConnectionsPerHost() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Getter for connectionsPerHost.
getConnectionTimeout() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Connection time out in milli seconds for doing something in mongo.
getConsistentHash() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
Returns the ConsistentHash instance that describes the current membership status.
getContentType() - Method in class org.axonframework.serialization.SerializedMetaData
 
getContentType() - Method in interface org.axonframework.serialization.SerializedObject
Returns the type of this representation's data.
getContentType() - Method in class org.axonframework.serialization.SimpleSerializedObject
 
getConverter() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Returns the Converter used by this serialized.
getConverter() - Method in class org.axonframework.serialization.JavaSerializer
 
getConverter() - Method in class org.axonframework.serialization.json.JacksonSerializer
 
getConverter() - Method in class org.axonframework.serialization.MessageSerializer
 
getConverter() - Method in interface org.axonframework.serialization.Serializer
Returns the Converter 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() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
getCorrelationData() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Get the correlation data contained in the message being processed by the Unit of Work.
getCreationPolicy() - Method in class org.axonframework.eventhandling.saga.SagaInitializationPolicy
Returns the creation policy
getCreationPolicy() - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
Returns the creation policy of the inspected method.
getCurrentDateTime() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Returns the "Current Date Time" as used by the scheduler.
getData() - Method in class org.axonframework.serialization.SerializedMetaData
 
getData() - Method in interface org.axonframework.serialization.SerializedObject
The actual data of the serialized object.
getData() - Method in class org.axonframework.serialization.SimpleSerializedObject
 
getData() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getData(Class<D>) - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getData() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Get the data of this representation.
getData(Class<D>) - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Get the data of this representation.
getData() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getData(Class<D>) - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getDefault() - Static method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntryConfiguration
Returns the default CommitEntryConfiguration.
getDefault() - Static method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Returns the default EventEntryConfiguration.
getDefaultCorrelationKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
Returns the default metadata key for the correlation id of a message.
getDefaultTraceKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
Returns the default metadata key for the trace id of a message.
getDelegate() - Method in class org.axonframework.messaging.MessageDecorator
Returns the wrapped message delegate.
getDelegates() - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
getDispatchedCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
Returns a list with all commands that have been dispatched by this command bus.
getDispatchInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the dispatch interceptors for the DisruptorCommandBus.
getDomainEventData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Extracts the next domain event entry from the given resultSet.
getEntityManager() - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
 
getEntityManager() - Method in interface org.axonframework.common.jpa.EntityManagerProvider
Returns the EntityManager instance to use.
getEntityManager() - Method in class org.axonframework.common.jpa.SimpleEntityManagerProvider
 
getError(Serializer) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the error of the command processing.
getEvent() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
The Event scheduled for publication.
getEvent() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
getEventBus() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
getEventBus() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Returns the event bus used by this fixture.
getEventIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
 
getEventIdentifier() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
Returns the identifier of the serialized event.
getEventIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
getEventIdentifier() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
 
getEvents() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntry
Returns the event entries stored as part of this commit.
getEventStore() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
Returns the event store this snapshotter uses to load domain events and store snapshot events.
getEventStore() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
getEventStore() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Returns the event store used by this fixture.
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.
getExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
Get the execution result in case the result is an exception.
getExchange() - Method in class org.axonframework.boot.AMQPProperties
 
getExecutionResult() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
 
getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Get the result of processing the Message.
getExecutionResult() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Get the result of the task that was executed by this Unit of Work.
getExecutionResults() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Returns a Map of ExecutionResult per Message.
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.commandhandling.model.ConflictingAggregateVersionException
Returns the version expected by the component loading the aggregate.
getFailedField() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
Returns the field that failed comparison, if any.
getFailedFieldActualValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
Returns the actual value of a failed field comparison, if any.
getFailedFieldExpectedValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
Returns the expected value of a failed field comparison, if any.
getFieldValue(Field, Object) - Static method in class org.axonframework.common.ReflectionUtils
Returns the value of the given field in the given object.
getGaps() - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
Get a SortedSet of this token's gaps.
getGlobalIndex() - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
Get the global sequence number of the event
getGossip() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
getGroupIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Returns the Quartz group identifier.
getHandler(Message<?>) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
Returns the MessageHandlingMember that is capable of handling the given message.
getHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Returns a list of detected members of the inspected entity that are capable of handling certain messages.
getHosts() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties.Gossip
 
getId() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
The unique identifier of this entry.
getIdentifier(T) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
Get the identifier of the given target entity.
getIdentifier(T) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
getIdentifier() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
Returns the identifier of the targeted Aggregate.
getIdentifier() - Method in class org.axonframework.domain.GenericMessage
Deprecated.
Get the message's identifier.
getIdentifier() - Method in interface org.axonframework.eventhandling.EventMessage
Returns the identifier of this event.
getIdentifier() - Method in class org.axonframework.messaging.AbstractMessage
 
getIdentifier() - Method in interface org.axonframework.messaging.Message
Returns the identifier of this message.
getIdentifier() - Method in class org.axonframework.messaging.MessageDecorator
 
getIndex() - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
Get the highest global sequence of events seen up until the point of this tracking token.
getInitialAssociationValue() - Method in class org.axonframework.eventhandling.saga.SagaInitializationPolicy
Returns the initial association value for a newly created saga.
getInstance() - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
Returns the AggregateLifecycle for the current aggregate.
getInstance() - Static method in class org.axonframework.common.annotation.PriorityAnnotationComparator
Returns the instance of the comparator.
getInstance() - Static method in class org.axonframework.common.IdentifierFactory
Returns an instance of the IdentifierFactory discovered on the classpath.
getInstance() - Static method in class org.axonframework.common.IdentifierValidator
Returns the singleton instance of the IdentifierValidator.
getInstance() - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
Get the current SagaLifecycle instance for the current thread.
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.
getIsLive() - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
Indicates whether this Aggregate instance is 'live'.
getIsLive() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
getIsLive() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
getJgroups() - Method in class org.axonframework.boot.DistributedCommandBusProperties
 
getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Returns the Quartz job identifier.
getKey() - Method in class org.axonframework.eventhandling.saga.AssociationValue
Returns the key of this association value.
getKnownEventIds() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
Returns an Iterable with all known identifiers of events tracked before and including this token.
getLastSeparator() - Method in class org.axonframework.test.matchers.ListMatcher
The separator to use between the two last events.
getLastSeparator() - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
getLastSequenceNumber() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Get the highest known sequence number in the upstream event entry stream.
getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
getLoadFactor() - Method in class org.axonframework.boot.DistributedCommandBusProperties
 
getLoadFactor() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
getLoadFactor() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Returns the current load factor of this node.
getLoadFactor() - Method in class org.axonframework.jgroups.commandhandling.JoinMessage
Returns the loadFactor the member wishes to join with.
getMatchers() - Method in class org.axonframework.test.matchers.ListMatcher
Returns a read-only list of Matchers, in the order they were provided in the constructor.
getMaxWaitTime() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
get the maximum time a blocked thread that waits for a connection should wait.
getMember(String, CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the member instance to which the given message should be routed.
getMembers() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the set of members registered with this consistent hash instance.
getMessage() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
getMessage() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
Returns the command message that was sent.
getMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
 
getMessage() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
getMessage() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Get the Message that is being processed in this context.
getMessage() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Get the message that is being processed by the Unit of Work.
getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getMessageIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the identifier of the message wrapping the object to upcast.
getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getMessageMonitor() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the message monitor to use.
getMessages() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Get the batch of messages that is being processed (or has been processed) by this unit of work.
getMetaData() - Method in class org.axonframework.domain.GenericMessage
Deprecated.
Get the message's metadata.
getMetaData() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
 
getMetaData() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
Returns the serialized data of the MetaData of the serialized Event.
getMetaData() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
getMetaData() - Method in class org.axonframework.messaging.GenericMessage
 
getMetaData() - Method in interface org.axonframework.messaging.Message
Returns the meta data for this event.
getMetaData() - Method in class org.axonframework.messaging.MessageDecorator
 
getMetaData() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
 
getMetaData() - Method in class org.axonframework.serialization.SerializedMessage
 
getMetaData() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getMetaData() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the meta data of the message wrapping the object being upcast.
getMetaData() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getMetrics() - Method in class org.axonframework.metrics.CapacityMonitor
 
getMetrics() - Method in class org.axonframework.metrics.EventProcessorLatencyMonitor
 
getMetrics() - Method in class org.axonframework.metrics.MessageCountingMonitor
 
getMetrics() - Method in class org.axonframework.metrics.MessageTimerMonitor
 
getMetrics() - Method in class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
 
getMode() - Method in class org.axonframework.boot.EventProcessorProperties.ProcessorSettings
 
getModules() - Method in interface org.axonframework.config.Configuration
Returns all modules that have been registered with this Configuration.
getModules() - Method in class org.axonframework.spring.config.AxonConfiguration
 
getName() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
 
getName() - Method in interface org.axonframework.eventhandling.EventProcessor
Returns the name of this event processor.
getName() - Method in class org.axonframework.mongo.serialization.BSONNode
Returns the name of the current node
getName() - Method in interface org.axonframework.serialization.SerializedType
Returns the name of the serialized type.
getName() - Method in class org.axonframework.serialization.SimpleSerializedType
 
getNodeName() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
Returns the name of the current node, as it is known to the Cluster.
getNodeName() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
getNonEmptyOrDefault(T, T) - Static method in class org.axonframework.common.ObjectUtils
Returns the given instance, if not null or of zero length, or otherwise the given defaultValue.
getObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
De-serializes the object and returns the result.
getObject() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
getObject() - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
 
getObject() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
getObject() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
 
getObject() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
 
getObject() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
getObject() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
getObject() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
 
getObjectMapper() - Method in class org.axonframework.serialization.json.JacksonSerializer
Returns the ObjectMapper used by this serializer, allowing for configuration of the serialization settings.
getObjectType() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
getObjectType() - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
 
getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
getObjectType() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
 
getObjectType() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
 
getObjectType() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
getObjectType() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
getObjectType() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
 
getOrComputeResource(String, Function<? super String, R>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns the resource attached under given name.
getOrDefault(T, Supplier<T>) - Static method in class org.axonframework.common.ObjectUtils
Returns the given instance, if not null, or otherwise the value provided by defaultProvider.
getOrDefault(T, T) - Static method in class org.axonframework.common.ObjectUtils
Returns the given instance, if not null, or otherwise the given defaultValue.
getOrDefaultResource(String, R) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns the resource attached under given name.
getOwner() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the identifier of the process (JVM) having a claim on this token, or null if the token isn't claimed.
getPayload() - Method in class org.axonframework.domain.GenericMessage
Deprecated.
Get the payload of this message.
getPayload() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
 
getPayload() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
Returns the serialized data of the Event Message's payload.
getPayload() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
getPayload() - Method in class org.axonframework.messaging.GenericMessage
 
getPayload() - Method in interface org.axonframework.messaging.Message
Returns the payload of this Event.
getPayload() - Method in class org.axonframework.messaging.MessageDecorator
 
getPayload() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
 
getPayload() - Method in class org.axonframework.serialization.SerializedMessage
 
getPayloadRevision() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the payload revision of the serialized payload of the command carried by this instance.
getPayloadType() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the payload type of the serialized payload of the command carried by this instance.
getPayloadType() - Method in class org.axonframework.domain.GenericMessage
Deprecated.
Get the type of payload of this message.
getPayloadType() - Method in class org.axonframework.messaging.GenericMessage
 
getPayloadType() - Method in interface org.axonframework.messaging.Message
Returns the type of the payload.
getPayloadType() - Method in class org.axonframework.messaging.MessageDecorator
 
getPayloadType() - Method in class org.axonframework.serialization.SerializedMessage
 
getPhase() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
getPhase() - Method in class org.axonframework.spring.config.AxonConfiguration
 
getPhase() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
getPhase() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
 
getPriority() - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
 
getPriority() - Method in class org.axonframework.common.property.DirectPropertyAccessStrategy
 
getPriority() - Method in class org.axonframework.common.property.PropertyAccessStrategy
The priority of this strategy.
getPriority() - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
 
getProcessor(String) - Method in class org.axonframework.config.EventHandlingConfiguration
Returns the Event Processor with the given name, if present.
getProcessor() - Method in class org.axonframework.config.SagaConfiguration
Returns the processor that processed events for the Saga in this Configuration.
getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the name of the process to which this token belongs.
getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
 
getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
 
getProcessors() - Method in class org.axonframework.boot.EventProcessorProperties
 
getProcessors() - Method in class org.axonframework.config.EventHandlingConfiguration
Returns a list of Event Processors that have been initialized.
getProducerType() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the producer type to use.
getProperties() - Method in class org.axonframework.amqp.eventhandling.AMQPMessage
Returns the additional properties to dispatch this Message with
getProperty(Class<? extends 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.
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.serialization.json.JacksonSerializer
Provides the ObjectReader, with which objects are read from the JSON form.
getRegistry() - Method in class org.axonframework.metrics.GlobalMetricRegistry
Returns the global MetricRegistry to which components are registered.
getRepository(Class<?>) - Static method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
Returns the Repository instance for Aggregate with given typeIdentifier used by the CommandHandlerInvoker that is running on the current thread.
getRepository() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
getRepository() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Returns the repository used by this fixture.
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.ConcludesBatchParameterResolverFactory
 
getResolver() - Method in class org.axonframework.eventhandling.TimestampParameterResolverFactory
 
getResolver() - Method in class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory
 
getResolver() - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
 
getResolver() - Method in class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
 
getResource(String) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns the resource 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.
getResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
Returns the execution result.
getResultRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the result revision of the serialized result for which this message is a reply.
getResultType() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the result type of the serialized result for which this message is a reply.
getReturnValue(Serializer) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the returnValue of the command processing.
getReturnValue(Serializer) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpReplyMessage
 
getRevision() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
Returns the revision of the serialized saga
getRevision() - Method in interface org.axonframework.serialization.SerializedType
Returns the revision identifier of the serialized object.
getRevision() - Method in class org.axonframework.serialization.SimpleSerializedType
 
getRevisionResolver() - Method in class org.axonframework.serialization.json.JacksonSerializer
Returns the revision resolver used by this serializer.
getRollbackConfiguration() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Returns the RollbackConfiguration indicating for which Exceptions the DisruptorCommandBus should perform a rollback, and which exceptions should result in a Commit.
getRoutingKey() - Method in class org.axonframework.amqp.eventhandling.AMQPMessage
Returns the Routing Key this message should be dispatched with
getRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
 
getRoutingKey(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.RoutingStrategy
Generates a routing key for the given command.
getSaga(Serializer) - Method in class org.axonframework.mongo.eventhandling.saga.repository.SagaEntry
Returns the Saga instance stored in this entry.
getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
Returns the Saga Initialization Policy for a Saga of the given sagaType and event.
getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSagaManager
 
getSagaId() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
Returns the identifier of the saga contained in this entry
getSagaId() - Method in class org.axonframework.mongo.eventhandling.saga.repository.SagaEntry
Get the identifier of this Saga.
getSagaIdentifier() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
 
getSagaIdentifier() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
Returns the Saga Identifier contained in this entry.
getSagaIdentifier() - Method in interface org.axonframework.eventhandling.saga.Saga
Returns the unique identifier of this saga.
getSagaManager() - Method in class org.axonframework.config.SagaConfiguration
Returns the SagaManager responsible for managing the lifecycle and invocation of Saga instances of the type defined in this Configuration
getSagaRepository() - Method in class org.axonframework.config.SagaConfiguration
Returns the SagaRepository instance used to load Saga instances in this Configuration.
getSagaStore() - Method in class org.axonframework.config.SagaConfiguration
Returns the Saga Store used by the Saga defined in this Configuration.
getSagaType() - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
Returns the class of Saga managed by this SagaManager
getSagaType() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
Returns the type identifier of the serialized saga
getSagaType() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
Returns the type (fully qualified class name) of the Saga this association value belongs to
getScheduledItems() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Returns a view of all the scheduled Events at the time this method is called.
getScheduleTime() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
The time the event was scheduled for publication.
getScheduleTime() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
getSegment() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the segment index of the process to which this token belongs.
getSegment() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
 
getSegment() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
 
getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.FullConcurrencyPolicy
 
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
 
getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.SequentialPolicy
 
getSequenceNumber() - Method in interface org.axonframework.eventsourcing.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.eventsourcing.eventstore.AbstractDomainEventEntry
 
getSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
 
getSequenceNumber() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventData
Returns the sequence number of the event in the aggregate.
getSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
getSequenceNumber() - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
 
getSequenceNumber() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
 
getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getSequenceNumber() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the sequence number of the event in the aggregate, or an empty Optional if the message wrapping the object being upcast does not contain a sequence number.
getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the serialized metadata of the command carried by this instance.
getSerializedObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
Returns the serialized object to deserialize upon request
getSerializedPayload() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the serialized payload of the command carried by this instance.
getSerializedResult() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the serialized result for which this message is a reply.
getSerializedSaga() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
Returns the serialized form of the Saga.
getSerializedToken() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the serialized token.
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.eventsourcing.eventstore.AbstractEventStorageEngine
Get the serializer used by this storage engine when storing and retrieving events.
getSerializer() - Method in class org.axonframework.serialization.LazyDeserializingObject
Returns the serializer to deserialize this object
getSnapshotData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Extracts the next snapshot entry from the given resultSet.
getSnapshotTrigger() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
The trigger instance that monitors this aggregate to trigger a snapshot
getSocketTimeOut() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Getter for the socket timeout.
getSource() - Method in class org.axonframework.boot.EventProcessorProperties.ProcessorSettings
 
getState() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Get the state of the event processor.
getState(OutputStream) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
getSubscriptions() - Method in class org.axonframework.test.utils.RecordingCommandBus
Returns a Map will all Command Names and their Command Handler that have been subscribed to this command bus.
getTargetType() - Method in class org.axonframework.eventhandling.AnnotationEventListenerAdapter
 
getTargetType() - Method in interface org.axonframework.eventhandling.EventListenerProxy
Returns the instance type that this proxy delegates all event handling to.
getterName(String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
Returns the name of the method that is used to access the property.
getterName(String) - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
 
getterName(String) - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
 
getThreadsAllowedToBlockForConnectionMultiplier() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Getter for the amount of threads that block in relation to the amount of possible connections.
getTimestamp() - Method in interface org.axonframework.eventhandling.EventMessage
Returns the timestamp of this event.
getTimestamp() - Method in class org.axonframework.eventhandling.GenericEventMessage
 
getTimestamp() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
 
getTimestamp() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
Returns the timestamp at which the event was first created.
getTimestamp() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
getTimestamp() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
 
getTimestamp() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
Get the timestamp of the last event tracked by this token.
getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getTimestamp() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the timestamp at which the event was first created.
getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getToken(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the token, deserializing it with given serializer
getTokenId() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
Returns the identifier of the scheduled task.
getTokenType() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the SerializedType of the serialized token.
getTrackedEventData(ResultSet, GapAwareTrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Extracts the next tracked event entry from the given resultSet.
getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getTrackingToken() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the tracking token of the event, or an empty Optional if the message wrapping the object being upcast does not contain a tracking token.
getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
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.
getTransactionMode() - Method in class org.axonframework.boot.AMQPProperties
 
getType() - Method in interface org.axonframework.eventsourcing.DomainEventMessage
Returns the type of the Aggregate that generated this DomainEvent.
getType() - Method in class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
 
getType() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
 
getType() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventData
Returns the type identifier of the aggregate.
getType() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
getType() - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
 
getType() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntry
 
getType() - Method in class org.axonframework.serialization.LazyDeserializingObject
Returns the class of the serialized object.
getType() - Method in class org.axonframework.serialization.SerializedMetaData
 
getType() - Method in interface org.axonframework.serialization.SerializedObject
Returns the description of the type of object contained in the data.
getType() - Method in class org.axonframework.serialization.SimpleSerializedObject
 
getType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
getType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Returns the type and version of the data contained in this representation.
getType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
getTypeByte() - Method in enum org.axonframework.amqp.eventhandling.legacy.EventMessageType
Returns the Type Byte for this EventMessageType.
getUpcasters() - Method in class org.axonframework.serialization.upcasting.GenericUpcasterChain
Returns the list of upcasters that makes up this chain.
getValue(T) - Method in class org.axonframework.common.property.DirectlyAccessedProperty
 
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.eventhandling.saga.AssociationValue
Returns the value of this association.
getValue() - Method in class org.axonframework.mongo.serialization.BSONNode
Returns the value of the current node
getValue() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
getValues() - Method in class org.axonframework.domain.MetaData
Deprecated.
Get this metadata's mappings.
getVersion(T) - Method in interface org.axonframework.commandhandling.model.inspection.AggregateModel
Get the current version number of the given aggregate.
getVersion(T) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
getVersion() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
Returns the version of the targeted Aggregate, or null if the version is irrelevant.
getViolatingMethod() - Method in exception org.axonframework.messaging.annotation.UnsupportedHandlerException
A reference to the method that violated the event handler rules.
getViolations() - Method in exception org.axonframework.messaging.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.
getWrappedAggregate() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
Get the delegate aggregate wrapped by this instance.
getWriter() - Method in class org.axonframework.serialization.json.JacksonSerializer
Provides the ObjectWriter, with which objects are serialized to JSON form.
getXStream() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Returns a reference to the underlying XStream instance, that does the actual serialization.
given(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
given(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
given(Object...) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Configures the given domainEvents as the "given" events.
given(List<?>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Configures the given domainEvents as the "given" events.
givenAggregate(String) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Use this method to indicate that an aggregate with given identifier published certain events.
givenAggregate(String) - Method in class org.axonframework.test.saga.SagaTestFixture
 
GivenAggregateEventPublisher - Interface in org.axonframework.test.saga
Interface to an object that publishes events on behalf of an aggregate.
givenAPublished(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Indicates that the given applicationEvent has been published in the past.
givenAPublished(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
 
givenCommands(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
givenCommands(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
givenCommands(Object...) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Configures the given commands as the command that will provide the "given" events.
givenCommands(List<?>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Configures the given commands as the command that will provide the "given" events.
givenNoPriorActivity() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
givenNoPriorActivity() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Indicates that no relevant activity has occurred in the past.
givenNoPriorActivity() - Method in interface org.axonframework.test.saga.FixtureConfiguration
Indicates that no relevant activity has occurred in the past.
givenNoPriorActivity() - Method in class org.axonframework.test.saga.SagaTestFixture
 
globalIndexColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the global index of the event.
GlobalMetricRegistry - Class in org.axonframework.metrics
Registry for application metrics with convenient ways to register Axon components.
GlobalMetricRegistry() - Constructor for class org.axonframework.metrics.GlobalMetricRegistry
Initializes a new GlobalMetricRegistry delegating to a new MetricRegistry with default settings.
GlobalMetricRegistry(MetricRegistry) - Constructor for class org.axonframework.metrics.GlobalMetricRegistry
Initializes a GlobalMetricRegistry delegating to the given metricRegistry.
GlobalSequenceTrackingToken - Class in org.axonframework.eventsourcing.eventstore
Tracking token based on the global sequence number of an event.
GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
Initializes a GlobalSequenceTrackingToken from the given globalIndex of the event.
Gossip() - Constructor for class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties.Gossip
 
gossipRouter() - Method in class org.axonframework.boot.autoconfig.JGroupsAutoConfiguration
 

H

handle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
 
handle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
Invokes the @CommandHandler annotated method that accepts the given command.
handle(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.model.Aggregate
Handle the given commandMessage on the aggregate root or one of its child entities.
handle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
handle(Message<?>, P) - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
handle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
handle(EventMessage<?>) - Method in class org.axonframework.eventhandling.AnnotationEventListenerAdapter
 
handle(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
 
handle(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in enum org.axonframework.eventhandling.DirectEventProcessingStrategy
 
handle(EventMessage<?>) - Method in interface org.axonframework.eventhandling.EventListener
Process the given event.
handle(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in interface org.axonframework.eventhandling.EventProcessingStrategy
Handle the given batch of events.
handle(List<EventMessage<?>>) - Method in class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
 
handle(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
 
handle(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
 
handle(EventMessage<?>) - Method in interface org.axonframework.eventhandling.saga.Saga
Handle the given event.
handle(Message<?>, T) - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
 
handle(EventMessage<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
handle(Message<?>, T) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
handle(Message<?>, T) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Handles the given message by invoking the appropriate method on given target.
handle(Message<?>, T) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
handle(UnitOfWork<? extends T>, InterceptorChain) - Method in class org.axonframework.messaging.interceptors.BeanValidationInterceptor
 
handle(List<T>) - Method in class org.axonframework.messaging.interceptors.BeanValidationInterceptor
 
handle(UnitOfWork<? extends T>, InterceptorChain) - Method in class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
 
handle(UnitOfWork<? extends T>, InterceptorChain) - Method in class org.axonframework.messaging.interceptors.LoggingInterceptor
 
handle(UnitOfWork<? extends T>, InterceptorChain) - Method in class org.axonframework.messaging.interceptors.TransactionManagingInterceptor
 
handle(T) - Method in interface org.axonframework.messaging.MessageDispatchInterceptor
Invoked each time a message is about to be dispatched.
handle(List<T>) - Method in interface org.axonframework.messaging.MessageDispatchInterceptor
Apply this interceptor to the given list of messages.
handle(T) - Method in interface org.axonframework.messaging.MessageHandler
Handles the given message.
handle(UnitOfWork<? extends T>, InterceptorChain) - Method in interface org.axonframework.messaging.MessageHandlerInterceptor
Invoked before a Message is handled by a designated MessageHandler.
handle(List<? extends EventMessage<?>>) - Method in class org.axonframework.spring.messaging.OutboundEventMessageChannelAdapter
If allows by the filter, wraps the given event in a GenericMessage ands sends it to the configured MessageChannel.
handle(EventMessage) - Method in class org.axonframework.test.saga.EventValidator
 
handle(Object, MetaData) - Method in interface org.axonframework.test.utils.CallbackBehavior
Invoked when the Command Bus receives a Command that is dispatched with a Callback method.
handle(Object, MetaData) - Method in class org.axonframework.test.utils.DefaultCallbackBehavior
 
handleError(ErrorContext) - Method in interface org.axonframework.eventhandling.ErrorHandler
Handle an error raised during event processing.
handleError(ErrorContext) - Method in enum org.axonframework.eventhandling.PropagatingErrorHandler
 
handleInSaga(EventMessage<?>) - Method in class org.axonframework.test.saga.SagaTestFixture
Handles the given event in the scope of a Unit of Work.
handleMessage(Message<?>) - Method in class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
Handles the given message.
handlePersistenceException(Exception, EventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Invoke when an Exception is raised while persisting an Event or Snapshot.
HandlerComparator - Class in org.axonframework.messaging.annotation
Comparator used by AnnotatedHandlerInspector to sort entity members.
HandlerDefinition - Interface in org.axonframework.messaging.annotation
Interface that describes an object capable of inspecting a method to determine if the method is suitable for message handling.
HandlerEnhancerDefinition - Interface in org.axonframework.messaging.annotation
Interface describing objects that are capable of enhancing a MessageHandler, giving it additional functionality.
hasAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
hasAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
hasAnnotation(Class<? extends Annotation>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Checks whether the method of the target entity contains the given annotationType.
hasAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
hasDelegate() - Method in class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
Indicates whether this callback has a delegate that needs to be notified of the command handling result
hasEqualsMethod(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the given class implements a customized equals method.
hasGaps() - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
Check if this token contains one ore more gaps.
hash(String) - Static method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the hash of the given routingKey.
hasHandler(EventMessage<?>) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
Check whether or not this invoker has handlers that can handle the given eventMessage.
hasHandler(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSagaManager
 
hasHandler(EventMessage<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
 
hashCode() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
 
hashCode() - Method in class org.axonframework.eventhandling.saga.AssociationValue
 
hashCode() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
 
hashCode() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
 
hashCode() - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
 
hashCode() - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
 
hashCode() - Method in class org.axonframework.messaging.MetaData
 
hashCode() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
 
hashCode() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
 
hashCode() - Method in class org.axonframework.serialization.SerializedMetaData
 
hashCode() - Method in class org.axonframework.serialization.SimpleSerializedObject
 
hashCode() - Method in class org.axonframework.serialization.SimpleSerializedType
 
hashCode() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
hashes() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
Returns the hashes covered by the member.
hasMoreChildren() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
hasNext() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Returns true if the stream has more events, meaning that a call to next() will not result in an exception.
hasNext() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
hasNextAvailable() - Method in interface org.axonframework.messaging.MessageStream
Checks whether or not the next message in the stream is available.
hasNextAvailable(int, TimeUnit) - Method in interface org.axonframework.messaging.MessageStream
Checks whether or not the next message in the stream is available.
HIGH - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should have high priority, effectively placing it "in the first half".
HsqlEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
Jdbc table factory for HSQL databases.
HsqlEventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
Default constructor of the factory
HsqlSagaSqlSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
Specialization of the GenericSagaSqlSchema for use in the HSQL database.
HsqlSagaSqlSchema() - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.HsqlSagaSqlSchema
 

I

idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
Returns the sql to register the auto incrementing global sequence column.
idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
 
idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
 
idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
 
idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
 
identifier() - Method in interface org.axonframework.commandhandling.model.Aggregate
Get the unique identifier of this aggregate
identifier() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
identifier() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
identifierAsString() - Method in interface org.axonframework.commandhandling.model.Aggregate
Get the unique identifier of this aggregate, represented as a String.
IdentifierFactory - Class in org.axonframework.common
Abstract Factory class that provides access to an IdentifierFactory implementation.
IdentifierFactory() - Constructor for class org.axonframework.common.IdentifierFactory
 
IdentifierValidator - Class in org.axonframework.common
Validates the structure of an object passed as Aggregate Identifier.
ifStarted(Consumer<UnitOfWork<?>>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
If a UnitOfWork is started, invokes the given consumer with the active Unit of Work.
IgnoreField - Class in org.axonframework.test.matchers
FieldFilter implementation that rejects a given Field
IgnoreField(Field) - Constructor for class org.axonframework.test.matchers.IgnoreField
Initialize an instance that ignores the given field
IgnoreField(Class<?>, String) - Constructor for class org.axonframework.test.matchers.IgnoreField
Initialize an instance that ignores the a field with given fieldName, which is declared on the given clazz.
ImportSelector() - Constructor for class org.axonframework.spring.config.SpringAxonAutoConfigurer.ImportSelector
 
InboundEventMessageChannelAdapter - Class in org.axonframework.spring.messaging
Adapter class that publishes Events from a Spring Messaging Message Channel on the Event Bus.
InboundEventMessageChannelAdapter() - Constructor for class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
Initialize the adapter to publish all incoming events to the subscribed processors.
InboundEventMessageChannelAdapter(EventBus) - Constructor for class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
Initialize an InboundEventMessageChannelAdapter instance that sends all incoming Event Messages to the given eventBus.
InboundEventMessageChannelAdapter(List<Consumer<List<? extends EventMessage<?>>>>, EventMessageConverter) - Constructor for class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
Initialize the adapter to publish all incoming events to the subscribed processors.
IncompatibleAggregateException - Exception in org.axonframework.eventsourcing
Exception indicating that an aggregate was not compatible with the requirements of the GenericAggregateFactory.
IncompatibleAggregateException(String, Exception) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
Initialize the exception with given message and cause.
IncompatibleAggregateException(String) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
Initialize the exception with given message.
InfraConfiguration - Class in org.axonframework.boot.autoconfig
 
InfraConfiguration() - Constructor for class org.axonframework.boot.autoconfig.InfraConfiguration
 
INITIAL_LOAD_FACTOR - Static variable in class org.axonframework.commandhandling.distributed.DistributedCommandBus
The initial load factor of this node when it is registered with the CommandRouter.
InitialEventRepresentation - Class in org.axonframework.serialization.upcasting.event
Implementation of an IntermediateEventRepresentation that contains the original serialized payload and metadata before these have been upcast.
InitialEventRepresentation(EventData<?>, Serializer) - Constructor for class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
Initializes an InitialEventRepresentation from the given eventData.
initializationFinished() - Method in interface org.axonframework.eventsourcing.SnapshotTrigger
Invoked when the initialization of the aggregate based on passed events is completed.
initialize(ConflictResolver) - Static method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
Initialize conflict resolution in the context of the current Unit of Work dealing with a command on an event sourced aggregate.
initialize(Callable<T>, AggregateModel<T>, EventBus) - Static method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Initialize an aggregate created by the given aggregateFactory which is described in the given aggregateModel.
initialize(T, AggregateModel<T>, EventBus) - Static method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Initialize an aggregate with the given aggregateRoot which is described in the given aggregateModel.
initialize(Configuration) - Method in class org.axonframework.config.AggregateConfigurer
 
initialize(Configuration) - Method in class org.axonframework.config.EventHandlingConfiguration
 
initialize(Configuration) - Method in interface org.axonframework.config.ModuleConfiguration
Initialize the module configuration using the given global config
initialize(Configuration) - Method in class org.axonframework.config.SagaConfiguration
 
initialize() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Initializes the QuartzEventScheduler.
initialize(T, AggregateModel<T>, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
Initializes an EventSourcedAggregate instance for the given aggregateRoot, based on the given inspector, which publishes events to the given eventBus.
initialize(Callable<T>, AggregateModel<T>, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
Initializes an EventSourcedAggregate instance using the given aggregateFactory, based on the given inspector, which publishes events to the given eventBus and stores events in the given eventStore.
initializeAdapterFor(Object, ParameterResolverFactory) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
Create an AnnotationEventListenerAdapter instance of the given bean.
initializeAdapterFor(Object, ParameterResolverFactory) - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
 
initializeState(DomainEventStream) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
Initialize the state of this Event Sourced Aggregate with the events from the given eventStream.
injectorAnnotationNames() - Method in class org.axonframework.eventhandling.saga.AbstractResourceInjector
Provides an array with fully qualified class names of the annotation that indicate an injection point for a resource.
injectResources(Object) - Method in class org.axonframework.eventhandling.saga.AbstractResourceInjector
 
injectResources(Object) - Method in enum org.axonframework.eventhandling.saga.repository.NoResourceInjector
 
injectResources(Object) - Method in interface org.axonframework.eventhandling.saga.ResourceInjector
Inject required resources into the given saga.
injectResources(Object) - Method in class org.axonframework.spring.saga.SpringResourceInjector
 
InMemoryEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore.inmemory
Thread-safe event storage engine that stores events and snapshots in memory.
InMemoryEventStorageEngine() - Constructor for class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
InMemorySagaStore - Class in org.axonframework.eventhandling.saga.repository.inmemory
SagaRepository implementation that stores all Saga instances in memory.
InMemorySagaStore() - Constructor for class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
 
InMemoryTokenStore - Class in org.axonframework.eventhandling.tokenstore.inmemory
Implementation of a TokenStore that stores tracking tokens in memory.
InMemoryTokenStore() - Constructor for class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
InputStreamToByteArrayConverter - Class in org.axonframework.serialization.converters
Converter that converts an InputStream to a byte array.
InputStreamToByteArrayConverter() - Constructor for class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
 
InputStreamToDom4jConverter - Class in org.axonframework.serialization.xml
Converter that converts an input stream to a Dom4J document.
InputStreamToDom4jConverter() - Constructor for class org.axonframework.serialization.xml.InputStreamToDom4jConverter
 
InputStreamToXomConverter - Class in org.axonframework.serialization.xml
Converter that converts an input stream to a XOM document.
InputStreamToXomConverter() - Constructor for class org.axonframework.serialization.xml.InputStreamToXomConverter
 
insertOrUpdateToken(ResultSet, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
If the given resultSet has no items this method should insert a new token entry.
insertSaga(Class<? extends T>, String, T, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
 
insertSaga(Class<?>, String, Object, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
 
insertSaga(Class<?>, String, Object, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
 
insertSaga(Class<?>, String, Object, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
 
insertSaga(Class<? extends T>, String, T, TrackingToken, Set<AssociationValue>) - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore
Adds a new Saga and its initial association values to the store.
insertSaga(Class<?>, String, Object, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.mongo.eventhandling.saga.repository.MongoSagaStore
 
insertTokenEntry(ResultSet, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Inserts a new token entry via the given updatable resultSet.
inspect(Class<? extends C>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Inspect another handler type and register the result to the inspector registry of this inspector.
inspectAggregate(Class<AT>) - Static method in class org.axonframework.commandhandling.model.inspection.ModelInspector
Create an inspector for given aggregateType that uses a ClasspathParameterResolverFactory to resolve method parameters.
inspectAggregate(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.commandhandling.model.inspection.ModelInspector
Create an inspector for given aggregateType that uses given parameterResolverFactory to resolve method parameters.
inspectType(Class<T>) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Create an inspector for given handlerType that uses a ClasspathParameterResolverFactory to resolve method parameters.
inspectType(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Create an inspector for given handlerType that uses given parameterResolverFactory to resolve method parameters.
INSTANCE - Static variable in class org.axonframework.commandhandling.callbacks.LoggingCallback
The singleton instance for this callback
INSTANCE - Static variable in class org.axonframework.commandhandling.callbacks.NoOpCallback
A statically available instance of the NoOpCallback.
INSTANCE - Static variable in class org.axonframework.common.caching.NoCache
Creates a singleton reference the the NoCache implementation.
INSTANCE - Static variable in class org.axonframework.common.DirectExecutor
Returns a singleton instance of the DirectExecutor.
instance() - Static method in enum org.axonframework.common.transaction.NoTransactionManager
Returns the singleton instance of this TransactionManager
instance() - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
Singleton instance of a PropagatingErrorHandler.
INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
Singleton HsqlEventTableFactory instance
INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
Singleton MySqlEventTableFactory instance
INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
Singleton PostgresEventTableFactory instance
instance() - Static method in class org.axonframework.messaging.annotation.HandlerComparator
Returns the singleton comparator managed by the HandlerComparator class.
instance() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
Returns the instance of {@link NoOpMessageMonitor}.
instance() - Static method in class org.axonframework.test.matchers.AllFieldsFilter
Returns the (singleton) instance of the AllFieldsFilter
instance() - Static method in class org.axonframework.test.matchers.NonTransientFieldsFilter
Returns the (singleton) instance of the AllFieldsFilter
intercept(CommandMessage<C>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Invokes all the dispatch interceptors.
intercept(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
Invokes all the dispatch interceptors.
InterceptorChain - Interface in org.axonframework.messaging
The interceptor chain manages the flow of a message through a chain of interceptors and ultimately to the message handler.
interceptorsFor(Configuration, String) - Method in class org.axonframework.config.EventHandlingConfiguration
Returns the list of Message Handler Interceptors registered for the given processorName.
IntermediateEventRepresentation - Interface in org.axonframework.serialization.upcasting.event
Interface describing the intermediate representation of an event during upcasting.
IntervalRetryScheduler - Class in org.axonframework.commandhandling.gateway
RetryScheduler implementation that retries commands at regular intervals when they fail because of an exception that is not explicitly non-transient.
IntervalRetryScheduler(ScheduledExecutorService, int, int) - Constructor for class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
Initializes the retry scheduler to schedule retries on the given executor using the given interval and allowing maxRetryCount retries before giving up permanently.
invoke(Object, Method, Object[]) - Method in interface org.axonframework.commandhandling.gateway.CommandGatewayFactory.InvocationHandler
Handle the invocation of the given invokedMethod, invoked on given proxy with given args.
invoke(Function<T, R>) - Method in interface org.axonframework.commandhandling.model.Aggregate
Invoke a method on the underlying aggregate root or one of its instances.
invoke(Function<T, R>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
invoke(Function<AR, R>) - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
invoke(Function<T, R>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
 
invoke(Function<T, R>) - Method in interface org.axonframework.eventhandling.saga.Saga
Execute the given invocation against the root object of this Saga instance.
invokeInitHandlers() - Method in class org.axonframework.config.DefaultConfigurer
Calls all registered init handlers.
invokeShutdownHandlers() - Method in class org.axonframework.config.DefaultConfigurer
Invokes all registered shutdown handlers
invokeStartHandlers() - Method in class org.axonframework.config.DefaultConfigurer
Invokes all registered start handlers
IOUtils - Class in org.axonframework.common.io
Utility methods for IO operations.
isAccessible(AccessibleObject) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the given member is accessible.
isActive() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
 
isActive() - Method in interface org.axonframework.eventhandling.saga.Saga
Indicates whether or not this saga is active.
isActive() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Indicates whether this UnitOfWork is started.
isAfter(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Check if this Phase comes after given other phase.
isAutoStart() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties.Gossip
 
isAutoStartup() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
isAutoStartup() - Method in class org.axonframework.spring.config.AxonConfiguration
 
isAutoStartup() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
isAutoStartup() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
 
isBefore(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Check if this Phase comes before given other phase.
isCauseOf(Throwable) - Static method in exception org.axonframework.common.AxonNonTransientException
Indicates whether the given throwable is a AxonNonTransientException exception or indicates to be caused by one.
isCurrent() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Check if the Unit of Work is the 'currently' active Unit of Work returned by CurrentUnitOfWork.get().
isDeleted() - Method in interface org.axonframework.commandhandling.model.Aggregate
Check if this aggregate has been deleted.
isDeleted() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
isDeleted() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
isDeserialized() - Method in class org.axonframework.serialization.LazyDeserializingObject
Indicates whether this object has already been deserialized.
isDuplicateKeyCode(SQLException, List<Integer>) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
 
isDuplicateKeyViolation(Exception) - Method in interface org.axonframework.common.jdbc.PersistenceExceptionResolver
Indicates whether the given exception represents a duplicate key violation.
isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcSQLErrorCodesResolver
 
isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
 
isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
 
isDurableMessages() - Method in class org.axonframework.boot.AMQPProperties
 
isEmpty() - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
Indicates whether any elements are contained within this map.
isEmpty() - Method in class org.axonframework.messaging.MetaData
 
isEnabled() - Method in class org.axonframework.boot.DistributedCommandBusProperties
 
isEnabled() - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
isEndingHandler() - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
Indicates whether this handler is one that ends the Saga lifecycle
isError() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Indicates whether the processor has been paused due to an error.
isExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
Check if the result of the execution yielded an exception.
isExpectReply() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Indicates whether the sender of this message requests a reply.
isExplicitlyNonTransient(Throwable) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
Indicates whether the given failure is clearly non-transient.
isFactoryHandler() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
isFactoryHandler() - Method in interface org.axonframework.commandhandling.model.inspection.CommandMessageHandlingMember
Check if this message handler creates a new instance of the entity of type T to handle this command.
isFalse(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
Asserts that the given expression is false.
isFirstMessage(Message<?>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Checks if the given message is the first of the batch being processed in this unit of work.
isFirstMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Checks if the message being processed now is the first of the batch being processed in this unit of work.
isHeld() - Method in interface org.axonframework.common.lock.Lock
Indicates whether the lock is still owned true, or whether it has been released false.
isImmediate() - Method in class org.axonframework.amqp.eventhandling.AMQPMessage
Whether to dispatch this message using the "immediate" flag
isLastMessage(Message<?>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Checks if the given message is the last of the batch being processed in this unit of work.
isLastMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
Checks if the message being processed now is the last of the batch being processed in this unit of work.
isLive() - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
Indicates whether this Aggregate instance is 'live'.
isLockHeld() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
Check if the aggregate currently holds a lock.
isMandatory() - Method in class org.axonframework.amqp.eventhandling.AMQPMessage
Whether to dispatch this message using the "mandatory" flag
isMetaDataDeserialized() - Method in class org.axonframework.serialization.SerializedMessage
Indicates whether the metaData of this message has already been deserialized.
isNonFinalPublicMember(Member) - Static method in class org.axonframework.common.ReflectionUtils
Checks whether the given member is public and non-final.
isPayloadDeserialized() - Method in class org.axonframework.serialization.SerializedMessage
Indicates whether the payload of this message has already been deserialized.
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
Indicates whether an object of the given targetClass should be post processed.
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
 
isRecoverEntry() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Indicates whether this entry is a recovery entry.
isReverseCallbackOrder() - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Check whether registered handlers for this phase should be invoked in the order of registration (first registered handler is invoked first) or in the reverse order of registration (last registered handler is invoked first).
isRolledBack() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
isRolledBack() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Check if the Unit of Work has been rolled back.
isRoot() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Check that returns true if this Unit of Work has not got a parent.
isRunning() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Indicates whether this processor is currently running (i.e.
isRunning() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
isRunning() - Method in class org.axonframework.spring.config.AxonConfiguration
 
isRunning() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
isRunning() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
 
isSerializedMetaData(SerializedObject<?>) - Static method in class org.axonframework.serialization.SerializedMetaData
Indicates whether the given serializedObject represents a serialized form of a MetaData object, such as the ones created by this class (see SerializedMetaData.SerializedMetaData(Object, Class).
isSingleton() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
isSingleton() - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
 
isSingleton() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
isSingleton() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
 
isSingleton() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
 
isSingleton() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
isSingleton() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
isSingleton() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
 
isStarted() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
Indicates whether a unit of work has already been started.
isStarted() - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Check if a Unit of Work in this phase has been started, i.e.
isSubscribed(MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
Indicates whether the given commandHandler is subscribed to this command bus.
isSubscribed(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
Indicates whether the given commandHandler is subscribed to commands of the given commandType on this command bus.
isSuccess() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Whether the reply message represents a successfully executed command.
isTransient(Field) - Static method in class org.axonframework.common.ReflectionUtils
Indicates whether the given field has the "transient" modifier
isTrue(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
Asserts that the given expression is true.
isValidIdentifier(Class<?>) - Method in class org.axonframework.common.IdentifierValidator
Indicates whether or not the given identifierType is safe to use as aggregate identifier
iterator() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
IteratorBackedDomainEventStream - Class in org.axonframework.eventsourcing.eventstore
DomainEventStream implementation that gets its messages from an Iterator.
IteratorBackedDomainEventStream(Iterator<? extends DomainEventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
Initialize the stream which provides access to message from the given iterator

J

JacksonSerializer - Class in org.axonframework.serialization.json
Serializer implementation that uses Jackson to serialize objects into a JSON format.
JacksonSerializer() - Constructor for class org.axonframework.serialization.json.JacksonSerializer
Initialize the serializer with a default ObjectMapper instance.
JacksonSerializer(ObjectMapper) - Constructor for class org.axonframework.serialization.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JacksonSerializer(RevisionResolver, Converter) - Constructor for class org.axonframework.serialization.json.JacksonSerializer
Initialize the serializer using a default ObjectMapper instance, using the given revisionResolver to define revision for each object to serialize, and given converter to be used by upcasters.
JacksonSerializer(ObjectMapper, RevisionResolver) - Constructor for class org.axonframework.serialization.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JacksonSerializer(ObjectMapper, RevisionResolver, Converter) - Constructor for class org.axonframework.serialization.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JacksonSerializer(ObjectMapper, RevisionResolver, Converter, ClassLoader) - Constructor for class org.axonframework.serialization.json.JacksonSerializer
Initialize the serializer with the given objectMapper to serialize and parse the objects to JSON.
JavaSerializationAMQPMessageConverter - Class in org.axonframework.amqp.eventhandling.legacy
Implementation of the AMQPMessageConverter interface that serializes the Message using Java Serialization, while the payload and meta data of the messages are serialized using the configured Serializer.
JavaSerializationAMQPMessageConverter(Serializer) - Constructor for class org.axonframework.amqp.eventhandling.legacy.JavaSerializationAMQPMessageConverter
Initializes the AMQPMessageConverter with the given serializer, using a PackageRoutingKeyResolver and requesting durable dispatching.
JavaSerializationAMQPMessageConverter(Serializer, RoutingKeyResolver, boolean) - Constructor for class org.axonframework.amqp.eventhandling.legacy.JavaSerializationAMQPMessageConverter
Initializes the AMQPMessageConverter with the given serializer, routingKeyResolver and requesting durable dispatching when durable is true.
JavaSerializer - Class in org.axonframework.serialization
Serializer implementation that uses Java serialization to serialize and deserialize object instances.
JavaSerializer() - Constructor for class org.axonframework.serialization.JavaSerializer
Initialize the serializer using a SerialVersionUIDRevisionResolver, which uses the SerialVersionUID field of the serializable object as the Revision.
JavaSerializer(RevisionResolver) - Constructor for class org.axonframework.serialization.JavaSerializer
Initialize the serializer using a SerialVersionUIDRevisionResolver.
JCacheAdapter - Class in org.axonframework.common.caching
Cache adapter implementation that allows providers implementing the JCache abstraction to be used.
JCacheAdapter(Cache) - Constructor for class org.axonframework.common.caching.JCacheAdapter
Initialize the adapter to forward call to the given jCache instance
JChannelFactory - Interface in org.axonframework.jgroups.commandhandling
Factory of a JChannel.
JdbcEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore.jdbc
EventStorageEngine implementation that uses JDBC to store and fetch events.
JdbcEventStorageEngine(ConnectionProvider, TransactionManager) - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Initializes an EventStorageEngine that uses JDBC to store and load events using the default EventSchema.
JdbcEventStorageEngine(Serializer, EventUpcaster, PersistenceExceptionResolver, ConnectionProvider, TransactionManager) - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Initializes an EventStorageEngine that uses JDBC to store and load events using the default EventSchema.
JdbcEventStorageEngine(Serializer, EventUpcaster, PersistenceExceptionResolver, Integer, ConnectionProvider, TransactionManager, Class<?>, EventSchema, Integer, Long) - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Initializes an EventStorageEngine that uses JDBC to store and load events.
JdbcException - Exception in org.axonframework.common.jdbc
Exception indicating an error occurred while interacting with a JDBC resource.
JdbcException(String, Throwable) - Constructor for exception org.axonframework.common.jdbc.JdbcException
Initialize the exception with given message and cause
JdbcSagaStore - Class in org.axonframework.eventhandling.saga.repository.jdbc
Jdbc implementation of the Saga Repository.
JdbcSagaStore(ConnectionProvider) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
Initializes a Saga Repository, using given connectionProvider to obtain connections to the database, using a Generic SQL Schema.
JdbcSagaStore(DataSource, SagaSqlSchema) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
Initializes a Saga Repository, using given dataSource to obtain connections to the database, and given sqldef to execute SQL statements.
JdbcSagaStore(ConnectionProvider, SagaSqlSchema) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
Initializes a Saga Repository, using given connectionProvider to obtain connections to the database, and given sqldef to execute SQL statements.
JdbcSagaStore(ConnectionProvider, SagaSqlSchema, Serializer) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
Initializes a Saga Repository, using given connectionProvider to obtain connections to the database, and given sqldef to execute SQL statements and serializer to serialize Sagas.
jdbcSQLErrorCodesResolver() - Method in class org.axonframework.boot.autoconfig.JpaAutoConfiguration
 
JdbcSQLErrorCodesResolver - Class in org.axonframework.eventsourcing.eventstore.jdbc
SQLErrorCodesResolver is an implementation of PersistenceExceptionResolver used to resolve sql error codes to see if it is an duplicate key constraint violation.
JdbcSQLErrorCodesResolver() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.JdbcSQLErrorCodesResolver
 
JdbcTokenStore - Class in org.axonframework.eventhandling.tokenstore.jdbc
Implementation of a token store that uses JDBC to save and load tokens.
JdbcTokenStore(ConnectionProvider, Serializer) - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Initialize the JpaTokenStore with given resources.
JdbcTokenStore(ConnectionProvider, Serializer, TokenSchema, TemporalAmount, String, Class<?>) - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Initialize the JpaTokenStore with given resources.
JdbcUtils - Class in org.axonframework.common.jdbc
Utility class for safely executing Jdbc queries.
JdbcUtils.SqlFunction - Interface in org.axonframework.common.jdbc
Describes a function that creates a new PreparedStatement ready to be executed.
JdbcUtils.SqlResultConverter<R> - Interface in org.axonframework.common.jdbc
Describes a function that converts a ResultSet into a result of type R.
JGroupsAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
JGroupsAutoConfiguration() - Constructor for class org.axonframework.boot.autoconfig.JGroupsAutoConfiguration
 
JGroupsConnector - Class in org.axonframework.jgroups.commandhandling
A Connector for the DistributedCommandBus based on JGroups that acts both as the discovery and routing mechanism (implementing CommandRouter) as well as the Connector between nodes (implementing CommandBusConnector).
JGroupsConnector(CommandBus, JChannel, String, Serializer) - Constructor for class org.axonframework.jgroups.commandhandling.JGroupsConnector
Initialize the connector using the given localSegment to handle commands on the local node, and the given channel to connect between nodes.
JGroupsConnector(CommandBus, JChannel, String, Serializer, RoutingStrategy) - Constructor for class org.axonframework.jgroups.commandhandling.JGroupsConnector
Initialize the connector using the given localSegment to handle commands on the local node, and the given channel to connect between nodes.
jgroupsConnectorFactoryBean(Serializer, CommandBus) - Method in class org.axonframework.boot.autoconfig.JGroupsAutoConfiguration
 
JGroupsConnectorFactoryBean - Class in org.axonframework.spring.commandhandling.distributed.jgroups
Spring Factory bean that creates a JGroupsConnector and starts it when the application context is started.
JGroupsConnectorFactoryBean() - Constructor for class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
JGroupsDispatchMessage - Class in org.axonframework.jgroups.commandhandling
JGroups message that contains a CommandMessage that needs to be dispatched on a remote command bus segment.
JGroupsDispatchMessage() - Constructor for class org.axonframework.jgroups.commandhandling.JGroupsDispatchMessage
Default constructor required by the Streamable and Externalizable interfaces.
JGroupsDispatchMessage(CommandMessage<?>, Serializer, boolean) - Constructor for class org.axonframework.jgroups.commandhandling.JGroupsDispatchMessage
Initialize a JGroupsDispatchMessage for the given commandMessage, to be serialized using given serializer.
JGroupsProperties() - Constructor for class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
JGroupsReplyMessage - Class in org.axonframework.jgroups.commandhandling
JGroups Message representing a reply to a dispatched command.
JGroupsReplyMessage() - Constructor for class org.axonframework.jgroups.commandhandling.JGroupsReplyMessage
Default constructor required by the Streamable and Externalizable interfaces.
JGroupsReplyMessage(String, boolean, Object, Serializer) - Constructor for class org.axonframework.jgroups.commandhandling.JGroupsReplyMessage
Initializes a JGroupsReplyMessage containing a reply to the command with given {commandIdentifier} and given returnValue.
JGroupsXmlConfigurationChannelFactory - Class in org.axonframework.jgroups.commandhandling
Implementation of a JChannelFactory that uses configuration from an xml file.
JGroupsXmlConfigurationChannelFactory(String) - Constructor for class org.axonframework.jgroups.commandhandling.JGroupsXmlConfigurationChannelFactory
Creates a JChannelFactory that uses configuration from a given xml file.
JoinMessage - Class in org.axonframework.jgroups.commandhandling
This message represents a notification of a Member joining the DistributedCommandBus with a given loadFactor.
JoinMessage() - Constructor for class org.axonframework.jgroups.commandhandling.JoinMessage
Default constructor required by the Streamable and Externalizable interfaces.
JoinMessage(Address, int, Predicate<? super CommandMessage<?>>) - Constructor for class org.axonframework.jgroups.commandhandling.JoinMessage
Initializes a JoinMessage with the given loadFactor.
JpaAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
JpaAutoConfiguration() - Constructor for class org.axonframework.boot.autoconfig.JpaAutoConfiguration
 
jpaConfiguration(EntityManagerProvider) - Static method in class org.axonframework.config.DefaultConfigurer
Returns a Configurer instance which has JPA versions of building blocks configured, such as a JPA based Event Store (see JpaEventStorageEngine), a JpaTokenStore and JpaSagaStore.
JpaEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore.jpa
EventStorageEngine implementation that uses JPA to store and fetch events.
JpaEventStorageEngine(EntityManagerProvider, TransactionManager) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Initializes an EventStorageEngine that uses JPA to store and load events.
JpaEventStorageEngine(Serializer, EventUpcaster, DataSource, EntityManagerProvider, TransactionManager) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Initializes an EventStorageEngine that uses JPA to store and load events.
JpaEventStorageEngine(Serializer, EventUpcaster, PersistenceExceptionResolver, Integer, EntityManagerProvider, TransactionManager, Long, Integer, boolean) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Initializes an EventStorageEngine that uses JPA to store and load events.
jpaMappedConfiguration(Class<A>, EntityManagerProvider) - Static method in class org.axonframework.config.AggregateConfigurer
Creates a Configuration for an aggregate of given aggregateType, which is mapped to a relational database using an EntityManager provided by given entityManagerProvider.
JpaSagaStore - Class in org.axonframework.eventhandling.saga.repository.jpa
JPA implementation of the Saga Store.
JpaSagaStore(EntityManagerProvider) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Initializes a Saga Repository with an XStreamSerializer and given entityManagerProvider.
JpaSagaStore(Serializer, EntityManagerProvider) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Initializes a Saga Repository with the given serializer and entityManagerProvider.
JpaTokenStore - Class in org.axonframework.eventhandling.tokenstore.jpa
Implementation of a token store that uses JPA to save and load tokens.
JpaTokenStore(EntityManagerProvider, Serializer) - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
Initializes a token store with given entityManagerProvider and serializer.
JpaTokenStore(EntityManagerProvider, Serializer, TemporalAmount, String) - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
Initialize the JpaTokenStore with given resources.
JsonNodeToByteArrayConverter - Class in org.axonframework.serialization.json
ContentTypeConverter implementation that converts a JsonNode object into a byte[].
JsonNodeToByteArrayConverter(ObjectMapper) - Constructor for class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
Initialize the converter, using given objectMapper to convert the JSonNode into bytes.
JSR303ViolationException - Exception in org.axonframework.messaging.interceptors
Exception indicating that a Message has been refused due to a structural validation failure.
JSR303ViolationException(Set<ConstraintViolation<Object>>) - Constructor for exception org.axonframework.messaging.interceptors.JSR303ViolationException
Initializes an exception with the given message and violations.

K

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

L

LAST - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should come last.
lastSequenceNumberProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntryConfiguration
Returns the name of the property containing the sequence number of the last event entry.
lastTimestampProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentpercommit.CommitEntryConfiguration
Returns the name of the property containing the timestamp of the last event entry of the commit.
LazyDeserializingObject<T> - Class in org.axonframework.serialization
Represents a serialized object that can be deserializedObjects upon request.
LazyDeserializingObject(T) - Constructor for class org.axonframework.serialization.LazyDeserializingObject
Creates an instance with the given deserializedObject object instance.
LazyDeserializingObject(SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serialization.LazyDeserializingObject
Creates an instance which will deserialize given serializedObject upon request.
LazyDeserializingObject(Supplier<SerializedObject<?>>, SerializedType, Serializer) - Constructor for class org.axonframework.serialization.LazyDeserializingObject
Creates an instance which will get the supplied SerializedObject and deserialize it upon request.
LegacyAwareJobDataBinder - Class in org.axonframework.eventhandling.scheduling.quartz
EventJobDataBinder implementation that adds support for Event publication Jobs scheduled in Axon 2.
LegacyAwareJobDataBinder() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.LegacyAwareJobDataBinder
Initialize the Job Data Binder to add legacy support while still allowing the default Axon 3 Job Data format
LegacyAwareJobDataBinder(EventJobDataBinder) - Constructor for class org.axonframework.eventhandling.scheduling.quartz.LegacyAwareJobDataBinder
Initialize the LegacyAwareJobDataBinder to add legacy job support, reverting to the given delegate when the given job is not a legacy job definition.
ListenerInvocationErrorHandler - Interface in org.axonframework.eventhandling
Interface of an error handler that is invoked when an exception is triggered as result of an EventListener handling an event.
ListMatcher<T> - Class in org.axonframework.test.matchers
Abstract implementation for matchers that use event-specific matchers to match against a list of items.
ListMatcher(Matcher<? super T>...) - Constructor for class org.axonframework.test.matchers.ListMatcher
Creates an abstract matcher to match a number of Matchers against Events contained inside a Collection.
listResults(JdbcUtils.SqlResultConverter<R>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Create a converter that produces a List of results of type R from a converter that produces a single result.
listWithAllOf(Matcher<T>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a List where all the given matchers must match with at least one of the items in that list.
ListWithAllOfMatcher<T> - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers match against at least one item in a given List.
ListWithAllOfMatcher(Matcher<T>...) - Constructor for class org.axonframework.test.matchers.ListWithAllOfMatcher
Construct a matcher that will return true if all the given matchers match against at least one item in any given List.
listWithAnyOf(Matcher<T>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a List of Events where at least one of the given matchers matches any of the Events in that list.
ListWithAnyOfMatcher<T> - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers match against at least one item in a given List.
ListWithAnyOfMatcher(Matcher<T>...) - Constructor for class org.axonframework.test.matchers.ListWithAnyOfMatcher
Construct a matcher that will return true if any of the given matchers matches against at least one item in a given List.
load(String, Long) - Method in class org.axonframework.commandhandling.model.AbstractRepository
 
load(String) - Method in class org.axonframework.commandhandling.model.AbstractRepository
 
load(String) - Method in interface org.axonframework.commandhandling.model.Repository
Load the aggregate with the given unique identifier.
load(String, Long) - Method in interface org.axonframework.commandhandling.model.Repository
Load the aggregate with the given unique identifier.
load(String) - Method in class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
Loads a known Saga instance by its unique identifier.
load(String) - Method in interface org.axonframework.eventhandling.saga.SagaRepository
Loads a known Saga instance by its unique identifier.
loadAssociationValues(EntityManager, Class<?>, String) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Loads the association values of the saga with given sagaIdentifier and sagaType.
loadOrCreateToken(String, int, EntityManager) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
Loads an existing TokenEntry or creates a new one using the given entityManager for given processorName and segment.
loadOrInsertToken(ResultSet, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Tries loading an existing token owned by a processor with given processorName and segment.
loadSaga(Class<S>, String) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
 
loadSaga(Class<S>, String) - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
 
loadSaga(Class<S>, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
 
loadSaga(Class<S>, String) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
 
loadSaga(Class<S>, String) - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore
Loads a known saga SagaStore.Entry instance with given sagaType and unique sagaIdentifier.
loadSaga(Class<S>, String) - Method in class org.axonframework.mongo.eventhandling.saga.repository.MongoSagaStore
 
local() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
 
local() - Method in interface org.axonframework.commandhandling.distributed.Member
 
local() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
 
Lock - Interface in org.axonframework.common.lock
Interface of a lock acquired to gain (exclusive) access to a shared resource, with a mechanism to release it again.
LockAcquisitionFailedException - Exception in org.axonframework.common.lock
Exception indicating that a lock could not be obtained.
LockAcquisitionFailedException(String, Throwable) - Constructor for exception org.axonframework.common.lock.LockAcquisitionFailedException
Initialize the exception with given message and cause
LockAcquisitionFailedException(String) - Constructor for exception org.axonframework.common.lock.LockAcquisitionFailedException
Initialize the exception with given message.
LockAwareAggregate<AR,A extends Aggregate<AR>> - Class in org.axonframework.commandhandling.model
Aggregate implementation that provides access to the lock held by the aggregate while a command is handled.
LockAwareAggregate(A, Lock) - Constructor for class org.axonframework.commandhandling.model.LockAwareAggregate
Initializes a new LockAwareAggregate for given wrappedAggregate and lock.
LockFactory - Interface in org.axonframework.common.lock
Interface to the lock factory.
LockingRepository<T,A extends Aggregate<T>> - Class in org.axonframework.commandhandling.model
Implementation of the Repository interface that takes provides a locking mechanism to prevent concurrent modifications of persisted aggregates.
LockingRepository(Class<T>) - Constructor for class org.axonframework.commandhandling.model.LockingRepository
Initialize a repository with a pessimistic locking strategy.
LockingRepository(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.model.LockingRepository
Initialize a repository with a pessimistic locking strategy and a parameter resolver factory.
LockingRepository(Class<T>, LockFactory) - Constructor for class org.axonframework.commandhandling.model.LockingRepository
Initialize the repository with the given LockFactory.
LockingRepository(Class<T>, LockFactory, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.model.LockingRepository
Initialize the repository with the given LockFactory and ParameterResolverFactory.
LockingSagaRepository<T> - Class in org.axonframework.eventhandling.saga.repository
Abstract implementation of a saga repository that locks access to a saga while the saga is being operated on.
LockingSagaRepository(LockFactory) - Constructor for class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
Initializes a saga repository that locks access to a saga while the saga is being operated on.
LoggingCallback - Class in org.axonframework.commandhandling.callbacks
CommandCallback implementation that simply logs the results of a command.
LoggingErrorHandler - Class in org.axonframework.eventhandling
Implementation of a ListenerInvocationErrorHandler that logs exceptions as errors but otherwise does nothing to prevent event handling from continuing.
LoggingErrorHandler() - Constructor for class org.axonframework.eventhandling.LoggingErrorHandler
Initialize the LoggingErrorHandler using the logger for "org.axonframework.eventhandling.LoggingErrorHandler".
LoggingErrorHandler(Logger) - Constructor for class org.axonframework.eventhandling.LoggingErrorHandler
Initialize the LoggingErrorHandler to use the given logger to log errors
LoggingInterceptor<T extends Message<?>> - Class in org.axonframework.messaging.interceptors
Message Handler Interceptor that logs incoming messages and their result to a SLF4J logger.
LoggingInterceptor(String) - Constructor for class org.axonframework.messaging.interceptors.LoggingInterceptor
Initialize the LoggingInterceptor with the given loggerName.
LoggingInterceptor() - Constructor for class org.axonframework.messaging.interceptors.LoggingInterceptor
Initialize the LoggingInterceptor with the default logger name, which is the fully qualified class name of this logger.
LOW - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should be placed at the "lower half".

M

managedAggregates(UnitOfWork<?>) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Returns the map of aggregates currently managed by this repository under the given unit of work.
map(Function<UnitOfWork<?>, T>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
If a Unit of Work is started, execute the given function on it.
markDeleted() - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
Marks this aggregate as deleted, instructing a repository to remove that aggregate at an appropriate time.
MatchAllFieldFilter - Class in org.axonframework.test.matchers
FieldFilter that delegates to an arbitrary number of other filters.
MatchAllFieldFilter(Collection<FieldFilter>) - Constructor for class org.axonframework.test.matchers.MatchAllFieldFilter
Initializes a filter that accepts any field that is accepted by all given filters
MatcherExecutionException - Exception in org.axonframework.test.matchers
Exception indicating that an error occurred that prevented successful execution of a matcher.
MatcherExecutionException(String) - Constructor for exception org.axonframework.test.matchers.MatcherExecutionException
Construct the exception with the given message.
MatcherExecutionException(String, Throwable) - Constructor for exception org.axonframework.test.matchers.MatcherExecutionException
Construct the exception with the given message and cause.
Matchers - Class in org.axonframework.test.matchers
Utility class containing static methods to obtain instances of (List) Matchers.
matches(Message<?>) - Method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
 
matches(Message) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
 
matches(Message<?>) - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
 
matches(Message) - Method in class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
 
matches(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
 
matches(Message<?>) - Method in interface org.axonframework.messaging.annotation.ParameterResolver
Indicates whether this resolver is capable of providing a value for the given message.
matches(Message) - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
 
matches(ConditionContext, AnnotatedTypeMetadata) - Method in class org.axonframework.spring.config.NoBeanOfType.NoBeanOfTypeDefined
 
matches(Object) - Method in class org.axonframework.test.matchers.EmptyCollectionMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.ListMatcher
 
matches(Predicate<T>) - Static method in class org.axonframework.test.matchers.Matchers
Returns a Matcher that matches with values defined by the given predicate.
matches(Object) - Method in class org.axonframework.test.matchers.NullOrVoidMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.PayloadMatcher
 
matches(Object) - Method in class org.axonframework.test.matchers.PayloadsMatcher
 
matchesList(List<T>) - Method in class org.axonframework.test.matchers.ExactSequenceMatcher
 
matchesList(List<T>) - Method in class org.axonframework.test.matchers.ListMatcher
Evaluates the matcher for argument item.
matchesList(List<T>) - Method in class org.axonframework.test.matchers.ListWithAllOfMatcher
 
matchesList(List<T>) - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
matchesList(List<T>) - Method in class org.axonframework.test.matchers.SequenceMatcher
 
matchesSafely(T) - Method in class org.axonframework.test.matchers.PredicateMatcher
 
matchRemainder(Iterator<Matcher<? super T>>) - Method in class org.axonframework.test.matchers.ListMatcher
Matches all the remaining Matchers in the given matcherIterator against null.
MavenArtifactRevisionResolver - Class in org.axonframework.serialization
RevisionResolver that uses Maven meta data to retrieve the application version.
MavenArtifactRevisionResolver(String, String) - Constructor for class org.axonframework.serialization.MavenArtifactRevisionResolver
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given groupId and artifactId.
MavenArtifactRevisionResolver(String, String, ClassLoader) - Constructor for class org.axonframework.serialization.MavenArtifactRevisionResolver
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given groupId and artifactId.
mayClaim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Check if given owner may claim this token.
md5Hex(String) - Static method in class org.axonframework.common.digest.Digester
Utility method that creates a hex string of the MD5 hash of the given input
Member - Interface in org.axonframework.commandhandling.distributed
Member of a cluster of connected command endpoints.
MemberAccessibilityCallback - Class in org.axonframework.common
PrivilegedAction that makes the given method accessible for reflection.
MemberAccessibilityCallback(AccessibleObject) - Constructor for class org.axonframework.common.MemberAccessibilityCallback
Initialize the callback to make the given method accessible for reflection.
MembershipUpdateFailedException - Exception in org.axonframework.jgroups.commandhandling
Exception indicating that a node has failed to update its membership details with the other nodes.
MembershipUpdateFailedException(String) - Constructor for exception org.axonframework.jgroups.commandhandling.MembershipUpdateFailedException
Initializes the exception using the given message.
MembershipUpdateFailedException(String, Throwable) - Constructor for exception org.axonframework.jgroups.commandhandling.MembershipUpdateFailedException
Initializes the exception using the given message and cause.
merge(T, T, Supplier<T>) - Static method in class org.axonframework.common.CollectionUtils
Merge two collections into a new collection instance.
mergedWith(Map<String, ?>) - Method in class org.axonframework.messaging.MetaData
Returns a MetaData instance containing values of this, combined with the given additionalEntries.
Message<T> - Interface in org.axonframework.messaging
Representation of a Message, containing a Payload and MetaData.
MessageCountingMonitor - Class in org.axonframework.metrics
Counts the number of ingested, successful, failed and processed messages
MessageCountingMonitor() - Constructor for class org.axonframework.metrics.MessageCountingMonitor
 
MessageDecorator<T> - Class in org.axonframework.messaging
Abstract implementation of a Message that delegates to an existing message.
MessageDecorator(Message<T>) - Constructor for class org.axonframework.messaging.MessageDecorator
Initializes a new decorator with given delegate message.
MessageDispatchInterceptor<T extends Message<?>> - Interface in org.axonframework.messaging
Interceptor that allows messages to be intercepted and modified before they are dispatched.
messageFilter() - Method in class org.axonframework.jgroups.commandhandling.JoinMessage
Returns the command message filter used by the member.
MessageHandler - Annotation Type in org.axonframework.messaging.annotation
Annotation indicating that a member method should be able to respond to Messages.
MessageHandler<T extends Message<?>> - Interface in org.axonframework.messaging
Interface for a component that processes Messages.
MessageHandlerInterceptor<T extends Message<?>> - Interface in org.axonframework.messaging
Workflow interface that allows for customized message handler invocation chains.
MessageHandlerInvocationException - Exception in org.axonframework.messaging.annotation
MessageHandlerInvocationException is a runtime exception that wraps an exception thrown by an invoked message handler.
MessageHandlerInvocationException(String, Throwable) - Constructor for exception org.axonframework.messaging.annotation.MessageHandlerInvocationException
Initialize the MessageHandlerInvocationException using given message and cause.
MessageHandlingMember<T> - Interface in org.axonframework.messaging.annotation
Interface describing a handler for specific messages targeting entities of a specific type.
MessageIdentifier - Annotation Type in org.axonframework.messaging.annotation
Annotation indication that a parameter on a Message Handler method should be injected with the identifier of a Message.
MessageIdentifierParameterResolverFactory - Class in org.axonframework.messaging.annotation
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a String type that are annotated with the MessageIdentifier annotation and assigns the identifier of the Message.
MessageIdentifierParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
Initialize a ParameterResolverFactory for MessageIdentifier annotated parameters
messageMonitor(Class<?>, String) - Method in interface org.axonframework.config.Configuration
Returns the message monitor configured for a component of given componentType and componentName.
MessageMonitor<T extends Message<?>> - Interface in org.axonframework.monitoring
Specifies a mechanism to monitor message processing.
messageMonitor(Class<?>, String) - Method in class org.axonframework.spring.config.AxonConfiguration
 
MessageMonitor.MonitorCallback - Interface in org.axonframework.monitoring
An interface to let the message processor inform the message monitor of the result of processing the message
messageOriginProvider() - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
MessageOriginProvider - Class in org.axonframework.messaging.correlation
CorrelationDataProvider that provides the identifier of a Message to other messages that are created as result of processing the first message.
MessageOriginProvider() - Constructor for class org.axonframework.messaging.correlation.MessageOriginProvider
Initializes a MessageOriginProvider that uses the default correlation id key: MessageOriginProvider.getDefaultCorrelationKey() and trace id key: MessageOriginProvider.getDefaultTraceKey().
MessageOriginProvider(String, String) - Constructor for class org.axonframework.messaging.correlation.MessageOriginProvider
Initializes a MessageOriginProvider that uses the given correlationKey.
MessageProcessingContext<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
Maintains the context around the processing of a single Message.
MessageProcessingContext(T) - Constructor for class org.axonframework.messaging.unitofwork.MessageProcessingContext
Creates a new processing context for the given message.
MessageSerializer - Class in org.axonframework.serialization
Wrapper around a serializer that provides SerializationAware support.
MessageSerializer(Serializer) - Constructor for class org.axonframework.serialization.MessageSerializer
Initializes the MessageSerializer as a wrapper around the given serializer.
MessageStream<M extends Message<?>> - Interface in org.axonframework.messaging
Interface for a tracked stream of Messages.
MessageTimerMonitor - Class in org.axonframework.metrics
Times allTimer messages, successful and failed messages
MessageTimerMonitor() - Constructor for class org.axonframework.metrics.MessageTimerMonitor
Creates a MessageTimerMonitor using a default clock
MessageTimerMonitor(Clock) - Constructor for class org.axonframework.metrics.MessageTimerMonitor
Creates a MessageTimerMonitor using the provided clock
messageWithPayload(Matcher<?>) - Static method in class org.axonframework.test.matchers.Matchers
Matches a single Message if the given payloadMatcher matches that message's payload.
MetaData - Class in org.axonframework.domain
Deprecated.
this class is available for backward compatibility with instances that were serialized with Axon 2. Use MetaData instead.
MetaData() - Constructor for class org.axonframework.domain.MetaData
Deprecated.
 
MetaData - Class in org.axonframework.messaging
Represents MetaData that is passed along with a payload in a Message.
MetaData(Map<String, ?>) - Constructor for class org.axonframework.messaging.MetaData
Initializes a MetaData instance with the given items as content.
metaDataColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the serialized metadata of the event.
MetaDataCommandTargetResolver - Class in org.axonframework.commandhandling
CommandTargetResolver implementation that uses MetaData entries to extract the identifier and optionally the version of the aggregate that the command targets.
MetaDataCommandTargetResolver(String) - Constructor for class org.axonframework.commandhandling.MetaDataCommandTargetResolver
Initializes the MetaDataCommandTargetResolver to use the given identifierKey as the MetaData key to the aggregate identifier, and a null (ignored) version.
MetaDataCommandTargetResolver(String, String) - Constructor for class org.axonframework.commandhandling.MetaDataCommandTargetResolver
Initializes the MetaDataCommandTargetResolver to use the given identifierKey as the MetaData key to the aggregate identifier, and the given versionKey as key to the (optional) version entry.
MetaDataDeserializer - Class in org.axonframework.serialization.json
JsonDeserializer implementation that deserializes MetaData instances.
MetaDataDeserializer() - Constructor for class org.axonframework.serialization.json.MetaDataDeserializer
 
metaDataProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the metadata.
MetaDataRoutingStrategy - Class in org.axonframework.commandhandling.distributed
RoutingStrategy implementation that uses the value in the MetaData of a CommandMessage assigned to a given key.
MetaDataRoutingStrategy(String) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Initializes the MetaDataRoutingStrategy where the given metaDataKey is used to get the Meta Data value.
MetaDataRoutingStrategy(String, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Initializes the MetaDataRoutingStrategy where the given metaDataKey is used to get the Meta Data value.
MetaDataValue - Annotation Type in org.axonframework.messaging.annotation
Annotation that indicates the parameter needs to be resolved to the value of the Message MetaData stored under the given key.
MethodAccessedProperty<T> - Class in org.axonframework.common.property
Property implementation that invokes a method to obtain a value of a property for a given instance.
MethodAccessedProperty(Method, String) - Constructor for class org.axonframework.common.property.MethodAccessedProperty
Initialize a reader that uses given accessorMethod to access a property with given propertyName.
MethodCommandHandlerDefinition - Class in org.axonframework.commandhandling.model.inspection
Implementation of a HandlerEnhancerDefinition that is used for CommandHandler annotated methods.
MethodCommandHandlerDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.MethodCommandHandlerDefinition
 
methodsOf(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Returns an Iterable of all the methods declared on the given class and its super classes.
modelFactory() - Method in interface org.axonframework.eventhandling.saga.metamodel.SagaModel
Returns the factory that created this model.
ModelInspector<T> - Class in org.axonframework.commandhandling.model.inspection
Inspector of an entity of type T that creates command and event handlers that delegate to a target entity and its child entities.
modelOf(Class<? extends C>) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
Get the EntityModel of an entity of type childEntityType in case it is the child of the modeled entity.
modelOf(Class<? extends C>) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
modelOf(Class<T>) - Method in class org.axonframework.eventhandling.saga.metamodel.DefaultSagaMetaModelFactory
 
modelOf(Class<T>) - Method in interface org.axonframework.eventhandling.saga.metamodel.SagaMetaModelFactory
Create a saga meta model for the given sagaType.
ModuleConfiguration - Interface in org.axonframework.config
Interface describing a module for the Axon Configuration API.
MongoEventStorageEngine - Class in org.axonframework.mongo.eventsourcing.eventstore
EventStorageEngine implementation that uses Mongo to store and fetch events.
MongoEventStorageEngine(MongoTemplate) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
Initializes an EventStorageEngine that uses Mongo to store and load events.
MongoEventStorageEngine(Serializer, EventUpcaster, MongoTemplate, StorageStrategy) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
Initializes an EventStorageEngine that uses Mongo to store and load events.
MongoEventStorageEngine(Serializer, EventUpcaster, Integer, MongoTemplate, StorageStrategy) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
Initializes an EventStorageEngine that uses Mongo to store and load events.
MongoEventStorageEngine(Serializer, EventUpcaster, PersistenceExceptionResolver, Integer, MongoTemplate, StorageStrategy) - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
Initializes an EventStorageEngine that uses Mongo to store and load events.
MongoFactory - Class in org.axonframework.mongo.eventsourcing.eventstore
Convenience class for creating Mongo instances.
MongoFactory() - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoFactory
 
MongoOptionsFactory - Class in org.axonframework.mongo.eventsourcing.eventstore
Factory class used to create a MongoOptions instance.
MongoOptionsFactory() - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Default constructor for the factory that initializes the defaults.
MongoSagaStore - Class in org.axonframework.mongo.eventhandling.saga.repository
Implementations of the SagaRepository that stores Sagas and their associations in a Mongo Database.
MongoSagaStore(MongoTemplate) - Constructor for class org.axonframework.mongo.eventhandling.saga.repository.MongoSagaStore
Initializes the Repository, using given mongoTemplate to access the collections containing the stored Saga instances.
MongoSagaStore(MongoTemplate, Serializer) - Constructor for class org.axonframework.mongo.eventhandling.saga.repository.MongoSagaStore
Initializes the Repository, using given mongoTemplate to access the collections containing the stored Saga instances, serializing Saga instances using the given serializer.
MongoTemplate - Interface in org.axonframework.mongo.eventhandling.saga.repository
Generic template for accessing Mongo for the axon sagas.
MongoTemplate - Interface in org.axonframework.mongo.eventsourcing.eventstore
Interface describing a mechanism that provides access to the Database and Collections required by the MongoEventStore.
MongoTrackingToken - Class in org.axonframework.mongo.eventsourcing.eventstore
Tracking token implementation produced by the MongoEventStorageEngine to keep track of the position in an event stream.
MonitorAwareCallback<C,R> - Class in org.axonframework.commandhandling
Wrapper for a callback that notifies a Message Monitor of the message execution result.
MonitorAwareCallback(CommandCallback<C, R>, MessageMonitor.MonitorCallback) - Constructor for class org.axonframework.commandhandling.MonitorAwareCallback
Initialize a callback wrapped around the delegate which will notify a Message Monitor for the given messageMonitorCallback.
moveDown() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
moveUp() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
MultiCorrelationDataProvider<T extends Message> - Class in org.axonframework.messaging.correlation
CorrelationDataProvider that combines the data of multiple other correlation providers.
MultiCorrelationDataProvider(List<? extends CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.correlation.MultiCorrelationDataProvider
Initialize the correlation data provider, delegating to given correlationDataProviders.
MultiMessageMonitor<T extends Message<?>> - Class in org.axonframework.monitoring
Delegates messages and callbacks to the given list of message monitors
MultiMessageMonitor(MessageMonitor<? super T>...) - Constructor for class org.axonframework.monitoring.MultiMessageMonitor
Initialize a message monitor with the given messageMonitors
MultiMessageMonitor(List<MessageMonitor<? super T>>) - Constructor for class org.axonframework.monitoring.MultiMessageMonitor
Initialize a message monitor with the given list of messageMonitors
MultiParameterResolverFactory - Class in org.axonframework.messaging.annotation
ParameterResolverFactory instance that delegates to multiple other instances, in the order provided.
MultiParameterResolverFactory(ParameterResolverFactory...) - Constructor for class org.axonframework.messaging.annotation.MultiParameterResolverFactory
Initializes an instance that delegates to the given delegates, in the order provided.
MultiParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.messaging.annotation.MultiParameterResolverFactory
Initializes an instance that delegates to the given delegates, in the order provided.
MySqlEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
Jdbc event entry table factory for MySql databases.
MySqlEventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
 

N

name() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
 
name() - Method in interface org.axonframework.commandhandling.distributed.Member
Returns the name of this Member.
name() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
 
negate() - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
negate() - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
negate() - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
NEUTRAL - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should have medium priority, effectively placing it "in the middle".
newInstance(Callable<T>) - Method in class org.axonframework.commandhandling.model.AbstractRepository
 
newInstance(Callable<T>) - Method in interface org.axonframework.commandhandling.model.Repository
Creates a new managed instance for the aggregate, using the given factoryMethod to instantiate the aggregate's root.
newInstance(String) - Static method in class org.axonframework.common.digest.Digester
Creates a new Digester instance for the given algorithm.
newInstance(long, Collection<Long>) - Static method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
Returns a new GapAwareTrackingToken instance based on the given index and collection of gaps.
newMD5Instance() - Static method in class org.axonframework.common.digest.Digester
Creates a new Digester instance for the MD5 Algorithm
newProcessingScheduler(EventProcessorTask.ShutdownCallback) - Method in class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
Creates a new scheduler instance that schedules tasks on the executor service for the managed EventListener.
newThread(Runnable) - Method in class org.axonframework.common.AxonThreadFactory
 
next() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Returns the next events in the stream, if available.
next() - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
Returns a new GlobalSequenceTrackingToken instance with sequence number incremented by 1.
next() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
nextAvailable() - Method in interface org.axonframework.messaging.MessageStream
Returns the next available message in the stream.
nextSequence() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
Returns the sequence number to be used for the next event applied by this Aggregate instance.
nextTrackingToken() - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
Returns the tracking token to use for the next event to be stored.
NoBeanOfType - Annotation Type in org.axonframework.spring.config
Annotation to be used in a configuration class on @Bean annotated methods if the method should only provide its bean if a bean of a given type does not exist yet.
NoBeanOfType.NoBeanOfTypeDefined - Class in org.axonframework.spring.config
Condition that checks if a bean with given class already exists in the Spring context.
NoBeanOfTypeDefined() - Constructor for class org.axonframework.spring.config.NoBeanOfType.NoBeanOfTypeDefined
 
NoCache - Class in org.axonframework.common.caching
Cache implementation that does absolutely nothing.
noCommands() - Static method in class org.axonframework.test.matchers.Matchers
Matches an empty List of Commands.
NoConflictResolver - Enum in org.axonframework.commandhandling.conflictresolution
Implementation of a ConflictResolver that does nothing.
noEvents() - Static method in class org.axonframework.test.matchers.Matchers
Matches an empty List of Events.
NoHandlerForCommandException - Exception in org.axonframework.commandhandling
Exception indicating that no suitable handler could be found for the given command.
NoHandlerForCommandException(String) - Constructor for exception org.axonframework.commandhandling.NoHandlerForCommandException
Initialize a NoHandlerForCommandException with the given message.
NONE - Static variable in class org.axonframework.eventhandling.saga.SagaInitializationPolicy
Value indicating there is no Initialization required
NonTransientFieldsFilter - Class in org.axonframework.test.matchers
FieldFilter implementation that only accepts non-transient Fields.
NoOpCallback - Class in org.axonframework.commandhandling.callbacks
Callback that does absolutely nothing when invoked.
NoOpCallback() - Constructor for class org.axonframework.commandhandling.callbacks.NoOpCallback
 
NoOpCloseHandler() - Constructor for class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
 
NoOpEventUpcaster - Enum in org.axonframework.serialization.upcasting.event
Event upcaster that does nothing.
NoOpMessageMonitor - Enum in org.axonframework.monitoring
A message monitor that returns a NoOp message callback
NoOpMessageMonitorCallback - Enum in org.axonframework.monitoring
A NoOp MessageMonitor callback
NoOpTransactionAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
NoOpTransactionAutoConfiguration() - Constructor for class org.axonframework.boot.autoconfig.NoOpTransactionAutoConfiguration
 
NoResourceInjector - Enum in org.axonframework.eventhandling.saga.repository
ResourceInjector that does not inject anything.
NoSnapshotTriggerDefinition - Enum in org.axonframework.eventsourcing
Implementation of SnapshotTriggerDefinition that doesn't trigger snapshots at all.
nothing() - Static method in class org.axonframework.test.matchers.Matchers
Matches against null or void.
notifyHandlers(UnitOfWork.Phase) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
notifyHandlers(UnitOfWork.Phase) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
Notify the handlers attached to the given phase.
notifyHandlers(UnitOfWork.Phase) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
 
notifyHandlers(UnitOfWork.Phase) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
notifyHandlers(UnitOfWork<T>, UnitOfWork.Phase) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Invoke the handlers in this collection attached to the given phase.
notNull(Object, Supplier<String>) - Static method in class org.axonframework.common.Assert
Assert that the given value is not null.
NoTransactionManager - Enum in org.axonframework.common.transaction
TransactionManager implementation that does nothing.
NullLockFactory - Enum in org.axonframework.common.lock
LockFactory implementation that does nothing.
NullOrVoidMatcher<T> - Class in org.axonframework.test.matchers
Matcher that matches against a null or void value.
NullOrVoidMatcher() - Constructor for class org.axonframework.test.matchers.NullOrVoidMatcher
 

O

ObjectUtils - Class in org.axonframework.common
Miscellaneous object utility methods
obtainLock(String) - Method in interface org.axonframework.common.lock.LockFactory
Obtain a lock for a resource identified by given identifier.
obtainLock(String) - Method in enum org.axonframework.common.lock.NullLockFactory
Obtain a lock for a resource identified by given identifier.
obtainLock(String) - Method in class org.axonframework.common.lock.PessimisticLockFactory
Obtain a lock for a resource identified by the given identifier.
of(Stream<? extends DomainEventMessage<?>>, Supplier<Long>) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Create a new DomainEventStream with events obtained from the given stream.
of(Stream<? extends DomainEventMessage<?>>) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Create a new DomainEventStream with events obtained from the given stream.
of(DomainEventMessage<?>) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Create a new DomainEventStream containing only the given event.
of(DomainEventMessage<?>...) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Create a new DomainEventStream from the given events.
of(List<? extends DomainEventMessage<?>>) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Create a new DomainEventStream with events obtained from the given list.
of(Instant, String) - Static method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
Returns a new instance of a MongoTrackingToken with given timestamp, eventIdentifier and sequenceNumber for the initial event in a stream.
of(T) - Static method in class org.axonframework.serialization.CachingSupplier
Factory method for a CachingSupplier that will supply the given value.
of(Supplier<T>) - Static method in class org.axonframework.serialization.CachingSupplier
Factory method for a CachingSupplier that delegates to the given supplier when asked to supply a value.
offsetBy(int) - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
Returns a new GlobalSequenceTrackingToken instance that is the sum of this token's sequence number and the given offset.
onCleanup(Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
onCleanup(Consumer<UnitOfWork<T>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Register given handler with the Unit of Work.
onCommit(Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
onCommit(Consumer<UnitOfWork<T>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Register given handler with the Unit of Work.
onEntryCreated(Object, Object) - Method in interface org.axonframework.common.caching.Cache.EntryListener
Invoked when a new item has been added to the cache
onEntryCreated(Object, Object) - Method in class org.axonframework.common.caching.Cache.EntryListenerAdapter
 
onEntryExpired(Object) - Method in interface org.axonframework.common.caching.Cache.EntryListener
Invoked when an entry has expired.
onEntryExpired(Object) - Method in class org.axonframework.common.caching.Cache.EntryListenerAdapter
 
onEntryRead(Object, Object) - Method in interface org.axonframework.common.caching.Cache.EntryListener
Invoked when an item was retrieved from the Cache
onEntryRead(Object, Object) - Method in class org.axonframework.common.caching.Cache.EntryListenerAdapter
 
onEntryRemoved(Object) - Method in interface org.axonframework.common.caching.Cache.EntryListener
Invoked when an item was removed from the cache, either following an expiry, or by explicitly calling Cache.remove(Object).
onEntryRemoved(Object) - Method in class org.axonframework.common.caching.Cache.EntryListenerAdapter
 
onEntryUpdated(Object, Object) - Method in interface org.axonframework.common.caching.Cache.EntryListener
Invoked when an item has been updated.
onEntryUpdated(Object, Object) - Method in class org.axonframework.common.caching.Cache.EntryListenerAdapter
 
onError(Exception, EventMessage<?>, EventListener) - Method in interface org.axonframework.eventhandling.ListenerInvocationErrorHandler
Invoked after given eventListener failed to handle given event.
onError(Exception, EventMessage<?>, EventListener) - Method in class org.axonframework.eventhandling.LoggingErrorHandler
 
onError(Exception, EventMessage<?>, EventListener) - Method in enum org.axonframework.eventhandling.PropagatingErrorHandler
 
onError(Exception, EventMessage<?>, EventListener) - Method in enum org.axonframework.eventhandling.ThrowingListenerErrorHandler
 
onEvent(CommandHandlingEntry, long, boolean) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
 
onEvent(CommandHandlingEntry, long, boolean) - Method in class org.axonframework.commandhandling.disruptor.EventPublisher
 
onFailure(CommandMessage<? extends C>, Throwable) - Method in class org.axonframework.commandhandling.callbacks.FailureLoggingCallback
 
onFailure(CommandMessage, Throwable) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
 
onFailure(CommandMessage<?>, Throwable) - Method in class org.axonframework.commandhandling.callbacks.LoggingCallback
 
onFailure(CommandMessage<?>, Throwable) - Method in class org.axonframework.commandhandling.callbacks.NoOpCallback
Invoked when command handling execution resulted in an error.
onFailure(CommandMessage<? extends C>, Throwable) - Method in interface org.axonframework.commandhandling.CommandCallback
Invoked when command handling execution resulted in an error.
onFailure(CommandMessage<? extends C>, Throwable) - Method in class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
 
onFailure(CommandMessage<? extends C>, Throwable) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
 
onFailure(CommandMessage<? extends C>, Throwable) - Method in class org.axonframework.commandhandling.gateway.RetryingCallback
 
onFailure(CommandMessage<? extends C>, Throwable) - Method in class org.axonframework.commandhandling.MonitorAwareCallback
 
onFailure(CommandMessage, Throwable) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector.SpringHttpReplyFutureCallback
 
onFailure(CommandMessage<?>, Throwable) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
onMessage(Message, Channel) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPMessageSource
 
onMessageIngested(Message<?>) - Method in class org.axonframework.metrics.CapacityMonitor
 
onMessageIngested(EventMessage<?>) - Method in class org.axonframework.metrics.EventProcessorLatencyMonitor
 
onMessageIngested(Message<?>) - Method in class org.axonframework.metrics.MessageCountingMonitor
 
onMessageIngested(Message<?>) - Method in class org.axonframework.metrics.MessageTimerMonitor
 
onMessageIngested(Message<?>) - Method in class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
 
onMessageIngested(T) - Method in interface org.axonframework.monitoring.MessageMonitor
Takes a message and returns a callback that should be used to inform the message monitor about the result of processing the message
onMessageIngested(T) - Method in class org.axonframework.monitoring.MultiMessageMonitor
Calls the message monitors with the given message and returns a callback that will trigger all the message monitor callbacks
onMessageIngested(Message<?>) - Method in enum org.axonframework.monitoring.NoOpMessageMonitor
 
onPrepareCommit(Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
onPrepareCommit(Consumer<UnitOfWork<T>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Register given handler with the Unit of Work.
onRollback(Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
onRollback(Consumer<UnitOfWork<T>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Register given handler with the Unit of Work.
onShutdown() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
 
onShutdown(Runnable) - Method in interface org.axonframework.config.Configuration
Registers a handler to be executed when the Configuration is shut down.
onShutdown(Runnable) - Method in class org.axonframework.spring.config.AxonConfiguration
 
onStart() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
 
onStart(Runnable) - Method in interface org.axonframework.config.Configuration
Registers a handler to be executed when this Configuration is started.
onStart(Runnable) - Method in class org.axonframework.spring.config.AxonConfiguration
 
onSuccess(CommandMessage<? extends C>, R) - Method in class org.axonframework.commandhandling.callbacks.FailureLoggingCallback
 
onSuccess(CommandMessage<? extends C>, R) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
 
onSuccess(CommandMessage, Object) - Method in class org.axonframework.commandhandling.callbacks.LoggingCallback
 
onSuccess(CommandMessage<?>, Object) - Method in class org.axonframework.commandhandling.callbacks.NoOpCallback
Invoked when command handling execution was successful.
onSuccess(CommandMessage<? extends C>, Object) - Method in class org.axonframework.commandhandling.callbacks.VoidCallback
Invoked when command handling execution was successful.
onSuccess(CommandMessage<? extends C>) - Method in class org.axonframework.commandhandling.callbacks.VoidCallback
Invoked when command handling execution was successful.
onSuccess(CommandMessage<? extends C>, R) - Method in interface org.axonframework.commandhandling.CommandCallback
Invoked when command handling execution was successful.
onSuccess(CommandMessage<? extends C>, R) - Method in class org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback
 
onSuccess(CommandMessage<? extends C>, R) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
 
onSuccess(CommandMessage<? extends C>, R) - Method in class org.axonframework.commandhandling.gateway.RetryingCallback
 
onSuccess(CommandMessage<? extends C>, R) - Method in class org.axonframework.commandhandling.MonitorAwareCallback
 
onSuccess(CommandMessage<? extends C>, R) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector.SpringHttpReplyFutureCallback
 
onSuccess(CommandMessage<?>, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
openStream(TrackingToken) - Method in interface org.axonframework.eventhandling.EventBus
Open an event stream containing all events since given tracking token.
openStream(TrackingToken) - Method in class org.axonframework.eventhandling.SimpleEventBus
This implementation only returns a stream if the specified trackingToken is null.
openStream(TrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
 
openStream(TrackingToken) - Method in interface org.axonframework.messaging.StreamableMessageSource
Open a stream containing all messages since given tracking token.
or(Predicate<? super CommandMessage<?>>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
or(Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
or(Predicate<? super CommandMessage<?>>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
or(Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
Oracle11EventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
Oracle 11 doesn't support the data type BIGINT, so NUMBER(19) is used as a substitute instead.
Oracle11EventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
 
Oracle11SagaSqlSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
Oracle 11 does not support AUTO_INCREMENT.
Oracle11SagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.Oracle11SagaSqlSchema
Initialize a Oracle11SagaSqlSchema using the given sagaSchema.
Oracle11TokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
Jdbc token entry table factory for Oracle databases.
Oracle11TokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory
 
Oracle11Utils - Class in org.axonframework.common.jdbc
Utility class with some specific hacks required to get certain features to work with Oracle v11.
ORDER_ASC - Static variable in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
The value to pass to Mongo to fetch documents in ascending order.
ORDER_DESC - Static variable in class org.axonframework.mongo.eventsourcing.eventstore.AbstractMongoEventStorageStrategy
The value to pass to Mongo to fetch documents in descending order.
ordered(ParameterResolverFactory...) - Static method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
Creates a MultiParameterResolverFactory instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
ordered(List<ParameterResolverFactory>) - Static method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
Creates a MultiParameterResolverFactory instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
org.axonframework.amqp.eventhandling - package org.axonframework.amqp.eventhandling
 
org.axonframework.amqp.eventhandling.legacy - package org.axonframework.amqp.eventhandling.legacy
 
org.axonframework.amqp.eventhandling.spring - package org.axonframework.amqp.eventhandling.spring
 
org.axonframework.boot - package org.axonframework.boot
 
org.axonframework.boot.autoconfig - package org.axonframework.boot.autoconfig
 
org.axonframework.commandhandling - package org.axonframework.commandhandling
Classes that implement the concept of command handling using explicit command objects.
org.axonframework.commandhandling.callbacks - package org.axonframework.commandhandling.callbacks
 
org.axonframework.commandhandling.conflictresolution - package org.axonframework.commandhandling.conflictresolution
 
org.axonframework.commandhandling.disruptor - package org.axonframework.commandhandling.disruptor
 
org.axonframework.commandhandling.distributed - package org.axonframework.commandhandling.distributed
 
org.axonframework.commandhandling.distributed.commandfilter - package org.axonframework.commandhandling.distributed.commandfilter
 
org.axonframework.commandhandling.gateway - package org.axonframework.commandhandling.gateway
 
org.axonframework.commandhandling.model - package org.axonframework.commandhandling.model
 
org.axonframework.commandhandling.model.inspection - package org.axonframework.commandhandling.model.inspection
 
org.axonframework.common - package org.axonframework.common
Contains common utility classes needed in different components of the framework.
org.axonframework.common.annotation - package org.axonframework.common.annotation
Contains the main classes for annotation support in Axon Framework.
org.axonframework.common.caching - package org.axonframework.common.caching
Package containing a Caching abstraction, while waiting for the JSR 107 to be fully specified and implemented.
org.axonframework.common.digest - package org.axonframework.common.digest
 
org.axonframework.common.io - package org.axonframework.common.io
 
org.axonframework.common.jdbc - package org.axonframework.common.jdbc
 
org.axonframework.common.jpa - package org.axonframework.common.jpa
 
org.axonframework.common.lock - package org.axonframework.common.lock
 
org.axonframework.common.property - package org.axonframework.common.property
 
org.axonframework.common.transaction - package org.axonframework.common.transaction
 
org.axonframework.config - package org.axonframework.config
 
org.axonframework.domain - package org.axonframework.domain
 
org.axonframework.eventhandling - package org.axonframework.eventhandling
Classes related to event handling and dispatching, such as Event Listeners and the Event Bus.
org.axonframework.eventhandling.async - package org.axonframework.eventhandling.async
 
org.axonframework.eventhandling.interceptors - package org.axonframework.eventhandling.interceptors
 
org.axonframework.eventhandling.saga - package org.axonframework.eventhandling.saga
 
org.axonframework.eventhandling.saga.metamodel - package org.axonframework.eventhandling.saga.metamodel
 
org.axonframework.eventhandling.saga.repository - package org.axonframework.eventhandling.saga.repository
 
org.axonframework.eventhandling.saga.repository.inmemory - package org.axonframework.eventhandling.saga.repository.inmemory
 
org.axonframework.eventhandling.saga.repository.jdbc - package org.axonframework.eventhandling.saga.repository.jdbc
 
org.axonframework.eventhandling.saga.repository.jpa - package org.axonframework.eventhandling.saga.repository.jpa
 
org.axonframework.eventhandling.scheduling - package org.axonframework.eventhandling.scheduling
 
org.axonframework.eventhandling.scheduling.java - package org.axonframework.eventhandling.scheduling.java
 
org.axonframework.eventhandling.scheduling.quartz - package org.axonframework.eventhandling.scheduling.quartz
 
org.axonframework.eventhandling.tokenstore - package org.axonframework.eventhandling.tokenstore
 
org.axonframework.eventhandling.tokenstore.inmemory - package org.axonframework.eventhandling.tokenstore.inmemory
 
org.axonframework.eventhandling.tokenstore.jdbc - package org.axonframework.eventhandling.tokenstore.jdbc
 
org.axonframework.eventhandling.tokenstore.jpa - package org.axonframework.eventhandling.tokenstore.jpa
 
org.axonframework.eventsourcing - package org.axonframework.eventsourcing
Classes related to event sourcing.
org.axonframework.eventsourcing.eventstore - package org.axonframework.eventsourcing.eventstore
Definitions and implementations of the Event store, the mechanism that can load event streams and append events to them.
org.axonframework.eventsourcing.eventstore.inmemory - package org.axonframework.eventsourcing.eventstore.inmemory
 
org.axonframework.eventsourcing.eventstore.jdbc - package org.axonframework.eventsourcing.eventstore.jdbc
JDBC Implementation of the EventStore.
org.axonframework.eventsourcing.eventstore.jpa - package org.axonframework.eventsourcing.eventstore.jpa
JPA Implementation of the EventStore.
org.axonframework.jgroups.commandhandling - package org.axonframework.jgroups.commandhandling
 
org.axonframework.messaging - package org.axonframework.messaging
Classes related to message processing in Axon Framework.
org.axonframework.messaging.annotation - package org.axonframework.messaging.annotation
 
org.axonframework.messaging.correlation - package org.axonframework.messaging.correlation
 
org.axonframework.messaging.interceptors - package org.axonframework.messaging.interceptors
 
org.axonframework.messaging.unitofwork - package org.axonframework.messaging.unitofwork
 
org.axonframework.metrics - package org.axonframework.metrics
 
org.axonframework.mongo - package org.axonframework.mongo
 
org.axonframework.mongo.eventhandling.saga.repository - package org.axonframework.mongo.eventhandling.saga.repository
 
org.axonframework.mongo.eventsourcing.eventstore - package org.axonframework.mongo.eventsourcing.eventstore
 
org.axonframework.mongo.eventsourcing.eventstore.documentpercommit - package org.axonframework.mongo.eventsourcing.eventstore.documentpercommit
 
org.axonframework.mongo.eventsourcing.eventstore.documentperevent - package org.axonframework.mongo.eventsourcing.eventstore.documentperevent
 
org.axonframework.mongo.serialization - package org.axonframework.mongo.serialization
 
org.axonframework.monitoring - package org.axonframework.monitoring
 
org.axonframework.serialization - package org.axonframework.serialization
Classes related to message processing in Axon Framework.
org.axonframework.serialization.converters - package org.axonframework.serialization.converters
 
org.axonframework.serialization.json - package org.axonframework.serialization.json
 
org.axonframework.serialization.upcasting - package org.axonframework.serialization.upcasting
 
org.axonframework.serialization.upcasting.event - package org.axonframework.serialization.upcasting.event
 
org.axonframework.serialization.xml - package org.axonframework.serialization.xml
 
org.axonframework.spring.commandhandling.distributed.jgroups - package org.axonframework.spring.commandhandling.distributed.jgroups
 
org.axonframework.spring.commandhandling.gateway - package org.axonframework.spring.commandhandling.gateway
 
org.axonframework.spring.config - package org.axonframework.spring.config
 
org.axonframework.spring.config.annotation - package org.axonframework.spring.config.annotation
 
org.axonframework.spring.eventhandling.scheduling.java - package org.axonframework.spring.eventhandling.scheduling.java
 
org.axonframework.spring.eventhandling.scheduling.quartz - package org.axonframework.spring.eventhandling.scheduling.quartz
 
org.axonframework.spring.eventsourcing - package org.axonframework.spring.eventsourcing
 
org.axonframework.spring.jdbc - package org.axonframework.spring.jdbc
 
org.axonframework.spring.messaging - package org.axonframework.spring.messaging
Utility classes used to connect Axon Event publishing mechanisms to a Spring Messaging Channel.
org.axonframework.spring.messaging.unitofwork - package org.axonframework.spring.messaging.unitofwork
 
org.axonframework.spring.saga - package org.axonframework.spring.saga
 
org.axonframework.spring.stereotype - package org.axonframework.spring.stereotype
 
org.axonframework.springcloud.commandhandling - package org.axonframework.springcloud.commandhandling
 
org.axonframework.test - package org.axonframework.test
Classes in support of testing Axon based applications.
org.axonframework.test.aggregate - package org.axonframework.test.aggregate
 
org.axonframework.test.eventscheduler - package org.axonframework.test.eventscheduler
 
org.axonframework.test.matchers - package org.axonframework.test.matchers
 
org.axonframework.test.saga - package org.axonframework.test.saga
 
org.axonframework.test.utils - package org.axonframework.test.utils
A collection of classes which may prove useful when testing Axon-based classes.
OutboundEventMessageChannelAdapter - Class in org.axonframework.spring.messaging
Adapter class that sends Events from an event bus to a Spring Messaging Message Channel.
OutboundEventMessageChannelAdapter(SubscribableMessageSource<EventMessage<?>>, MessageChannel) - Constructor for class org.axonframework.spring.messaging.OutboundEventMessageChannelAdapter
Initialize an adapter to forward messages from the given messageSource to the given channel.
OutboundEventMessageChannelAdapter(SubscribableMessageSource<EventMessage<?>>, MessageChannel, Predicate<? super EventMessage<?>>) - Constructor for class org.axonframework.spring.messaging.OutboundEventMessageChannelAdapter
Initialize an adapter to forward messages from the given messageSource to the given channel.
OutboundEventMessageChannelAdapter(SubscribableMessageSource<EventMessage<?>>, MessageChannel, Predicate<? super EventMessage<?>>, EventMessageConverter) - Constructor for class org.axonframework.spring.messaging.OutboundEventMessageChannelAdapter
Initialize an adapter to forward messages from the given messageSource to the given channel.
ownerColum() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns the name of the column containing the name of the machine that is currently the owner of this token.

P

PackageRoutingKeyResolver - Class in org.axonframework.amqp.eventhandling
RoutingKeyResolver implementation that uses the package name of the Message's payload as routing key.
PackageRoutingKeyResolver() - Constructor for class org.axonframework.amqp.eventhandling.PackageRoutingKeyResolver
 
ParameterResolver<T> - Interface in org.axonframework.messaging.annotation
Interface for a mechanism that resolves handler method parameter values from a given Message.
parameterResolverFactory() - Method in interface org.axonframework.config.Configuration
Returns the Parameter Resolver Factory defined in this Configuration
ParameterResolverFactory - Interface in org.axonframework.messaging.annotation
Interface for objects capable of creating Parameter Resolver instances for annotated handler methods.
parametersMatch(Message<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
Checks if the parameter resolvers of this member are compatible with the given message.
parent() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
parent() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
parent() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns an optional for the parent of this Unit of Work.
parseInstant(CharSequence) - Static method in class org.axonframework.common.DateTimeUtils
Parse the given timestamp into an Instant.
pause() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Pause this Unit of Work by unregistering it with the CurrentUnitOfWork.
pause() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Stops processing if it currently running, but doesn't stop free up the processing thread.
payloadColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the serialized payload of the event.
PayloadMatcher<T extends Message> - Class in org.axonframework.test.matchers
Matcher that matches any message (e.g.
PayloadMatcher(Matcher<?>) - Constructor for class org.axonframework.test.matchers.PayloadMatcher
Constructs an instance with the given payloadMatcher.
payloadMatching(Predicate<Object>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
Returns a Predicate for a ConflictResolver that responds affirmative if the payload of any event in a list of unseen events matches the given messageFilter.
payloadMatching(Class<T>, Predicate<? super T>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
Returns a Predicate for a ConflictResolver that responds affirmative if the payload of any event in a list of unseen events is of given payloadType and matches the given messageFilter.
PayloadParameterResolver - Class in org.axonframework.messaging.annotation
Implementation of a ParameterResolver that resolves the Message payload as parameter in a handler method.
PayloadParameterResolver(Class<?>) - Constructor for class org.axonframework.messaging.annotation.PayloadParameterResolver
Initializes a new PayloadParameterResolver for a method parameter of given payloadType.
payloadProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the payload data.
payloadRevision - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
payloadRevisionColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the revision number of the serialized payload.
payloadRevisionProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the payload revision.
PayloadsMatcher - Class in org.axonframework.test.matchers
Matches a list of Messages if the list of their payloads matches the given matcher..
PayloadsMatcher(Matcher<? extends Iterable<?>>) - Constructor for class org.axonframework.test.matchers.PayloadsMatcher
Constructs an instance that uses the given matcher to match the payloads.
payloadsMatching(Matcher<? extends List<?>>) - Static method in class org.axonframework.test.matchers.Matchers
Matches a list of Messages if a list containing their respective payloads matches the given matcher.
payloadType - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
payloadType() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
Returns the sql to describe the type of payload column.
payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
 
payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
 
payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
 
payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
 
payloadType() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
payloadType() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Returns the payload type of messages that can be processed by this handler.
payloadType() - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
payloadTypeColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the event payload type.
PayloadTypeMessageMonitorWrapper<T extends MessageMonitor<Message<?>> & com.codahale.metrics.MetricSet> - Class in org.axonframework.metrics
A MessageMonitor implementation which creates a new MessageMonitor for every Message payload type ingested by it.
PayloadTypeMessageMonitorWrapper(Supplier<T>, Function<Class<?>, String>) - Constructor for class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
Create a PayloadTypeMessageMonitorWrapper which builds monitors through a given monitorSupplier for every message payload type encountered and sets the monitor name as specified by the monitorNameBuilder.
payloadTypeOf(Class<T>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
Returns a Predicate for a ConflictResolver that responds affirmative if the payload type of any event in a list of unseen events is assignable to given payloadType.
payloadTypeProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the payload type.
peek() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Returns the next events in the stream, if available, without moving the pointer forward.
peek() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
peek() - Method in interface org.axonframework.messaging.MessageStream
Checks whether or not the next message in the stream is immediately available.
PersistenceExceptionResolver - Interface in org.axonframework.common.jdbc
The PersistenceExceptionResolver is used to find out if an exception is caused by duplicate keys.
PessimisticLockFactory - Class in org.axonframework.common.lock
Implementation of a LockFactory that uses a pessimistic locking strategy.
PessimisticLockFactory() - Constructor for class org.axonframework.common.lock.PessimisticLockFactory
Creates a new IdentifierBasedLock instance.
phase() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
phase() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns the current phase of the Unit of Work.
PK() - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
Constructor for JPA
PK(String, int) - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
Constructs a primary key for a TokenEntry
PK() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
Constructor for JPA.
postDelete(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Perform action that needs to be done directly after deleting an aggregate and committing the aggregate's uncommitted events.
PostgresEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
Jdbc table factory for Postgress databases.
PostgresSagaSqlSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
SQL schema supporting postgres databases.
PostgresSagaSqlSchema() - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
Initialize a PostgresSagaSqlSchema using the default schema configuration.
PostgresSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
Initialize a PostgresSagaSqlSchema using the given sagaSchema.
PostgresTokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
Jdbc token entry table factory for Postgres databases.
PostgresTokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.PostgresTokenTableFactory
 
postProcessAfterInitialization(Object, String) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
postProcessBeforeInitialization(Object, String) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
postProcessInstance(T) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
Perform any processing that must be done on an aggregate instance that was reconstructed from a Snapshot Event.
postSave(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Perform action that needs to be done directly after updating an aggregate and committing the aggregate's uncommitted events.
predicate(Predicate<T>) - Static method in class org.axonframework.test.matchers.Matchers
Returns a Matcher that matches with values defined by the given predicate.
PredicateMatcher<T> - Class in org.axonframework.test.matchers
Matcher implementation that delegates the matching to a Predicate.
PredicateMatcher(Predicate<T>) - Constructor for class org.axonframework.test.matchers.PredicateMatcher
Initializes the matcher using given predicate to test values to match against.
prepareCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
Process given events while the Unit of Work root is preparing for commit.
prepareCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
 
prepareForCommit(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Register handlers with the current Unit of Work that save or delete the given aggregate when the Unit of Work is committed.
prepareForCommit(LockAwareAggregate<T, A>) - Method in class org.axonframework.commandhandling.model.LockingRepository
 
prepareForCommit(LockAwareAggregate<T, EventSourcedAggregate<T>>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
prepareTrigger(Class<?>) - Method in class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
 
prepareTrigger(Class<?>) - Method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
 
prepareTrigger(Class<?>) - Method in interface org.axonframework.eventsourcing.SnapshotTriggerDefinition
Prepares a new trigger for an aggregate with the given aggregateIdentifier and aggregateType.
priority() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
Priority - Annotation Type in org.axonframework.common
Indicates the relative priority of the annotated component.
priority() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
priority() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Returns a number representing the priority of this handler over other handlers capable of processing the same message.
priority() - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
PriorityAnnotationComparator<T> - Class in org.axonframework.common.annotation
Comparator that compares objects based on the value on an @Priority annotation.
proceed() - Method in class org.axonframework.messaging.DefaultInterceptorChain
 
proceed() - Method in interface org.axonframework.messaging.InterceptorChain
Signals the Interceptor Chain to continue processing the message.
process(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
Process a batch of events.
process(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
 
ProcessingGroup - Annotation Type in org.axonframework.config
Hint for the Configuration API that the annotated Event Handler object should be assigned to an Event Processor with the specified name.
processingLoop() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Fetch and process event batches continuously for as long as the processor is not shutting down.
processInterceptors(CommandMessage<C>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Invokes all the dispatch interceptors and returns the CommandMessage instance that should be dispatched.
processorNameColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns the name of the column containing the name of the processor to which the token belongs.
ProcessorSettings() - Constructor for class org.axonframework.boot.EventProcessorProperties.ProcessorSettings
 
PropagatingErrorHandler - Enum in org.axonframework.eventhandling
Singleton ErrorHandler implementation that does not do anything.
Property<T> - Interface in org.axonframework.common.property
Interface describing a mechanism that can read a predefined property from a given instance.
PropertyAccessException - Exception in org.axonframework.common.property
Exception indicating that a predefined property is not accessible.
PropertyAccessException(String, Throwable) - Constructor for exception org.axonframework.common.property.PropertyAccessException
Initializes the PropertyAccessException with given message and cause.
PropertyAccessStrategy - Class in org.axonframework.common.property
Abstract Strategy that provides access to all PropertyAccessStrategy implementations.
PropertyAccessStrategy() - Constructor for class org.axonframework.common.property.PropertyAccessStrategy
 
propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
 
propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.DirectPropertyAccessStrategy
 
propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.PropertyAccessStrategy
Returns a Property instance for the given property, defined in given targetClass, or null if no such property is found on the class.
publish(EventMessage<?>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Publish an event to the aggregate root and its entities first and external event handlers (using the given event bus) later.
publish(EventMessage<?>, P) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedChildEntity
 
publish(EventMessage<?>, T) - Method in interface org.axonframework.commandhandling.model.inspection.ChildEntity
Publish the given msg to the appropriate handlers on the given declaringInstance
publish(EventMessage<?>, T) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
Publish given event message on the given target entity.
publish(EventMessage<?>, T) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
publish(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
 
publish(EventMessage<?>...) - Method in interface org.axonframework.eventhandling.EventBus
Publish a collection of events on this bus (one, or multiple).
publish(List<? extends EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventBus
Publish a collection of events on this bus (one, or multiple).
publish(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
published(Object...) - Method in interface org.axonframework.test.saga.GivenAggregateEventPublisher
Register the given events as being published somewhere in the past.
publishes(Object) - Method in interface org.axonframework.test.saga.WhenAggregateEventPublisher
Register the given event to be published on behalf of an aggregate.
publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Publish an event to external event handlers using the given event bus.
publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
put(K, V) - Method in interface org.axonframework.common.caching.Cache
Stores the given value in the cache, under given key.
put(K, V) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
put(K, V) - Method in class org.axonframework.common.caching.JCacheAdapter
 
put(Object, Object) - Method in class org.axonframework.common.caching.NoCache
 
put(K, V) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
put(String, Object) - Method in class org.axonframework.messaging.MetaData
This operation is not supported.
putAll(Map<? extends String, ?>) - Method in class org.axonframework.messaging.MetaData
This operation is not supported.
putIfAbsent(K, V) - Method in interface org.axonframework.common.caching.Cache
Stores the given value in the cache, under given key, if no element is yet available under that key.
putIfAbsent(K, V) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
putIfAbsent(K, V) - Method in class org.axonframework.common.caching.JCacheAdapter
 
putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.NoCache
 
putIfAbsent(K, V) - Method in class org.axonframework.common.caching.WeakReferenceCache
 

Q

QuartzEventScheduler - Class in org.axonframework.eventhandling.scheduling.quartz
EventScheduler implementation that delegates scheduling and triggering to a Quartz Scheduler.
QuartzEventScheduler() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
QuartzEventScheduler.DirectEventJobDataBinder - Class in org.axonframework.eventhandling.scheduling.quartz
QuartzEventSchedulerFactoryBean - Class in org.axonframework.spring.eventhandling.scheduling.quartz
Spring FactoryBean that creates a QuartzEventScheduler instance using resources found in the Spring Application Context.
QuartzEventSchedulerFactoryBean() - Constructor for class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
QuartzScheduleToken - Class in org.axonframework.eventhandling.scheduling.quartz
ScheduleToken implementation representing a scheduled Quartz Job.
QuartzScheduleToken(String, String) - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Initialize a token for the given jobIdentifier and groupIdentifier.
queryByIdentifier(String) - Static method in class org.axonframework.mongo.eventhandling.saga.repository.SagaEntry
Returns the Mongo Query to find a Saga based on its identifier.
queuedMessages() - Method in class org.axonframework.eventhandling.AbstractEventBus
Returns a list of all the events staged for publication in this Unit of Work.

R

readAMQPMessage(byte[], Map<String, Object>) - Method in interface org.axonframework.amqp.eventhandling.AMQPMessageConverter
Reconstruct an EventMessage from the given messageBody and headers.
readAMQPMessage(byte[], Map<String, Object>) - Method in class org.axonframework.amqp.eventhandling.DefaultAMQPMessageConverter
 
readAMQPMessage(byte[], Map<String, Object>) - Method in class org.axonframework.amqp.eventhandling.legacy.JavaSerializationAMQPMessageConverter
 
readAssociationValues(ResultSet) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
readAssociationValues(ResultSet) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Reads a Set of AssociationValues from the given resultSet, which has been returned by executing the Statement returned from SagaSqlSchema.sql_findAssociations(Connection, String, String).
readEventData(String, long) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Returns a Stream of serialized event data entries for an aggregate with given identifier.
readEventData(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Returns a global Stream containing all serialized event data entries in the event storage that have a TrackingToken greater than the given trackingToken.
readEventData(String, long) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
 
readEventData(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Returns a global Stream containing all serialized event data entries in the event storage that have a TrackingToken greater than the given trackingToken.
readEventData(Connection, String, long, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to read domain event entries for an aggregate with given identifier starting with the first entry having a sequence number that is equal or larger than the given firstSequenceNumber.
readEventData(Connection, TrackingToken, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to read tracked event entries stored since given tracking token.
readEventMessage() - Method in class org.axonframework.amqp.eventhandling.legacy.EventMessageReader
Reads an EventMessage from the underlying input.
readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
 
readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
 
readEvents(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Open an event stream containing all domain events belonging to the given aggregateIdentifier.
readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
 
readEvents(TrackingToken, boolean) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Open an event stream containing all events stored since given tracking token.
readEvents(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Get a DomainEventStream containing all events published by the aggregate with given aggregateIdentifier.
readEvents(String, long) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Get a DomainEventStream containing all events published by the aggregate with given aggregateIdentifier starting with the first event having a sequence number that is equal or larger than the given firstSequenceNumber.
readEvents(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
Open an event stream containing all domain events belonging to the given aggregateIdentifier.
readEvents(String, long) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
Open an event stream containing all domain events belonging to the given aggregateIdentifier.
readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
Open an event stream containing all events stored since given tracking token.
readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
readExternal(ObjectInput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsDispatchMessage
 
readExternal(ObjectInput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsReplyMessage
 
readExternal(ObjectInput) - Method in class org.axonframework.jgroups.commandhandling.JoinMessage
 
readFrom(DataInput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsDispatchMessage
 
readFrom(DataInput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsReplyMessage
 
readPayload(ResultSet, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Reads a serialized object from the given resultSet at given columnIndex.
readResolve() - Method in class org.axonframework.messaging.MetaData
Java Serialization specification method that will ensure that deserialization will maintain a single instance of empty MetaData.
readSerializedData(ResultSet, String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Returns the serialized token data from the given resultSet at given columnName.
readSerializedSaga(ResultSet) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
readSerializedSaga(ResultSet) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Reads a SerializedObject from the given resultSet, which has been returned by executing the Statement returned from SagaSqlSchema.sql_loadSaga(java.sql.Connection, String)

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

readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
 
readSnapshot(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Try to load a snapshot event of the aggregate with given aggregateIdentifier.
readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Returns an optional serialized event entry for given aggregateIdentifier if the backing database contains a snapshot of the aggregate.
readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
readSnapshotData(Connection, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to read the snapshot entry of an aggregate with given identifier
readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
readSnapshotData(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
 
readTimeStamp(ResultSet, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Reads a timestamp from the given resultSet at given columnIndex.
readToken(ResultSet) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
readToken(ResultSet) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Reads a token from the given resultSet.
readTokenEntry(ResultSet) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Convert given resultSet to an AbstractTokenEntry.
receive(Message) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
receiveCommand(SpringHttpDispatchMessage<C>) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector
 
reconfigure(Class<?>, SnapshotTrigger) - Method in class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
 
reconfigure(Class<?>, SnapshotTrigger) - Method in interface org.axonframework.eventsourcing.SnapshotTriggerDefinition
Reconfigure the necessary infrastructure components in the given trigger instance, which may have been lost in the (de)serialization process.
reconstruct(T, AggregateModel<T>, long, boolean, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
Reconstructs an EventSourcedAggregate instance with given aggregateRoot.
RecordingCommandBus - Class in org.axonframework.test.utils
CommandBus implementation that does not perform any actions on subscriptions or dispatched commands, but records them instead.
RecordingCommandBus() - Constructor for class org.axonframework.test.utils.RecordingCommandBus
 
ReflectionUtils - Class in org.axonframework.common
Utility class for working with Java Reflection API.
register(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
Registers a PropertyAccessStrategy implementation at runtime.
registerAggregateFactory(AggregateFactory<?>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
Registers the given aggregateFactory with this snapshotter.
registerAggregateFactory(AggregateFactory<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerAggregateFactory(AggregateFactory<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers the given aggregateFactory with the fixture.
registerAggregateIdentifier(String) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Registers the identifier of the aggregate that will process the next command.
registerAnnotatedCommandHandler(Object) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerAnnotatedCommandHandler(Object) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers an annotatedCommandHandler with this fixture.
registerAnnotationCommandHandlerBeanPostProcessor(BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.AnnotationDrivenRegistrar
Create the BeanDefinition for the AnnotationCommandHandlerBeanPostProcessor and register it.
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.boot.DefaultEntityRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.AnnotationDrivenRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer
 
registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
 
registerCacheEntryListener(Cache.EntryListener) - Method in interface org.axonframework.common.caching.Cache
Registers the given cacheEntryListener to listen for Cache changes.
registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.NoCache
 
registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
registerCommandBus(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers new metrics to the registry to monitor a CommandBus.
registerCommandCallback(CommandCallback<C, R>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
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.
registerCommandDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerCommandDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Register a command dispatch interceptor which will always be invoked before a command is dispatched on the command bus to perform a task specified in the interceptor.
registerCommandGateway(Class<T>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Creates a Command Gateway for the given gatewayInterface and registers that as a resource.
registerCommandGateway(Class<T>, T) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Creates a Command Gateway for the given gatewayInterface and registers that as a resource.
registerCommandGateway(Class<I>) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerCommandGateway(Class<I>, I) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerCommandHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
Registers a command handler bean with this configuration.
registerCommandHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.DefaultConfigurer
 
registerCommandHandler(Class<?>, MessageHandler<CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerCommandHandler(String, MessageHandler<CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerCommandHandler(Class<?>, MessageHandler<CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a commandHandler to handle commands of the given commandType with the command bus used by this fixture.
registerCommandHandler(String, MessageHandler<CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a commandHandler to handle commands of the given commandType with the command bus used by this fixture.
registerCommandHandlerInterceptor(MessageHandlerInterceptor<CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerCommandHandlerInterceptor(MessageHandlerInterceptor<CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Register a command handler interceptor which may be invoked before or after the command has been dispatched on the command bus to perform a task specified in the interceptor.
registerComponent(Class<C>, Function<Configuration, ? extends C>) - Method in interface org.axonframework.config.Configurer
Register a component which should be made available to other components or modules in this Configuration.
registerComponent(Class<C>, Function<Configuration, ? extends C>) - Method in class org.axonframework.config.DefaultConfigurer
 
registerComponent(Class<?>, String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers new metrics to the registry to monitor a component of given type.
registerConverter(ContentTypeConverter) - Method in class org.axonframework.serialization.ChainingConverter
Registers the given converter with this factory.
registerConverter(Class<? extends ContentTypeConverter>) - Method in class org.axonframework.serialization.ChainingConverter
Registers a convert of the given converterType with this factory, only if initialization of such a converter is possible.
registerConverters(ChainingConverter) - Method in class org.axonframework.mongo.serialization.DBObjectXStreamSerializer
 
registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Registers any converters that are specific to the type of content written by this serializer.
registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.json.JacksonSerializer
Registers converters with the given converter which depend on the actual contents of the serialized for to represent a JSON format.
registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.xml.XStreamSerializer
 
registerCorrelationDataProvider(CorrelationDataProvider) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
registerCorrelationDataProvider(CorrelationDataProvider) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Register given correlationDataProvider with this Unit of Work.
RegisterDefaultEntities - Annotation Type in org.axonframework.boot
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Registers the given list of dispatch interceptors to the command bus.
registerDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Registers the given dispatchInterceptor which is invoked for each Command dispatched through the Command Gateways created by this factory.
registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Registers the given list of dispatch interceptors to the command bus.
registerDispatchInterceptor(MessageDispatchInterceptor<EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
Register the given interceptor with this bus.
registerDispatchInterceptor(MessageDispatchInterceptor<EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventBus
Register the given interceptor with this bus.
registerEventBus(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventBus.
registerEventHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.EventHandlingConfiguration
Register an Event Handler Bean with this configuration.
registerEventProcessor(String, EventHandlingConfiguration.EventProcessorBuilder) - Method in class org.axonframework.config.EventHandlingConfiguration
Defines the Event Processor builder for an Event Processor with the given name.
registerEventProcessor(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventProcessor.
registerEventProcessorFactory(EventHandlingConfiguration.EventProcessorBuilder) - Method in class org.axonframework.config.EventHandlingConfiguration
Allows for more fine-grained definition of the Event Processor to use for each group of Event Listeners.
registerFieldFilter(FieldFilter) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerFieldFilter(FieldFilter) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers the given fieldFilter, which is used to define which Fields are used when comparing objects.
registerFieldFilter(FieldFilter) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers the given fieldFilter, which is used to define which Fields are used when comparing objects.
registerFieldFilter(FieldFilter) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Registers the given interceptor to the command bus.
registerHandlerInterceptor(String, Function<Configuration, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventHandlingConfiguration
Register the given interceptorBuilder to build an Message Handling Interceptor for the Event Processor with given processorName.
registerHandlerInterceptor(BiFunction<Configuration, String, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventHandlingConfiguration
Register the given interceptorBuilder to build an Message Handling Interceptor for Event Processors created in this configuration.
registerHandlerInterceptor(Function<Configuration, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.config.SagaConfiguration
Registers the handler interceptor provided by the given handlerInterceptorBuilder function with the processor defined in this configuration.
registerIgnoredField(Class<?>, String) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerIgnoredField(Class<?>, String) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Indicates that a field with given fieldName, which is declared in given declaringClass is ignored when performing deep equality checks.
registerIgnoredField(Class<?>, String) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Indicates that a field with given fieldName, which is declared in given declaringClass is ignored when performing deep equality checks.
registerIgnoredField(Class<?>, String) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerInjectableResource(Object) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerInjectableResource(Object) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a resource that is eligible for injection in handler method (e.g.
registerInterceptor(MessageHandlerInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
 
registerInterceptor(MessageHandlerInterceptor<? super EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventProcessor
Registers the given interceptor to this event processor.
registerMetric(String, T) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers a Metric to the registry under the given name.
registerModule(ModuleConfiguration) - Method in interface org.axonframework.config.Configurer
Register an Axon module with this configuration.
registerModule(ModuleConfiguration) - Method in class org.axonframework.config.DefaultConfigurer
 
registerRepository(EventSourcingRepository<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerRepository(EventSourcingRepository<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers an arbitrary event sourcing repository with the fixture.
registerResource(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers the given resource.
registerResource(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerRoot(Callable<T>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
Registers the aggregate root created by the given aggregateFactory with this aggregate.
registerSubscribingEventProcessor(String) - Method in class org.axonframework.config.EventHandlingConfiguration
Register a subscribing processor with given name that subscribes to the Event Bus.
registerSubscribingEventProcessor(String, Function<Configuration, SubscribableMessageSource<? extends EventMessage<?>>>) - Method in class org.axonframework.config.EventHandlingConfiguration
Register a subscribing processor with given name that subscribes to the given messageSource.
registerTrackingProcessor(String) - Method in class org.axonframework.config.EventHandlingConfiguration
Register a TrackingProcessor using default configuration for the given name.
registerTrackingProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in class org.axonframework.config.EventHandlingConfiguration
Registers a TrackingProcessor using the given source to read messages from.
registerWithConfigurer(Configurer) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers the metric registry with the given configurer via Configurer.configureMessageMonitor(Function).
registerWithUnitOfWork() - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
Registers this aggregate with the current unit of work if one is started.
Registration - Interface in org.axonframework.common
Interface that provides a mechanism to cancel a registration.
release() - Method in interface org.axonframework.common.lock.Lock
Releases this lock.
releaseClaim(String) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Release any claim of ownership currently active on this Token, if owned by the given owner.
releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
releaseClaim(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Creates a new PreparedStatement to release the current claim this node has on a token belonging to a processor with given processorName and segment.
releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
releaseClaim(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Release a claim of the token for given processorName and segment.
RemoteCommandHandlingException - Exception in org.axonframework.commandhandling.distributed
Exception indicating that an error has occurred while remotely handling a command.
RemoteCommandHandlingException(String) - Constructor for exception org.axonframework.commandhandling.distributed.RemoteCommandHandlingException
Initializes the exception using the given message.
RemoteCommandHandlingException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.RemoteCommandHandlingException
Initializes the exception using the given message and cause.
remove(K) - Method in interface org.axonframework.common.caching.Cache
Removes the entry stored under given key.
remove(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
remove(K) - Method in class org.axonframework.common.caching.JCacheAdapter
 
remove(Object) - Method in class org.axonframework.common.caching.NoCache
 
remove(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
remove(AssociationValue) - Method in interface org.axonframework.eventhandling.saga.AssociationValues
Removes the given associationValue, if it is contained by this instance.
remove(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
remove(AssociationValue, String, String) - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
Removes an association between the given associationValue and sagaIdentifier.
remove() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
 
remove(Object) - Method in class org.axonframework.messaging.MetaData
This operation is not supported.
removeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Removes the given associationValue of the saga with given sagaIdentifier and sagaType.
removeAssociationWith(String, String) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
Removes the given association from the currently active Saga.
removeAssociationWith(String, Number) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
Removes the given association from the currently active Saga.
removedAssociations() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
Returns the Set of association values that have been removed since the last AssociationValues.commit().
removedAssociations() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
ReplyMessage - Class in org.axonframework.commandhandling.distributed
Base class for reply messages which may be used in the CommandBusConnector for replying on received commands from other nodes.
ReplyMessage() - Constructor for class org.axonframework.commandhandling.distributed.ReplyMessage
Default constructor required for de-/serialization of extending classes.
ReplyMessage(String, boolean, Object, Serializer) - Constructor for class org.axonframework.commandhandling.distributed.ReplyMessage
Initializes a ReplyMessage containing a reply to the command with given {commandIdentifier} and given returnValue.
reportDifferenceInStoredVsPublished(Collection<DomainEventMessage<?>>, Collection<EventMessage<?>>, Throwable) - Method in class org.axonframework.test.aggregate.Reporter
Report a failed assertion due to a difference in the stored versus the published events.
reportDifferentEventContents(Class<?>, Field, Object, Object) - Method in class org.axonframework.test.aggregate.Reporter
Report an error due to a difference in on of the fields of an event.
Reporter - Class in org.axonframework.test.aggregate
The reporter generates extensive human readable reports of what the expected outcome of a test was, and what the actual results were.
Reporter() - Constructor for class org.axonframework.test.aggregate.Reporter
 
reportFailed(Matcher<? super T>) - Method in class org.axonframework.test.matchers.ListMatcher
Report the given matcher as a failing matcher.
reportFailure(Throwable) - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
Notify the monitor that a failure occurred during processing of the message
reportFailure(Throwable) - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
 
reportIgnored() - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
Notify the monitor that the message was ignored
reportIgnored() - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
 
reportIllegalState(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Invoked when an the given aggregate instance has been detected that has been part of a rolled back Unit of Work.
reportIllegalState(LockAwareAggregate<T, EventSourcedAggregate<T>>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
reportSuccess() - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
Notify the monitor that the message was handled successfully
reportSuccess() - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
 
reportUnexpectedException(Throwable, Description) - Method in class org.axonframework.test.aggregate.Reporter
Reports an error due to an unexpected exception.
reportUnexpectedReturnValue(Object, Description) - Method in class org.axonframework.test.aggregate.Reporter
Report an error due to an unexpected return value, while an exception was expected.
reportWrongEvent(Collection<?>, Collection<?>, Throwable) - Method in class org.axonframework.test.aggregate.Reporter
Report an error in the ordering or count of events.
reportWrongEvent(Collection<?>, StringDescription, Throwable) - Method in class org.axonframework.test.aggregate.Reporter
Report an error in the ordering or count of events.
reportWrongException(Throwable, Description) - Method in class org.axonframework.test.aggregate.Reporter
Report an error due to a an exception of an unexpected type.
reportWrongResult(Object, Description) - Method in class org.axonframework.test.aggregate.Reporter
Reports an error due to a wrong return value.
Repository<T> - Interface in org.axonframework.commandhandling.model
The repository provides an abstraction of the storage of aggregates.
repository() - Method in interface org.axonframework.config.AggregateConfiguration
Returns the repository defined to load instances of the Aggregate type defined in this configuration
repository() - Method in class org.axonframework.config.AggregateConfigurer
 
repository(Class<T>) - Method in interface org.axonframework.config.Configuration
Returns the Repository configured for the given aggregateType.
repository(Class<T>) - Method in class org.axonframework.spring.config.AxonConfiguration
 
RepositoryContentValidator<T> - Class in org.axonframework.test.saga
Helper class for the validation of Saga Repository content.
reschedule(ScheduleToken, Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Cancel a scheduled event and schedule another in its place.
reset(CommandMessage<?>, MessageHandler<? super CommandMessage<?>>, int, int, BlacklistDetectingCallback, List<MessageHandlerInterceptor<? super CommandMessage<?>>>, List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Resets this entry, preparing it for use for another command.
reset(T) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Resets the state of this Unit of Work, by setting its phase to NOT_STARTED, replacing the message of this Unit of Work with given message, and clearing its collection of registered handlers.
reset(T) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Reset the processing context.
resetAsRecoverEntry(String) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Resets this entry, preparing it for use as a recovery entry.
resolveAddress(Member) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
Resolve the JGroups Address of the given Member.
resolveAssociation(EventMessage<?>) - Method in interface org.axonframework.eventhandling.saga.metamodel.SagaModel
Returns the AssociationValue used to find sagas of type T that can handle the given eventMessage.
resolveClassName(SerializedType) - Method in class org.axonframework.serialization.json.JacksonSerializer
Resolve the class name from the given serializedType.
resolveGenericType(Field, int) - Static method in class org.axonframework.common.ReflectionUtils
Resolve a generic type parameter from a field declaration
resolveParameterValue(Message<?>) - Method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
 
resolveParameterValue(Message) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
 
resolveParameterValue(Message<?>) - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
 
resolveParameterValue(Message) - Method in class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
 
resolveParameterValue(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
 
resolveParameterValue(Message<?>) - Method in interface org.axonframework.messaging.annotation.ParameterResolver
Resolves the parameter value to use for the given message, or null if no suitable parameter value can be resolved.
resolveParameterValue(Message) - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
 
resolvePrimitiveWrapperType(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
Returns the boxed wrapper type for the given primitiveType.
resolveReturnValue(CommandMessage<?>, Aggregate<T>) - Method in class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
Resolves the value to return when the given command has created the given aggregate.
resolveRoutingKey(EventMessage<?>) - Method in class org.axonframework.amqp.eventhandling.PackageRoutingKeyResolver
 
resolveRoutingKey(EventMessage<?>) - Method in interface org.axonframework.amqp.eventhandling.RoutingKeyResolver
Returns the Routing Key to use when sending the given eventMessage to the Message Broker.
resolveTarget(CommandMessage<?>) - Method in class org.axonframework.commandhandling.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() - Method in interface org.axonframework.config.Configuration
Returns the ResourceInjector used to provide resources to Saga instances.
ResourceInjector - Interface in org.axonframework.eventhandling.saga
Interface describing a mechanism to inject resources into Saga instances.
resourceInjector() - Method in class org.axonframework.spring.config.AxonConfiguration
 
resources() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
resources() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns a mutable map of resources registered with the Unit of Work.
restTemplate() - Method in class org.axonframework.boot.autoconfig.SpringCloudAutoConfiguration
 
resultRevision - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
resultType - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
ResultValidator - Interface in org.axonframework.test.aggregate
Interface describing the operations available on the "validate result" (a.k.a.
ResultValidatorImpl - Class in org.axonframework.test.aggregate
Implementation of the ResultValidator.
ResultValidatorImpl(List<EventMessage<?>>, FieldFilter) - Constructor for class org.axonframework.test.aggregate.ResultValidatorImpl
Initialize the ResultValidatorImpl with the given storedEvents and publishedEvents.
resume() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
Resume a paused Unit of Work by registering it with the CurrentUnitOfWork.
RetryingCallback<C,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<C, R>, 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.
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 - Variable in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
 
Revision - Annotation Type in org.axonframework.serialization
Annotation that attaches revision information to a Serializable object.
revisionOf(Class<?>) - Method in class org.axonframework.serialization.AnnotationRevisionResolver
 
revisionOf(Class<?>) - Method in class org.axonframework.serialization.FixedValueRevisionResolver
 
revisionOf(Class<?>) - Method in class org.axonframework.serialization.MavenArtifactRevisionResolver
 
revisionOf(Class<?>) - Method in interface org.axonframework.serialization.RevisionResolver
Returns the revision for the given payloadType.
revisionOf(Class<?>) - Method in class org.axonframework.serialization.SerialVersionUIDRevisionResolver
 
RevisionResolver - Interface in org.axonframework.serialization
Interface towards a mechanism that resolves the revision of a given payload type.
rollback() - Method in interface org.axonframework.common.transaction.Transaction
Roll back this transaction.
rollback(Throwable) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
rollback() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Initiates the rollback of this Unit of Work, invoking all registered rollback (and clean-up handlers {@link #onCleanup(Consumer)} respectively.
rollback(Throwable) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Initiates the rollback of this Unit of Work, invoking all registered rollback (and clean-up handlers {@link #onCleanup(Consumer)} respectively.
RollbackConfiguration - Interface in org.axonframework.messaging.unitofwork
The RollbackConfiguration defines if a Unit of Work should be rolled back when an exception is raised during the processing of a Message.
RollbackConfigurationType - Enum in org.axonframework.messaging.unitofwork
Enum containing common rollback configurations for the Unit of Work.
rollBackOn(Throwable) - Method in interface org.axonframework.messaging.unitofwork.RollbackConfiguration
Decides whether the given throwable should trigger a rollback.
rollbackTransaction(TransactionStatus) - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
Rolls back the transaction with given status if the transaction is new and not completed.
root() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
Returns the (annotated) Saga instance.
root() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns the root of this Unit of Work.
rootType() - Method in interface org.axonframework.commandhandling.model.Aggregate
Get the class type of the wrapped aggregate root that the Aggregate defers to for command handling.
rootType() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
rootType() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
routingKey() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
routingKey() - Method in interface org.axonframework.commandhandling.model.inspection.CommandMessageHandlingMember
Returns the property of the command that is to be used as routing key towards this command handler instance.
routingKey() - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
Get the name of the routing key property on commands and events that provides the identifier that should be used to target entities of this kind.
routingKey() - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
RoutingKeyResolver - Interface in org.axonframework.amqp.eventhandling
Interface toward a mechanism that provides the AMQP Routing Key for a given EventMessage.
routingKeyResolver() - Method in class org.axonframework.boot.autoconfig.AMQPAutoConfiguration
 
RoutingStrategy - Interface in org.axonframework.commandhandling.distributed
Interface describing a mechanism that generates a routing key for a given command.
run() - Method in class org.axonframework.common.MemberAccessibilityCallback
 
run() - Method in class org.axonframework.eventhandling.async.EventProcessorTask
 

S

saga() - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore.Entry
Returns the Saga instance in unserialized form.
Saga<T> - Interface in org.axonframework.eventhandling.saga
Interface describing an implementation of a Saga.
Saga - Annotation Type in org.axonframework.spring.stereotype
Annotation that informs Axon's auto configurer for Spring that a given Component is a saga instance.
sagaCollection() - Method in class org.axonframework.mongo.eventhandling.saga.repository.DefaultMongoTemplate
 
sagaCollection() - Method in interface org.axonframework.mongo.eventhandling.saga.repository.MongoTemplate
Returns a reference to the collection containing the saga instances.
SagaConfiguration<S> - Class in org.axonframework.config
Module Configuration implementation that defines a Saga.
SagaCreationException - Exception in org.axonframework.eventhandling.saga.repository
Exception triggered when a new saga instance could not be instantiated.
SagaCreationException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.repository.SagaCreationException
Initializes the exception using the given message and cause.
SagaCreationPolicy - Enum in org.axonframework.eventhandling.saga
Enumeration containing the possible Creation Policies for Sagas.
SagaEntry<T> - Class in org.axonframework.eventhandling.saga.repository.jpa
Java Persistence Entity allowing sagas to be stored in a relational database.
SagaEntry(T, String, Serializer) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.SagaEntry
Constructs a new SagaEntry for the given saga.
SagaEntry() - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.SagaEntry
Constructor required by JPA.
SagaEntry<T> - Class in org.axonframework.mongo.eventhandling.saga.repository
Java representation of sagas stored in a mongo instance
SagaEntry(String, T, Set<AssociationValue>, Serializer) - Constructor for class org.axonframework.mongo.eventhandling.saga.repository.SagaEntry
Constructs a new SagaEntry for the given saga.
SagaEntry(Document) - Constructor for class org.axonframework.mongo.eventhandling.saga.repository.SagaEntry
Initializes a Saga entry using a DBObject containing the Mongo Document
sagaEntryEntityName() - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Intended for clients to override.
sagaEntryTable() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
Returns the name of the sagaEntry table
SagaEventHandler - Annotation Type in org.axonframework.eventhandling.saga
Method-level annotation indicating that the annotated method is an event handler method for the saga instance.
SagaExecutionException - Exception in org.axonframework.eventhandling.saga
Exception triggered by a saga while it is processing an event or processing a task.
SagaExecutionException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.SagaExecutionException
Initializes the exception using the given message and cause.
sagaId - Variable in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
 
SagaInitializationPolicy - Class in org.axonframework.eventhandling.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.eventhandling.saga.SagaInitializationPolicy
Creates an instance using the given creationPolicy and initialAssociationValue.
SagaInstantiationException - Exception in org.axonframework.eventhandling.saga
Exception triggered during initialization of a Saga.
SagaInstantiationException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.SagaInstantiationException
Initializes the exception using the given message and cause.
SagaLifecycle - Class in org.axonframework.eventhandling.saga
Abstract base class of a component that models a saga's life cycle.
SagaLifecycle() - Constructor for class org.axonframework.eventhandling.saga.SagaLifecycle
 
SagaMetaModelFactory - Interface in org.axonframework.eventhandling.saga.metamodel
Interface of a factory for a SagaModel for any given saga type.
SagaMethodMessageHandlerDefinition - Class in org.axonframework.eventhandling.saga
Utility class that inspects annotation on a Saga instance and returns the relevant configuration for its Event Handlers.
SagaMethodMessageHandlerDefinition() - Constructor for class org.axonframework.eventhandling.saga.SagaMethodMessageHandlerDefinition
 
SagaMethodMessageHandlingMember<T> - Class in org.axonframework.eventhandling.saga
A data holder containing information of SagaEventHandler annotated methods.
SagaMethodMessageHandlingMember(MessageHandlingMember<T>, SagaCreationPolicy, String, Property, boolean) - Constructor for class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
Creates a SagaMethodMessageHandler.
SagaModel<T> - Interface in org.axonframework.eventhandling.saga.metamodel
Interface of a model that describes a Saga of type T.
SagaRepository<T> - Interface in org.axonframework.eventhandling.saga
Interface towards the storage mechanism of Saga instances.
sagaSchema() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
Returns the SagaSchema used to configure this sql saga schema.
SagaSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
SagaSchema allows specification of custom storage locations for the saga repositories.
SagaSchema() - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
Initialize SagaSchema with default values.
SagaSchema(String, String) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
Initialize SagaSchema with custom locations for event entry tables.
SagaSqlSchema - Interface in org.axonframework.eventhandling.saga.repository.jdbc
Interface describing the SQL statements that the JdbcSagaRepository needs to execute against the underlying database.
SagaStorageException - Exception in org.axonframework.eventhandling.saga
Exception indicating that an error has occurred while storing a Saga.
SagaStorageException(String) - Constructor for exception org.axonframework.eventhandling.saga.SagaStorageException
Initialize a SagaStorageException with the given descriptive message.
SagaStorageException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.SagaStorageException
Initialize a SagaStorageException with the given descriptive message and cause.
sagaStore(Serializer, EntityManagerProvider) - Method in class org.axonframework.boot.autoconfig.JpaAutoConfiguration
 
SagaStore<T> - Interface in org.axonframework.eventhandling.saga.repository
Provides a mechanism to find, load update and delete sagas of type T from an underlying storage like a database.
SagaStore.Entry<T> - Interface in org.axonframework.eventhandling.saga.repository
Interface describing a Saga entry fetched from a SagaStore.
SagaTestFixture<T> - Class in org.axonframework.test.saga
Fixture for testing Annotated Sagas based on events and time passing.
SagaTestFixture(Class<T>) - Constructor for class org.axonframework.test.saga.SagaTestFixture
Creates an instance of the AnnotatedSagaTestFixture to test sagas of the given sagaType.
sagaType - Variable in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
 
schedule(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
Schedules this task for execution when all pre-conditions have been met.
schedule(Instant, 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(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
 
schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
 
schedule(Instant, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
schedule(Duration, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
ScheduledItem - Interface in org.axonframework.test.eventscheduler
Interface describing an event to be scheduled at a given date and time.
scheduleEvents(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.EventProcessorTask
Schedules a batch of events 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(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
 
scheduleSnapshot(Class<?>, String) - Method in interface org.axonframework.eventsourcing.Snapshotter
Schedules snapshot taking for an aggregate with given 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.
schema() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Returns the EventSchema that defines the table and column names of event tables in the database.
segmentColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns the name of the column containing the segment of the processor to which the token belongs.
segmentCount() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
Returns this member's segment count which relates to the relative load factor of the member.
selectForUpdate(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Returns a PreparedStatement to select a token entry from the underlying storage.
selectImports(AnnotationMetadata) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer.ImportSelector
 
send(List<? extends EventMessage<?>>) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sends the given events to the configured AMQP Exchange.
send(Member, CommandMessage<? extends C>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Sends the given command to the node assigned to handle messages with the given routingKey.
send(Member, CommandMessage<C>, CommandCallback<? super C, R>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Sends the given command to the node assigned to handle messages with the given routingKey.
send(C, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Sends the given command, and invokes the callback when the command is processed.
send(C, CommandCallback<? super C, 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(C, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
 
send(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
 
send(Member, CommandMessage<? extends C>) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
send(Member, CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
send(Member, CommandMessage<? extends C>) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector
 
send(Member, CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector
 
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.
SequenceEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
EventStorageEngine implementation that combines the streams of two event storage engines.
SequenceEventStorageEngine(EventStorageEngine, EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
Initializes a new SequenceEventStorageEngine using given historicStorage and activeStorage.
SequenceMatcher<T> - Class in org.axonframework.test.matchers
A matcher that will match if all the given matchers each match against an item that the previous matcher matched against.
SequenceMatcher(Matcher<? super T>...) - Constructor for class org.axonframework.test.matchers.SequenceMatcher
Construct a matcher that will return true if all the given matchers match against an item positioned after the item that the previous matcher matched against.
SequenceNumber - Annotation Type in org.axonframework.eventsourcing
Annotation indicating that a parameter on an Event Handler method should be injected with the SequenceNumber of a DomainEventMessage.
sequenceNumberColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the aggregate sequence number of the event.
SequenceNumberParameterResolver() - Constructor for class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
 
SequenceNumberParameterResolverFactory - Class in org.axonframework.eventsourcing
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.eventsourcing.SequenceNumberParameterResolverFactory
Initializes a ParameterResolverFactory for SequenceNumber annotated parameters
SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver - Class in org.axonframework.eventsourcing
ParameterResolver that resolves SequenceNumber parameters
sequenceNumberProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the aggregate sequence number of the event.
sequenceOf(Matcher<T>...) - Static method in class org.axonframework.test.matchers.Matchers
Matches a list of Events if each of the matchers match against an Event that comes after the Event that the previous matcher matched against.
SequencingPolicy<T> - Interface in org.axonframework.eventhandling.async
Interface to a policy definition for concurrent processing, for example event handling.
SequentialPerAggregatePolicy - Class in org.axonframework.eventhandling.async
Concurrency policy that requires sequential processing of events raised by the same aggregate.
SequentialPerAggregatePolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
 
SequentialPolicy - Class in org.axonframework.eventhandling.async
SequencingPolicy that requires serialized handling of all events delivered to an event handler.
SequentialPolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPolicy
 
SerializationAware - Interface in org.axonframework.serialization
Marker interface for messages that have special serialization awareness.
SerializationException - Exception in org.axonframework.serialization
Indicates that an exception occurred while serializing or deserializing an object.
SerializationException(String) - Constructor for exception org.axonframework.serialization.SerializationException
Initializes the exception using the given message.
SerializationException(String, Throwable) - Constructor for exception org.axonframework.serialization.SerializationException
Initializes the exception using the given message and cause.
serialize(Object, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
serialize(Object, Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
 
serialize(Object, Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
serialize(Object, Class<T>) - Method in class org.axonframework.serialization.MessageSerializer
 
serialize(Object, Class<T>) - Method in interface org.axonframework.serialization.Serializer
Serialize the given object into a Serialized Object containing the given expectedRepresentation.
SerializedMessage<T> - Class in org.axonframework.serialization
A message containing serialized payload data and metadata.
SerializedMessage(String, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serialization.SerializedMessage
Initializes a SerializedMessage with given identifier from the given serialized payload and metadata.
SerializedMessage(String, LazyDeserializingObject<T>, LazyDeserializingObject<MetaData>) - Constructor for class org.axonframework.serialization.SerializedMessage
Initializes a SerializedMessage with given identifier from the given lazily deserializing payload and metadata.
serializedMetaData - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
SerializedMetaData<T> - Class in org.axonframework.serialization
Represents the serialized form of a MetaData instance.
SerializedMetaData(T, Class<T>) - Constructor for class org.axonframework.serialization.SerializedMetaData
Construct an instance with given bytes representing the serialized form of a MetaData instance.
SerializedObject<T> - Interface in org.axonframework.serialization
Interface describing the structure of a serialized object.
SerializedObjectHolder - Class in org.axonframework.serialization
Holder that keeps references to serialized representations of a payload and meta data of a specific message.
SerializedObjectHolder(Message) - Constructor for class org.axonframework.serialization.SerializedObjectHolder
Initialize the holder for the serialized representations of the payload and meta data of given message
serializedObjectType() - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Intended for clients to override.
serializedPayload - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
serializedResult - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
serializedSaga - Variable in class org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry
 
SerializedSaga - Class in org.axonframework.eventhandling.saga.repository.jpa
Specialization of the SerializedObject for Sagas represented as byte array.
SerializedSaga(byte[], String, String) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.SerializedSaga
Initialize a SerializedSaga instance with given data, of given type and revision.
SerializedType - Interface in org.axonframework.serialization
Describes the type of a serialized object.
serializeMetaData(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
 
serializeMetaData(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serialization.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.serialization.MessageSerializer
Serialize the meta data of given message to the given expectedRepresentation.
serializeMetaData(Serializer, Class<T>) - Method in interface org.axonframework.serialization.SerializationAware
Serialize the meta data of this message using given serializer, using given expectedRepresentation.
serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
 
serializeMetaData(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
 
serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
 
serializePayload(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serialization.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.serialization.MessageSerializer
Serialize the payload of given message to the given expectedRepresentation.
serializePayload(Serializer, Class<T>) - Method in interface org.axonframework.serialization.SerializationAware
Serialize the payload of this message using given serializer, using given expectedRepresentation.
serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
 
serializePayload(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
 
serializer() - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
serializer() - Method in interface org.axonframework.config.Configuration
Returns the serializer defined in this Configuration
Serializer - Interface in org.axonframework.serialization
Interface describing a serialization mechanism.
SerialVersionUIDRevisionResolver - Class in org.axonframework.serialization
RevisionResolver implementation that returns the (String representation of the) serialVersionUID of a class.
SerialVersionUIDRevisionResolver() - Constructor for class org.axonframework.serialization.SerialVersionUIDRevisionResolver
 
ServiceRegistryException - Exception in org.axonframework.commandhandling.distributed
Exception that is triggered when an error occurs that is related to the registration or deregistration of a member to the distributed command bus service registry.
ServiceRegistryException(String) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
Initializes the exception using the given message.
ServiceRegistryException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
Initializes the exception using the given message and cause.
set(UnitOfWork<?>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
Binds the given unitOfWork to the current thread.
setAdditionalConverters(List<ContentTypeConverter>) - Method in class org.axonframework.serialization.ChainingConverter
Setter for dependency injection frameworks that require property methods.
setAdditionalFactories(List<ParameterResolverFactory>) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
Defines any additional parameter resolver factories that need to be used to resolve parameters.
setApplicationContext(ApplicationContext) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.AxonConfiguration
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.messaging.ApplicationContextEventPublisher
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.saga.SpringResourceInjector
 
setAttribute(String, String) - Method in class org.axonframework.mongo.serialization.BSONNode
Sets an attribute to this node.
setAutoStart(boolean) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties.Gossip
 
setBeanClassLoader(ClassLoader) - Method in class org.axonframework.boot.autoconfig.AxonAutoConfiguration
 
setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer
 
setBeanName(String) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
setBeanName(String) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
 
setBindAddr(String) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
setBindPort(String) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
setBufferSize(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the buffer size to use.
setCache(Cache) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the cache in which loaded aggregates will be stored.
setCallbackBehavior(CallbackBehavior) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback.
setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.saga.SagaTestFixture
 
setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.utils.RecordingCommandBus
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback.
setChannelFactory(JChannelFactory) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the JChannelFactory that allows programmatic definition of the JChannel.
setChannelName(String) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Optionally sets the logical channel name of the channel.
setClusterName(String) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
setClusterName(String) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the name of the cluster to subscribe to.
setCommandBus(CommandBus) - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
Sets the command bus on which the Gateway must dispatch commands.
setCommandBus(CommandBus) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
Sets the command bus to use when subscribing command handlers.
setCommandCallbacks(List<CommandCallback<?, ?>>) - Method in class org.axonframework.spring.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(List<MessageDispatchInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
Sets the interceptors that should be invoked before a command is dispatched the the Command Bus.
setCommandHandlers(Collection<MessageHandler>) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
Sets the command handlers to subscribe to the bus.
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.
setConfiguration(String) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the JGroups configuration file to load.
setConfigurationFile(String) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
setConnectionFactory(ConnectionFactory) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sets the ConnectionFactory providing the Connections and Channels to send messages on.
setConnectionsPerHost(int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Setter for the connections per host that are allowed.
setConnectionTimeout(int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Setter for the connection time out.
setCoolingDownPeriod(long) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the cooling down period in milliseconds.
setDispatchInterceptors(List<MessageDispatchInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Configures the CommandDispatchInterceptor to use with the DisruptorCommandBus when commands are dispatched.
setDurable(boolean) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Whether or not messages should be marked as "durable" when sending them out.
setDurableMessages(boolean) - Method in class org.axonframework.boot.AMQPProperties
 
setEnabled(boolean) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
setEnabled(boolean) - Method in class org.axonframework.boot.DistributedCommandBusProperties
 
setEntityManager(EntityManager) - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
Sets the container managed entityManager to use.
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.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
Sets the eventBus that scheduled events should be published to.
setEventBus(EventBus) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the event bus to which scheduled events need to be published.
setEventHandlers(List<Object>) - Method in class org.axonframework.spring.config.EventHandlerRegistrar
Registers the given beans as event handlers with the Event Handler Configuration.
setEventJobDataBinder(EventJobDataBinder) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the EventJobDataBinder instance which reads / writes the event message to publish to the JobDataMap.
setEventJobDataBinder(EventJobDataBinder) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the EventJobDataBinder instance which reads / writes the event message to publish to the JobDataMap.
setEventStore(EventStore) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
Sets the Event Store instance to write the snapshots to
setExceptionResult(Exception) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
Registers the exception that occurred while processing the incoming command.
setExchange(Exchange) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sets the name of the exchange to dispatch published messages to.
setExchange(String) - Method in class org.axonframework.boot.AMQPProperties
 
setExchangeName(String) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sets the name of the exchange to dispatch published messages to.
setExecutionResult(ExecutionResult) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
Set the execution result of processing the current Message.
setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
 
setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Set the execution result of processing the current Message.
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.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
Sets the executor to process the creation (and storage) of each snapshot.
setExecutorService(ScheduledExecutorService) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
Sets the ExecutorService implementation that monitors the triggers and provides the Threads to publish events.
setFieldValue(Field, Object, T) - Static method in class org.axonframework.common.ReflectionUtils
Set the field of object to a certain value.
setForceFlushOnSave(boolean) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
Indicates whether the EntityManager's state should be flushed each time an aggregate is saved.
setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken.
setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken.
setGapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out.
setGapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out.
setGatewayInterface(Class<T>) - Method in class org.axonframework.spring.commandhandling.gateway.CommandGatewayFactoryBean
Sets the interface that describes the gateway instance to describe.
setGossip(DistributedCommandBusProperties.JGroupsProperties.Gossip) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
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.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the group identifier to use when scheduling jobs with Quartz.
setHosts(String) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties.Gossip
 
setInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the interceptor to use in the default local segment (a SimpleCommandBus).
setInvokerInterceptors(List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - 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.
setJgroups(DistributedCommandBusProperties.JGroupsProperties) - Method in class org.axonframework.boot.DistributedCommandBusProperties
 
setJoinTimeout(long) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the number of milliseconds to wait for this member to join the group.
setLoadFactor(int) - Method in class org.axonframework.boot.DistributedCommandBusProperties.JGroupsProperties
 
setLoadFactor(int) - Method in class org.axonframework.boot.DistributedCommandBusProperties
 
setLocalSegment(CommandBus) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the CommandBus instance on which local commands must be dispatched.
setMaxWaitTime(int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Set the max wait time for a blocked thread in milli seconds.
setMessageConverter(AMQPMessageConverter) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sets the Message Converter that creates AMQP Messages from Event Messages and vice versa.
setMessageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the message monitor to use.
setMode(EventProcessorProperties.Mode) - Method in class org.axonframework.boot.EventProcessorProperties.ProcessorSettings
 
setMongoAddresses(List<ServerAddress>) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoFactory
Provide a list of ServerAddress objects to use for locating the Mongo replica set.
setMongoOptions(MongoClientOptions) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoFactory
Provide an instance of MongoOptions to be used for the connections.
setOwnerColum(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the owner column.
setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
Sets the ParameterResolverFactory to create the Parameter Resolvers with that provide the parameter values for the handler methods.
setPhase(UnitOfWork.Phase) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
Overwrite the current phase with the given phase.
setPhase(int) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the phase in which this bean must be started.
setProcessorNameColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the processor name column.
setProducerType(ProducerType) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the producer type to use.
setPrototypeBeanName(String) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
Sets the name of the prototype bean this repository serves.
setPublisherAckTimeout(long) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sets the maximum amount of time (in milliseconds) the publisher may wait for the acknowledgement of published messages.
setPublisherInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>>) - 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.
setRegisterMBean(boolean) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Registers the JChannel monitoring bean after the channel has connected.
setReportIllegalStateChange(boolean) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
setReportIllegalStateChange(boolean) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Sets whether or not the fixture should detect and report state changes that occur outside of Event Handler methods.
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.
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.spring.commandhandling.gateway.CommandGatewayFactoryBean
Sets the RetryScheduler that will be invoked when a command fails execution.
setRollbackCause(Throwable) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
Sets the cause for rolling back this Unit of Work.
setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
 
setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the rollback configuration for the DisruptorCommandBus to use.
setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Sets the RollbackConfiguration that allows you to change when the UnitOfWork is committed.
setRoutingKeyResolver(RoutingKeyResolver) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sets the RoutingKeyResolver that provides the Routing Key for each message to dispatch.
setRoutingStrategy(RoutingStrategy) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the RoutingStrategy that the JGroupsConnector will use to determine to which endpoint a message should be routed.
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.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the backing Quartz Scheduler for this timer.
setSegmentColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the processor segment column.
setSerializer(Serializer) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Sets the serializer to serialize messages with when sending them to the Exchange.
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.eventhandling.saga.repository.jdbc.JdbcSagaStore
Sets the Serializer instance to serialize Sagas with.
setSerializer(Serializer) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
Sets the serializer used to serialize events before they are dispatched to the destination.
setSocketTimeOut(int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Setter for the socket time out.
setSource(String) - Method in class org.axonframework.boot.EventProcessorProperties.ProcessorSettings
 
setState(InputStream) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
setSuppressExceptions(boolean) - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
Sets whether or not to suppress any exceptions that are cause by invoking Sagas.
setThreadsAllowedToBlockForConnectionMultiplier(int) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoOptionsFactory
Set the multiplier for the amount of threads to block in relation to the maximum amount of connections.
setTimestampColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the timestamp column.
setTokenColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the serialized token column.
setTokenTable(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the token entry table.
setTokenTypeColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the token type column.
setTransactional(boolean) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Whether this Terminal should dispatch its Events in a transaction or not.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
The TransactionDefinition to use by the transaction manager.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
The TransactionDefinition to use by the transaction manager.
setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
Optionally sets the transaction definition to use.
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.eventhandling.scheduling.quartz.QuartzEventScheduler
Sets the transaction manager that manages a transaction around the publication of an event.
setTransactionManager(Object) - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
Sets the actual transaction manager.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
Sets the transaction manager that manages the transaction around the publication of an event.
setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.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.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
Sets the transaction manager to manager underlying transaction with.
setTransactionMode(AMQPProperties.TransactionMode) - Method in class org.axonframework.boot.AMQPProperties
 
setUseExplicitFlush(boolean) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Sets whether or not to do an explicit EntityManager.flush() after each data modifying operation on the backing storage.
setValue(String) - Method in class org.axonframework.mongo.serialization.BSONNode
Sets the value of this node.
setValue(String) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
setWaitForPublisherAck(boolean) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Enables or diables the RabbitMQ specific publisher acknowledgements (confirms).
setWaitStrategy(WaitStrategy) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
Sets the WaitStrategy, which used to make dependent threads wait for tasks to be completed.
setWriteConcern(WriteConcern) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoFactory
Provided a write concern to be used by the mongo instance.
shutDown() - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Shuts down this component and unsubscribes it from its messageSource.
shutdown() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
Shuts down the Executor used to asynchronously dispatch incoming commands.
shutdown() - Method in class org.axonframework.config.AggregateConfigurer
 
shutdown() - Method in interface org.axonframework.config.Configuration
Shuts down the components defined in this Configuration
shutdown() - Method in class org.axonframework.config.EventHandlingConfiguration
 
shutdown() - Method in interface org.axonframework.config.ModuleConfiguration
Invoked prior to shutdown of the application.
shutdown() - Method in class org.axonframework.config.SagaConfiguration
 
shutDown() - Method in interface org.axonframework.eventhandling.EventProcessor
Stop processing events.
shutDown() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
Shut down this processor.
shutDown() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Shut down the processor.
shutDown() - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
Method to invoke when the application shuts down.
shutdown() - Method in class org.axonframework.spring.config.AxonConfiguration
 
SimpleCommandBus - Class in org.axonframework.commandhandling
Implementation of the CommandBus that dispatches commands to the handlers subscribed to that specific command's name.
SimpleCommandBus() - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
Initializes the SimpleCommandBus.
SimpleCommandBus(TransactionManager, MessageMonitor<? super CommandMessage<?>>) - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
Initializes the SimpleCommandBus with the given transactionManager and messageMonitor
SimpleCorrelationDataProvider - Class in org.axonframework.messaging.correlation
CorrelationDataProvider implementation defines correlation headers by the header names.
SimpleCorrelationDataProvider(String...) - Constructor for class org.axonframework.messaging.correlation.SimpleCorrelationDataProvider
Initializes the CorrelationDataProvider to return the meta data of messages with given metaDataKeys as correlation data.
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 supports streaming of events via SimpleEventBus.openStream(TrackingToken) but only of the most recently published events as it is not backed by a cache or event storage.
SimpleEventBus() - Constructor for class org.axonframework.eventhandling.SimpleEventBus
Initializes an event bus using a NoOpMessageMonitor and default queue capacity of Integer.MAX_VALUE.
SimpleEventBus(int, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SimpleEventBus
Initializes an event bus.
SimpleEventHandlerInvoker - Class in org.axonframework.eventhandling
Implementation of an EventHandlerInvoker that forwards events to a list of registered EventListeners.
SimpleEventHandlerInvoker(Object...) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
Initializes a SimpleEventHandlerInvoker containing one or more eventListeners.
SimpleEventHandlerInvoker(List<?>, ListenerInvocationErrorHandler) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
Initializes a SimpleEventHandlerInvoker containing the given list of eventListeners.
SimpleEventHandlerInvoker(List<?>, ParameterResolverFactory, ListenerInvocationErrorHandler) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
Initializes a SimpleEventHandlerInvoker containing the given list of eventListeners.
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, TransactionManager) - 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.spring.eventhandling.scheduling.java
Spring FactoryBean that creates a SimpleEventScheduler instance using resources found in the Spring Application Context.
SimpleEventSchedulerFactoryBean() - Constructor for class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
SimpleMember<E> - Class in org.axonframework.commandhandling.distributed
An endpoint in the network for a command handling service.
SimpleMember(String, E, boolean, Consumer<SimpleMember<E>>) - Constructor for class org.axonframework.commandhandling.distributed.SimpleMember
Create the service member
SimpleResourceInjector - Class in org.axonframework.eventhandling.saga
A resource injector that checks for javax.inject.Inject annotated fields and setter methods to inject resources.
SimpleResourceInjector(Object...) - Constructor for class org.axonframework.eventhandling.saga.SimpleResourceInjector
Initializes the resource injector to inject to given resources.
SimpleResourceInjector(Collection<?>) - Constructor for class org.axonframework.eventhandling.saga.SimpleResourceInjector
Initializes the resource injector to inject to given resources.
SimpleResourceParameterResolverFactory - Class in org.axonframework.messaging.annotation
A ParameterResolverFactory implementation for simple resource injections.
SimpleResourceParameterResolverFactory(Iterable<?>) - Constructor for class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
Initialize the ParameterResolverFactory to inject the given resource in applicable parameters.
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.
SimpleSerializedObject<T> - Class in org.axonframework.serialization
SerializedObject implementation that takes all properties as constructor parameters.
SimpleSerializedObject(T, Class<T>, SerializedType) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
Initializes a SimpleSerializedObject using given data and serializedType.
SimpleSerializedObject(T, Class<T>, String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
Initializes a SimpleSerializedObject using given data and a serialized type identified by given type and revision.
SimpleSerializedType - Class in org.axonframework.serialization
SerializedType implementation that takes its properties as constructor parameters.
SimpleSerializedType(String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedType
Initialize with given objectType and revisionNumber
simulateAutoIncrement(Connection, String, String) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
Oracle11 does not have auto incremented values.
SingleEntryMultiUpcaster<T> - Class in org.axonframework.serialization.upcasting
Abstract implementation of an Upcaster that eases the common process of upcasting one intermediate representation to several other representations by applying a simple flat mapping function to the input stream of intermediate representations.
SingleEntryMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
 
SingleEntryUpcaster<T> - Class in org.axonframework.serialization.upcasting
Abstract implementation of an Upcaster that eases the common process of upcasting one intermediate representation to another representation by applying a simple mapping function to the input stream of intermediate representations.
SingleEntryUpcaster() - Constructor for class org.axonframework.serialization.upcasting.SingleEntryUpcaster
 
SingleEventUpcaster - Class in org.axonframework.serialization.upcasting.event
Abstract implementation of an event Upcaster that eases the common process of upcasting one intermediate event representation to another representation by applying a simple mapping function to the input stream of intermediate representations.
SingleEventUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.SingleEventUpcaster
 
size() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
Returns the number of AssociationValue instances available in this container
size() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
 
size() - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
Returns an approximation of the size of this map.
size() - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
Returns the number of Sagas currently contained in this repository.
size() - Method in class org.axonframework.messaging.MetaData
 
snapshotCollection() - Method in class org.axonframework.mongo.eventsourcing.eventstore.DefaultMongoTemplate
Returns a reference to the collection containing the snapshot events.
snapshotCollection() - Method in interface org.axonframework.mongo.eventsourcing.eventstore.MongoTemplate
Returns a reference to the collection containing the snapshot events.
SnapshotEventEntry - Class in org.axonframework.eventsourcing.eventstore.jpa
Default implementation of an event entry containing a serialized snapshot of an aggregate.
SnapshotEventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
Construct a new default snapshot event entry from an aggregate.
SnapshotEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
Default constructor required by JPA
snapshotEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Returns the name of the Snaphot event entity.
snapshotTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Returns the name of the snapshot event table.
Snapshotter - Interface in org.axonframework.eventsourcing
Interface describing instances that are capable of creating snapshot events for aggregates.
SnapshotTrigger - Interface in org.axonframework.eventsourcing
Interface describing a mechanism that keeps track of an Aggregate's activity in order to trigger a snapshot.
SnapshotTriggerDefinition - Interface in org.axonframework.eventsourcing
Interface describing the mechanism for triggering Snapshots.
SpringAggregateSnapshotter - Class in org.axonframework.spring.eventsourcing
Snapshotter implementation that uses the AggregateRoot as state for the snapshot.
SpringAggregateSnapshotter(EventStore, ParameterResolverFactory, Executor, TransactionManager) - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
Initializes a snapshotter using the ParameterResolverFactory instances available on the classpath.
SpringAggregateSnapshotterFactoryBean - Class in org.axonframework.spring.eventsourcing
Implementation of the AggregateSnapshotter that eases the configuration when used within a Spring Application Context.
SpringAggregateSnapshotterFactoryBean() - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
 
SpringAMQPMessageSource - Class in org.axonframework.amqp.eventhandling.spring
MessageListener implementation that deserializes incoming messages and forwards them to one or more event processors.
SpringAMQPMessageSource(Serializer) - Constructor for class org.axonframework.amqp.eventhandling.spring.SpringAMQPMessageSource
Initializes an SpringAMQPMessageSource with DefaultAMQPMessageConverter using given serializer.
SpringAMQPMessageSource(AMQPMessageConverter) - Constructor for class org.axonframework.amqp.eventhandling.spring.SpringAMQPMessageSource
Initializes an SpringAMQPMessageSource with given messageConverter to convert the incoming AMQP message into an EventMessage.
SpringAMQPPublisher - Class in org.axonframework.amqp.eventhandling.spring
EventBusTerminal implementation that uses an AMQP 0.9 compatible Message Broker to dispatch event messages.
SpringAMQPPublisher(SubscribableMessageSource<EventMessage<?>>) - Constructor for class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Initialize this instance to publish message as they are published on the given messageSource.
SpringAxonAutoConfigurer - Class in org.axonframework.spring.config
ImportBeanDefinitionRegistrar implementation that sets up an infrastructure Configuration based on beans available in the application context.
SpringAxonAutoConfigurer() - Constructor for class org.axonframework.spring.config.SpringAxonAutoConfigurer
 
SpringAxonAutoConfigurer.ImportSelector - Class in org.axonframework.spring.config
Implementation of an SpringAxonAutoConfigurer.ImportSelector that enables the import of the SpringAxonAutoConfigurer after all @Configuration beans have been processed.
SpringBeanParameterResolverFactory - Class in org.axonframework.spring.config.annotation
ParameterResolverFactory implementation that resolves parameters in the Spring Application Context.
SpringBeanParameterResolverFactory() - Constructor for class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
Default constructor, which relies on Spring to inject the application context.
SpringBeanParameterResolverFactory(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
Convenience constructor to use when an instance is not managed by Spring, but an application context is available.
SpringCloudAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
SpringCloudAutoConfiguration() - Constructor for class org.axonframework.boot.autoconfig.SpringCloudAutoConfiguration
 
springCloudCommandRouter(DiscoveryClient) - Method in class org.axonframework.boot.autoconfig.SpringCloudAutoConfiguration
 
SpringCloudCommandRouter - Class in org.axonframework.springcloud.commandhandling
A CommandRouter implementation which uses Spring Clouds DiscoveryClients to discover and notify other nodes for routing Commands.
SpringCloudCommandRouter(DiscoveryClient, RoutingStrategy, Serializer) - Constructor for class org.axonframework.springcloud.commandhandling.SpringCloudCommandRouter
Deprecated.
serializer is no longer customizable
SpringCloudCommandRouter(DiscoveryClient, RoutingStrategy) - Constructor for class org.axonframework.springcloud.commandhandling.SpringCloudCommandRouter
Initialize a CommandRouter with the given DiscoveryClient to update it's own membership as a CommandRouter and to create it's own awareness of available nodes to send commands to in a ConsistentHash.
SpringContextParameterResolverFactoryBuilder - Class in org.axonframework.spring.config.annotation
Creates and registers a bean definition for a Spring Context aware ParameterResolverFactory.
SpringDataSourceConnectionProvider - Class in org.axonframework.spring.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.spring.jdbc.SpringDataSourceConnectionProvider
Initialize the connection provider, using given dataSource to obtain a connection, when required.
springHttpCommandBusConnector(CommandBus, RestTemplate, Serializer) - Method in class org.axonframework.boot.autoconfig.SpringCloudAutoConfiguration
 
SpringHttpCommandBusConnector - Class in org.axonframework.springcloud.commandhandling
 
SpringHttpCommandBusConnector(CommandBus, RestOperations, Serializer) - Constructor for class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector
 
SpringHttpCommandBusConnector.SpringHttpReplyFutureCallback<C,R> - Class in org.axonframework.springcloud.commandhandling
 
SpringHttpDispatchMessage<C> - Class in org.axonframework.springcloud.commandhandling
Spring Http message that contains a CommandMessage that needs to be dispatched on a remote command bus segment.
SpringHttpDispatchMessage(CommandMessage<?>, Serializer, boolean) - Constructor for class org.axonframework.springcloud.commandhandling.SpringHttpDispatchMessage
Initialize a SpringHttpDispatchMessage for the given commandMessage, to be serialized using given serializer.
SpringHttpReplyFutureCallback() - Constructor for class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector.SpringHttpReplyFutureCallback
 
SpringHttpReplyMessage<R> - Class in org.axonframework.springcloud.commandhandling
Spring Http Message representing a reply to a dispatched command.
SpringHttpReplyMessage(String, boolean, Object, Serializer) - Constructor for class org.axonframework.springcloud.commandhandling.SpringHttpReplyMessage
Initializes a SpringHttpReplyMessage containing a reply to the command with given {commandIdentifier} and given returnValue.
SpringParameterResolverFactoryBean - Class in org.axonframework.spring.config.annotation
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.spring.config.annotation.SpringParameterResolverFactoryBean
 
SpringPrototypeAggregateFactory<T> - Class in org.axonframework.spring.eventsourcing
AggregateFactory implementation that uses Spring prototype beans to create new uninitialized instances of Aggregates.
SpringPrototypeAggregateFactory() - Constructor for class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
 
SpringResourceInjector - Class in org.axonframework.spring.saga
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.spring.saga.SpringResourceInjector
 
SpringTransactionManager - Class in org.axonframework.spring.messaging.unitofwork
TransactionManager implementation that uses a PlatformTransactionManager as underlying transaction manager.
SpringTransactionManager(PlatformTransactionManager, TransactionDefinition) - Constructor for class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
 
SpringTransactionManager(PlatformTransactionManager) - Constructor for class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
Initializes the SpringTransactionManager with the given transactionManager and the default transaction definition.
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.HsqlSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.Oracle11SagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in interface org.axonframework.eventhandling.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.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.Oracle11SagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that creates the table for storing Sagas.
sql_deleteAssociationEntries(Connection, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_deleteAssociationEntries(Connection, String) - Method in interface org.axonframework.eventhandling.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.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_deleteSagaEntry(Connection, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that deletes a Saga with given sagaIdentifier.
sql_findAssociations(Connection, String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_findAssociations(Connection, String, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that finds the associations of a Saga of given sagaType and given sagaIdentifier.
sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that finds identifiers of Sagas of given sagaType associated with the given association key and value.
sql_loadSaga(Connection, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_loadSaga(Connection, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that loads a single Saga, with given sagaId.
sql_removeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_removeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.eventhandling.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.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_storeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.eventhandling.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.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_storeSaga(Connection, String, String, String, byte[]) - Method in interface org.axonframework.eventhandling.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.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_updateSaga(Connection, String, byte[], String, String) - Method in interface org.axonframework.eventhandling.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.eventsourcing.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.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
Initializes the SQLErrorCodesResolver using the given list of SQL Codes representing Key Constraint Violations.
SQLErrorCodesResolver(DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
SQLErrorCodesResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
SQLErrorCodesResolver(Properties, String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
SQLErrorCodesResolver(Properties, DataSource) - Constructor for class org.axonframework.eventsourcing.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.eventsourcing.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.eventsourcing.eventstore.jpa.SQLStateResolver
Constructor that uses the standard SQL state category for the check.
SQLStateResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
Constructor that can be used to supply a specific SQL state code for the check.
stagedDomainEventMessages(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Returns a Stream of all DomainEventMessages that have been staged for publication by an Aggregate with given aggregateIdentifier.
start() - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPPublisher
Subscribes this publisher to the messageSource provided during initialization.
start() - Method in class org.axonframework.config.AggregateConfigurer
 
start() - Method in interface org.axonframework.config.Configuration
Starts this configuration.
start() - Method in interface org.axonframework.config.Configurer
Builds the configuration and starts it immediately.
start() - Method in class org.axonframework.config.EventHandlingConfiguration
 
start() - Method in interface org.axonframework.config.ModuleConfiguration
Invoked when the Configuration is started.
start() - Method in class org.axonframework.config.SagaConfiguration
 
start() - Method in interface org.axonframework.eventhandling.EventProcessor
Start processing events.
start() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
Start this processor.
start() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Start this processor.
start() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
 
start() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Starts the current unit of work.
start() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
start() - Method in class org.axonframework.spring.config.AxonConfiguration
 
start() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
start() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
 
startAndGet(T) - Static method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork.
startNode(String) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
startNode(String, Class) - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
startRecording() - Method in class org.axonframework.test.saga.CommandValidator
Starts recording commands on the command bus.
startRecording() - Method in class org.axonframework.test.saga.EventValidator
Starts recording event published by the event bus.
startRecording() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
Tells this class to start monitoring activity in infrastructure classes.
StartSaga - Annotation Type in org.axonframework.eventhandling.saga
Indicates that the annotated SagaEventHandler method can trigger the creation of a new Saga instance.
startTransaction() - Method in enum org.axonframework.common.transaction.NoTransactionManager
 
startTransaction() - Method in interface org.axonframework.common.transaction.TransactionManager
Starts a transaction.
startTransaction() - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
 
state(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
Asserts that the value of state is true.
stop() - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
Shuts down the command bus.
stop() - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
stop(Runnable) - Method in class org.axonframework.spring.commandhandling.distributed.jgroups.JGroupsConnectorFactoryBean
 
stop() - Method in class org.axonframework.spring.config.AxonConfiguration
 
stop(Runnable) - Method in class org.axonframework.spring.config.AxonConfiguration
 
stop(Runnable) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
stop() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
stop(Runnable) - Method in class org.axonframework.spring.config.EventHandlerRegistrar
 
stop() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
 
storageEngine() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Returns the EventStorageEngine used by the event store.
StorageStrategy - Interface in org.axonframework.mongo.eventsourcing.eventstore
Interface towards the mechanism that prescribes the structure in which events are stored in the Event Store.
store(String, CommandCallbackWrapper<E, C, R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
Stores a callback
storeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
Stores the given associationValue of the saga with given sagaIdentifier and sagaType.
storeSaga(AnnotatedSaga<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Stores a newly created Saga instance.
storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
 
storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Store the given snapshot of an Aggregate.
storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
 
storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Store an event that contains a snapshot of an aggregate.
storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
Stores the given (temporary) snapshot event.
storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoEventStorageEngine
 
storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
storeToken(TrackingToken, String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Stores the given token in the store.
StreamableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
Interface for a source of messages that processors can track.
StreamUtils - Class in org.axonframework.messaging
Utility class for working with Streams.
StringToByteArrayConverter - Class in org.axonframework.serialization.converters
ContentTypeConverter that converts String into byte arrays.
StringToByteArrayConverter() - Constructor for class org.axonframework.serialization.converters.StringToByteArrayConverter
 
StringToDBObjectContentTypeConverter - Class in org.axonframework.mongo.serialization
ContentTypeConverter implementation that converts a String containing its Binary JSON representation into a DBObject structure.
StringToDBObjectContentTypeConverter() - Constructor for class org.axonframework.mongo.serialization.StringToDBObjectContentTypeConverter
 
StubEventScheduler - Class in org.axonframework.test.eventscheduler
EventScheduler implementation that uses it's own concept of "Current Time" for the purpose of testing.
StubEventScheduler() - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
Creates an instance of the StubScheduler that uses the current date time as its conceptual "current time".
StubEventScheduler(TemporalAccessor) - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
Creates an instance of the StubScheduler that uses the given currentDateTime as its conceptual "current time".
StubScheduleToken - Class in org.axonframework.test.eventscheduler
ScheduleToken returned by the StubEventScheduler.
SubscribableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
Interface for a source of messages to which message processors can subscribe.
subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.amqp.eventhandling.spring.SpringAMQPMessageSource
 
subscribe(CommandBus) - Method in class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
Subscribe this command handler to the given commandBus.
subscribe(CommandBus) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
Subscribe this command handler to the given commandBus.
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.CommandBus
Subscribe the given handler to commands with the given commandName.
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
 
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Subscribes a command message handler for commands with given commandName.
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Subscribe the given handler to commands with the given commandName.
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Subscribe the given handler to commands with given commandName.
subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
 
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
subscribe(Consumer<List<? extends M>>) - Method in interface org.axonframework.messaging.SubscribableMessageSource
Subscribe the given messageProcessor to this message source.
subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
 
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.springcloud.commandhandling.SpringHttpCommandBusConnector
 
subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
SubscribingEventProcessor - Class in org.axonframework.eventhandling
Event processor implementation that subscribes to the EventBus for events.
SubscribingEventProcessor(String, EventHandlerInvoker, SubscribableMessageSource<EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
SubscribingEventProcessor(String, EventHandlerInvoker, SubscribableMessageSource<EventMessage<?>>, EventProcessingStrategy, ErrorHandler) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
SubscribingEventProcessor(String, EventHandlerInvoker, SubscribableMessageSource<? extends EventMessage<?>>, EventProcessingStrategy, ErrorHandler, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
SubscribingEventProcessor(String, EventHandlerInvoker, RollbackConfiguration, SubscribableMessageSource<? extends EventMessage<?>>, EventProcessingStrategy, ErrorHandler, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
subscribingSagaManager(Class<S>) - Static method in class org.axonframework.config.SagaConfiguration
Initialize a configuration for a Saga of given sagaType, using a Subscribing Event Processor to process incoming Events.
subscribingSagaManager(Class<S>, Function<Configuration, SubscribableMessageSource<EventMessage<?>>>) - Static method in class org.axonframework.config.SagaConfiguration
Initialize a configuration for a Saga of given sagaType, using a Subscribing Event Processor to process incoming Events from the message source provided by given messageSourceBuilder
subset(String...) - Method in class org.axonframework.messaging.MetaData
Returns a MetaData instance containing a subset of the keys in this instance.
success(R) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
Invokes CommandCallback.onSuccess(CommandMessage, Object) with given result on the wrapped callback.
success - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
supplyException(String, long, long) - Method in interface org.axonframework.commandhandling.conflictresolution.ConflictExceptionSupplier
Creaates an instance of an exception indicating a conflict in an aggregate with given aggregateIdentifier, the given expectedVersion and actualVersion.
supportedCommandNames() - Method in class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
 
supportedCommandNames() - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
 
supportedCommandNames() - Method in interface org.axonframework.commandhandling.SupportedCommandNamesAware
Returns the set of command names this component supports.
SupportedCommandNamesAware - Interface in org.axonframework.commandhandling
Describes a component capable of specifying which commands it is able to handle.
supportedPayloadType() - Method in interface org.axonframework.messaging.annotation.ParameterResolver
Returns the class of the payload that is supported by this resolver.
supportedPayloadType() - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
 
suspect() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
 
suspect() - Method in interface org.axonframework.commandhandling.distributed.Member
Mark this member as suspect, i.e.
suspect() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
 
suspect(Address) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 

T

TargetAggregateIdentifier - Annotation Type in org.axonframework.commandhandling
Field or method level annotation that marks a field or method providing the identifier of the aggregate that a command targets.
TargetAggregateVersion - Annotation Type in org.axonframework.commandhandling
Field or method level annotation that marks a field or method providing the expected version of the aggregate that a command targets.
targetType() - Method in class org.axonframework.mongo.serialization.DBObjectToStringContentTypeConverter
 
targetType() - Method in class org.axonframework.mongo.serialization.DocumentToStringContentTypeConverter
 
targetType() - Method in class org.axonframework.mongo.serialization.StringToDBObjectContentTypeConverter
 
targetType() - Method in class org.axonframework.serialization.ChainedConverter
 
targetType() - Method in interface org.axonframework.serialization.ContentTypeConverter
The returned type of IntermediateRepresentation
targetType() - Method in class org.axonframework.serialization.converters.BlobToInputStreamConverter
 
targetType() - Method in class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
 
targetType() - Method in class org.axonframework.serialization.converters.ByteArrayToStringConverter
 
targetType() - Method in class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
 
targetType() - Method in class org.axonframework.serialization.converters.StringToByteArrayConverter
 
targetType() - Method in class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
 
targetType() - Method in class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
 
targetType() - Method in class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
 
targetType() - Method in class org.axonframework.serialization.xml.InputStreamToDom4jConverter
 
targetType() - Method in class org.axonframework.serialization.xml.InputStreamToXomConverter
 
targetType() - Method in class org.axonframework.serialization.xml.XomToStringConverter
 
test(CommandMessage) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
test(CommandMessage) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
test(CommandMessage) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
test(CommandMessage) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
TestExecutor - Interface in org.axonframework.test.aggregate
Interface describing the operations available on a test fixture in the execution stage.
ThrowingListenerErrorHandler - Enum in org.axonframework.eventhandling
Implementation that simply throws the reported exception.
Timeout - Annotation Type in org.axonframework.commandhandling.gateway
Class or method level annotation that indicates the calling thread should not wait longer than the provided timeout for the results of a command.
Timestamp - Annotation Type in org.axonframework.eventhandling
Annotation indication that a parameter on an Event Handler method should be injected with the Timestamp of an Event Message.
timestamp() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the storage timestamp of this token entry.
timestampAsString() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the storage timestamp of this token entry as a String.
timestampColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns the name of the column containing the timestamp of the token (the time this token was last saved).
timestampColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the timestamp of the event.
TimestampParameterResolverFactory - Class in org.axonframework.eventhandling
AbstractAnnotatedParameterResolverFactory that accepts parameters with type Instant that are annotated with the Timestamp annotation and assigns the timestamp of the EventMessage.
TimestampParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.TimestampParameterResolverFactory
Initializes a ParameterResolverFactory for Timestamp annotated parameters
timestampProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the timestamp of the event.
toJobData(Object) - Method in interface org.axonframework.eventhandling.scheduling.quartz.EventJobDataBinder
Write an eventMessage (or its payload) to a JobDataMap.
toJobData(Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.LegacyAwareJobDataBinder
 
toJobData(Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
 
tokenColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns the name of the column containing the serialized token.
TokenEntry - Class in org.axonframework.eventhandling.tokenstore.jpa
Implementation of a token entry compatible with JPA that stores its serialized token as a byte array.
TokenEntry(String, int, TrackingToken, Serializer) - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
Initializes a new token entry for given token, processorName and segment.
TokenEntry() - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
Default constructor for JPA
TokenEntry.PK - Class in org.axonframework.eventhandling.tokenstore.jpa
Primary key for token entries used by JPA
TokenSchema - Class in org.axonframework.eventhandling.tokenstore.jdbc
Schema of an token entry to be stored using Jdbc.
TokenSchema() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Initializes the default TokenSchema
TokenSchema.Builder - Class in org.axonframework.eventhandling.tokenstore.jdbc
Builder for an TokenSchema that gets initialized with default values.
tokenStore(Serializer, EntityManagerProvider) - Method in class org.axonframework.boot.autoconfig.JpaAutoConfiguration
 
TokenStore - Interface in org.axonframework.eventhandling.tokenstore
Describes a component capable of storing and retrieving event tracking tokens.
tokenTable() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns the name of the token entry table.
TokenTableFactory - Interface in org.axonframework.eventhandling.tokenstore.jdbc
Interface describing a factory for JDBC to create the table containing tracking token entries.
tokenType() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
Returns the sql to describe the type of token column.
tokenType() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.PostgresTokenTableFactory
 
tokenTypeColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Returns the name of the column containing the name of the type to which the token should be deserialized.
toString() - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
toString() - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
toString() - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
toString() - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
toString() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
 
toString() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
 
toString() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
 
toString() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
 
toString() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
 
toString() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
 
toString() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
 
toString() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
 
toString() - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
 
toString() - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
 
toString() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
toString() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
 
toString() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
 
toString() - Method in class org.axonframework.serialization.SimpleSerializedObject
 
toString() - Method in class org.axonframework.serialization.SimpleSerializedType
 
TrackedDomainEventData<T> - Class in org.axonframework.eventsourcing.eventstore
Specialization of the DomainEventData class that includes the Token representing the position of this event in a stream.
TrackedDomainEventData(TrackingToken, DomainEventData<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
Initialize the TrackingDomainEventData with given trackingToken and domainEventEntry.
TrackedEventData<T> - Interface in org.axonframework.eventsourcing.eventstore
Interface describing the properties of serialized Event Messages containing a TrackingToken.
trackedEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Returns a comma separated list of tracked domain event column names to select from an event entry.
TrackedEventMessage<T> - Interface in org.axonframework.eventhandling
Represents an EventMessage containing a TrackingToken.
TrackingEventProcessor - Class in org.axonframework.eventhandling
EventProcessor implementation that tracks events from a StreamableMessageSource.
TrackingEventProcessor(String, EventHandlerInvoker, StreamableMessageSource<TrackedEventMessage<?>>, TokenStore, TransactionManager) - Constructor for class org.axonframework.eventhandling.TrackingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
TrackingEventProcessor(String, EventHandlerInvoker, StreamableMessageSource<TrackedEventMessage<?>>, TokenStore, TransactionManager, int) - Constructor for class org.axonframework.eventhandling.TrackingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
TrackingEventProcessor(String, EventHandlerInvoker, StreamableMessageSource<TrackedEventMessage<?>>, TokenStore, TransactionManager, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.TrackingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
TrackingEventProcessor(String, EventHandlerInvoker, RollbackConfiguration, ErrorHandler, StreamableMessageSource<TrackedEventMessage<?>>, TokenStore, TransactionManager, int, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.TrackingEventProcessor
Initializes an EventProcessor with given name that subscribes to the given messageSource for events.
TrackingEventProcessor.State - Enum in org.axonframework.eventhandling
 
TrackingEventStream - Interface in org.axonframework.eventsourcing.eventstore
Describes a stream of TrackedEventMessages.
trackingSagaManager(Class<S>) - Static method in class org.axonframework.config.SagaConfiguration
Initialize a configuration for a Saga of given sagaType, using a Tracking Event Processor to process incoming Events.
trackingSagaManager(Class<S>, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Static method in class org.axonframework.config.SagaConfiguration
Initialize a configuration for a Saga of given sagaType, using a Tracking Event Processor to process incoming Events from a Message Source provided by given messageSourceBuilder.
trackingToken() - Method in class org.axonframework.eventhandling.GenericTrackedEventMessage
 
trackingToken() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
 
trackingToken() - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore.Entry
Returns the tracking token of the last event handled by the Saga.
trackingToken() - Method in interface org.axonframework.eventhandling.saga.Saga
Returns the TrackingToken belonging to the EventMessage last processed by this instance, or null if this instance never handled an EventMessage, or if it received an EventMessage that doesn't carry a TrackingToken.
trackingToken() - Method in interface org.axonframework.eventhandling.TrackedEventMessage
Returns the TrackingToken of the event message.
trackingToken() - Method in class org.axonframework.eventsourcing.eventstore.GenericTrackedDomainEventEntry
Deprecated.
 
trackingToken() - Method in class org.axonframework.eventsourcing.eventstore.TrackedDomainEventData
 
trackingToken() - Method in interface org.axonframework.eventsourcing.eventstore.TrackedEventData
Returns the TrackingToken of the serialized event.
TrackingToken - Interface in org.axonframework.eventsourcing.eventstore
Tag interface identifying a token that is used to identify the position of an event in an event stream.
trackingToken() - Method in class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
 
TrackingTokenParameterResolverFactory - Class in org.axonframework.eventsourcing.eventstore
Implementation of a ParameterResolverFactory that resolves the TrackingToken of an event message if that message is a TrackedEventMessage.
TrackingTokenParameterResolverFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.TrackingTokenParameterResolverFactory
 
Transaction - Interface in org.axonframework.common.transaction
Interface of an object that represents a started transaction that can be committed or rolled back.
TRANSACTION_MANAGER_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
The key used to locate the optional TransactionManager in the scheduler context.
TransactionAutoConfiguration - Class in org.axonframework.boot.autoconfig
 
TransactionAutoConfiguration() - Constructor for class org.axonframework.boot.autoconfig.TransactionAutoConfiguration
 
TransactionManager - Interface in org.axonframework.common.transaction
Interface towards a mechanism that manages transactions

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

TransactionManagerFactoryBean - Class in org.axonframework.spring.config
Factory Bean that wraps transaction manager instances with an implementation of TransactionManager, if necessary (and possible).
TransactionManagerFactoryBean() - Constructor for class org.axonframework.spring.config.TransactionManagerFactoryBean
 
TransactionManagingInterceptor<T extends Message<?>> - Class in org.axonframework.messaging.interceptors
Interceptor that uses a TransactionManager to start a new transaction before a Message is handled.
TransactionManagingInterceptor(TransactionManager) - Constructor for class org.axonframework.messaging.interceptors.TransactionManagingInterceptor
Initializes a TransactionManagingInterceptor that uses the given transactionManager.
TransactionMethodExecutionException - Exception in org.axonframework.eventhandling
Wrapper for exceptions that occurred while calling an @BeforeTransaction or @AfterTransaction annotated method.
TransactionMethodExecutionException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.TransactionMethodExecutionException
Initialize the exception with given message and cause.
transform(EventMessage<?>) - Method in class org.axonframework.spring.messaging.OutboundEventMessageChannelAdapter
Transforms the given Axon event into a Spring Messaging Message.
transformMessage(Function<T, ? extends Message<?>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
 
transformMessage(Function<T, ? extends Message<?>>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
 
transformMessage(Function<T, ? extends Message<?>>) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
 
transformMessage(Function<T, ? extends Message<?>>) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Transform the Message being processed using the given operator.
transformMessage(Function<T, ? extends Message<?>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Transform the Message being processed using the given operator and stores the result.
transformMessage(Message<?>) - Method in class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
Transforms the given incoming Spring Messaging message to an Axon EventMessage.
TRIGGER - Static variable in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
A singleton instance of a SnapshotTrigger that does nothing.
type() - Method in interface org.axonframework.commandhandling.model.Aggregate
Get the String representation of the aggregate's type.
type() - Method in interface org.axonframework.commandhandling.model.inspection.AggregateModel
Get the String representation of the modeled aggregate's type.
type() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
type() - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
 
type() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
typeColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the aggregate type of the event.
typeForClass(Class) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
typeForClass(Class) - Method in class org.axonframework.serialization.JavaSerializer
 
typeForClass(Class) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
typeForClass(Class) - Method in class org.axonframework.serialization.MessageSerializer
 
typeForClass(Class) - Method in interface org.axonframework.serialization.Serializer
Returns the type identifier for the given class.
typeMatches(Message<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
Checks if this member can handle the type of the given message.
typeProperty() - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration
Get the name of the property with the aggregate type.

U

UnableToClaimTokenException - Exception in org.axonframework.eventhandling.tokenstore
Exception indicating that a processor tried to claim a Token (either by retrieving or updating it) that has already been claimed by another process.
UnableToClaimTokenException(String) - Constructor for exception org.axonframework.eventhandling.tokenstore.UnableToClaimTokenException
Initialize the exception with given message.
unblock() - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
underlyingReader() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamReader
 
underlyingWriter() - Method in class org.axonframework.mongo.serialization.DBObjectHierarchicalStreamWriter
 
UniformPropertyAccessStrategy - Class in org.axonframework.common.property
PropertyAccessStrategy implementation that finds properties defined according to the Uniform Access Principle (see Wikipedia).
UniformPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.UniformPropertyAccessStrategy
 
UnitOfWork<T extends Message<?>> - Interface in org.axonframework.messaging.unitofwork
This class represents a Unit of Work that monitors the processing of a Message.
UnitOfWork.Phase - Enum in org.axonframework.messaging.unitofwork
Enum indicating possible phases of the Unit of Work.
UnitOfWorkAwareConnectionProviderWrapper - Class in org.axonframework.common.jdbc
Wrapper for a ConnectionProvider that checks if a connection is already attached to the Unit of Work, favoring that connection over creating a new one.
UnitOfWorkAwareConnectionProviderWrapper(ConnectionProvider) - Constructor for class org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper
Initializes a ConnectionProvider, using given delegate to create a new instance, when on is not already attached to the Unit of Work.
UnknownSerializedTypeException - Exception in org.axonframework.serialization
Exception indicating that an object could not be deserialized, because its serialized type cannot be mapped to a class.
UnknownSerializedTypeException(SerializedType) - Constructor for exception org.axonframework.serialization.UnknownSerializedTypeException
Initialize the constructor with a default message, containing details of the given serializedType
UnknownSerializedTypeException(SerializedType, Throwable) - Constructor for exception org.axonframework.serialization.UnknownSerializedTypeException
Initialize the constructor with a default message, containing details of the given serializedType
unregister(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
Removes all strategies registered using the PropertyAccessStrategy.register(PropertyAccessStrategy) method.
UnresolvedRoutingKeyPolicy - Enum in org.axonframework.commandhandling.distributed
 
unsavedSagaResource(UnitOfWork<?>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Returns a set of identifiers of sagas that may have changed in the context of the given unitOfWork and have not been saved yet.
UnsupportedHandlerException - Exception in org.axonframework.messaging.annotation
Thrown when an @...Handler annotated method was found that does not conform to the rules that apply to those methods.
UnsupportedHandlerException(String, Member) - Constructor for exception org.axonframework.messaging.annotation.UnsupportedHandlerException
Initialize the exception with a message and the violatingMethod.
unwrap(Class<HT>) - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
 
unwrap(Class<H>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
unwrap(Class<HT>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Returns the wrapped handler object if its type is an instance of the given handlerType.
unwrap(Class<HT>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
upcast(SerializedType, Class<T>, Function<T, T>, Function<MetaData, MetaData>) - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
upcast(SerializedType, Class<T>, Function<T, T>, Function<MetaData, MetaData>) - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Upcast the serialized payload of the event (leaving other aspects of the event the same).
upcast(Stream<IntermediateEventRepresentation>) - Method in enum org.axonframework.serialization.upcasting.event.NoOpEventUpcaster
 
upcast(SerializedType, Class<S>, Function<S, S>, Function<MetaData, MetaData>) - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
upcast(Stream<T>) - Method in class org.axonframework.serialization.upcasting.GenericUpcasterChain
 
upcast(Stream<T>) - Method in class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
 
upcast(Stream<T>) - Method in class org.axonframework.serialization.upcasting.SingleEntryUpcaster
 
upcast(Stream<T>) - Method in interface org.axonframework.serialization.upcasting.Upcaster
Apply this upcaster to a stream of intermediateRepresentations and return the altered stream.
upcastAndDeserializeDomainEvents(Stream<? extends DomainEventData<?>>, Serializer, EventUpcaster, boolean) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
Upcasts and deserializes the given eventEntryStream using the given serializer and upcasterChain.
upcastAndDeserializeTrackedEvents(Stream<? extends TrackedEventData<?>>, Serializer, EventUpcaster, boolean) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
Upcasts and deserializes the given eventEntryStream using the given serializer and upcasterChain.
UpcastedEventRepresentation<T> - Class in org.axonframework.serialization.upcasting.event
Implementation of an IntermediateEventRepresentation that contains upcast functions for the payload and metadata of a previous representation.
UpcastedEventRepresentation(SerializedType, IntermediateEventRepresentation, Function<T, T>, Function<MetaData, MetaData>, Class<T>, Converter) - Constructor for class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
Initializes an UpcastedEventRepresentation from source data and given upcast functions for payload and metadata.
Upcaster<T> - Interface in org.axonframework.serialization.upcasting
Interface for Upcasters.
upcastPayload(SerializedType, Class<T>, Function<T, T>) - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Upcast the serialized payload of the event (leaving other aspects of the event the same).
update(byte[]) - Method in class org.axonframework.common.digest.Digester
Update the Digester with given additionalData.
update(Function<Configuration, ? extends B>) - Method in class org.axonframework.config.Component
Updates the builder function for this component.
updateLoadFactor(int) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Updates the load factor of this node compared to other nodes registered with the CommandRouter.
updateMembership(int, Predicate<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.distributed.CommandRouter
Updates the load factor and capabilities of this member representing the current endpoint if the implementation allows memberships to be updated dynamically.
updateMembership(int, Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
updateMembership(int, Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.springcloud.commandhandling.SpringCloudCommandRouter
 
updateMemberships(HeartbeatEvent) - Method in class org.axonframework.springcloud.commandhandling.SpringCloudCommandRouter
 
updateSaga(AnnotatedSaga<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
Update a stored Saga, by replacing it with the given saga instance.
updateSaga(Class<? extends T>, String, T, TrackingToken, AssociationValues) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
 
updateSaga(Class<?>, String, Object, TrackingToken, AssociationValues) - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
 
updateSaga(Class<?>, String, Object, TrackingToken, AssociationValues) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
 
updateSaga(Class<?>, String, Object, TrackingToken, AssociationValues) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
 
updateSaga(Class<? extends T>, String, T, TrackingToken, AssociationValues) - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore
Updates a given Saga after its state was modified.
updateSaga(Class<?>, String, Object, TrackingToken, AssociationValues) - Method in class org.axonframework.mongo.eventhandling.saga.repository.MongoSagaStore
 
updateToken(TrackingToken, Serializer) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Update this entry with the given token, serializing it using given serializer.
updateToken(TrackingToken, Serializer, Class<T>) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Update the token data to the given token, using given serializer to serialize it to the given contentType.
updateToken(TrackingToken, Serializer) - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
 
updateToken(TrackingToken, Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
 
usingTrackingProcessors() - Method in class org.axonframework.config.EventHandlingConfiguration
Configure the use of Tracking Event Processors, instead of the default Subscribing ones.
UTF8 - Static variable in class org.axonframework.common.io.IOUtils
Represents the UTF-8 character set.

V

validateMessage(Object, Validator) - Method in class org.axonframework.messaging.interceptors.BeanValidationInterceptor
Validate the given message using the given validator.
validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.commandhandling.model.AbstractRepository
Checks the aggregate for concurrent changes.
validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
valueOf(String) - Static method in enum org.axonframework.amqp.eventhandling.legacy.EventMessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.boot.AMQPProperties.TransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.boot.EventProcessorProperties.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.commandhandling.conflictresolution.NoConflictResolver
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.common.lock.NullLockFactory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.common.transaction.NoTransactionManager
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.DirectEventProcessingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.saga.repository.NoResourceInjector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.saga.SagaCreationPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.ThrowingListenerErrorHandler
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventhandling.TrackingEventProcessor.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.messaging.unitofwork.RollbackConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.serialization.upcasting.event.NoOpEventUpcaster
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.axonframework.amqp.eventhandling.legacy.EventMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.boot.AMQPProperties.TransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.boot.EventProcessorProperties.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.commandhandling.conflictresolution.NoConflictResolver
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.common.lock.NullLockFactory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.common.transaction.NoTransactionManager
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventhandling.DirectEventProcessingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventhandling.saga.repository.NoResourceInjector
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventhandling.saga.SagaCreationPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventhandling.ThrowingListenerErrorHandler
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventhandling.TrackingEventProcessor.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.axonframework.messaging.MetaData
 
values() - Static method in enum org.axonframework.messaging.unitofwork.RollbackConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.serialization.upcasting.event.NoOpEventUpcaster
Returns an array containing the constants of this enum type, in the order they are declared.
version() - Method in interface org.axonframework.commandhandling.model.Aggregate
Get the aggregate's version.
version() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
 
version() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
 
version() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
VersionedAggregateIdentifier - Class in org.axonframework.commandhandling
Structure that holds an Aggregate Identifier and an expected version of an aggregate.
VersionedAggregateIdentifier(String, Long) - Constructor for class org.axonframework.commandhandling.VersionedAggregateIdentifier
Initializes a VersionedAggregateIdentifier with the given identifier and version.
viewAccepted(View) - Method in class org.axonframework.jgroups.commandhandling.JGroupsConnector
 
VoidCallback<C> - Class in org.axonframework.commandhandling.callbacks
Abstract callback that can be extended when no result is expected from the command handler execution.
VoidCallback() - Constructor for class org.axonframework.commandhandling.callbacks.VoidCallback
 

W

WeakReferenceCache - Class in org.axonframework.common.caching
Cache implementation that keeps values in the cache until the garbage collector has removed them.
WeakReferenceCache() - Constructor for class org.axonframework.common.caching.WeakReferenceCache
 
when(Object) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
when(Object, Map<String, ?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
when(Object) - Method in interface org.axonframework.test.aggregate.TestExecutor
Dispatches the given command to the appropriate command handler and records all activity in the fixture for result validation.
when(Object, Map<String, ?>) - Method in interface org.axonframework.test.aggregate.TestExecutor
Dispatches the given command and meta data to the appropriate command handler and records all activity in the fixture for result validation.
whenAggregate(String) - Method in class org.axonframework.test.saga.SagaTestFixture
 
whenAggregate(String) - Method in interface org.axonframework.test.saga.WhenState
Use this method to indicate that an aggregate with given identifier should publish certain events, while recording the outcome.
WhenAggregateEventPublisher - Interface in org.axonframework.test.saga
Interface to an object that publishes events on behalf of an aggregate.
whenPublishingA(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
 
whenPublishingA(Object) - Method in interface org.axonframework.test.saga.WhenState
Use this method to indicate an application is published, while recording the outcome.
WhenState - Interface in org.axonframework.test.saga
Interface providing an API to methods in the "when" state of the fixture execution.
whenTimeAdvancesTo(Instant) - Method in class org.axonframework.test.saga.SagaTestFixture
 
whenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.saga.WhenState
Mimic an elapsed time with no relevant activity for the Saga.
whenTimeElapses(Duration) - Method in class org.axonframework.test.saga.SagaTestFixture
 
whenTimeElapses(Duration) - Method in interface org.axonframework.test.saga.WhenState
Mimic an elapsed time with no relevant activity for the Saga.
with(Member, int, Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Registers the given member with given loadFactor and commandFilter if it is not already contained in the ConsistentHash.
with(String, Object) - Static method in class org.axonframework.messaging.MetaData
Creates a MetaData instances with a single entry, with the given key and given value.
withAggregateIdentifierColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event identifier column.
withAggregateIdentifierProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
withEventIdentifierColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event identifier column.
withEventIdentifierProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
withEventTable(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the domain events table.
withGlobalIndexColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the global index column.
withMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandMessage
Returns a copy of this CommandMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.EventMessage
Returns a copy of this EventMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericEventMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.eventsourcing.DomainEventMessage
Returns a copy of this DomainEventMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.AbstractMessage
 
withMetaData(MetaData) - Method in class org.axonframework.messaging.AbstractMessage
Returns a new message instance with the same payload and properties as this message but given metaData.
withMetaData(MetaData) - Method in class org.axonframework.messaging.GenericMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.Message
Returns a copy of this Message with the given metaData.
withMetaData(MetaData) - Method in class org.axonframework.serialization.SerializedMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.serialization.SerializedMessage
 
withMetaDataColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event metadata column.
withMetaDataProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
without(Member) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Deregisters the given member and returns a new ConsistentHash with updated memberships.
withoutKeys(Set<String>) - Method in class org.axonframework.messaging.MetaData
Returns a MetaData instance with the items with given keys removed.
withPayloadColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event payload column.
withPayloadProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
withPayloadRevisionColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event payload revision column.
withPayloadRevisionProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
withPayloadTypeColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event payload type column.
withPayloadTypeProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
withSequenceNumberColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event identifier column.
withSequenceNumberProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
withSnapshotTable(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the snapshot events table.
withTimestampColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the timestamp column.
withTimestampProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
withTransienceCheckDisabled() - Method in interface org.axonframework.test.saga.FixtureConfiguration
Disables the check that injected resources are stored in fields that are marked 'transient'.
withTransienceCheckDisabled() - Method in class org.axonframework.test.saga.SagaTestFixture
 
withTypeColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the aggregate type column.
withTypeProperty(String) - Method in class org.axonframework.mongo.eventsourcing.eventstore.documentperevent.EventEntryConfiguration.Builder
 
wrap(Connection, Class<I>, I, ConnectionWrapperFactory.ConnectionCloseHandler) - Static method in class org.axonframework.common.jdbc.ConnectionWrapperFactory
Wrap the given connection, creating a Proxy with an additional wrapperInterface (implemented by given wrapperHandler).
wrap(Connection, ConnectionWrapperFactory.ConnectionCloseHandler) - Static method in class org.axonframework.common.jdbc.ConnectionWrapperFactory
Wrap the given connection, creating a Proxy with an additional wrapperInterface (implemented by given wrapperHandler).
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.commandhandling.model.inspection.MethodCommandHandlerDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlerDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in interface org.axonframework.messaging.annotation.HandlerEnhancerDefinition
Enhance the given original handler.
WrappedMessageHandlingMember<T> - Class in org.axonframework.messaging.annotation
Abstract implementation of a MessageHandlingMember that delegates to a wrapped MessageHandlingMember.
WrappedMessageHandlingMember(MessageHandlingMember<T>) - Constructor for class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
Initializes the member using the given delegate.
wrapToFireAndForget(CommandGatewayFactory.InvocationHandler<CompletableFuture<R>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Wrap the given delegate in an InvocationHandler that returns immediately after invoking the delegate.
wrapToReturnNullOnInterrupted(CommandGatewayFactory.InvocationHandler<R>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Wrap the given delegate in an InvocationHandler that returns null when the delegate throws an InterruptedException.
wrapToReturnNullOnTimeout(CommandGatewayFactory.InvocationHandler<R>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Wrap the given delegate in an InvocationHandler that returns null when the delegate throws a TimeoutException.
wrapToReturnWithFixedTimeout(CommandGatewayFactory.InvocationHandler<CompletableFuture<R>>, long, TimeUnit) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Wraps the given delegate and waits for the result in the Future to become available, with given timeout and timeUnit.
wrapToReturnWithTimeoutInArguments(CommandGatewayFactory.InvocationHandler<CompletableFuture<R>>, int, int) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Wraps the given delegate and waits for the result in the Future to become available using given indices to resolve the parameters that provide the timeout to use.
wrapToWaitForResult(CommandGatewayFactory.InvocationHandler<CompletableFuture<R>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Wraps the given delegate and waits for the result in the Future to become available.
wrapUndeclaredExceptions(CommandGatewayFactory.InvocationHandler<R>, Class<?>[]) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Wraps the given delegate in an InvocationHandler that wraps exceptions not declared on the method in a CommandExecutionException.
writeEventMessage(EventMessage) - Method in class org.axonframework.amqp.eventhandling.legacy.EventMessageWriter
Writes the given eventMessage to the underling output.
writeExternal(ObjectOutput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsDispatchMessage
 
writeExternal(ObjectOutput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsReplyMessage
 
writeExternal(ObjectOutput) - Method in class org.axonframework.jgroups.commandhandling.JoinMessage
 
writeReplace() - Method in class org.axonframework.serialization.SerializedMessage
Java Serialization API Method that provides a replacement to serialize, as the fields contained in this instance are not serializable themselves.
writeTimestamp(PreparedStatement, int, Instant) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Write a timestamp from a Instant to a data value suitable for the database scheme.
writeTo(DataOutput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsDispatchMessage
 
writeTo(DataOutput) - Method in class org.axonframework.jgroups.commandhandling.JGroupsReplyMessage
 

X

XomToStringConverter - Class in org.axonframework.serialization.xml
Converter that converts XOM Document instances to a String.
XomToStringConverter() - Constructor for class org.axonframework.serialization.xml.XomToStringConverter
 
XStreamSerializer - Class in org.axonframework.serialization.xml
Serializer that uses XStream to serialize and deserialize arbitrary objects.
XStreamSerializer() - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(RevisionResolver) - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(XStream) - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Initialize a generic serializer using the UTF-8 character set.
XStreamSerializer(Charset) - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Initialize the serializer using the given charset.
XStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Initialize the serializer using the given charset and xStream instance.
XStreamSerializer(Charset, XStream, RevisionResolver, Converter) - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Initialize the serializer using the given charset and xStream instance.
A B C D E F G H I J K L M N O P Q R S T U V W X 
Skip navigation links

Copyright © 2010–2017. All rights reserved.