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.
AbstractAggregateFactory(Class<T>, Set<Class<? extends T>>) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
Initialize an AggregateFactory for the given polymorphic aggregateBaseType and it's aggregateSubTypes.
AbstractAggregateFactory(AggregateModel<T>) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
Initializes an AggregateFactory for the given aggregateModel.
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
 
AbstractChildEntityDefinition - Class in org.axonframework.modelling.command.inspection
Abstract implementation of the ChildEntityDefinition to provide reusable functionality for collections of ChildEntityDefinitions.
AbstractChildEntityDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
 
AbstractCommandGateway - Class in org.axonframework.commandhandling.gateway
Abstract implementation of a CommandGateway, which handles the dispatch interceptors and retrying on failure.
AbstractCommandGateway(AbstractCommandGateway.Builder) - Constructor for class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Instantiate an AbstractCommandGateway based on the fields contained in the AbstractCommandGateway.Builder.
AbstractCommandGateway.Builder - Class in org.axonframework.commandhandling.gateway
Abstract Builder class to instantiate AbstractCommandGateway implementations.
AbstractDeadlineManager - Class in org.axonframework.deadline
Abstract implementation of the DeadlineManager to be implemented by concrete solutions for the DeadlineManager.
AbstractDeadlineManager() - Constructor for class org.axonframework.deadline.AbstractDeadlineManager
 
AbstractDomainEventEntry<T> - Class in org.axonframework.eventhandling
Abstract base class of a serialized domain event.
AbstractDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.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.eventhandling.AbstractDomainEventEntry
Reconstruct an event entry from a stored object.
AbstractDomainEventEntry() - Constructor for class org.axonframework.eventhandling.AbstractDomainEventEntry
Default constructor required by JPA
AbstractEventBus - Class in org.axonframework.eventhandling
Base class for the Event Bus.
AbstractEventBus(AbstractEventBus.Builder) - Constructor for class org.axonframework.eventhandling.AbstractEventBus
Instantiate an AbstractEventBus based on the fields contained in the AbstractEventBus.Builder.
AbstractEventBus.Builder - Class in org.axonframework.eventhandling
Abstract Builder class to instantiate AbstractEventBus implementations.
AbstractEventEntry<T> - Class in org.axonframework.eventhandling
Abstract base class of a serialized event.
AbstractEventEntry(EventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.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.eventhandling.AbstractEventEntry
Reconstruct an event entry from a stored object.
AbstractEventEntry() - Constructor for class org.axonframework.eventhandling.AbstractEventEntry
Default constructor required by JPA
AbstractEventGateway - Class in org.axonframework.eventhandling.gateway
Abstract implementation of an EventGateway, which handles the dispatch interceptors.
AbstractEventGateway(AbstractEventGateway.Builder) - Constructor for class org.axonframework.eventhandling.gateway.AbstractEventGateway
Instantiate an AbstractEventGateway based on the fields contained in the AbstractEventGateway.Builder.
AbstractEventGateway.Builder - Class in org.axonframework.eventhandling.gateway
Abstract Builder class to instantiate AbstractEventGateway implementations.
AbstractEventProcessor - Class in org.axonframework.eventhandling
Abstract implementation of an EventProcessor.
AbstractEventProcessor(AbstractEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.AbstractEventProcessor
Instantiate a AbstractEventProcessor based on the fields contained in the AbstractEventProcessor.Builder.
AbstractEventProcessor.Builder - Class in org.axonframework.eventhandling
Abstract Builder class to instantiate a AbstractEventProcessor.
AbstractEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
Abstract EventStorageEngine implementation that takes care of event serialization and upcasting.
AbstractEventStorageEngine(AbstractEventStorageEngine.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Instantiate a AbstractEventStorageEngine based on the fields contained in the AbstractEventStorageEngine.Builder.
AbstractEventStorageEngine.Builder - Class in org.axonframework.eventsourcing.eventstore
Abstract Builder class to instantiate an AbstractEventStorageEngine.
AbstractEventStore - Class in org.axonframework.eventsourcing.eventstore
Abstract implementation of an EventStore that uses a EventStorageEngine to store and load events.
AbstractEventStore(AbstractEventStore.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Instantiate an AbstractEventStore based on the fields contained in the AbstractEventStore.Builder.
AbstractEventStore.Builder - Class in org.axonframework.eventsourcing.eventstore
Abstract Builder class to instantiate an AbstractEventStore.
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
 
AbstractQualifiedBeanCondition - Class in org.axonframework.springboot.util
Abstract implementations for conditions that match against the availability of beans of a specific type with a given qualifier.
AbstractQualifiedBeanCondition(String, String, String) - Constructor for class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
Initialize the condition, looking for properties on a given annotation
AbstractRepository<T,A extends Aggregate<T>> - Class in org.axonframework.modelling.command
Abstract implementation of the Repository that takes care of the dispatching of events when an aggregate is persisted.
AbstractRepository(AbstractRepository.Builder<T>) - Constructor for class org.axonframework.modelling.command.AbstractRepository
Instantiate a AbstractRepository based on the fields contained in the AbstractRepository.Builder.
AbstractRepository.Builder<T> - Class in org.axonframework.modelling.command
Abstract Builder class to instantiate AbstractRepository implementations.
AbstractResourceInjector - Class in org.axonframework.modelling.saga
Abstract implementation of a ResourceInjector for sagas that injects field and method resources.
AbstractResourceInjector() - Constructor for class org.axonframework.modelling.saga.AbstractResourceInjector
 
AbstractResponseType<R> - Class in org.axonframework.messaging.responsetypes
Abstract implementation of the ResponseType which contains match functions for the majority of the Type options available.
AbstractResponseType(Class<?>) - Constructor for class org.axonframework.messaging.responsetypes.AbstractResponseType
Instantiate a ResponseType with the given expectedResponseType as the type to be matched against and to which the query response should be converted to, as is or as the contained type for an array/list/etc.
AbstractRetryScheduler - Class in org.axonframework.commandhandling.gateway
An abstract base class for RetrySchedulers.
AbstractRetryScheduler(AbstractRetryScheduler.Builder) - Constructor for class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
Construct the AbstractRetryScheduler from its builder.
AbstractRetryScheduler.Builder<B extends AbstractRetryScheduler.Builder> - Class in org.axonframework.commandhandling.gateway
A builder class for the RetryScheduler implementations.
AbstractRoutingStrategy - Class in org.axonframework.commandhandling.distributed
Abstract implementation of the RoutingStrategy interface that includes a fallback RoutingStrategy which prescribes what happens when routing cannot be resolved by this implementation.
AbstractRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
AbstractRoutingStrategy(RoutingStrategy) - Constructor for class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
Initializes the strategy using given RoutingStrategy prescribing the fallback approach when this implementation cannot resolve a routing key.
AbstractSagaEntry<T> - Class in org.axonframework.modelling.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.modelling.saga.repository.jpa.AbstractSagaEntry
Constructs a new SagaEntry for the given saga.
AbstractSagaEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
Default constructor required by JPA.
AbstractSagaManager<T> - Class in org.axonframework.modelling.saga
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager implementations.
AbstractSagaManager(AbstractSagaManager.Builder<T>) - Constructor for class org.axonframework.modelling.saga.AbstractSagaManager
Instantiate a AbstractSagaManager based on the fields contained in the AbstractSagaManager.Builder.
AbstractSagaManager.Builder<T> - Class in org.axonframework.modelling.saga
Abstract Builder class to instantiate AbstractSagaManager implementations.
AbstractSequencedDomainEventEntry<T> - Class in org.axonframework.eventhandling
Abstract base class of a serialized domain event.
AbstractSequencedDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.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.eventhandling.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(AbstractSnapshotter.Builder) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
Instantiate a AbstractSnapshotter based on the fields contained in the AbstractSnapshotter.Builder.
AbstractSnapshotter.Builder - Class in org.axonframework.eventsourcing
Abstract Builder class to instantiate AbstractSnapshotter implementations.
AbstractSnapshotTrigger - Class in org.axonframework.eventsourcing
Abstract implementation of the SnapshotTrigger that schedules snapshots on the Unit of Work.
AbstractSnapshotTrigger(Snapshotter, Class<?>) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotTrigger
Instantiate a AbstractSnapshotTrigger based on the Snapshotter and aggregateType Class.
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(AbstractXStreamSerializer.Builder) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
Instantiate a AbstractXStreamSerializer based on the fields contained in the AbstractXStreamSerializer.Builder.
AbstractXStreamSerializer.Builder - Class in org.axonframework.serialization
Abstract Builder class to instantiate AbstractXStreamSerializer.
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.NonStaticFieldsFilter
 
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.
acquireAttempts(int) - Method in class org.axonframework.common.lock.PessimisticLockFactory.Builder
Indicates howmany attempts should be done to acquire a lock.
activate() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
Activates this lifecycle instance.
ActiveGrpcChannelChecker - Class in org.axonframework.axonserver.connector.heartbeat.connection.checker
Deprecated.
in through use of the AxonServer java connector
ActiveGrpcChannelChecker(AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.heartbeat.connection.checker.ActiveGrpcChannelChecker
Deprecated.
Constructs an ActiveGrpcChannelChecker based on the connection manager.
activeProcessorThreads() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Returns an approximation of the number of threads currently processing events.
activeSubscriptions() - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Provides the set of running subscription queries.
activeSubscriptions() - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
 
ActivityHandle() - Constructor for class org.axonframework.lifecycle.ShutdownLatch.ActivityHandle
 
actualVersion() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
The actual version of the loaded aggregate
actualVersion() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
 
add(AssociationValue) - Method in interface org.axonframework.modelling.saga.AssociationValues
Adds the given associationValue, if it has not been previously added.
add(AssociationValue) - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
add(AssociationValue, String, String) - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
Adds an association between the given associationValue and sagaIdentifier.
ADD_ALL - Static variable in class org.axonframework.common.annotation.AnnotationUtils
Boolean specifying that a AnnotationUtils.findAnnotationAttributes(AnnotatedElement, String, boolean) invocation should contain all attributes of the target annotation recursively taken into account attributes of other annotations the target is present on.
addAlias(String, Class) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Adds an alias to use instead of the fully qualified class name.
addCachedAssociations(Iterable<AssociationValue>, String, Class<?>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
Registers the associations of a saga with given sagaIdentifier and given sagaType with the associations cache.
addedAssociations() - Method in interface org.axonframework.modelling.saga.AssociationValues
Returns the Set of association values that have been added since the last AssociationValues.commit().
addedAssociations() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
AddedTrackerStatus - Class in org.axonframework.eventhandling
References a new EventTrackerStatus which work just has started on.
AddedTrackerStatus(EventTrackerStatus) - Constructor for class org.axonframework.eventhandling.AddedTrackerStatus
Initializes the AddedTrackerStatus using the given addedTrackerStatus.
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.disruptor.commandhandling.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.
addMessageSource(String, StreamableMessageSource<TrackedEventMessage<?>>) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource.Builder
Adds a message source to the list of sources.
addPackageAlias(String, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Add an alias for a package.
advance(TrackingToken, TrackingToken) - Static method in interface org.axonframework.eventhandling.WrappedToken
Advance the given base TrackingToken to the target.
advancedTo(TrackingToken) - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
advancedTo(String, TrackingToken) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
Advances a single token within the tokenMap
advancedTo(TrackingToken) - Method in class org.axonframework.eventhandling.ReplayToken
 
advancedTo(TrackingToken) - Method in class org.axonframework.eventhandling.TrackerStatus
Advance this TrackerStatus' TrackingToken towards the given trackingToken.
advancedTo(TrackingToken) - Method in interface org.axonframework.eventhandling.WrappedToken
Advance this token to the given newToken.
advanceTimeBy(Duration, DeadlineConsumer) - Method in class org.axonframework.test.deadline.StubDeadlineManager
Advances time by the given duration and invokes the given deadlineConsumer for each deadline scheduled until that time.
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, DeadlineConsumer) - Method in class org.axonframework.test.deadline.StubDeadlineManager
Advances time to the given newDateTime and invokes the given deadlineConsumer for each deadline scheduled 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.eventhandling.GapAwareTrackingToken
Returns a new GapAwareTrackingToken instance based on this token but which has advanced to given index.
advanceToNextTrigger() - Method in class org.axonframework.test.deadline.StubDeadlineManager
Advances the "current time" of the manager to the next scheduled deadline, and returns that deadline.
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.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.
afterEach(ExtensionContext) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycleExtension
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
 
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.modelling.command
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.
AGGREGATE_CREATION_POLICY - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing an aggregate creation policy to be used when handling a command.
AGGREGATE_ID - Static variable in class org.axonframework.messaging.Headers
Key pointing to the aggregate identifier of a message.
AGGREGATE_SEQ - Static variable in class org.axonframework.messaging.Headers
Key pointing to the aggregate sequence of a message.
AGGREGATE_TYPE - Static variable in class org.axonframework.messaging.Headers
Key pointing to the aggregate type of a message.
AggregateAnnotationCommandHandler<T> - Class in org.axonframework.modelling.command
Command handler that handles commands based on CommandHandler annotations on an aggregate.
AggregateAnnotationCommandHandler(AggregateAnnotationCommandHandler.Builder<T>) - Constructor for class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
Instantiate a AggregateAnnotationCommandHandler based on the fields contained in the AggregateAnnotationCommandHandler.Builder.
AggregateAnnotationCommandHandler.Builder<T> - Class in org.axonframework.modelling.command
Builder class to instantiate a AggregateAnnotationCommandHandler.
AggregateBlacklistedException - Exception in org.axonframework.disruptor.commandhandling
Exception indicating that an aggregate has been blacklisted by the DisruptorCommandBus.
AggregateBlacklistedException(String, String, Throwable) - Constructor for exception org.axonframework.disruptor.commandhandling.AggregateBlacklistedException
Initializes the exception with given aggregateIdentifier, given explanatory message and cause.
AggregateCacheEntry<T> - Class in org.axonframework.eventsourcing
 
AggregateCacheEntry(EventSourcedAggregate<T>) - Constructor for class org.axonframework.eventsourcing.AggregateCacheEntry
 
AggregateConfiguration<A> - Interface in org.axonframework.config
Specialization of the Module Configuration for modules that define an Aggregate Configuration.
aggregateConfiguration(Class<A>) - Method in interface org.axonframework.config.Configuration
Returns the AggregateConfiguration for the given aggregateType.
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).
AggregateCreationPolicy - Enum in org.axonframework.modelling.command
Enumeration containing the possible creation policies for aggregates.
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.
AggregateEntityNotFoundException - Exception in org.axonframework.modelling.command
Exception indicating that the an entity for an aggregate could not be found.
AggregateEntityNotFoundException(String) - Constructor for exception org.axonframework.modelling.command.AggregateEntityNotFoundException
Initialize a AggregateEntityNotFoundException with given message.
AggregateEntityNotFoundException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateEntityNotFoundException
Initialize a AggregateEntityNotFoundException with given message and cause.
aggregateFactories(AggregateFactory<?>...) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Sets the aggregateFactories supported by this snapshotter.
aggregateFactories(List<AggregateFactory<?>>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Sets the aggregateFactories supported by this snapshotter.
aggregateFactory() - Method in interface org.axonframework.config.AggregateConfiguration
Returns the AggregateFactory defined in this configuration.
aggregateFactory() - Method in class org.axonframework.config.AggregateConfigurer
 
aggregateFactory(Class<A>) - Method in interface org.axonframework.config.Configuration
Returns the AggregateFactory configured for the given aggregateType.
AggregateFactory<T> - Interface in org.axonframework.eventsourcing
Interface describing objects capable of creating instances of aggregates to be initialized with an event stream.
aggregateFactory(AggregateFactory<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Sets the AggregateFactory used to create new Aggregate instances.
aggregateIdentifier() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
The identifier of the conflicting aggregate, as a String.
aggregateIdentifier() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
 
AggregateIdentifier - Annotation Type in org.axonframework.modelling.command
Field or Method annotation that identifies the member 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.
aggregateIdentifierColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event identifier column.
AggregateInvocationException - Exception in org.axonframework.modelling.command
Exception thrown when an invocation on a method of an aggregate gives rise to an exception.
AggregateInvocationException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateInvocationException
Initializes the exception using the given message and cause.
AggregateLifecycle - Class in org.axonframework.modelling.command
Abstract base class of a component that models an aggregate's life cycle.
AggregateLifecycle() - Constructor for class org.axonframework.modelling.command.AggregateLifecycle
 
AggregateLoadTimeSnapshotTriggerDefinition - Class in org.axonframework.eventsourcing
A Snapshotter trigger mechanism which based on the loading time of an Aggregate decides when to trigger the creation of a snapshot.
AggregateLoadTimeSnapshotTriggerDefinition(Snapshotter, long) - Constructor for class org.axonframework.eventsourcing.AggregateLoadTimeSnapshotTriggerDefinition
Initialize a SnapshotTriggerDefinition to trigger snapshot creation using the given snapshotter when loading the aggregate instance takes longer than the given loadTimeMillisThreshold.
AggregateMember - Annotation Type in org.axonframework.modelling.command
Marker annotation for a Field or Method that references one or more Entities capable of handling Commands or Events.
AggregateMemberAnnotatedChildEntityCollectionDefinition - Class in org.axonframework.modelling.command.inspection
Implementation of a AbstractChildEntityDefinition that is used to detect Collections of entities (member type assignable to Iterable) annotated with AggregateMember.
AggregateMemberAnnotatedChildEntityCollectionDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
 
AggregateMemberAnnotatedChildEntityDefinition - Class in org.axonframework.modelling.command.inspection
Implementation of a ChildEntityDefinition that is used to detect single entities annotated with AggregateMember.
AggregateMemberAnnotatedChildEntityDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
 
AggregateMemberAnnotatedChildEntityMapDefinition - Class in org.axonframework.modelling.command.inspection
Implementation of a AbstractChildEntityDefinition that is used to detect Maps with entities as values annotated with AggregateMember.
AggregateMemberAnnotatedChildEntityMapDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
 
AggregateMetaModelFactory - Interface in org.axonframework.modelling.command.inspection
Interface of a factory for an AggregateModel for any given type defining an aggregate.
aggregateModel() - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
Gets the aggregate model.
aggregateModel(AggregateModel<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
aggregateModel() - Method in class org.axonframework.modelling.command.AbstractRepository
Returns the aggregate model stored by this repository.
aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
Sets the AggregateModel of generic type T, describing the structure of the aggregate this Repository will store.
aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Sets the AggregateModel of generic type T, describing the structure of the aggregate the AnnotationCommandHandlerAdapter will handle.
aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
 
AggregateModel<T> - Interface in org.axonframework.modelling.command.inspection
Specialized EntityModel that describes the capabilities and properties of an aggregate root of type T.
aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
 
AggregateModellingException - Exception in org.axonframework.modelling.command.inspection
Thrown if an aggregate model is invalid.
AggregateModellingException(String) - Constructor for exception org.axonframework.modelling.command.inspection.AggregateModellingException
Constructs this exception with given message explaining the cause.
AggregateNotFoundException - Exception in org.axonframework.modelling.command
Exception indicating that the an aggregate could not be found in the repository.
AggregateNotFoundException(String, String) - Constructor for exception org.axonframework.modelling.command.AggregateNotFoundException
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier and given message.
AggregateNotFoundException(String, String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateNotFoundException
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier and with the given message and cause.
AggregateRolledBackException - Exception in org.axonframework.modelling.command
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.modelling.command.AggregateRolledBackException
Initialize the exception for an aggregate with given aggregateIdentifier.
AggregateRoot - Annotation Type in org.axonframework.modelling.command
Annotation placed on types that should be treated as the root of an aggregate.
AggregateScopeDescriptor - Class in org.axonframework.commandhandling.model
Deprecated.
in favor of the AggregateScopeDescriptor
AggregateScopeDescriptor(String, Object) - Constructor for class org.axonframework.commandhandling.model.AggregateScopeDescriptor
Deprecated.
Instantiate a AggregateScopeDescriptor with the provided type and identifier.
AggregateScopeDescriptor - Class in org.axonframework.modelling.command
Describes the scope of an Aggregate by means of its type and identifier.
AggregateScopeDescriptor(String, Supplier<Object>) - Constructor for class org.axonframework.modelling.command.AggregateScopeDescriptor
Instantiate an AggregateScopeDescriptor with a type and identifierSupplier.
AggregateScopeDescriptor(String, Object) - Constructor for class org.axonframework.modelling.command.AggregateScopeDescriptor
Instantiate an AggregateScopeDescriptor with the provided type and identifier.
AggregateSnapshotter - Class in org.axonframework.eventsourcing
Implementation of a snapshotter that uses the actual aggregate and its state to create a snapshot event.
AggregateSnapshotter(AggregateSnapshotter.Builder) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
Instantiate a AggregateSnapshotter based on the fields contained in the AggregateSnapshotter.Builder.
aggregateSnapshotter(Configuration, HandlerDefinition, ParameterResolverFactory, EventStore, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
AggregateSnapshotter.Builder - Class in org.axonframework.eventsourcing
Builder class to instantiate a AggregateSnapshotter.
AggregateStateCorruptedException - Exception in org.axonframework.disruptor.commandhandling
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.disruptor.commandhandling.AggregateStateCorruptedException
Initializes the exception with given aggregateIdentifier and given explanatory message.
AggregateStateCorruptedException(String, String, Throwable) - Constructor for exception org.axonframework.disruptor.commandhandling.AggregateStateCorruptedException
Initializes the exception with given aggregateIdentifier, given explanatory message and cause.
AggregateStreamCreationException - Exception in org.axonframework.modelling.command
Exception indicating that concurrent access to a repository was detected.
AggregateStreamCreationException(String) - Constructor for exception org.axonframework.modelling.command.AggregateStreamCreationException
Initialize the exception with the given message.
AggregateStreamCreationException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateStreamCreationException
Initialize the exception with the given 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
 
aggregateType - Variable in class org.axonframework.modelling.command.AbstractRepository.Builder
 
aggregateType(Class<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Sets the aggregateType as a Class, specifying the type of aggregate an AggregateModel should be created for.
AggregateVersion - Annotation Type in org.axonframework.modelling.command
Field or Method annotation that indicates the member contains the value that represents the version of the Aggregate, used for optimistic locking, as well as state validation for commands.
allCommandHandlerInterceptors() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Gets all command handler interceptors per type in this aggregate hierarchy.
allCommandHandlers() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Gets all command handlers per type in this aggregate hierarchy.
allEventHandlers() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Gets all event handlers per type in this aggregate hierarchy.
AllFieldsFilter - Class in org.axonframework.test.matchers
FieldFilter implementation that accepts all Fields.
allow(DomainEventData<?>) - Method in interface org.axonframework.eventsourcing.snapshotting.SnapshotFilter
Function applied to filter out snapshot data in the form of a DomainEventData.
ALLOW_REPLAY - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing whether the handler is allowed to be invoked on replays.
allowAll() - Static method in interface org.axonframework.eventsourcing.snapshotting.SnapshotFilter
A SnapshotFilter implementation which allows all snapshots.
AllowReplay - Annotation Type in org.axonframework.eventhandling
Annotation marking a Handler (or class) as being capable of handling replays, or not, depending on the value passed.
and(CommandMessageFilter) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
and(CommandMessageFilter) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
and(CommandMessageFilter) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
and(CommandMessageFilter) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
and(CommandMessageFilter) - Method in interface org.axonframework.commandhandling.distributed.CommandMessageFilter
Returns a filter that matches when both this instance and the given other match.
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.
andBatchSize(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
 
AndCommandMessageFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
A CommandMessageFilter implementation that matches whenever both supplied CommandMessageFilter instances match.
AndCommandMessageFilter(CommandMessageFilter, CommandMessageFilter) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
Initialize the filter to match when both the first and the second filter match.
andEventAvailabilityTimeout(long, TimeUnit) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Set the duration where a Tracking Processor will wait for the availability of Events, in each cycle, before extending the claim on the tokens it owns.
andEventTrackerStatusChangeListener(EventTrackerStatusChangeListener) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Sets the EventTrackerStatusChangeListener which will be called on EventTrackerStatus changes.
andGiven(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
andGiven(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
andGiven(Object...) - Method in interface org.axonframework.test.aggregate.TestExecutor
Configures the given domainEvents as the "given" events.
andGiven(List<?>) - Method in interface org.axonframework.test.aggregate.TestExecutor
Configures the given domainEvents as the "given" events.
andGivenCommands(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
andGivenCommands(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
andGivenCommands(Object...) - Method in interface org.axonframework.test.aggregate.TestExecutor
Configures the given commands as the command that will provide the "given" events.
andGivenCommands(List<?>) - Method in interface org.axonframework.test.aggregate.TestExecutor
Configures the given commands as the command that will provide the "given" events.
andGivenCurrentTime(Instant) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
andGivenCurrentTime(Instant) - Method in interface org.axonframework.test.aggregate.TestExecutor
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start of the given state.
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.
andInitialSegmentsCount(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
 
andInitialTrackingToken(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Sets the Builder to use to create the initial tracking token.
andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
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 interface org.axonframework.commandhandling.CommandResultMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandResultMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.deadline.DeadlineMessage
Returns a copy of this DeadlineMessage with its MetaData merged with given additionalMetaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.deadline.GenericDeadlineMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.DomainEventMessage
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData.
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.GenericDomainEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.replay.GenericResetContext
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.replay.ResetContext
Returns a copy of this ResetContext with it MetaData merged with the given metaData.
andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.AbstractMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.GenericResultMessage
 
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.messaging.responsetypes.ConvertingResponseMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.ResultMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryResponseMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
 
andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
 
andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.QueryMessage
Returns a copy of this QueryMessage with its MetaData merged with given metaData.
andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.QueryResponseMessage
Returns a copy of this QueryResponseMessage with its MetaData merged with given metaData.
andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.SubscriptionQueryMessage
Returns a copy of this SubscriptionQueryMessage with its MetaData merged with given metaData.
andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.SubscriptionQueryUpdateMessage
 
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(EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer.PooledStreamingProcessorConfiguration
Returns a configuration that applies the given other configuration after applying this.
andThen(Runnable) - Method in interface org.axonframework.modelling.command.ApplyMore
Execute the given runnable after applying the previous event.
andThen(Runnable) - Method in class org.axonframework.modelling.command.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.modelling.command.ApplyMore
Apply a subsequent event to the aggregate after applying another event.
andThenApply(Supplier<?>) - Method in class org.axonframework.modelling.command.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, Map<String, ?>) - Method in interface org.axonframework.test.saga.ContinuedGivenState
Indicates that the given event with given metaData has been published in the past.
andThenAPublished(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
 
andThenAPublished(Object, Map<String, ?>) - Method in class org.axonframework.test.saga.SagaTestFixture
 
andThenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.aggregate.TestExecutor
Deprecated.
in favor of TestExecutor.whenThenTimeAdvancesTo(Instant). This function incorrectly suggests you can proceed with other operations after calling it, which is made impossible due to the ResultValidator return type
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.aggregate.TestExecutor
Deprecated.
in favor of TestExecutor.whenThenTimeElapses(Duration). This function incorrectly suggests you can proceed with other operations after calling it, which is made impossible due to the ResultValidator return type
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
 
andThreadFactory(Function<String, ThreadFactory>) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Sets the ThreadFactory to use to create the threads to process events on.
andTokenClaimInterval(long, TimeUnit) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Sets the time to wait after a failed attempt to claim any token, before making another attempt.
AnnotatedAggregate<T> - Class in org.axonframework.modelling.command.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.modelling.command.inspection.AnnotatedAggregate
Initialize an Aggregate instance for the given aggregateRoot, described by the given aggregateModel that will publish events to the given eventBus.
AnnotatedAggregate(T, AggregateModel<T>, EventBus, RepositoryProvider) - Constructor for class org.axonframework.modelling.command.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.modelling.command.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, RepositoryProvider) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Initialize an Aggregate instance for the given aggregateRoot, described by the given aggregateModel that will publish events to the given eventBus.
AnnotatedAggregateMetaModelFactory - Class in org.axonframework.modelling.command.inspection
AggregateMetaModelFactory implementation that uses annotations on the target aggregate's members to build up the meta model of the aggregate.
AnnotatedAggregateMetaModelFactory() - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Initializes an instance which uses the default, classpath based, ParameterResolverFactory to detect parameters for annotated handlers.
AnnotatedAggregateMetaModelFactory(ParameterResolverFactory) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Initializes an instance which uses the given parameterResolverFactory to detect parameters for annotated handlers.
AnnotatedAggregateMetaModelFactory(ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Initializes an instance which uses the given parameterResolverFactory to detect parameters for annotated handlers and handlerDefinition to create concrete handlers.
AnnotatedChildEntity<P,C> - Class in org.axonframework.modelling.command.inspection
Implementation of a ChildEntity that uses annotations on a target entity to resolve event and command handlers.
AnnotatedChildEntity(EntityModel<C>, boolean, BiFunction<CommandMessage<?>, P, C>, BiFunction<EventMessage<?>, P, Stream<C>>) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedChildEntity
Initiates a new AnnotatedChildEntity instance that uses the provided entityModel to delegate command and event handling to an annotated child entity.
AnnotatedCommandHandlerInterceptor<T> - Class in org.axonframework.modelling.command.inspection
Annotated command handler interceptor on aggregate.
AnnotatedCommandHandlerInterceptor(MessageHandlingMember<T>, T) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedCommandHandlerInterceptor
Initializes annotated command handler interceptor with delegate handler and target on which handler is to be invoked.
AnnotatedHandlerAttributes - Class in org.axonframework.messaging.annotation
Container for message handler attributes, constructed through inspecting an AnnotatedElement.
AnnotatedHandlerAttributes(AnnotatedElement) - Constructor for class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
Create an AnnotatedHandlerAttributes containing all attributes of annotations (meta-)annotated with HasHandlerAttributes on the given annotatedElement.
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.modelling.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, SagaModel<T>) - Constructor for class org.axonframework.modelling.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.modelling.saga
Implementation of the SagaManager that uses annotations on the Sagas to describe the lifecycle management.
AnnotatedSagaManager(AnnotatedSagaManager.Builder<T>) - Constructor for class org.axonframework.modelling.saga.AnnotatedSagaManager
Instantiate a AnnotatedSagaManager based on the fields contained in the AnnotatedSagaManager.Builder.
AnnotatedSagaManager.Builder<T> - Class in org.axonframework.modelling.saga
Builder class to instantiate a AnnotatedSagaManager.
AnnotatedSagaRepository<T> - Class in org.axonframework.modelling.saga.repository
SagaRepository implementation extending from the LockingSagaRepository dealing with annotated Sagas.
AnnotatedSagaRepository(AnnotatedSagaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
Instantiate a AnnotatedSagaRepository based on the fields contained in the AnnotatedSagaRepository.Builder.
AnnotatedSagaRepository.Builder<T> - Class in org.axonframework.modelling.saga.repository
Builder class to instantiate a AnnotatedSagaRepository.
annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
annotationAttributes(Class<? extends Annotation>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
AnnotationCommandHandlerAdapter<T> - Class in org.axonframework.commandhandling
Adapter that turns any @CommandHandler annotated bean into a MessageHandler implementation.
AnnotationCommandHandlerAdapter(T) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
Wraps the given annotatedCommandHandler, allowing it to be subscribed to a Command Bus.
AnnotationCommandHandlerAdapter(T, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
Wraps the given annotatedCommandHandler, allowing it to be subscribed to a Command Bus.
AnnotationCommandHandlerAdapter(T, ParameterResolverFactory, HandlerDefinition) - 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.modelling.command
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.modelling.command.AnnotationCommandTargetResolver
Deprecated.
AnnotationCommandTargetResolver(AnnotationCommandTargetResolver.Builder) - Constructor for class org.axonframework.modelling.command.AnnotationCommandTargetResolver
Instantiate a AnnotationCommandTargetResolver based on the fields contained in the AnnotationCommandTargetResolver.Builder.
AnnotationCommandTargetResolver.Builder - Class in org.axonframework.modelling.command
Builder class to instantiate a AnnotationCommandTargetResolver.
AnnotationDriven - Annotation Type in org.axonframework.spring.config
Annotation for @Configuration that will automatically subscribe @CommandHandler and @QueryHandler annotated beans with the CommandBus and QueryBus, 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
 
AnnotationEventHandlerAdapter - Class in org.axonframework.eventhandling
Adapter that turns any bean with EventHandler annotated methods into an EventMessageHandler.
AnnotationEventHandlerAdapter(Object) - Constructor for class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
Wraps the given annotatedEventListener, allowing it to be subscribed to an Event Bus.
AnnotationEventHandlerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
Wraps the given annotatedEventListener, allowing it to be subscribed to an Event Bus.
AnnotationEventHandlerAdapter(Object, ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
Wraps the given annotatedEventListener, allowing it to be subscribed to an Event Bus.
AnnotationQueryHandlerAdapter<T> - Class in org.axonframework.queryhandling.annotation
Adapter that turns any @QueryHandler annotated bean into a MessageHandler implementation.
AnnotationQueryHandlerAdapter(T) - Constructor for class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
Initializes the adapter, forwarding call to the given target.
AnnotationQueryHandlerAdapter(T, ParameterResolverFactory) - Constructor for class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
Initializes the adapter, forwarding call to the given target, resolving parameters using the given parameterResolverFactory.
AnnotationQueryHandlerAdapter(T, ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
Initializes the adapter, forwarding call to the given target, resolving parameters using the given parameterResolverFactory and creating handlers using handlerDefinition.
AnnotationQueryHandlerBeanPostProcessor - Class in org.axonframework.spring.config.annotation
Spring Bean post processor that automatically generates an adapter for each bean containing QueryHandler annotated methods.
AnnotationQueryHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
 
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 RoutingKey (meta-)annotation on the command message's payload.
AnnotationRoutingStrategy(AnnotationRoutingStrategy.Builder) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Instantiate a AnnotationRoutingStrategy based on the fields contained in the given builder.
AnnotationRoutingStrategy() - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Deprecated.
AnnotationRoutingStrategy(Class<? extends Annotation>) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Deprecated.
AnnotationRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Deprecated.
AnnotationRoutingStrategy(Class<? extends Annotation>, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Deprecated.
AnnotationRoutingStrategy.Builder - Class in org.axonframework.commandhandling.distributed
Builder class to instantiate a AnnotationRoutingStrategy.
AnnotationSagaMetaModelFactory - Class in org.axonframework.modelling.saga.metamodel
Default implementation of a SagaMetaModelFactory.
AnnotationSagaMetaModelFactory() - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
AnnotationSagaMetaModelFactory(ParameterResolverFactory) - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
Initializes a AnnotationSagaMetaModelFactory with given parameterResolverFactory and ClasspathHandlerDefinition.
AnnotationSagaMetaModelFactory(ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
Initializes a AnnotationSagaMetaModelFactory with given parameterResolverFactory and given handlerDefinition.
annotationType(Class<? extends Annotation>) - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.Builder
Sets the annotationType Class searched for by this routing strategy on a CommandMessage to base the routing key on.
AnnotationUtils - Class in org.axonframework.common.annotation
Utility class for locating annotations and attribute values on elements.
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(Connection, 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.jdbc.JdbcEventStorageEngine
 
appendEvents(AppendEventsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Set the PreparedStatement to be used on JdbcEventStorageEngine.appendEvents(Connection, List, Serializer) en}.
appendEvents(Connection, EventSchema, Class<?>, List<? extends EventMessage<?>>, Serializer, TimestampWriter) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.appendEvents(List, Serializer).
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(EventMessage<?>...) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
AppendEventsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.appendEvents(List, Serializer)
appendSnapshot(Connection, DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
appendSnapshot(AppendSnapshotStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
appendSnapshot(Connection, EventSchema, Class<?>, DomainEventMessage<?>, Serializer, TimestampWriter) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
AppendSnapshotStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.storeSnapshot(DomainEventMessage, Serializer).
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(MetaData) - Method in class org.axonframework.axonserver.connector.util.GrpcMetadataSerializer
 
apply(O) - Method in class org.axonframework.axonserver.connector.util.GrpcObjectSerializer
 
apply(Message) - Method in class org.axonframework.axonserver.connector.util.GrpcPayloadSerializer
 
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.
apply(Object, MetaData) - Static method in class org.axonframework.modelling.command.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.modelling.command.AggregateLifecycle
Apply a DomainEventMessage with given payload without metadata (though interceptors can also be used to provide metadata).
apply(Statement, Description) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycleRule
Deprecated.
 
applyMessageOrPayload(Object) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Apply a new event message to the aggregate and then publish this message to external systems.
ApplyMore - Interface in org.axonframework.modelling.command
Interface that describes a mechanism that enables the application of an additional event after another event is applied.
asCollection(Object) - Static method in class org.axonframework.common.CollectionUtils
Returns a Collection instance that contains the elements of the given potentialCollection.
asCommandMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandMessage
Returns the given command as a CommandMessage.
asCommandResultMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandResultMessage
Returns the given commandResult as a CommandResultMessage instance.
asCommandResultMessage(Throwable) - Static method in class org.axonframework.commandhandling.GenericCommandResultMessage
Creates a Command Result Message with the given exception result.
asDeadlineMessage(String, Object) - Static method in class org.axonframework.deadline.GenericDeadlineMessage
Deprecated.
Use GenericDeadlineMessage.asDeadlineMessage(String, Object, Instant) instead, as it sets the timestamp of the deadline, rather than the current time
asDeadlineMessage(String, Object, Instant) - Static method in class org.axonframework.deadline.GenericDeadlineMessage
Returns the given deadlineName and messageOrPayload as a DeadlineMessage which expires at the given expiryTime.
asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventhandling.EventUtils
Deprecated.
since this method is not used for external use. This method is intended to deduce whether a given EventMessage is a DomainEventMessage and if not, push it into being one by adjusting the fields. However, this is only intended to simplify the storage of events. This does not make a regular EventMessage a DomainEventMessage by any means. The only way to have a true DomainEventMessage is by publishing events from within an Aggregate, by using the AggregateLifecycle operations.
asEventMessage(Object) - Static method in class org.axonframework.eventhandling.GenericEventMessage
Returns the given event as an EventMessage.
asMessage(Object) - Static method in class org.axonframework.messaging.GenericMessage
Returns a Message representing the given payloadOrMessage, either by wrapping it or by returning it as-is.
asNullableResponseMessage(Class<R>, Object) - Static method in class org.axonframework.queryhandling.GenericQueryResponseMessage
Creates a QueryResponseMessage for the given result with a declaredType as the result type.
asResetContext(Object) - Static method in class org.axonframework.eventhandling.replay.GenericResetContext
Returns the given messageOrPayload as a ResetContext.
asResponseMessage(Object) - Static method in class org.axonframework.queryhandling.GenericQueryResponseMessage
Creates a QueryResponseMessage for the given result.
asResponseMessage(Class<R>, Throwable) - Static method in class org.axonframework.queryhandling.GenericQueryResponseMessage
Creates a Query Response Message with given declaredType and exception.
asResultMessage(Object) - Static method in class org.axonframework.messaging.GenericResultMessage
Returns the given result as a ResultMessage instance.
asResultMessage(Throwable) - Static method in class org.axonframework.messaging.GenericResultMessage
Creates a ResultMessage with the given exception result.
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.
assertDeadlinesMet(Object...) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that the given expected deadlines have been met (which have passed in time).
assertDeadlinesMetMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that deadlines have been met (which have passed in time) match the given matcher.
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.
assertNonEmpty(String, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given string is not null and does not equal an empty String.
assertNonNull(T, Supplier<? extends X>) - Static method in class org.axonframework.common.Assert
Assert that the given value is non null.
assertNonNull(T, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given value is non null.
assertNoScheduledDeadlineMatching(Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that no deadline matching the given matcher has been scheduled.
assertNoScheduledDeadlines() - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that no deadlines are scheduled.
assertNoScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
Asserts that no event matching the given matcher has been scheduled after the given duration.
assertNoScheduledEventMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
Asserts that no event matching the given matcher has been scheduled at the given scheduledTime.
assertNoScheduledEvents() - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
Asserts that no events are scheduled for publication.
assertPositive(int, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given value is positive, meaning greater than, or equal to, zero.
assertPositive(long, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given value is positive, meaning greater than, or equal to, zero.
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.
assertScheduledDeadlineMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that a deadline scheduled after given duration matches the given matcher.
assertScheduledDeadlineMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that a deadline scheduled at the given scheduledTime matches the given matcher.
assertScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.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.eventscheduler.EventSchedulerValidator
Asserts that an event matching the given matcher is scheduled for publication at the given scheduledTime.
assertStrictPositive(int, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given value is strictly positive, meaning greater than zero.
assertStrictPositive(long, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given value is strictly positive, meaning greater than zero.
assertThat(T, Predicate<T>, Supplier<? extends X>) - Static method in class org.axonframework.common.Assert
Assert that the given value will result to true through the assertion Predicate.
assertThat(T, Predicate<T>, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given value will result to true through the assertion Predicate.
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.modelling.saga.AssociationValues
Returns this instance as a Set of Association Values.
asSet() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
assignHandlerInstancesMatching(String, Predicate<Object>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Configures a rule to assign Event Handler beans that match the given criteria to the Processing Group with given name, with neutral priority (value 0).
assignHandlerInstancesMatching(String, int, Predicate<Object>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Configures a rule to assign Event Handler beans that match the given criteria to the Processing Group with given name, with given priority.
assignHandlerInstancesMatching(String, int, Predicate<Object>) - Method in class org.axonframework.config.EventProcessingModule
 
assignHandlerTypesMatching(String, Predicate<Class<?>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Configures a rule to assign Event Handler beans that match the given criteria to the Processing Group with given name, with neutral priority (value 0).
assignHandlerTypesMatching(String, int, Predicate<Class<?>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Configures a rule to assign Event Handler beans that match the given criteria to the Processing Group with given name, with given priority.
assignHandlerTypesMatching(String, int, Predicate<Class<?>>) - Method in class org.axonframework.config.EventProcessingModule
 
assignProcessingGroup(String, String) - Method in interface org.axonframework.config.EventProcessingConfigurer
Defines a mapping for assigning processing groups to processors.
assignProcessingGroup(Function<String, String>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Defines a rule for assigning processing groups to processors if processing group to processor name mapping does not contain the entry.
assignProcessingGroup(String, String) - Method in class org.axonframework.config.EventProcessingModule
 
assignProcessingGroup(Function<String, String>) - Method in class org.axonframework.config.EventProcessingModule
 
associateWith(String, String) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
Registers a AssociationValue with the currently active saga.
associateWith(String, Number) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
Registers a AssociationValue with the currently active saga.
associateWith(AssociationValue) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
Registers a AssociationValue with the currently active saga.
AssociationResolver - Interface in org.axonframework.modelling.saga
Used to derive the value of an association property as designated by the association property name.
associationsCache(Cache) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
Sets the associationsCache of type Cache used to store Saga associations with.
AssociationValue - Class in org.axonframework.modelling.saga
A combination of key and value by which a Saga can be found.
AssociationValue(String, String) - Constructor for class org.axonframework.modelling.saga.AssociationValue
Creates a Association Value instance with the given key and value.
AssociationValueEntry - Class in org.axonframework.modelling.saga.repository.jpa
JPA wrapper around an Association Value.
AssociationValueEntry(String, String, AssociationValue) - Constructor for class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
Initialize a new AssociationValueEntry for a saga with given sagaIdentifier and associationValue.
AssociationValueEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
Constructor required by JPA.
associationValueEntryTable() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
Returns the name of the associationValueEntry table
AssociationValueMap - Class in org.axonframework.modelling.saga.repository
In-memory storage for AssociationValue to Saga mappings.
AssociationValueMap() - Constructor for class org.axonframework.modelling.saga.repository.AssociationValueMap
Initializes a new and empty AssociationValueMap.
AssociationValues - Interface in org.axonframework.modelling.saga
Interface describing a container of Association Values for a single Saga instance.
associationValues() - Method in interface org.axonframework.modelling.saga.repository.SagaStore.Entry
Returns the Set of association values of the fetched Saga entry.
AssociationValuesImpl - Class in org.axonframework.modelling.saga
Default implementation of the AssociationValues interface.
AssociationValuesImpl() - Constructor for class org.axonframework.modelling.saga.AssociationValuesImpl
Initializes a new AssociationValues object without initial associations.
AssociationValuesImpl(Set<AssociationValue>) - Constructor for class org.axonframework.modelling.saga.AssociationValuesImpl
Initializes a new AssociationValues object with given initial associations.
asStream() - Method in interface org.axonframework.common.stream.BlockingStream
Returns this MessageStream as a Stream of Messages.
asStream(BlockingStream<M>) - Static method in class org.axonframework.common.stream.StreamUtils
Convert the given messageStream to a regular java Stream.
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.EventStreamUtils
Convert the given domainEventStream to a regular java Stream of domain event messages.
asTrackedEventMessage(EventMessage<T>, TrackingToken) - Static method in class org.axonframework.eventhandling.EventUtils
Convert an EventMessage to a TrackedEventMessage using the given trackingToken.
asUpdateMessage(Object) - Static method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
Creates GenericSubscriptionQueryUpdateMessage from provided payload which represents incremental update.
asUpdateMessage(Class<T>, Throwable) - Static method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
Creates a GenericSubscriptionQueryUpdateMessage with the given declaredType and exception result.
AsynchronousCommandBus - Class in org.axonframework.commandhandling
Specialization of the SimpleCommandBus that processed Commands asynchronously from the calling thread.
AsynchronousCommandBus(AsynchronousCommandBus.Builder) - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
Instantiate a AsynchronousCommandBus based on the fields contained in the AsynchronousCommandBus.Builder.
AsynchronousCommandBus.Builder - Class in org.axonframework.commandhandling
Builder class to instantiate a AsynchronousCommandBus.
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.
attachTransaction(TransactionManager) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Attach a transaction to this Unit of Work, using the given transactionManager.
attribute(String) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
attribute(String) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Retrieve a single attributes for the given attributeKey.
attribute(String) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
attribute(String) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
autoConfigBasePackages(ApplicationContext) - Static method in class org.axonframework.springboot.util.XStreamSecurityTypeUtility
Retrieves the auto-configuration base packages from AutoConfigurationPackages.get(BeanFactory).
AutoConfiguration() - Constructor for class org.axonframework.springboot.MetricsProperties.AutoConfiguration
 
AutowiredResourceInjector - Class in org.axonframework.test.utils
Deprecated.
in favor of the SimpleResourceInjector
AutowiredResourceInjector(Iterable<Object>) - Constructor for class org.axonframework.test.utils.AutowiredResourceInjector
Deprecated.
Initializes the resource injector to inject to given resources.
availableProcessorThreads() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Returns the number of threads this processor has available to assign segments.
awaitCompletion(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
Wait for completion of the command, or for the timeout to expire.
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.springboot.autoconfig
 
AxonAutoConfiguration(EventProcessorProperties, SerializerProperties, TagsConfigurationProperties, ApplicationContext) - Constructor for class org.axonframework.springboot.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.
axonFrameworkVersionResolver(Supplier<String>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
Deprecated.
Not ued anymore
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.
AxonServerAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Configures Axon Server as implementation for the CommandBus, QueryBus and EventStore.
AxonServerAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
AxonServerCommandBus - Class in org.axonframework.axonserver.connector.command
Axon CommandBus implementation that connects to Axon Server to submit and receive commands and command responses.
AxonServerCommandBus(AxonServerCommandBus.Builder) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerCommandBus
Instantiate a AxonServerCommandBus based on the fields contained in the AxonServerCommandBus.Builder.
axonServerCommandBus(AxonServerConnectionManager, AxonServerConfiguration, CommandBus, Serializer, RoutingStrategy, CommandPriorityCalculator, CommandLoadFactorProvider, TargetContextResolver<? super CommandMessage<?>>) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
AxonServerCommandBus.Builder - Class in org.axonframework.axonserver.connector.command
Builder class to instantiate an AxonServerCommandBus.
AxonServerCommandDispatchException - Exception in org.axonframework.axonserver.connector.command
Exception thrown if there is a problem dispatching a command on Axon Server.
AxonServerCommandDispatchException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
Initialize the exception with given errorCode and errorMessage.
AxonServerCommandDispatchException(String, String, Throwable) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
 
AxonServerConfiguration - Class in org.axonframework.axonserver.connector
Configuration class provided configurable fields and defaults for anything Axon Server related.
AxonServerConfiguration() - Constructor for class org.axonframework.axonserver.connector.AxonServerConfiguration
Instantiate a default AxonServerConfiguration.
axonServerConfiguration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
Sets the AxonServerConfiguration used to correctly configure connections between Axon clients and Axon Server.
axonServerConfiguration() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
AxonServerConfiguration.Builder - Class in org.axonframework.axonserver.connector
 
AxonServerConfiguration.FlowControlConfiguration - Class in org.axonframework.axonserver.connector
Configuration class for Flow Control of specific message types.
AxonServerConfiguration.HeartbeatConfiguration - Class in org.axonframework.axonserver.connector
 
AxonServerConnectionManager - Class in org.axonframework.axonserver.connector
The component which manages all the connections which an Axon client can establish with an Axon Server instance.
AxonServerConnectionManager(AxonServerConnectionManager.Builder, AxonServerConnectionFactory) - Constructor for class org.axonframework.axonserver.connector.AxonServerConnectionManager
Instantiate a AxonServerConnectionManager based on the fields contained in the AxonServerConnectionManager.Builder, using the given connectionFactory to obtain connections to AxonServer.
axonServerConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the AxonServerConnectionManager used to create connections between this application and an Axon Server instance.
axonServerConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the AxonServerConnectionManager used to create connections between this application and an Axon Server instance.
AxonServerConnectionManager.Builder - Class in org.axonframework.axonserver.connector
Builder class to instantiate an AxonServerConnectionManager.
AxonServerEventScheduler - Class in org.axonframework.axonserver.connector.event.axon
Implementation of the EventScheduler that uses Axon Server to schedule the events.
AxonServerEventScheduler(AxonServerEventScheduler.Builder) - Constructor for class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
AxonServerEventScheduler.Builder - Class in org.axonframework.axonserver.connector.event.axon
Builder class to instantiate an AxonServerEventScheduler.
AxonServerEventStore - Class in org.axonframework.axonserver.connector.event.axon
Axon EventStore implementation that connects to the AxonIQ AxonServer Server to store and retrieve Events.
AxonServerEventStore(AxonServerEventStore.Builder) - Constructor for class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
Instantiate a AxonServerEventStore based on the fields contained in the AxonServerEventStore.Builder.
AxonServerEventStore.Builder - Class in org.axonframework.axonserver.connector.event.axon
Builder class to instantiate a AxonServerEventStore.
AxonServerException - Exception in org.axonframework.axonserver.connector
Generic exception indicating an error related to AxonServer.
AxonServerException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
Initializes the exception using the given code and errorMessage.
AxonServerException(String, String) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
Initializes the exception using the given code and message.
AxonServerException(String, String, String, List<String>) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
Initializes the exception using the given message, code, source and details.
AxonServerException(String, String, Throwable) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
Initializes the exception using the given message, code, and cause.
AxonServerQueryBus - Class in org.axonframework.axonserver.connector.query
Axon QueryBus implementation that connects to Axon Server to submit and receive queries and query responses.
AxonServerQueryBus(AxonServerQueryBus.Builder) - Constructor for class org.axonframework.axonserver.connector.query.AxonServerQueryBus
Instantiate a AxonServerQueryBus based on the fields contained in the AxonServerQueryBus.Builder.
AxonServerQueryBus.Builder - Class in org.axonframework.axonserver.connector.query
Builder class to instantiate an AxonServerQueryBus.
AxonServerQueryDispatchException - Exception in org.axonframework.axonserver.connector.query
An AxonServer Exception which is thrown on a Query Dispatching exception.
AxonServerQueryDispatchException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
Initializes an AxonServer Query Dispatch Exception using the given code and errorMessage.
AxonServerQueryDispatchException(String, String) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
Initializes an AxonServer Query Dispatch Exception using the given code and message.
AxonServerQueryDispatchException(String, String, String, List<String>) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
Initializes an AxonServer Query Dispatch Exception using the given message, code, source and details .
AxonServerRegistration - Class in org.axonframework.axonserver.connector.command
Wrapper around standard Axon Framework Registration.
AxonServerRegistration(Registration, Runnable) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerRegistration
Instantiate an AxonServerRegistration, which wraps the given wrappedRegistration and runs the provided closeCallback on a Registration.close() and AxonServerRegistration.cancel() call
AxonServerRemoteCommandHandlingException - Exception in org.axonframework.axonserver.connector.command
Exception indicating a problem that was reported by the remote end of a connection.
AxonServerRemoteCommandHandlingException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
Initialize the exception with given errorCode and errorMessage.
AxonServerRemoteQueryHandlingException - Exception in org.axonframework.axonserver.connector.query
An AxonServer Exception which is thrown on a Query Handling exception.
AxonServerRemoteQueryHandlingException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
Initialize a Query Handling exception from a remote source.
AxonServerSubscriptionQueryResult<I,U> - Class in org.axonframework.axonserver.connector.query.subscription
A SubscriptionQueryResult that emits initial response and update when subscription query response message is received.
AxonServerSubscriptionQueryResult(SubscriptionQueryResult, SubscriptionMessageSerializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
Instantiate a AxonServerSubscriptionQueryResult which will emit its initial response and the updates of the subscription query.
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.springboot.autoconfig.NoOpTransactionAutoConfiguration
 
axonTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.springboot.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

backoffFactor(long) - Method in class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler.Builder
Sets the backoff factor in milliseconds at which to schedule a retry.
BatchingEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
AbstractEventStorageEngine implementation that fetches events in batches from the backing database.
BatchingEventStorageEngine(BatchingEventStorageEngine.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Instantiate a BatchingEventStorageEngine based on the fields contained in the BatchingEventStorageEngine.Builder.
BatchingEventStorageEngine.Builder - Class in org.axonframework.eventsourcing.eventstore
Abstract Builder class to instantiate a BatchingEventStorageEngine.
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(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies the number of events to be processed inside a single transaction.
batchSize() - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Returns the maximum number of event entries to be fetched per batch.
batchSize(int) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
Sets the batchSize specifying the number of events that should be read at each database access.
batchSize(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
 
batchSize(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
 
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.
BeanValidationInterceptor(ValidatorFactory) - Constructor for class org.axonframework.messaging.interceptors.BeanValidationInterceptor
Initializes a validation interceptor using the given ValidatorFactory.
beforeEach(ExtensionContext) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycleExtension
 
beforeStart(ClientCallStreamObserver<Object>) - Method in class org.axonframework.axonserver.connector.util.UpstreamAwareStreamObserver
 
BlacklistDetectingCallback<C,R> - Class in org.axonframework.disruptor.commandhandling
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.disruptor.commandhandling.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
 
BlockingStream<M> - Interface in org.axonframework.common.stream
Interface for a stream that can be polled for information using (optionally blocking) pull operations.
bufferSize(int) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the buffer size to use.
build() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
Initializes a AxonServerConfiguration as specified through this Builder.
build() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
Initializes a AxonServerConnectionManager as specified through this Builder.
build() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Initializes a AxonServerCommandBus as specified through this Builder.
build() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
Initializes a AxonServerEventScheduler as specified through this Builder.
build() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Initializes a AxonServerEventStore as specified through this Builder.
build() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Initializes a AxonServerQueryBus as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
Initializes a AsynchronousCommandBus as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.Builder
Initializes a AnnotationRoutingStrategy implementation as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
Initializes a DistributedCommandBus as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.Builder
Initializes a MetaDataRoutingStrategy implementation as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
Initializes a CommandGatewayFactory as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
Initializes a DefaultCommandGateway as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler.Builder
Initializes a ExponentialBackOffIntervalRetryScheduler as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler.Builder
Initializes a IntervalRetryScheduler as specified through this Builder.
build() - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
Initializes a SimpleCommandBus as specified through this Builder.
build() - Method in class org.axonframework.common.lock.PessimisticLockFactory.Builder
Builds the PessimisticLockFactory instance using the properties defined in this builder
build(String, Configuration, EventHandlerInvoker) - Method in interface org.axonframework.config.EventProcessingConfigurer.EventProcessorBuilder
Builds an EventProcessor with the given name, Configuration and EventHandlerInvoker.
build() - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
Initializes a QuartzDeadlineManager as specified through this Builder.
build() - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
Initializes a SimpleDeadlineManager as specified through this Builder.
build() - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Initializes a DisruptorCommandBus as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy.Builder
Initializes a PropertySequencingPolicy as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
Initializes a DefaultEventGateway as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Initializes a PooledStreamingEventProcessor as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
Initializes a SimpleEventScheduler as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
Initializes a QuartzEventScheduler as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.SimpleEventBus.Builder
Initializes a SimpleEventBus as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Initializes a SimpleEventHandlerInvoker as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
Initializes a SubscribingEventProcessor as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Initializes a JdbcTokenStore as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Builds a new TokenSchema from builder values.
build() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
Initializes a JpaTokenStore as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
Initializes a TrackingEventProcessor as specified through this Builder.
build() - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Initializes a AggregateSnapshotter as specified through this Builder.
build() - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Initializes a EventSourcingRepository or CachingEventSourcingRepository as specified through this Builder.
build() - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
Initializes a EmbeddedEventStore as specified through this Builder.
build() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Builds a new EventSchema from builder values.
build() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Initializes a JdbcEventStorageEngine as specified through this Builder.
build(Connection, EventSchema, Class<?>, List<? extends EventMessage<?>>, Serializer, TimestampWriter) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.AppendEventsStatementBuilder
build(Connection, EventSchema, Class<?>, DomainEventMessage<?>, Serializer, TimestampWriter) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.AppendSnapshotStatementBuilder
build(Connection, EventSchema, SortedSet<Long>) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.CleanGapsStatementBuilder
Creates a statement to be used at JdbcEventStorageEngine.cleanGaps(TrackingToken)
build(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.CreateHeadTokenStatementBuilder
Creates a statement to be used at JdbcEventStorageEngine.createHeadToken().
build(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.CreateTailTokenStatementBuilder
Creates a statement to be used at JdbcEventStorageEngine.createTailToken().
build(Connection, EventSchema, Instant) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.CreateTokenAtStatementBuilder
Creates a statement to be used at JdbcEventStorageEngine.createTokenAt(Instant).
build(Connection, EventSchema, String, long) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.DeleteSnapshotsStatementBuilder
build(Connection, EventSchema, long) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.FetchTrackedEventsStatementBuilder
build(Connection, EventSchema, String) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.LastSequenceNumberForStatementBuilder
build(Connection, EventSchema, String, long, int) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.ReadEventDataForAggregateStatementBuilder
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.
build(Connection, EventSchema, long, int, List<Long>) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.ReadEventDataWithGapsStatementBuilder
build(Connection, EventSchema, long, int) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.ReadEventDataWithoutGapsStatementBuilder
build(Connection, EventSchema, String) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.ReadSnapshotDataStatementBuilder
Creates a statement to be used at JdbcEventStorageEngine.readSnapshotData(String)
build() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Initializes a JpaEventStorageEngine as specified through this Builder.
build() - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource.Builder
Initializes a MultiStreamableMessageSource as specified through this Builder.
build() - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
Initializes a RevisionSnapshotFilter as specified through this Builder.
build() - Method in class org.axonframework.metrics.MessageTimerMonitor.Builder
Initializes a MessageTimerMonitor as specified through this Builder.
build() - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
Initializes a MessageTimerMonitor as specified through this Builder.
build() - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
Initializes a MessageTimerMonitor as specified through this Builder.
build() - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Initializes a AggregateAnnotationCommandHandler as specified through this Builder.
build() - Method in class org.axonframework.modelling.command.AnnotationCommandTargetResolver.Builder
Initializes a AnnotationCommandTargetResolver as specified through this Builder.
build() - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
Initializes a GenericJpaRepository as specified through this Builder.
build() - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
Initializes a AnnotatedSagaManager as specified through this Builder.
build() - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Initializes a AnnotatedSagaRepository as specified through this Builder.
build() - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
Initializes a CachingSagaStore as specified through this Builder.
build() - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
Initializes a JdbcSagaStore as specified through this Builder.
build() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
Initializes a JpaSagaStore as specified through this Builder.
build() - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
Initializes a DefaultQueryGateway as specified through this Builder.
build() - Method in class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler.Builder
Initializes a LoggingQueryInvocationErrorHandler as specified through this Builder.
build() - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
Initializes a SimpleQueryBus as specified through this Builder.
build() - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter.Builder
Initializes a SimpleQueryUpdateEmitter as specified through this Builder.
build() - Method in class org.axonframework.serialization.JavaSerializer.Builder
Deprecated.
Initializes a JavaSerializer as specified through this Builder.
build() - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Initializes a JacksonSerializer as specified through this Builder.
build() - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
Initializes a XStreamSerializer as specified through this Builder.
build() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
Initializes a SpringAggregateSnapshotter as specified through this Builder.
buildAggregateModel() - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
Instantiate the AggregateModel of generic type T describing the structure of the Aggregate this Repository will store.
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
 
buildContext() - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
Builds a context of generic type C to be used when processing the stream of intermediate object representations T.
buildContext() - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
Builds a context of generic type C to be used when processing the stream of intermediate object representations T.
builder() - Static method in class org.axonframework.axonserver.connector.AxonServerConfiguration
Builder() - Constructor for class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
builder() - Static method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Instantiate a Builder to be able to create an AxonServerConnectionManager.
Builder() - Constructor for class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
 
builder() - Static method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
Instantiate a Builder to be able to create an AxonServerCommandBus.
Builder() - Constructor for class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
 
builder() - Static method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
Instantiate a Builder to be able to create a AxonServerEventScheduler.
Builder() - Constructor for class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
 
builder() - Static method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
Instantiate a Builder to be able to create a AxonServerEventStore.
Builder() - Constructor for class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
 
builder() - Static method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
Instantiate a Builder to be able to create an AxonServerQueryBus.
Builder() - Constructor for class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
 
builder() - Static method in class org.axonframework.commandhandling.AsynchronousCommandBus
Instantiate a Builder to be able to create a AsynchronousCommandBus.
Builder() - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
 
builder() - Static method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Instantiate a Builder to be able to create a AnnotationRoutingStrategy.
Builder() - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.Builder
 
builder() - Static method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Instantiate a Builder to be able to create a DistributedCommandBus.
Builder() - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
 
builder() - Static method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Instantiate a Builder to be able to create a MetaDataRoutingStrategy.
Builder() - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.Builder
 
Builder() - Constructor for class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
 
Builder() - Constructor for class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
 
builder() - Static method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Instantiate a Builder to be able to create a CommandGatewayFactory.
Builder() - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
 
builder() - Static method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Instantiate a Builder to be able to create a DefaultCommandGateway.
Builder() - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
 
builder() - Static method in class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler
Instantiate a Builder to be able to create a ExponentialBackOffIntervalRetryScheduler.
Builder() - Constructor for class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler.Builder
 
builder() - Static method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
Instantiate a Builder to be able to create a IntervalRetryScheduler.
Builder() - Constructor for class org.axonframework.commandhandling.gateway.IntervalRetryScheduler.Builder
 
builder() - Static method in class org.axonframework.commandhandling.SimpleCommandBus
Instantiate a Builder to be able to create a SimpleCommandBus.
Builder() - Constructor for class org.axonframework.commandhandling.SimpleCommandBus.Builder
 
builder() - Static method in class org.axonframework.common.lock.PessimisticLockFactory
Creates a builder to construct an instance of this LockFactory.
Builder() - Constructor for class org.axonframework.common.lock.PessimisticLockFactory.Builder
Default constructor
builder() - Static method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
Instantiate a Builder to be able to create a QuartzDeadlineManager.
Builder() - Constructor for class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
 
builder() - Static method in class org.axonframework.deadline.SimpleDeadlineManager
Instantiate a Builder to be able to create a SimpleDeadlineManager.
Builder() - Constructor for class org.axonframework.deadline.SimpleDeadlineManager.Builder
 
builder() - Static method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Instantiate a Builder to be able to create a DisruptorCommandBus.
Builder() - Constructor for class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
 
Builder() - Constructor for class org.axonframework.eventhandling.AbstractEventBus.Builder
 
Builder() - Constructor for class org.axonframework.eventhandling.AbstractEventProcessor.Builder
 
builder(Class<T>, Class<K>) - Static method in class org.axonframework.eventhandling.async.PropertySequencingPolicy
Instantiate a Builder to be able to create a PropertySequencingPolicy.
Builder() - Constructor for class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
 
builder() - Static method in class org.axonframework.eventhandling.gateway.DefaultEventGateway
Instantiate a Builder to be able to create a DefaultEventGateway.
Builder() - Constructor for class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
 
builder() - Static method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
Instantiate a Builder to be able to create a PooledStreamingEventProcessor.
Builder() - Constructor for class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
 
builder() - Static method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
Instantiate a Builder to be able to create a SimpleEventScheduler.
Builder() - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
 
builder() - Static method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Instantiate a Builder to be able to create a QuartzEventScheduler.
Builder() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
 
builder() - Static method in class org.axonframework.eventhandling.SimpleEventBus
Instantiate a Builder to be able to create a SimpleEventBus.
Builder() - Constructor for class org.axonframework.eventhandling.SimpleEventBus.Builder
 
builder() - Static method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
Instantiate a Builder to be able to create a SimpleEventHandlerInvoker.
Builder() - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
 
builder() - Static method in class org.axonframework.eventhandling.SubscribingEventProcessor
Instantiate a Builder to be able to create a SubscribingEventProcessor.
Builder() - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
 
builder() - Static method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Instantiate a Builder to be able to create a JdbcTokenStore.
Builder() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
 
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.eventhandling.tokenstore.jpa.JpaTokenStore
Instantiate a Builder to be able to create a JpaTokenStore.
Builder() - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
 
builder() - Static method in class org.axonframework.eventhandling.TrackingEventProcessor
Instantiate a Builder to be able to create a TrackingEventProcessor.
Builder() - Constructor for class org.axonframework.eventhandling.TrackingEventProcessor.Builder
 
Builder() - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
 
builder() - Static method in class org.axonframework.eventsourcing.AggregateSnapshotter
Instantiate a Builder to be able to create a AggregateSnapshotter.
Builder() - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
 
builder(Class<T>) - Static method in class org.axonframework.eventsourcing.EventSourcingRepository
Instantiate a Builder to be able to create a EventSourcingRepository for aggregate type T.
Builder(Class<T>) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Creates a builder for a Repository for given aggregateType.
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
 
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
 
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
 
builder() - Static method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
Instantiate a Builder to be able to create an EmbeddedEventStore.
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.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.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Instantiate a Builder to be able to create a JdbcEventStorageEngine.
builder() - Static method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Instantiate a Builder to be able to create a JpaEventStorageEngine.
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
 
builder() - Static method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
Instantiate a Builder to be able to create an MultiStreamableMessageSource.
Builder() - Constructor for class org.axonframework.eventsourcing.MultiStreamableMessageSource.Builder
 
builder() - Static method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter
Instantiate a Builder to be able to create a RevisionSnapshotFilter.
Builder() - Constructor for class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
 
builder() - Static method in class org.axonframework.metrics.MessageTimerMonitor
Instantiate a Builder to be able to create a MessageTimerMonitor.
Builder() - Constructor for class org.axonframework.metrics.MessageTimerMonitor.Builder
 
builder() - Static method in class org.axonframework.micrometer.EventProcessorLatencyMonitor
Instantiate a Builder to be able to create a EventProcessorLatencyMonitor.
Builder() - Constructor for class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
 
builder() - Static method in class org.axonframework.micrometer.MessageTimerMonitor
Instantiate a Builder to be able to create a MessageTimerMonitor.
Builder() - Constructor for class org.axonframework.micrometer.MessageTimerMonitor.Builder
 
Builder(Class<T>) - Constructor for class org.axonframework.modelling.command.AbstractRepository.Builder
Creates a builder for a Repository for given aggregateType.
builder() - Static method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
Instantiate a Builder to be able to create a AggregateAnnotationCommandHandler.
Builder() - Constructor for class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
 
builder() - Static method in class org.axonframework.modelling.command.AnnotationCommandTargetResolver
Instantiate a Builder to be able to create a AnnotationCommandTargetResolver.
Builder() - Constructor for class org.axonframework.modelling.command.AnnotationCommandTargetResolver.Builder
 
builder(Class<T>) - Static method in class org.axonframework.modelling.command.GenericJpaRepository
Instantiate a Builder to be able to create a GenericJpaRepository for aggregate type T.
Builder(Class<T>) - Constructor for class org.axonframework.modelling.command.GenericJpaRepository.Builder
Creates a builder for a Repository for given aggregateType.
Builder(Class<T>) - Constructor for class org.axonframework.modelling.command.LockingRepository.Builder
Creates a builder for a Repository for given aggregateType.
Builder() - Constructor for class org.axonframework.modelling.saga.AbstractSagaManager.Builder
 
builder() - Static method in class org.axonframework.modelling.saga.AnnotatedSagaManager
Instantiate a Builder to be able to create a AnnotatedSagaManager.
Builder() - Constructor for class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
 
builder() - Static method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
Instantiate a Builder to be able to create an AnnotatedSagaRepository.
Builder() - Constructor for class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
 
builder() - Static method in class org.axonframework.modelling.saga.repository.CachingSagaStore
Instantiate a Builder to be able to create a CachingSagaStore.
Builder() - Constructor for class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
 
builder() - Static method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
Instantiate a Builder to be able to create a JdbcSagaStore.
Builder() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
 
builder() - Static method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
Instantiate a Builder to be able to create a JpaSagaStore.
Builder() - Constructor for class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
 
Builder() - Constructor for class org.axonframework.modelling.saga.repository.LockingSagaRepository.Builder
 
builder() - Static method in class org.axonframework.queryhandling.DefaultQueryGateway
Instantiate a Builder to be able to create a DefaultQueryGateway.
Builder() - Constructor for class org.axonframework.queryhandling.DefaultQueryGateway.Builder
 
builder() - Static method in class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler
Instantiate a Builder to be able to create a LoggingQueryInvocationErrorHandler.
Builder() - Constructor for class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler.Builder
 
builder() - Static method in class org.axonframework.queryhandling.SimpleQueryBus
Instantiate a Builder to be able to create a SimpleQueryBus.
Builder() - Constructor for class org.axonframework.queryhandling.SimpleQueryBus.Builder
 
builder() - Static method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
Instantiate a Builder to be able to create a SimpleQueryUpdateEmitter.
Builder() - Constructor for class org.axonframework.queryhandling.SimpleQueryUpdateEmitter.Builder
 
Builder() - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer.Builder
 
builder() - Static method in class org.axonframework.serialization.JavaSerializer
Deprecated.
Instantiate a Builder to be able to create a JavaSerializer.
Builder() - Constructor for class org.axonframework.serialization.JavaSerializer.Builder
Deprecated.
 
builder() - Static method in class org.axonframework.serialization.json.JacksonSerializer
Instantiate a Builder to be able to create a JacksonSerializer.
Builder() - Constructor for class org.axonframework.serialization.json.JacksonSerializer.Builder
 
Builder(String, String) - Constructor for class org.axonframework.serialization.upcasting.event.EventTypeUpcaster.Builder
Instantiate a EventTypeUpcaster.Builder as a shorthand to create an EventTypeUpcaster.
builder() - Static method in class org.axonframework.serialization.xml.XStreamSerializer
Instantiate a Builder to be able to create a XStreamSerializer.
Builder() - Constructor for class org.axonframework.serialization.xml.XStreamSerializer.Builder
 
builder() - Static method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
Instantiate a Builder to be able to create a SpringAggregateSnapshotter.
Builder() - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
 
BuilderUtils - Class in org.axonframework.common
Utility class containing reusable functionality for implementing the Builder Pattern in (infrastructure) components.
buildHandlerDefinition() - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Return the set HandlerDefinition, or create and return it if it is null.
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.
buildMonitor(String, MeterRegistry) - Static method in class org.axonframework.micrometer.CapacityMonitor
Creates a capacity monitor with the default time window 10 minutes
buildMonitor(String, MeterRegistry, Function<Message<?>, Iterable<Tag>>) - Static method in class org.axonframework.micrometer.CapacityMonitor
Creates a capacity monitor with the default time window 10 minutes
buildMonitor(String, MeterRegistry, long, TimeUnit) - Static method in class org.axonframework.micrometer.CapacityMonitor
Creates a capacity monitor with the default system clock.
buildMonitor(String, MeterRegistry, long, TimeUnit, Function<Message<?>, Iterable<Tag>>) - Static method in class org.axonframework.micrometer.CapacityMonitor
Creates a capacity monitor with the default system clock.
buildMonitor(String, MeterRegistry, long, TimeUnit, Clock) - Static method in class org.axonframework.micrometer.CapacityMonitor
Creates a capacity monitor with the given time window.
buildMonitor(String, MeterRegistry, long, TimeUnit, Clock, Function<Message<?>, Iterable<Tag>>) - Static method in class org.axonframework.micrometer.CapacityMonitor
Creates a capacity monitor with the given time window.
buildMonitor(String, MeterRegistry) - Static method in class org.axonframework.micrometer.EventProcessorLatencyMonitor
Deprecated.
buildMonitor(String, MeterRegistry, Function<Message<?>, Iterable<Tag>>) - Static method in class org.axonframework.micrometer.EventProcessorLatencyMonitor
Deprecated.
buildMonitor(String, MeterRegistry) - Static method in class org.axonframework.micrometer.MessageCountingMonitor
Creates a message counting monitor
buildMonitor(String, MeterRegistry, Function<Message<?>, Iterable<Tag>>) - Static method in class org.axonframework.micrometer.MessageCountingMonitor
Creates a message counting monitor
buildMonitor(String, MeterRegistry) - Static method in class org.axonframework.micrometer.MessageTimerMonitor
Deprecated.
in favor of using the MessageTimerMonitor.builder()
buildMonitor(String, MeterRegistry, Function<Message<?>, Iterable<Tag>>) - Static method in class org.axonframework.micrometer.MessageTimerMonitor
Deprecated.
in favor of using the MessageTimerMonitor.builder()
buildMonitor(String, MeterRegistry, Clock) - Static method in class org.axonframework.micrometer.MessageTimerMonitor
Deprecated.
in favor of using the MessageTimerMonitor.builder()
buildMonitor(String, MeterRegistry, Clock, Function<Message<?>, Iterable<Tag>>) - Static method in class org.axonframework.micrometer.MessageTimerMonitor
Deprecated.
in favor of using the MessageTimerMonitor.builder()
buildOutcome(boolean, String) - Method in class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
 
buildOutcome(boolean, String) - Method in class org.axonframework.springboot.util.OnMissingQualifiedBeanCondition
 
buildOutcome(boolean, String) - Method in class org.axonframework.springboot.util.OnQualifiedBeanCondition
 
buildParameterResolverFactory() - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Return the set ParameterResolverFactory, or create and return it if it is null.
buildQuerySerializer() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Build a QuerySerializer using the configured messageSerializer, genericSerializer and configuration.
buildSagaModel() - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
Instantiate the SagaModel of generic type T describing the structure of the Saga this AbstractSagaManager implementation will manage.
buildSagaModel() - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Instantiate the SagaModel of generic type T describing the structure of the Saga this SagaRepository will store.
buildSerializer() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Build a CommandSerializer using the configured serializer and configuration.
buildSubscriptionMessageSerializer() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Build a SubscriptionMessageSerializer using the configured messageSerializer, genericSerializer and configuration.
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.
byDefaultAssignHandlerInstancesTo(Function<Object, String>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that defines the Event Processing Group name to assign Event Handler beans to when no other, more explicit, rule matches and no ProcessingGroup annotation is found.
byDefaultAssignHandlerInstancesTo(Function<Object, String>) - Method in class org.axonframework.config.EventProcessingModule
 
byDefaultAssignHandlerTypesTo(Function<Class<?>, String>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that defines the Event Processing Group name to assign Event Handler and Saga beans to when no other, more explicit, rule matches and no ProcessingGroup annotation is found.
byDefaultAssignHandlerTypesTo(Function<Class<?>, String>) - Method in class org.axonframework.config.EventProcessingModule
 
byDefaultAssignTo(String) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers the processingGroup name to assign Event Handler and Saga beans to when no other, more explicit, rule matches and no ProcessingGroup annotation is found.
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(Cache) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the Cache in which loaded aggregates will be stored.
cache - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
cache(Cache) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Sets the Cache which services repositories for specific aggregate types.
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.
cachedEvents(int) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
Sets the maximum number of events in the cache that is shared between the streams of tracking event processors.
CachingEventSourcingRepository<T> - Class in org.axonframework.eventsourcing
Implementation of the event sourcing repository that uses a cache to improve loading performance.
CachingEventSourcingRepository(EventSourcingRepository.Builder<T>) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
Instantiate a CachingEventSourcingRepository based on the fields contained in the EventSourcingRepository.Builder.
CachingSagaStore<T> - Class in org.axonframework.modelling.saga.repository
Saga Repository implementation that adds caching behavior to the repository it wraps.
CachingSagaStore(CachingSagaStore.Builder<T>) - Constructor for class org.axonframework.modelling.saga.repository.CachingSagaStore
Instantiate a CachingSagaStore based on the fields contained in the CachingSagaStore.Builder.
CachingSagaStore.Builder<T> - Class in org.axonframework.modelling.saga.repository
Builder class to instantiate a CachingSagaStore.
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.
callWithInterceptorChain(InterceptorChain, Callable<R>) - Static method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
Invoke the given action with the given interceptorChain being available for parameter injection.
callWithResult(Object, Callable<?>) - Static method in class org.axonframework.messaging.annotation.ResultParameterResolverFactory
Calls the given action (typically a handler invocation) such that the given result is available for injection as parameter
cancel() - Method in class org.axonframework.axonserver.connector.command.AxonServerRegistration
 
cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
 
cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
Deprecated.
 
cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.DisposableResult
Deprecated.
 
cancel(boolean) - Method in interface org.axonframework.axonserver.connector.util.Scheduler.ScheduledTask
Cancels the scheduled registration.
cancel() - Method in interface org.axonframework.common.Registration
Cancels this Registration.
cancel() - Method in class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
 
cancelAll(String) - Method in interface org.axonframework.deadline.DeadlineManager
Cancels all the deadlines corresponding to the given deadlineName.
cancelAll(String) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
 
cancelAll(String) - Method in class org.axonframework.deadline.SimpleDeadlineManager
 
cancelAll(String) - Method in class org.axonframework.test.deadline.StubDeadlineManager
 
cancelAllWithinScope(String) - Method in interface org.axonframework.deadline.DeadlineManager
Cancels all deadlines corresponding to the given deadlineName that are scheduled within Scope.describeCurrentScope().
cancelAllWithinScope(String, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
Cancels all deadlines corresponding to the given deadlineName and scope.
cancelAllWithinScope(String, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
 
cancelAllWithinScope(String, ScopeDescriptor) - Method in class org.axonframework.deadline.SimpleDeadlineManager
 
cancelAllWithinScope(String, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
 
cancelCallbacks(A) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
cancelCallbacksForChannel(A) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
Removes all callbacks for a given channel.
cancelSchedule(ScheduleToken) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
Cancel a scheduled event.
cancelSchedule(String, String) - Method in interface org.axonframework.deadline.DeadlineManager
Cancels the deadline corresponding to the given deadlineName / scheduleId combination.
cancelSchedule(String, String) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
 
cancelSchedule(String, String) - Method in class org.axonframework.deadline.SimpleDeadlineManager
 
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(String, String) - Method in class org.axonframework.test.deadline.StubDeadlineManager
 
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.
canConvertDataTo(Class<?>) - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
 
canConvertDataTo(Class<?>) - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
Checks if the data can be converted to the given requiredType.
canConvertDataTo(Class<?>) - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
 
canHandle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
 
canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
Indicates whether the processor can/should handle the given eventMessage for the given segment.
canHandle(EventMessage<?>) - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
 
canHandle(EventMessage<?>, Segment) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
Check whether or not this invoker has handlers that can handle the given eventMessage for a given segment.
canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
 
canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
canHandle(EventMessage<?>, Collection<Segment>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Indicates whether any of the components handling events for this Processor are able to handle the given eventMessage for any of the given segments.
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
 
canHandle(T) - Method in interface org.axonframework.messaging.MessageHandler
Indicates whether this handler can handle the given message
canHandle(CommandMessage<?>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
 
canHandle(Message<?>) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
canHandle(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
 
canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager
 
canHandle(QueryMessage<?, ?>) - Method in class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
 
canHandleMessageType(Class<? extends Message>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
canHandleMessageType(Class<? extends Message>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Checks if this handlers is capable of handling Message implementations of the given messageType.
canHandleMessageType(Class<? extends Message>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
canHandleMessageType(Class<? extends Message>) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
 
canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
 
canHandleType(Class<?>) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
Check whether or not this invoker has handlers that can handle the given payloadType.
canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
 
canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
canHandleType(Class<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
canHandleType(Class<?>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Checks if this handler is capable of handling messages with the given payloadType.
canHandleType(Class<?>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
canHandleType(Class<?>) - Method in interface org.axonframework.messaging.MessageHandler
Indicates whether this handler can handle messages of given type
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.
canResolve(ScopeDescriptor) - Method in interface org.axonframework.messaging.ScopeAware
Check whether this implementation can resolve a Scope object based on the provided scopeDescription.
canResolve(ScopeDescriptor) - Method in class org.axonframework.modelling.command.AbstractRepository
 
canResolve(ScopeDescriptor) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
 
canSerializeTo(Class<T>) - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
Deprecated.
 
canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
canSerializeTo(Class<T>) - Method in interface org.axonframework.serialization.Serializer
Indicates whether this Serializer is capable of serializing to the given expectedRepresentation.
canUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
Checks if this upcaster can upcast the given intermediateRepresentation.
canUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
Checks if this upcaster can upcast the given intermediateRepresentation.
canUpcast(IntermediateEventRepresentation) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
 
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.
CapacityMonitor - Class in org.axonframework.micrometer
Calculates capacity by tracking, within the configured time window, the average message processing time and multiplying that by the amount of messages processed.
caughtUp() - Method in class org.axonframework.eventhandling.TrackerStatus
Returns this TrackerStatus if it is caught up, otherwise return a new instance with the caught up flag set to true.
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.
chainedInterceptor(Class<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Returns an Interceptor Chain of annotated interceptor methods defined on the given type.
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.
channelCustomizer(UnaryOperator<ManagedChannelBuilder<?>>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
Registers the given channelCustomization, which configures the underling ManagedChannelBuilder used to set up connections to AxonServer.
charset(Charset) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Sets the Charset used for the in- and output streams required by XStream for the to and from xml function calls.
charset(Charset) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
 
ChildEntity<T> - Interface in org.axonframework.modelling.command.inspection
Interface describing en entity that is a child of another entity.
ChildEntityDefinition - Interface in org.axonframework.modelling.command.inspection
Interface describing the definition of a Child Entity.
ChildForwardingCommandMessageHandlingMember<P,C> - Class in org.axonframework.modelling.command.inspection
Implementation of a CommandMessageHandlingMember that forwards commands to a child entity.
ChildForwardingCommandMessageHandlingMember(List<MessageHandlingMember<? super C>>, MessageHandlingMember<? super C>, BiFunction<CommandMessage<?>, P, C>) - Constructor for class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
Initializes a ChildForwardingCommandMessageHandlingMember that routes commands to a compatible child entity.
claim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Attempt to claim ownership of this token.
claimExtensionThreshold(long) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies a time in milliseconds the work packages of this processor should extend the claim on a TrackingToken.
claimTimeout(TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Sets the claimTimeout specifying the amount of time this process will wait after which this process will force a claim of a TrackingToken.
claimTimeout(TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
Sets the claimTimeout specifying the amount of time this process will wait after which this process will force a claim of a TrackingToken.
claimToken(Connection, AbstractTokenEntry<?>) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Tries to claim the given token entry.
classForType(SerializedType) - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
 
classForType(SerializedType) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
classForType(SerializedType) - Method in class org.axonframework.serialization.JavaSerializer
Deprecated.
 
classForType(SerializedType) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
classForType(SerializedType) - Method in interface org.axonframework.serialization.Serializer
Returns the class for the given type identifier.
classLoader(ClassLoader) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Sets the ClassLoader used as an override for default ClassLoader used in the XStream.
classLoader(ClassLoader) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Sets the ClassLoader used as an override for default ClassLoader used in the ObjectMapper.
classLoader(ClassLoader) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
 
ClasspathHandlerDefinition - Class in org.axonframework.messaging.annotation
HandlerDefinition instance that locates other HandlerDefinition instances on the class path.
ClasspathHandlerEnhancerDefinition - Class in org.axonframework.messaging.annotation
HandlerEnhancerDefinition instance that locates other HandlerEnhancerDefinition instances on the class path.
ClasspathParameterResolverFactory - Class in org.axonframework.messaging.annotation
ParameterResolverFactory instance that locates other ParameterResolverFactory instances on the class path.
cleanGaps(CleanGapsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Set the PreparedStatement to be used on JdbcEventStorageEngine.cleanGaps(Connection, SortedSet).
cleanGaps(Connection, SortedSet<Long>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to be used at JdbcEventStorageEngine.cleanGaps(TrackingToken).
cleanGaps(Connection, EventSchema, SortedSet<Long>) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on internal cleanGaps operation.
CleanGapsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.cleanGaps(TrackingToken)
cleanupDelay(long) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
Sets the delay between two clean ups of lagging event processors.
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.
clear() - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
Clears all the associations.
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.
clientId(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
clock - Static variable in class org.axonframework.eventhandling.GenericEventMessage
Clock instance used to set the time on new events.
clock(Clock) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Defines the Clock used for time dependent operation by this EventProcessor.
clock - Static variable in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
The clock used to persist timestamps in this entry.
clock - Static variable in class org.axonframework.eventsourcing.AggregateLoadTimeSnapshotTriggerDefinition
 
clock(Clock) - Method in class org.axonframework.metrics.MessageTimerMonitor.Builder
Sets the Clock used to define the processing duration of a given message being pushed through this MessageMonitor.
clock(Clock) - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
Sets the Clock used to define the processing duration of a given message being pushed through this MessageMonitor.
clock(Clock) - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
Sets the Clock used to define the processing duration of a given message being pushed through this MessageMonitor.
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() - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
 
close() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResultStreamAdapter
 
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.common.stream.BlockingStream
 
close() - Method in class org.axonframework.lifecycle.ShutdownLatch.ActivityHandle
close() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
Closes this lifecycle instance, restoring to the situation prior to this lifecycle being started.
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 AutoCloseable, while suppressing any IOExceptions it will generate.
code() - Method in exception org.axonframework.axonserver.connector.AxonServerException
 
code() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
Return a String defining the error code.
CollectionUtils - Class in org.axonframework.common
Utility methods for operations on collections.
combine(SnapshotFilter) - Method in interface org.axonframework.eventsourcing.snapshotting.SnapshotFilter
Combines this SnapshotFilter with the give other filter in an "AND" operation, effectively validating whether both return true on a SnapshotFilter.allow(DomainEventData) call of each.
COMMAND_NAME - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the name of the CommandMessage the handler can handle.
COMMAND_ROUTING_KEY - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the routing key used to route a CommandMessage to the handler.
CommandBus - Interface in org.axonframework.commandhandling
The mechanism that dispatches Command objects to their appropriate CommandHandler.
commandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
Sets the CommandBus used to dispatch commands.
commandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
Sets the CommandBus on which to dispatch CommandMessages.
commandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
 
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
 
commandBus(TransactionManager, AxonConfiguration, DuplicateCommandHandlerResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
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, ? super 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.
CommandExecutionException(String, Throwable, Object) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
Initializes the exception with given message, cause and an object providing application-specific details.
commandFlowControl(int, int, int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
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.
commandGateway(CommandBus) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
CommandGatewayFactory - Class in org.axonframework.commandhandling.gateway
Factory that creates Gateway implementations from custom interface definitions.
CommandGatewayFactory(CommandGatewayFactory.Builder) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Instantiate a CommandGatewayFactory based on the fields contained in the CommandGatewayFactory.Builder.
CommandGatewayFactory.Builder - Class in org.axonframework.commandhandling.gateway
Builder class to instantiate a CommandGatewayFactory.
CommandGatewayFactory.InvocationHandler<R> - Interface in org.axonframework.commandhandling.gateway
Interface towards the mechanism that handles a method call on a gateway interface method.
CommandHandler - Annotation Type in org.axonframework.commandhandling
Marker annotation to mark any method on an object as being a CommandHandler.
CommandHandlerInterceptor - Annotation Type in org.axonframework.modelling.command
Annotation used to mark methods on Aggregate members which can intercept commands.
CommandHandlerInterceptorHandlingMember<T> - Interface in org.axonframework.modelling.command.inspection
Deprecated.
in favor of the more generic MessageInterceptingMember
commandHandlerInterceptors() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
commandHandlerInterceptors(Class<? extends T>) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Gets command handler interceptors for provided type in this aggregate hierarchy.
CommandHandlerInvoker - Class in org.axonframework.disruptor.commandhandling
Component of the DisruptorCommandBus that invokes the command handler.
CommandHandlerInvoker(Cache, int) - Constructor for class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
Create an aggregate invoker instance for the given segment and cache.
commandHandlers() - Method in class org.axonframework.modelling.command.inspection.AnnotatedChildEntity
 
commandHandlers() - Method in interface org.axonframework.modelling.command.inspection.ChildEntity
Returns the command handlers declared in this entity.
commandHandlers() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
commandHandlers(Class<? extends T>) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Gets command handlers for provided type in this aggregate hierarchy.
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.disruptor.commandhandling
DataHolder for the DisruptorCommandBus.
CommandHandlingEntry() - Constructor for class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Initializes the CommandHandlingEntry
commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
commandLoadFactor(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
CommandLoadFactorProvider - Interface in org.axonframework.axonserver.connector.command
Provides the load factor value of the client for the specific command.
commandLoadFactorProvider(AxonServerConfiguration) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
CommandMessage<T> - Interface in org.axonframework.commandhandling
Represents a Message carrying a command as its payload.
CommandMessageFilter - Interface in org.axonframework.commandhandling.distributed
Interface describing a filter that can be applied to commands to describe the type of commands supported by a node in a cluster.
CommandMessageHandler - Interface in org.axonframework.commandhandling
MessageHandler specialization for handlers of Command Messages.
CommandMessageHandlingMember<T> - Interface in org.axonframework.commandhandling
Interface describing a message handler capable of handling a specific command.
commandName() - Method in interface org.axonframework.commandhandling.CommandMessageHandlingMember
Returns the name of the command that can be handled.
commandName - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
commandName() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
CommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
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.
CommandPriorityCalculator - Interface in org.axonframework.axonserver.connector.command
Calculate the priority of CommandMessage based on its content.
commandPriorityCalculator() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
CommandResultMessage<R> - Interface in org.axonframework.commandhandling
Message that represents a result from handling a CommandMessage.
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.
commandRouter(CommandRouter) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
Sets the CommandRouter used to determine the target node for each dispatched command.
CommandSerializer - Class in org.axonframework.axonserver.connector.command
Converter between Axon Framework CommandMessages and Axon Server gRPC Command messages.
CommandSerializer(Serializer, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.command.CommandSerializer
Instantiate a serializer used to convert Axon CommandMessages and CommandResultMessages into Axon Server gRPC messages and vice versa.
commandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the CommandTargetResolver that must be used to indicate which Aggregate instance will be invoked by an incoming command.
commandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Sets the CommandTargetResolver used to resolve the command handling target.
CommandTargetResolver - Interface in org.axonframework.modelling.command
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 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.
commit() - Method in interface org.axonframework.modelling.saga.AssociationValues
Resets the tracked changes.
commit() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
commit(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
Commits the given modified saga to the underlying saga store.
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.eventhandling.GlobalSequenceTrackingToken
 
compareTo(Segment) - Method in class org.axonframework.eventhandling.Segment
 
compareTo(ScheduledDeadlineInfo) - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
 
compareTo(StubScheduleToken) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
complete(Predicate<SubscriptionQueryMessage<?, ?, ?>>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Completes subscription queries matching given filter.
complete(Class<Q>, Predicate<? super Q>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Completes subscription queries matching given query type and filter.
complete(Predicate<SubscriptionQueryMessage<?, ?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
 
complete() - Method in interface org.axonframework.queryhandling.SinkWrapper
Wrapper around Sink complete().
complete() - Method in class org.axonframework.queryhandling.UpdateHandlerRegistration
CompletedEmitterException - Exception in org.axonframework.queryhandling
Exception indicating that QueryUpdateEmitter is completed, thus cannot be used to emit messages and report errors.
CompletedEmitterException(String) - Constructor for exception org.axonframework.queryhandling.CompletedEmitterException
Initializes the exception with given message.
completeExceptionally(Predicate<SubscriptionQueryMessage<?, ?, ?>>, Throwable) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Completes with an error subscription queries matching given filter.
completeExceptionally(Class<Q>, Predicate<? super Q>, Throwable) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Completes with an error subscription queries matching given query type and filter
completeExceptionally(Predicate<SubscriptionQueryMessage<?, ?, ?>>, Throwable) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
 
completeRequestStream() - Method in class org.axonframework.axonserver.connector.util.UpstreamAwareStreamObserver
Completes the request steam related to this stream observer.
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.
componentName(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
computeRetryInterval(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
Compute the amount of milliseconds delay until the next retry, given the information passed.
computeRetryInterval(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>) - Method in class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler
 
computeRetryInterval(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
 
computeSegment(int, int...) - Static method in class org.axonframework.eventhandling.Segment
Creates a Segment instance for the given segmentId based on the given availableSegmentsIds.
computeSegments(int...) - Static method in class org.axonframework.eventhandling.Segment
Compute the Segment's from a given list of segmentId's.
concat(DomainEventStream, DomainEventStream) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Concatenate two DomainEventStreams.
ConcatenatingDomainEventStream - Class in org.axonframework.eventsourcing.eventstore
DomainEventStream implementation that concatenates multiple streams, taking into account that some sequence numbers may appear in more than one stream.
ConcatenatingDomainEventStream(DomainEventStream...) - Constructor for class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
Initialize the stream, concatenating the given streams.
ConcatenatingDomainEventStream(Collection<DomainEventStream>) - Constructor for class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
Initialize the stream, concatenating the given streams.
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.modelling.command
Exception indicating that concurrent access to a repository was detected.
ConcurrencyException(String) - Constructor for exception org.axonframework.modelling.command.ConcurrencyException
Initialize a ConcurrencyException with the given message.
ConcurrencyException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.ConcurrencyException
Initialize a ConcurrencyException with the given message and cause.
ConditionalOnMissingQualifiedBean - Annotation Type in org.axonframework.springboot.util
Conditional that only matches when for the specified bean class in the BeanFactory there is an instance which has the given qualifier set on it.
ConditionalOnQualifiedBean - Annotation Type in org.axonframework.springboot.util
Conditional that only matches when for the specified bean class in the BeanFactory there is an instance which has the given qualifier set on it.
ConfigToken - Class in org.axonframework.eventhandling.tokenstore
A special implementation of a Token that is used to store configuration specific to the underlying storage of each TokenStore instance.
ConfigToken(Map<String, String>) - Constructor for class org.axonframework.eventhandling.tokenstore.ConfigToken
Initialize a ConfigToken instance using the given config properties.
configuration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the AxonServerConfiguration used to configure several components within the Axon Server Command Bus, like setting the client id or the number of command handling threads used.
configuration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Sets the AxonServerConfiguration describing the servers to connect with and how to manage flow control.
configuration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the AxonServerConfiguration used to configure several components within the Axon Server Query Bus, like setting the client id or the number of query handling threads used.
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.
ConfigurationScopeAwareProvider - Class in org.axonframework.config
Implementation of the ScopeAwareProvider which will retrieve a List of ScopeAware components in a lazy manner.
ConfigurationScopeAwareProvider(Configuration) - Constructor for class org.axonframework.config.ConfigurationScopeAwareProvider
Instantiate a lazy ScopeAwareProvider with the given configuration parameter.
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.
configureCache(Function<Configuration, Cache>) - Method in class org.axonframework.config.AggregateConfigurer
Configures the Cache to use for the repository created for this Aggregate type.
configureCommandBus(Function<Configuration, CommandBus>) - Method in interface org.axonframework.config.Configurer
Configures the given Command Bus to use in this configuration.
configureCommandHandler(Function<Configuration, AggregateAnnotationCommandHandler<A>>) - 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
 
configureDefaultStreamableMessageSource(Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Configures which StreamableMessageSource to use for Tracking Event Processors if none was explicitly provided.
configureDefaultStreamableMessageSource(Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
configureDefaultSubscribableMessageSource(Function<Configuration, SubscribableMessageSource<EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Configures which SubscribableMessageSource to use for Subscribing Event Processors if none was explicitly provided.
configureDefaultSubscribableMessageSource(Function<Configuration, SubscribableMessageSource<EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
configureEmbeddedEventStore(Function<Configuration, EventStorageEngine>) - Method in interface org.axonframework.config.Configurer
Configures 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
Configures the given Event Bus to use in this configuration.
configureEventHandling(EventProcessingConfigurer, ApplicationContext) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
configureEventSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
Configures the given event Serializer to use in this configuration.
configureEventSerializer(Function<Configuration, Serializer>) - Method in class org.axonframework.config.DefaultConfigurer
 
configureEventStore(Function<Configuration, EventStore>) - Method in interface org.axonframework.config.Configurer
Configures the given Event Store to use in this configuration.
configureEventStreamFilter(Function<Configuration, Predicate<? super DomainEventMessage<?>>>) - Method in class org.axonframework.config.AggregateConfigurer
Configures an event stream filter for the EventSourcingRepository for the Aggregate type under configuration.
configureFilterEventsByType(Function<Configuration, Boolean>) - Method in class org.axonframework.config.AggregateConfigurer
Configures a function that determines whether or not the EventSourcingRepository for the Aggregate type under configuration should filter out events with non-matching types.
configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in interface org.axonframework.config.Configurer
Configures the Message Monitor to use for the Message processing components in this configuration, unless more specific configuration based on the component's type, or type and name is available.
configureMessageMonitor(Class<?>, Function<Configuration, MessageMonitor<Message<?>>>) - Method in interface org.axonframework.config.Configurer
Configures the builder function to create the Message Monitor for the Message processing components in this configuration that match the given componentType, unless more specific configuration based on both type and name is available.
configureMessageMonitor(Class<?>, MessageMonitorFactory) - Method in interface org.axonframework.config.Configurer
Configures the factory to create the Message Monitor for the Message processing components in this configuration that match the given componentType, unless more specific configuration based on both type and name is available.
configureMessageMonitor(Class<?>, String, Function<Configuration, MessageMonitor<Message<?>>>) - Method in interface org.axonframework.config.Configurer
Configures the builder function to create the Message Monitor for the Message processing components in this configuration that match the given class and name.
configureMessageMonitor(Class<?>, String, MessageMonitorFactory) - Method in interface org.axonframework.config.Configurer
Configures the factory create the Message Monitor for those Message processing components in this configuration that match the given class and name.
configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in class org.axonframework.config.DefaultConfigurer
 
configureMessageMonitor(Class<?>, MessageMonitorFactory) - Method in class org.axonframework.config.DefaultConfigurer
 
configureMessageMonitor(Class<?>, String, MessageMonitorFactory) - Method in class org.axonframework.config.DefaultConfigurer
 
configureMessageSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
Configures the given event Serializer to use in this configuration.
configureMessageSerializer(Function<Configuration, Serializer>) - Method in class org.axonframework.config.DefaultConfigurer
 
configureModule(Configurer) - Method in class org.axonframework.axonserver.connector.ServerConnectorConfigurerModule
 
configureModule(Configurer) - Method in interface org.axonframework.config.ConfigurerModule
Configure this module to the given global Configurer.
configureModule(Configurer) - Method in class org.axonframework.metrics.MetricsConfigurerModule
 
configureModule(Configurer) - Method in class org.axonframework.micrometer.MetricsConfigurerModule
 
configureQueryBus(Function<Configuration, QueryBus>) - Method in interface org.axonframework.config.Configurer
Configures the given Query Bus to use in this configuration.
configureQueryUpdateEmitter(Function<Configuration, QueryUpdateEmitter>) - Method in interface org.axonframework.config.Configurer
Configures the given Query Update Emitter to use in this configuration.
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.
configureRepository(Function<Configuration, SagaRepository<T>>) - Method in class org.axonframework.config.SagaConfigurer
Configures a SagaRepository for this Saga.
configureResourceInjector(Function<Configuration, ResourceInjector>) - Method in interface org.axonframework.config.Configurer
Configures the given Resource Injector to use for Sagas in this configuration.
ConfigurerFactoryBean - Class in org.axonframework.spring.config
FactoryBean that creates an instance of a Configurer for use in a Spring Application Context.
ConfigurerFactoryBean(Configurer) - Constructor for class org.axonframework.spring.config.ConfigurerFactoryBean
Initialize the factory bean, using the given configurer to make available in the Application Context, once configured by the ConfigurerModules in that context.
ConfigurerModule - Interface in org.axonframework.config
Interface describing a configurer for a module in the Axon Configuration API.
configureSagaManager(Function<Configuration, AbstractSagaManager<T>>) - Method in class org.axonframework.config.SagaConfigurer
Configures a Saga Manager for this Saga.
configureSagaStore(Function<Configuration, SagaStore<? super T>>) - Method in class org.axonframework.config.SagaConfigurer
Configures a SagaStore for this Saga.
configureSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
Configures the given Serializer to use in this configuration.
configureSnapshotFilter(Function<Configuration, SnapshotFilter>) - Method in class org.axonframework.config.AggregateConfigurer
Configure a SnapshotFilter for the Aggregate type under configuration.
configureSnapshotter(Function<Configuration, Snapshotter>) - Method in interface org.axonframework.config.Configurer
Registers a Snapshotter instance with this Configurer.
configureSnapshotTrigger(Function<Configuration, SnapshotTriggerDefinition>) - Method in class org.axonframework.config.AggregateConfigurer
Configures snapshotting for the Aggregate type under configuration.
configureTags(Function<Configuration, TagsConfiguration>) - Method in interface org.axonframework.config.Configurer
Configures the given Tags Configuration to use in this configuration.
configureTransactionManager(Function<Configuration, TransactionManager>) - Method in interface org.axonframework.config.Configurer
Configures the given Transaction Manager to use in this configuration.
configureWeakReferenceCache() - Method in class org.axonframework.config.AggregateConfigurer
Configures a WeakReferenceCache to be used for the repository created for this Aggregate type.
ConflictDescription - Interface in org.axonframework.eventsourcing.conflictresolution
Descries a conflict between expected and actual version of an aggregate.
ConflictExceptionSupplier<T extends Exception> - Interface in org.axonframework.eventsourcing.conflictresolution
Interface describing a factory for exceptions that indicate an unresolved conflict in an aggregate instance.
ConflictingAggregateVersionException - Exception in org.axonframework.modelling.command
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.modelling.command.ConflictingAggregateVersionException
Initializes the exception using the given message.
ConflictingAggregateVersionException(String, long, long, Throwable) - Constructor for exception org.axonframework.modelling.command.ConflictingAggregateVersionException
Initializes the exception using the given message and cause.
ConflictingModificationException - Exception in org.axonframework.modelling.command
Root of a hierarchy of exceptions indicating the detection of conflicting concurrent modifications.
ConflictingModificationException(String) - Constructor for exception org.axonframework.modelling.command.ConflictingModificationException
Initializes the exception using the given message.
ConflictingModificationException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.ConflictingModificationException
Initializes the exception using the given message and cause.
ConflictResolution - Class in org.axonframework.eventsourcing.conflictresolution
ParameterResolverFactory that add support for the ConflictResolver parameter type in annotated handlers.
ConflictResolution() - Constructor for class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
 
ConflictResolver - Interface in org.axonframework.eventsourcing.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.eventsourcing.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.
connectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
Sets the AxonServerConnectionManager used to create connections between this application and an Axon Server instance.
ConnectionProvider - Interface in org.axonframework.common.jdbc
Interface towards a mechanism that provides access to a JDBC Connection.
connectionProvider(ConnectionProvider) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Sets the ConnectionProvider used to provide connections to the underlying database.
connectionProvider(ConnectionProvider) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the ConnectionProvider which provides access to a JDBC connection.
connectionProvider(ConnectionProvider) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
Sets the ConnectionProvider which provides access to a JDBC connection.
connectionProvider(DataSource) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
 
ConnectionSanityChecker - Interface in org.axonframework.axonserver.connector.heartbeat
Deprecated.
in through use of the AxonServer java connector
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 or commit.
connector(CommandBusConnector) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
Sets the CommandBusConnector which performs the actual transport of the message to the destination node.
connectTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
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(Function<String, String>) - Constructor for class org.axonframework.commandhandling.distributed.ConsistentHash
Initializes a new ConsistentHash using the given hashFunction to calculate positions for each member on the ring.
ConsistentHash.ConsistentHashMember - Class in org.axonframework.commandhandling.distributed
Member implementation used by a ConsistentHash registry.
ConsistentHashChangeListener - Interface in org.axonframework.commandhandling.distributed
Represents a listener that is notified when a ConsistentHash instance of the component it is registered with has changed.
consume(ScopeDescriptor, DeadlineMessage<?>) - Method in interface org.axonframework.test.deadline.DeadlineConsumer
Consumes given deadlineMessage.
ContainerManagedEntityManagerProvider - Class in org.axonframework.springboot.util.jpa
EntityManagerProvider implementation that expects the container to inject the default container managed EntityManager instance.
ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
 
contains(String) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
contains(String) - Method in interface org.axonframework.messaging.HandlerAttributes
Validates whether the given attributeKey is present in this object.
contains(String) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
contains(AssociationValue) - Method in interface org.axonframework.modelling.saga.AssociationValues
Indicates whether this instance contains the given associationValue.
contains(AssociationValue) - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
containsKey(Object) - Method in interface org.axonframework.common.caching.Cache
Indicates whether there is an item stored under given key.
containsKey(Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
containsKey(Object) - Method in class org.axonframework.common.caching.JCacheAdapter
 
containsKey(Object) - Method in class org.axonframework.common.caching.NoCache
 
containsKey(Object) - 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
 
contentType(Class<?>) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Sets the contentType to which a TrackingToken should be serialized.
ContentTypeConverter<S,T> - Interface in org.axonframework.serialization
Interface describing a mechanism that converts the data type of IntermediateRepresentations of SerializedObjects for Upcasters.
context(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
ContextAddingInterceptor - Class in org.axonframework.axonserver.connector.util
Deprecated.
in through use of the AxonServer java connector
ContextAddingInterceptor(String) - Constructor for class org.axonframework.axonserver.connector.util.ContextAddingInterceptor
Deprecated.
Constructs a ContextAddingInterceptor to attach the given context.
ContextAwareConflictExceptionSupplier<T> - Interface in org.axonframework.eventsourcing.conflictresolution
ConflictExceptionSupplier that is provided with more details of a version conflict.
ContextAwareEventMultiUpcaster<C> - 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.
ContextAwareEventMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.ContextAwareEventMultiUpcaster
 
ContextAwareSingleEntryMultiUpcaster<T,C> - 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.
ContextAwareSingleEntryMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
 
ContextAwareSingleEntryUpcaster<T,C> - 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.
ContextAwareSingleEntryUpcaster() - Constructor for class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
 
ContextAwareSingleEventUpcaster<C> - 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.
ContextAwareSingleEventUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.ContextAwareSingleEventUpcaster
 
ContinuedGivenState - Interface in org.axonframework.test.saga
Interface describing methods that can be executed after the first "given" state has been supplied.
convert(ErrorMessage, Supplier<Object>) - Method in enum org.axonframework.axonserver.connector.ErrorCode
Converts the errorMessage to the relevant AxonException
convert(ErrorMessage) - Method in enum org.axonframework.axonserver.connector.ErrorCode
Converts the errorMessage to the relevant AxonException
convert(Throwable) - Method in enum org.axonframework.axonserver.connector.ErrorCode
Converts the throwable to the relevant AxonException
convert(String, Throwable) - Method in enum org.axonframework.axonserver.connector.ErrorCode
Converts the source and the throwable to the relevant AxonException
convert(Map<String, MetaDataValue>) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
Convert the given Map of MetaDataValues to a Map containing the Java representations of each of those values.
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(Object) - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
Converts the given response of type Object into the type List with generic type R from this ResponseType instance.
convert(Object) - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
 
convert(Object) - Method in interface org.axonframework.messaging.responsetypes.ResponseType
Converts the given response of type Object into the type R of this ResponseType instance.
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(Converter) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Sets the Converter used as a converter factory providing converter instances utilized by upcasters to convert between different content types.
Converter - Interface in org.axonframework.serialization
Interface describing a mechanism that can convert data from one to another type.
converter(Converter) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Sets the Converter used as a converter factory providing converter instances utilized by upcasters to convert between different content types.
converter(Converter) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
 
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
convertFromMetaDataValue(MetaDataValue) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
Convert the given MetaDataValue to its Java representation.
ConvertingResponseMessage<R> - Class in org.axonframework.messaging.responsetypes
Implementation of a QueryResponseMessage that is aware of the requested response type and performs a just-in-time conversion to ensure the response is formatted as requested.
ConvertingResponseMessage(ResponseType<R>, QueryResponseMessage<?>) - Constructor for class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
Initialize a response message, using expectedResponseType to convert the payload from the responseMessage, if necessary.
convertToMetaDataValue(Object) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
Convert the given value into a MetaDataValue, attempting to maintain the source type as much as possible in the returned MetaDataValue.
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.
coolingDownPeriod(long) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the cooling down period in milliseconds.
coordinatorExecutor(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies the ScheduledExecutorService used by the coordinator of this PooledStreamingEventProcessor.
coordinatorExecutor(Function<String, ScheduledExecutorService>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies a builder to construct a ScheduledExecutorService used by the coordinator of this PooledStreamingEventProcessor.
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(CorrelationDataProvider...) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
Initializes the interceptor that registers given correlationDataProviders with the current Unit of Work.
CorrelationDataInterceptor(Collection<CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
Initializes the interceptor that registers given correlationDataProviders 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
 
covers(TrackingToken) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
 
covers(TrackingToken) - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
 
covers(TrackingToken) - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
covers(TrackingToken) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
Compares this token to other checking each member token with its counterpart to see if they are covered in the other token.
covers(TrackingToken) - Method in class org.axonframework.eventhandling.ReplayToken
 
covers(TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
 
covers(TrackingToken) - Method in interface org.axonframework.eventhandling.TrackingToken
Indicates whether this token covers the other token completely.
create(Configuration, Class<?>, String) - Method in interface org.axonframework.config.MessageMonitorFactory
Function to create a Message Monitor based on the given configuration, component type and component name.
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
 
createChildDefinition(Member, EntityModel<T>) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
 
createChildDefinition(Member, EntityModel<T>) - Method in interface org.axonframework.modelling.command.inspection.ChildEntityDefinition
Inspect the given member, 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
 
createEventEntity(EventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Returns a Jpa event entity for given eventMessage.
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.
createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
 
createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
 
createHeadToken() - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Creates a token that is at the head of an event stream - that tracks all new events.
createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
createHeadToken(CreateHeadTokenStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Set the PreparedStatement to be used on JdbcEventStorageEngine.createHeadToken(Connection).
createHeadToken(Connection) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to be used at JdbcEventStorageEngine.createHeadToken().
createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
createHeadToken(Connection, EventSchema) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.createHeadToken().
createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
createHeadToken() - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
createHeadToken() - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
 
createHeadToken() - Method in interface org.axonframework.messaging.StreamableMessageSource
Creates the token at the end of an event stream.
CreateHeadTokenStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.createHeadToken()
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.config.ConfigurationParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventhandling.replay.ReplayParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventhandling.TrackingTokenParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
 
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.InterceptorChainParameterResolverFactory
 
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.ResultParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.ScopeDescriptorParameterResolverFactory
 
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
 
createInstance(String, Supplier<T>) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
Creates a new Saga instance.
createInstance(String, Supplier<T>) - Method in interface org.axonframework.modelling.saga.SagaRepository
Creates a new Saga instance.
createInstance(Executable, Parameter[], int) - Method in class org.axonframework.spring.config.annotation.SpringBeanDependencyResolverFactory
 
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.modelling.command.inspection.AnnotatedAggregate
Creates an EventMessage with given payload and metaData.
createModel(Class<? extends T>) - Method in interface org.axonframework.modelling.command.inspection.AggregateMetaModelFactory
Create an Aggregate meta model for the given aggregateType.
createModel(Class<? extends T>, Set<Class<? extends T>>) - Method in interface org.axonframework.modelling.command.inspection.AggregateMetaModelFactory
Create an Aggregate meta model for the given aggregateType and provided subtypes.
createModel(Class<? extends T>, Set<Class<? extends T>>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
 
createNew(Class<T>, Callable<T>) - Static method in class org.axonframework.modelling.command.AggregateLifecycle
Creates a new aggregate 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
 
createReplayToken(TrackingToken, TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
Creates a new TrackingToken that represents the given startPosition of a stream, in reset state, when appropriate.
createReplayToken(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
Creates a new TrackingToken that represents the tail position of a stream, in reset state, when appropriate.
createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
Create a repository instance for an aggregate created by the given aggregateFactory.
createRepository(EventStore, RepositoryProvider, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
Create a repository instance for an aggregate created by the given aggregateFactory.
createRepository(EventStore, AggregateFactory<T>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate that is created by the given eventStore and aggregateFactory.
createRepository(EventStore, AggregateFactory<T>, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate that is created by the given eventStore and aggregateFactory.
createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate, source from given eventStore, that is created by the given aggregateFactory.
createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate, source from given eventStore, that is created by the given aggregateFactory.
createRepository(EventStore, AggregateFactory<T>, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate that is created by the given aggregateFactory and sourced from given eventStore.
createRepository(EventStore, AggregateFactory<T>, ParameterResolverFactory, HandlerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate that is created by the given aggregateFactory and sourced from given eventStore.
createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate, sourced from given eventStore, that is created by the given aggregateFactory.
createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory, HandlerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Creates a repository instance for an Event Sourced aggregate, sourced from given eventStore, that is created by the given aggregateFactory.
createSagaEntry(Object, String, Serializer) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
Intended for clients to override.
createSagaIdentifier(Segment) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
Creates a Saga identifier that will cause a Saga instance to be considered part of the given segment.
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.
createSchema() - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
Creates the SQL Schema required to store Sagas and their associations.
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
 
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.
createSortedSetOf(Collection<Long>, long) - Static method in class org.axonframework.eventhandling.GapAwareTrackingToken
Construct a SortedSet of the given gaps to be set in this Tracking Token.
createStreamableMessageSourceForContext(String) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
Creates a StreamableMessageSource that streams events from the given context, rather than the default context the application was configured to connect to.
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.
createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
 
createTailToken() - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Creates a token that is at the tail of an event stream - that tracks events from the beginning of time.
createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
createTailToken(CreateTailTokenStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Set the PreparedStatement to be used on JdbcEventStorageEngine.createTailToken(Connection).
createTailToken(Connection) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to be used at JdbcEventStorageEngine.createTailToken().
createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
createTailToken(Connection, EventSchema) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.createTailToken().
createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
createTailToken() - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
createTailToken() - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
 
createTailToken() - Method in interface org.axonframework.messaging.StreamableMessageSource
Creates the token at the beginning of an event stream.
CreateTailTokenStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.createTailToken()
createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
 
createTokenAt(Instant) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Creates a token that tracks all events after given dateTime.
createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
 
createTokenAt(CreateTokenAtStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Set the PreparedStatement to be used on JdbcEventStorageEngine.createTokenAt.
createTokenAt(Connection, Instant) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to be used at JdbcEventStorageEngine.createTokenAt(Instant).
createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
createTokenAt(Connection, EventSchema, Instant) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Build the PreparedStatement to be used on JdbcEventStorageEngine.createTokenAt(Instant).
createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
 
createTokenAt(Instant) - Method in interface org.axonframework.messaging.StreamableMessageSource
Creates a token that tracks all events after given dateTime.
CreateTokenAtStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.createTokenAt(Instant)
createTokenSince(Duration) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
 
createTokenSince(Duration) - Method in interface org.axonframework.messaging.StreamableMessageSource
Creates a token that tracks all events since the last duration.
createWriter(Writer) - Method in class org.axonframework.serialization.xml.CompactDriver
 
createWriter(OutputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
 
CreationPolicy - Annotation Type in org.axonframework.modelling.command
Annotation used to specify the creation policy for a command handler.
creationPolicy() - Method in interface org.axonframework.modelling.command.inspection.CreationPolicyMember
Returns the creation policy set on the MessageHandlingMember.
CreationPolicyMember<T> - Interface in org.axonframework.modelling.command.inspection
Interface specifying a message handler containing a creation policy definition.
currentDateTime() - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
The current date time as stated by the configured StubDeadlineManager.
currentInterceptorChain() - Static method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
Returns the current interceptor chain registered for injection as a parameter.
currentTime() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
currentTime() - Method in interface org.axonframework.test.aggregate.TestExecutor
Returns the time as "known" by the fixture.
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

dataSource(DataSource) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the PersistenceExceptionResolver as a SQLErrorCodesResolver, using the provided DataSource to resolve the error codes.
dataSource(DataSource) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
Sets the ConnectionProvider by providing a DataSource.
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.
dataType(Class<?>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the dataType specifying the serialized type of the Event Message's payload and Meta Data.
DateTimeUtils - Class in org.axonframework.common
Some utility methods regarding Date and Time.
DEADLINE_NAME - Static variable in class org.axonframework.messaging.Headers
Key pointing to the deadline name of a DeadlineMessage.
DeadlineConsumer - Interface in org.axonframework.test.deadline
Functional interface describing a Consumer of a DeadlineMessage.
DeadlineException - Exception in org.axonframework.deadline
Exception which occurs during deadline message processing.
DeadlineException(String, Throwable) - Constructor for exception org.axonframework.deadline.DeadlineException
Initializes deadline exception with message and actual cause.
DeadlineHandler - Annotation Type in org.axonframework.deadline.annotation
Annotation used to mark handlers which are capable of handling a DeadlineMessage.
DeadlineHandlingMember<T> - Interface in org.axonframework.deadline.annotation
Interface describing a message handler capable of handling a specific deadline.
DeadlineJob - Class in org.axonframework.deadline.quartz
Quartz job which depicts handling of a scheduled deadline message.
DeadlineJob() - Constructor for class org.axonframework.deadline.quartz.DeadlineJob
 
DeadlineJob.DeadlineJobDataBinder - Class in org.axonframework.deadline.quartz
This binder is used to map deadline message and deadline scopes to the job data and vice versa.
DeadlineJobDataBinder() - Constructor for class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
 
deadlineManager() - Method in interface org.axonframework.config.Configuration
Returns the DeadlineManager defined in this Configuration.
DeadlineManager - Interface in org.axonframework.deadline
Contract for deadline managers.
DeadlineManagerValidator - Class in org.axonframework.test.deadline
Helps validation of deadline mechanism provided by StubDeadlineManager.
DeadlineManagerValidator(StubDeadlineManager, FieldFilter) - Constructor for class org.axonframework.test.deadline.DeadlineManagerValidator
Instantiates this validator with deadlineManager which is used for validation purposes and fieldFilter.
DeadlineMessage<T> - Interface in org.axonframework.deadline
Represents a Message for a Deadline, specified by its deadline name and optionally containing a deadline payload.
deadlineMessage(Serializer, JobDataMap) - Static method in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
Extracts a DeadlineMessage from provided jobDataMap.
deadlineMessage() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
Retrieve a DeadlineMessage constructed out of the deadlineName and deadlineInfo.
DeadlineMethodMessageHandlerDefinition - Class in org.axonframework.deadline.annotation
Implementation of a HandlerEnhancerDefinition that is used for DeadlineHandler annotated methods.
DeadlineMethodMessageHandlerDefinition() - Constructor for class org.axonframework.deadline.annotation.DeadlineMethodMessageHandlerDefinition
 
deadlineScope(Serializer, JobDataMap) - Static method in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
Extracts a ScopeDescriptor describing the deadline Scope, pulled from provided jobDataMap.
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.
declaredType(Class<?>) - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
Gets the declared aggregate type based on given class type.
declaringClass(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
Returns the class on which the method with given methodName and parameters of type parameterTypes is declared.
declaringClass() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Gets the declaring class of this Message Handling Member.
decrypt(EventWithToken) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
 
decrypt(Event) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
 
decryptBytes(int, byte[]) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
 
DEFAULT_VALUE - Static variable in interface org.axonframework.axonserver.connector.command.CommandLoadFactorProvider
The default value for command load factor: 100.
defaultAxonObjectMapper() - Method in class org.axonframework.springboot.autoconfig.ObjectMapperAutoConfiguration
 
defaultAxonXStream(ApplicationContext) - Method in class org.axonframework.springboot.autoconfig.XStreamAutoConfiguration
 
defaultBackpressure() - Static method in class org.axonframework.queryhandling.SubscriptionQueryBackpressure
Deprecated.
Creates default backpressure, using Project Reactor's FluxSink.OverflowStrategy ERROR strategy.
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
 
defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the callback to use when commands are dispatched in a "fire and forget" method, such as AxonServerCommandBus.dispatch(CommandMessage).
defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
 
defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
Sets the callback to use when commands are dispatched in a "fire and forget" method, such as DistributedCommandBus.dispatch(CommandMessage).
defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
Sets the callback to use when commands are dispatched in a "fire and forget" method, such as SimpleCommandBus.dispatch(CommandMessage).
defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the callback to use when commands are dispatched in a "fire and forget" method, such as DisruptorCommandBus.dispatch(CommandMessage).
defaultCommandExecutorServiceBuilder() - Static method in interface org.axonframework.axonserver.connector.util.ExecutorServiceBuilder
Create a default ExecutorServiceBuilder used to create a ThreadPoolExecutor for processing incoming commands.
DefaultCommandGateway - Class in org.axonframework.commandhandling.gateway
Default implementation of the CommandGateway interface.
DefaultCommandGateway(DefaultCommandGateway.Builder) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
Instantiate a DefaultCommandGateway based on the fields contained in the DefaultCommandGateway.Builder.
defaultCommandGateway(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Returns a DefaultCommandGateway that will use the configuration's CommandBus to dispatch commands.
DefaultCommandGateway.Builder - Class in org.axonframework.commandhandling.gateway
Builder class to instantiate a DefaultCommandGateway.
defaultCommandPriorityCalculator() - Static method in interface org.axonframework.axonserver.connector.command.CommandPriorityCalculator
Returns a default implementation of the CommandPriorityCalculator, always returning priority 0.
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.
defaultConfiguration(boolean) - Static method in class org.axonframework.config.DefaultConfigurer
Returns a Configurer instance with default components configured, such as a SimpleCommandBus and SimpleEventBus, indicating whether to autoLocateConfigurerModules.
DefaultConfigurer - Class in org.axonframework.config
Entry point of the Axon Configuration API.
DefaultConfigurer() - Constructor for class org.axonframework.config.DefaultConfigurer
Initialize the Configurer.
DefaultConflictDescription - Class in org.axonframework.eventsourcing.conflictresolution
ConflictDescription implementation that takes the necessary information in the Constructor.
DefaultConflictDescription(String, long, long, List<DomainEventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
Initialize the instance using given values.
DefaultConflictResolver - Class in org.axonframework.eventsourcing.conflictresolution
Implementation of a ConflictResolver that fetches any unseen changes from the EventStore.
DefaultConflictResolver(EventStore, String, long, long) - Constructor for class org.axonframework.eventsourcing.conflictresolution.DefaultConflictResolver
Initializes a DefaultConflictResolver using the given eventStore to load unseen events since given expectedVersion.
defaultDeadlineManager(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default DeadlineManager implementation.
DefaultEntityRegistrar - Class in org.axonframework.springboot.util
 
DefaultEntityRegistrar() - Constructor for class org.axonframework.springboot.util.DefaultEntityRegistrar
 
defaultEventBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default EventBus implementation.
defaultEventBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
defaultEventGateway(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Returns a DefaultEventGateway that will use the configuration's EventBus to publish events.
DefaultEventGateway - Class in org.axonframework.eventhandling.gateway
Default implementation of the EventGateway interface.
DefaultEventGateway(DefaultEventGateway.Builder) - Constructor for class org.axonframework.eventhandling.gateway.DefaultEventGateway
Instantiate a DefaultEventGateway based on the fields contained in the DefaultEventGateway.Builder.
DefaultEventGateway.Builder - Class in org.axonframework.eventhandling.gateway
A Builder class for DefaultEventGateways.
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
 
defaultHandlerDefinition(Class<?>) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default HandlerDefinition.
DefaultHandlers<Case,Handler> - Class in org.axonframework.axonserver.connector
Deprecated.
in through use of the AxonServer java connector
DefaultHandlers() - Constructor for class org.axonframework.axonserver.connector.DefaultHandlers
Deprecated.
 
defaultHeaders(EventMessage<?>, SerializedObject<?>) - Static method in class org.axonframework.messaging.Headers
Generate defaults headers to recognise an event message.
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
 
DefaultInstructionAckSource<T> - Class in org.axonframework.axonserver.connector
Default implementation of InstructionAckSource.
DefaultInstructionAckSource(Function<InstructionAck, T>) - Constructor for class org.axonframework.axonserver.connector.DefaultInstructionAckSource
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.
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
 
defaultQueryBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default QueryBus implementations.
defaultQueryBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
defaultQueryExecutorServiceBuilder() - Static method in interface org.axonframework.axonserver.connector.util.ExecutorServiceBuilder
Create a default ExecutorServiceBuilder used to create a ThreadPoolExecutor for processing incoming queries.
defaultQueryGateway(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Returns a DefaultQueryGateway that will use the configuration's QueryBus to dispatch queries.
DefaultQueryGateway - Class in org.axonframework.queryhandling
Implementation of the QueryGateway interface that allows the registration of dispatchInterceptors.
DefaultQueryGateway(DefaultQueryGateway.Builder) - Constructor for class org.axonframework.queryhandling.DefaultQueryGateway
Instantiate a DefaultQueryGateway based on the fields contained in the DefaultQueryGateway.Builder.
DefaultQueryGateway.Builder - Class in org.axonframework.queryhandling
Builder class to instantiate a DefaultQueryGateway.
defaultQueryPriorityCalculator() - Static method in interface org.axonframework.axonserver.connector.query.QueryPriorityCalculator
Returns a default implementation of the QueryPriorityCalculator, always returning priority 0.
defaultQueryUpdateEmitter(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default QueryUpdateEmitter implementation.
defaultQueryUpdateEmitter() - Method in class org.axonframework.spring.config.AxonConfiguration
 
defaultResourceInjector(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Returns a ConfigurationResourceInjector that injects resources defined in the given config Configuration.
defaultSerializer(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default Serializer implementation.
defaultSerializer() - Static method in class org.axonframework.serialization.json.JacksonSerializer
Instantiate a default JacksonSerializer.
defaultSerializer() - Static method in class org.axonframework.serialization.xml.XStreamSerializer
Deprecated.
in favor of using the XStreamSerializer.builder() to construct an instance using a configured XStream instance. Using this shorthand still works, but will use an XStream instance that allows everything. Although this works, XStream expects the types or wildcards for the types to be defined to ensure the application stays secure. As such, it is highly recommended to follow their recommended approach.
defaultSnapshotter(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
Provides the default Snapshotter implementation, defaulting to a AggregateSnapshotter.
defaultStrategy() - Static method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
Instantiate a default AnnotationRoutingStrategy.
DefaultSubscriptionQueryResult<I,U> - Class in org.axonframework.queryhandling
Default implementation of SubscriptionQueryResult.
DefaultSubscriptionQueryResult(Mono<I>, Flux<U>, Registration) - Constructor for class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
Initializes the result with mono and flux used for result retrieval.
defaultTyping() - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Configures the underlying ObjectMapper to include type information when serializing Java objects into JSON.
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).
delegates() - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
 
delegateSagaStore(SagaStore<T>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
Sets the SagaStore instance providing access to (persisted) entries.
deleteSaga(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.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.modelling.saga.repository.CachingSagaStore
 
deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
 
deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
 
deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
 
deleteSaga(Class<? extends T>, String, Set<AssociationValue>) - Method in interface org.axonframework.modelling.saga.repository.SagaStore
Deletes a Saga with given sagaType and sagaIdentifier and all its associations.
deleteSnapshots(DeleteSnapshotsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
deleteSnapshots(Connection, String, long) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
deleteSnapshots(Connection, EventSchema, String, long) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
deleteSnapshots(String, long) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Deletes all snapshots from the underlying storage with given aggregateIdentifier.
DeleteSnapshotsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.storeSnapshot(DomainEventMessage, Serializer)
deleteToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
deleteToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
deleteToken(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.
deleteToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
deleteToken(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Deletes the token for the processor with given processorName and segment.
DenyAll - Enum in org.axonframework.commandhandling.distributed.commandfilter
DenyCommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
A CommandMessageFilter implementation which denies CommandMessages based on their CommandMessage.getCommandName().
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(StreamingEventProcessor) - Static method in class org.axonframework.axonserver.connector.processor.StreamingEventProcessorInfoMessage
Create an EventProcessorInfo based on the given eventProcessor.
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
 
describeCurrentScope() - Static method in class org.axonframework.messaging.Scope
Provide a description of the current Scope.
describeScope() - Method in class org.axonframework.messaging.Scope
Provide a description of this Scope.
describeScope() - Method in class org.axonframework.modelling.command.AggregateLifecycle
 
describeScope() - Method in class org.axonframework.modelling.saga.SagaLifecycle
 
describeTo(StringBuilder) - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
 
describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericEventMessage
 
describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
 
describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericTrackedEventMessage
 
describeTo(StringBuilder) - Method in class org.axonframework.messaging.GenericResultMessage
 
describeTo(StringBuilder) - Method in class org.axonframework.messaging.MessageDecorator
Describe the message specific properties to the given stringBuilder.
describeTo(StringBuilder) - Method in class org.axonframework.queryhandling.GenericQueryMessage
 
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.EqualsMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.ListMatcher
 
describeTo(Description) - Method in class org.axonframework.test.matchers.MapEntryMatcher
 
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
 
describeType() - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
describeType() - Method in class org.axonframework.commandhandling.GenericCommandResultMessage
 
describeType() - Method in class org.axonframework.deadline.GenericDeadlineMessage
 
describeType() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
 
describeType() - Method in class org.axonframework.eventhandling.GenericEventMessage
 
describeType() - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
 
describeType() - Method in class org.axonframework.eventhandling.GenericTrackedEventMessage
 
describeType() - Method in class org.axonframework.eventhandling.replay.GenericResetContext
 
describeType() - Method in class org.axonframework.messaging.GenericResultMessage
 
describeType() - Method in class org.axonframework.messaging.MessageDecorator
Describe the type of message, used in MessageDecorator.toString().
describeType() - Method in class org.axonframework.queryhandling.GenericQueryMessage
 
describeType() - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
 
describing(Throwable) - Static method in class org.axonframework.messaging.RemoteExceptionDescription
Provide a description as a List of Strings of all the causes in the given exception.
DescriptionUtils - Class in org.axonframework.test.saga
Utility class for creating a description.
deserialize(Command) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
Convert a Command into a CommandMessage.
deserialize(CommandResponse) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
Convert a CommandResponse into a CommandResultMessage.
deserialize(SerializedObject<S>) - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
 
deserialize(SubscriptionQuery) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Deserializes the given subscriptionQuery into a SubscriptionQueryMessage.
deserialize(QueryResponse) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Deserializes the given queryResponse into a QueryResponseMessage.
deserialize(QueryUpdate) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Deserializes the given queryUpdate into a SubscriptionQueryUpdateMessage.
deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.JavaSerializer
Deprecated.
 
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 interface org.axonframework.serialization.Serializer
Deserializes the first object read from the given bytes.
DeserializedResult<I,U> - Class in org.axonframework.axonserver.connector.query.subscription
Deprecated.
in through use of the AxonServer java connector
DeserializedResult(SubscriptionQueryResult<QueryResponse, QueryUpdate>, SubscriptionMessageSerializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
Deprecated.
Instantiate a DeserializedResult wrapping the delegate which will be serialized by the given serializer.
deserializeRequest(QueryRequest) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
Convert a QueryRequest into a QueryMessage.
deserializeResponse(QueryResponse, ResponseType<R>) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
Convert a QueryResponse into a QueryResponseMessage.
deserializeWithType(JsonParser, DeserializationContext, TypeDeserializer) - Method in class org.axonframework.serialization.json.MetaDataDeserializer
 
destroy() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
 
details() - Method in exception org.axonframework.axonserver.connector.AxonServerException
 
details() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
Return a List of Strings, each describing a single "cause".
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in interface org.axonframework.eventsourcing.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.eventsourcing.conflictresolution.ConflictResolver
Resolve conflicts between changes to be applied to the aggregate and unseen changes made to the aggregate.
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ContextAwareConflictExceptionSupplier<T>) - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictResolver
Resolve conflicts between unseen changes made to the aggregate and new changes that are about to be made.
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ContextAwareConflictExceptionSupplier<T>) - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictResolver
 
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
 
detectConflicts(Predicate<List<DomainEventMessage<?>>>) - Method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
 
detectConflicts(Predicate<List<DomainEventMessage<?>>>, ContextAwareConflictExceptionSupplier<T>) - Method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
 
determinePriority(CommandMessage<?>) - Method in interface org.axonframework.axonserver.connector.command.CommandPriorityCalculator
Determines the priority of the given command.
determinePriority(QueryMessage<?, ?>) - Method in interface org.axonframework.axonserver.connector.query.QueryPriorityCalculator
Determines the priority of the given query.
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
Deprecated.
in favor of DirectEventJobDataBinder(Serializer), as the Serializer is a hard requirement.
DirectEventJobDataBinder(Serializer) - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
Instantiate a QuartzEventScheduler.DirectEventJobDataBinder with the provided Serializer for de-/serializing event messages.
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
 
disableAxonTypeSecurity() - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Configures the underlying XStream instance to not include Axon's classes by default.
disableAxonTypeSecurity() - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
 
DisallowReplay - Annotation Type in org.axonframework.eventhandling
Annotation marking a Handler (or class) as not being able to handle replays
disconnect(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Disconnects any active connection for the given context, forcing a new connection to be established when one is requested.
disconnect() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Disconnects any active connections, forcing a new connection to be established when one is requested.
disconnect() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
Disconnect the command bus for receiving commands from Axon Server, by unsubscribing all registered command handlers.
disconnect() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
Disconnect the query bus from Axon Server, by unsubscribing all known query handlers.
disconnect() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Disconnect the command bus for receiving new commands, by unsubscribing all registered command handlers.
dispatch(CommandMessage<C>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
 
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, ? super 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.distributed.DistributedCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, ? super 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>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
 
dispatch(CommandMessage<C>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
 
dispatch(CommandMessage<C>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
DispatchInterceptors<M extends Message<?>> - Class in org.axonframework.axonserver.connector
Composite of MessageDispatchInterceptors that apply all interceptors in the order of registration.
DispatchInterceptors() - Constructor for class org.axonframework.axonserver.connector.DispatchInterceptors
 
dispatchInterceptors(MessageDispatchInterceptor<? super CommandMessage<?>>...) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
dispatchInterceptors(MessageDispatchInterceptor<? super CommandMessage<?>>...) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
Sets the MessageDispatchInterceptors which are invoked before dispatching a CommandMessage on the CommandBus.
dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
Sets the MessageDispatchInterceptors which are invoked before dispatching a CommandMessage on the CommandBus.
dispatchInterceptors(MessageDispatchInterceptor<? super CommandMessage<?>>...) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
 
dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
 
dispatchInterceptors() - Method in class org.axonframework.deadline.AbstractDeadlineManager
Provides a list of registered dispatch interceptors.
dispatchInterceptors(List<MessageDispatchInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Configures MessageDispatchInterceptor of generic type CommandMessage to use with the DisruptorCommandBus when commands are dispatched.
dispatchInterceptors(MessageDispatchInterceptor<? super EventMessage<?>>...) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
dispatchInterceptors(List<MessageDispatchInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
dispatchInterceptors(MessageDispatchInterceptor<? super EventMessage<?>>...) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
 
dispatchInterceptors(List<MessageDispatchInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
 
dispatchInterceptors(MessageDispatchInterceptor<? super QueryMessage<?, ?>>...) - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
dispatchInterceptors(List<MessageDispatchInterceptor<? super QueryMessage<?, ?>>>) - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
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.
DisposableResult<I,U> - Class in org.axonframework.axonserver.connector.query.subscription
Deprecated.
in through use of the AxonServer java connector
DisposableResult(SubscriptionQueryResult<I, U>, Registration) - Constructor for class org.axonframework.axonserver.connector.query.subscription.DisposableResult
Deprecated.
Instantiate a DisposableResult wrapping the delegate, opening up the capability to DisposableResult.cancel() it.
DisruptorCommandBus - Class in org.axonframework.disruptor.commandhandling
Asynchronous CommandBus implementation with very high performance characteristics.
DisruptorCommandBus(DisruptorCommandBus.Builder) - Constructor for class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
Instantiate a DisruptorCommandBus based on the fields contained in the DisruptorCommandBus.Builder.
DisruptorCommandBus.Builder - Class in org.axonframework.disruptor.commandhandling
Builder class to instantiate a DisruptorCommandBus.
DisruptorUnitOfWork<T extends Message<?>> - Class in org.axonframework.disruptor.commandhandling
Specialized UnitOfWork instance for the DisruptorCommandBus.
DisruptorUnitOfWork() - Constructor for class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
 
distinct(List<E>) - Static method in class org.axonframework.common.ListUtils
Returns a new list containing unique elements from the given list.
Distributed<MessageBus> - Interface in org.axonframework.messaging
A contract towards being a distributed message bus implementation.
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(DistributedCommandBus.Builder) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
Instantiate a DistributedCommandBus based on the fields contained in the DistributedCommandBus.Builder.
DistributedCommandBus.Builder - Class in org.axonframework.commandhandling.distributed
Builder class to instantiate a DistributedCommandBus.
DistributedCommandBusProperties - Class in org.axonframework.springboot
Defines the properties for the Distributed Command Bus, when automatically configured in the Application Context.
DistributedCommandBusProperties() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties
 
DistributedCommandBusProperties.JGroupsProperties - Class in org.axonframework.springboot
The JGroups specific configuration for the Distributed Command Bus.
DistributedCommandBusProperties.JGroupsProperties.Gossip - Class in org.axonframework.springboot
 
DistributedCommandBusProperties.SpringCloudProperties - Class in org.axonframework.springboot
 
doApply(P, MetaData) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
doApply(T, MetaData) - Method in class org.axonframework.modelling.command.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.modelling.command.inspection.AnnotatedAggregate
 
doApply(T, MetaData) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
 
doAssociateWith(AssociationValue) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
Registers a AssociationValue with the given saga.
doAssociateWith(AssociationValue) - Method in class org.axonframework.modelling.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.modelling.saga.repository.AnnotatedSagaRepository
 
doCreateInstance(String, Supplier<T>) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
Creates a new Saga instance.
doCreateNew(Callable<T>) - Method in class org.axonframework.modelling.command.AbstractRepository
Creates a new aggregate instance using the given factoryMethod.
doCreateNew(Class<T>, Callable<T>) - Method in class org.axonframework.modelling.command.AggregateLifecycle
Creates a new aggregate instance.
doCreateNew(Class<R>, Callable<R>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
doCreateNew(Callable<T>) - Method in class org.axonframework.modelling.command.LockingRepository
 
doCreateNew(Class<T>, Callable<T>) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
 
doCreateNewForLock(Callable<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
doCreateNewForLock(Callable<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository
 
doCreateNewForLock(Callable<T>) - Method in class org.axonframework.modelling.command.LockingRepository
Creates a new aggregate instance using the given factoryMethod.
doDelete(A) - Method in class org.axonframework.modelling.command.AbstractRepository
Removes the aggregate from the repository.
doDelete(LockAwareAggregate<T, A>) - Method in class org.axonframework.modelling.command.LockingRepository
Verifies whether all locks are valid and delegates to LockingRepository.doDeleteWithLock(Aggregate) to perform actual deleting.
doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
doDeleteWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository
 
doDeleteWithLock(A) - Method in class org.axonframework.modelling.command.LockingRepository
Perform the actual deleting of the aggregate.
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, ? super R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Performs the actual dispatching logic.
doEnd() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
Marks the saga as ended.
doEnd() - Method in class org.axonframework.modelling.saga.SagaLifecycle
SagaLifecycle instance method to mark the current saga as ended.
doLoad(String, Long) - Method in class org.axonframework.modelling.command.AbstractRepository
Loads and initialized the aggregate with the given aggregateIdentifier.
doLoad(String, Long) - Method in class org.axonframework.modelling.command.LockingRepository
Perform the actual loading of an aggregate.
doLoad(String) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
 
doLoad(String) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
Loads a known Saga instance by its unique identifier.
doLoadOrCreate(String, Callable<T>) - Method in class org.axonframework.modelling.command.AbstractRepository
Loads an aggregate from the reporsitory.
doLoadOrCreate(String, Callable<T>) - Method in class org.axonframework.modelling.command.LockingRepository
 
doLoadSaga(String) - Method in class org.axonframework.modelling.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.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.
doLoadWithLock(String, Long) - Method in class org.axonframework.modelling.command.GenericJpaRepository
 
doLoadWithLock(String, Long) - Method in class org.axonframework.modelling.command.LockingRepository
Loads the aggregate with the given aggregateIdentifier.
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.eventhandling
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(Function<EventSchema, String>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Set a comma separated list of domain event column names to select from an event or snapshot entry.
domainEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get a comma separated list of domain event column names to select from an event or snapshot entry.
domainEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Deprecated.
DomainEventMessage<T> - Interface in org.axonframework.eventhandling
Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain.
DomainEventSequenceAware - Interface in org.axonframework.eventhandling
Contract describing a component which is aware of DomainEventMessage their sequences and is capable of providing the last known sequence number for a given Aggregate identifier.
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.modelling.command.AggregateLifecycle
Marks this aggregate as deleted.
doMarkDeleted() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
doMarkDeleted() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
 
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<Object, Object>) - Method in class org.axonframework.common.caching.JCacheAdapter
 
doRemoveAssociation(AssociationValue) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
Removes the given association from this Saga.
doRemoveAssociation(AssociationValue) - Method in class org.axonframework.modelling.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.modelling.command.AbstractRepository
Performs the actual saving of the aggregate.
doSave(LockAwareAggregate<T, A>) - Method in class org.axonframework.modelling.command.LockingRepository
Verifies whether all locks are valid and delegates to LockingRepository.doSaveWithLock(Aggregate) to perform actual storage.
doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
 
doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
doSaveWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository
 
doSaveWithLock(A) - Method in class org.axonframework.modelling.command.LockingRepository
Perform the actual saving of the aggregate.
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
 
doSleepFor(long) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Instructs the current Thread to sleep until the given deadline.
doUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
Upcasts the given intermediateRepresentation.
doUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
Upcasts the given intermediateRepresentation.
doUpcast(IntermediateEventRepresentation) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
 
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.
DuplicateCommandHandlerResolution - Class in org.axonframework.commandhandling
Enumeration describing a set of reasonable DuplicateCommandHandlerResolver implementations.
DuplicateCommandHandlerResolution() - Constructor for class org.axonframework.commandhandling.DuplicateCommandHandlerResolution
 
duplicateCommandHandlerResolver(DuplicateCommandHandlerResolver) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
 
DuplicateCommandHandlerResolver - Interface in org.axonframework.commandhandling
Functional interface towards resolving the occurrence of a duplicate command handler being subscribed.
duplicateCommandHandlerResolver(DuplicateCommandHandlerResolver) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
Sets the DuplicateCommandHandlerResolver used to resolves the road to take when a duplicate command handler is subscribed.
duplicateCommandHandlerResolver(DuplicateCommandHandlerResolver) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the DuplicateCommandHandlerResolver used to resolves the road to take when a duplicate command handler is subscribed.
duplicateCommandHandlerResolver() - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
DuplicateCommandHandlerSubscriptionException - Exception in org.axonframework.commandhandling
Exception indicating a duplicate Command Handler was subscribed whilst this behavior is purposefully guarded against.
DuplicateCommandHandlerSubscriptionException(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Constructor for exception org.axonframework.commandhandling.DuplicateCommandHandlerSubscriptionException
Initialize a duplicate command handler subscription exception using the given initialHandler and duplicateHandler to form a specific message.
DuplicateCommandHandlerSubscriptionException(String) - Constructor for exception org.axonframework.commandhandling.DuplicateCommandHandlerSubscriptionException
Initializes a duplicate command handler subscription exception using the given message.

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(EmbeddedEventStore.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
Instantiate a EmbeddedEventStore based on the fields contained in the EmbeddedEventStore.Builder.
EmbeddedEventStore.Builder - Class in org.axonframework.eventsourcing.eventstore
Builder class to instantiate an EmbeddedEventStore.
emit(Predicate<SubscriptionQueryMessage<?, ?, U>>, SubscriptionQueryUpdateMessage<U>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Emits incremental update (as return value of provided update function) to subscription queries matching given filter.
emit(Predicate<SubscriptionQueryMessage<?, ?, U>>, U) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Emits given incremental update to subscription queries matching given filter.
emit(Class<Q>, Predicate<? super Q>, SubscriptionQueryUpdateMessage<U>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Emits given incremental update to subscription queries matching given query type and filter.
emit(Class<Q>, Predicate<? super Q>, U) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Emits given incremental update to subscription queries matching given query type and filter.
emit(Predicate<SubscriptionQueryMessage<?, ?, U>>, SubscriptionQueryUpdateMessage<U>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
 
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.
emptyType() - Static method in interface org.axonframework.serialization.SerializedType
Returns the type that represents an empty message, of undefined type.
emptyType() - Static method in class org.axonframework.serialization.SimpleSerializedType
Returns the type that represents an empty message, of undefined type.
encrypt(Event) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
 
encryptBytes(int, byte[]) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
 
end() - Method in class org.axonframework.lifecycle.ShutdownLatch.ActivityHandle
Mark this activity as being finalized.
end() - Static method in class org.axonframework.modelling.saga.SagaLifecycle
Marks the saga as ended.
endpoint() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
Returns this Member's endpoint.
EndSaga - Annotation Type in org.axonframework.modelling.saga
Indicates that the annotated SagaEventHandler method indicates the end of a Saga instance's lifecycle.
EndSagaMessageHandlerDefinition - Class in org.axonframework.modelling.saga
A HandlerEnhancerDefinition inspecting the existence of the EndSaga annotation on MessageHandlingMembers.
EndSagaMessageHandlerDefinition() - Constructor for class org.axonframework.modelling.saga.EndSagaMessageHandlerDefinition
 
EndSagaMessageHandlerDefinition.EndSageMessageHandlingMember<T> - Class in org.axonframework.modelling.saga
A WrappedMessageHandlingMember implementation dedicated towards MessageHandlingMembers annotated with EndSaga.
EndSageMessageHandlingMember(MessageHandlingMember<T>) - Constructor for class org.axonframework.modelling.saga.EndSagaMessageHandlerDefinition.EndSageMessageHandlingMember
Initializes the member using the given delegate.
endScope() - Method in class org.axonframework.messaging.Scope
End a Scope by removing this from a Deque contained in a ThreadLocal.
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.eventsourcing.conflictresolution.DefaultConflictResolver
ensureSagaResourcesInitialized() - Method in class org.axonframework.test.saga.SagaTestFixture
Initializes the saga resources if it hasn't already done so.
entityClass() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Returns the class this model describes
EntityId - Annotation Type in org.axonframework.modelling.command
Field or Method annotation that marks the member 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 - Interface in org.axonframework.common.jpa
Provides components with an EntityManager to access the persistence mechanism.
entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
Sets the EntityManagerProvider which provides the EntityManager used to access the underlying database.
entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the EntityManagerProvider which provides the EntityManager used to access the underlying database for this EventStorageEngine implementation.
entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
Sets the EntityManagerProvider which provides the EntityManager instance for this repository.
entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
Sets the EntityManagerProvider which provides the EntityManager used to access the underlying database.
entityManagerProvider() - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
 
EntityModel<T> - Interface in org.axonframework.modelling.command.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.
EqualRevisionPredicate - Class in org.axonframework.eventsourcing.eventstore
A predicate that matches against DomainEventData instances that have a revision 'equal' to the revision of the class is has serialized data for.
EqualRevisionPredicate(RevisionResolver, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.EqualRevisionPredicate
Initializes the Predicate with given resolver to resolve revision of the class represented by the serialized data.
equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
 
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.commandfilter.NegateCommandMessageFilter
 
equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.OrCommandMessageFilter
 
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.eventhandling.GapAwareTrackingToken
 
equals(Object) - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
 
equals(Object) - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
equals(Object) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
 
equals(Object) - Method in class org.axonframework.eventhandling.ReplayToken
 
equals(Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
 
equals(Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
 
equals(Object) - Method in class org.axonframework.eventhandling.Segment
 
equals(Object) - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
 
equals(Object) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
 
equals(Object) - Method in class org.axonframework.eventhandling.TrackerStatus
 
equals(Object) - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
 
equals(Object) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
equals(Object) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
equals(Object) - Method in class org.axonframework.messaging.MetaData
 
equals(Object) - Method in class org.axonframework.messaging.RemoteExceptionDescription
 
equals(Object) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
equals(Object) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
equals(Object) - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
 
equals(Object) - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
 
equals(Object) - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
 
equals(Object) - Method in class org.axonframework.modelling.saga.AssociationValue
 
equals(Object) - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
 
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.deadline.ScheduledDeadlineInfo
 
equals(Object) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
EqualsMatcher<T> - Class in org.axonframework.test.matchers
Matcher testing for object equality as per Object.equals(Object o)
EqualsMatcher(T) - Constructor for class org.axonframework.test.matchers.EqualsMatcher
 
equalTo(T) - Static method in class org.axonframework.test.matchers.EqualsMatcher
 
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
error(Throwable) - Method in interface org.axonframework.queryhandling.SinkWrapper
Wrapper around Sink error(Throwable).
errorCode() - Method in exception org.axonframework.axonserver.connector.AxonServerException
 
ErrorCode - Enum in org.axonframework.axonserver.connector
Converts an Axon Server Error to the relevant Axon framework exception.
errorCode() - Method in enum org.axonframework.axonserver.connector.ErrorCode
 
errorCode() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
ErrorContext - Class in org.axonframework.eventhandling
Describes the context of an error.
ErrorContext(String, Throwable, List<? extends EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.ErrorContext
Instantiate an ErrorContext for the given eventProcessor, due to the given error, with the given failedEvents.
errorHandler(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the ErrorHandler tied to the given processorName.
errorHandler(String) - Method in class org.axonframework.config.EventProcessingModule
 
errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
Sets the ErrorHandler invoked when an UnitOfWork is rolled back during processing.
ErrorHandler - Interface in org.axonframework.eventhandling
Interface of the error handler that will be invoked if event processing fails.
errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
 
errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
 
errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
 
errorHandler(QueryInvocationErrorHandler) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
Sets the QueryInvocationErrorHandler to handle exceptions during query handler invocation.
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
Deprecated.
in favor of the default message keys | only maintained for backwards compatibility
EventBuffer - Class in org.axonframework.axonserver.connector.event.axon
Client-side buffer of messages received from the server.
EventBuffer(EventStream, EventUpcaster, Serializer, boolean) - Constructor for class org.axonframework.axonserver.connector.event.axon.EventBuffer
Initializes an Event Buffer, passing messages through given upcasterChain and deserializing events using given serializer.
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(EventBus) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
Sets the EventBus used to publish events.
eventBus(EventBus) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
 
eventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
Sets the EventBus used to publish events on to, once the schedule has been met.
eventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
Sets the EventBus used to publish events on once the schedule has been met.
eventBus(EventBus) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
Sets the EventBus to which events are published.
eventBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
eventBus(AxonConfiguration) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
eventCipher(EventCipher) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
EventCipher - Class in org.axonframework.axonserver.connector.event.util
Deprecated.
in through use of the AxonServer java connector
EventCipher() - Constructor for class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
Constructs a default EventCipher.
EventCipher(byte[]) - Constructor for class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
Constructs a EventCipher using the given secretKey.
EventCipher(Function<Event, Integer>, List<byte[]>) - Constructor for class org.axonframework.axonserver.connector.event.util.EventCipher
Deprecated.
 
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.eventhandling
Interface describing the properties of serialized Event Messages.
eventFlowControl(int, int, int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
eventGateway() - Method in interface org.axonframework.config.Configuration
Returns the Event Gateway defined in this Configuration.
EventGateway - Interface in org.axonframework.eventhandling.gateway
Interface towards the Event Handling components of an application.
eventGateway(EventBus) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
eventHandled(EventMessage<?>) - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
 
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(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
Sets the EventHandlerInvoker which will handle all the individual EventMessages.
eventHandlerInvoker() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
Returns the invoker assigned to this processor.
EventHandlerInvoker - Interface in org.axonframework.eventhandling
Interface for an event message handler that defers handling to one or more other handlers.
eventHandlerInvoker(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
 
eventHandlerInvoker(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
 
eventHandlerInvoker(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
 
EventHandlerRegistrar - Class in org.axonframework.spring.config
Spring Bean that registers Event Handler beans with the EventHandlingConfiguration.
EventHandlerRegistrar(AxonConfiguration, ModuleConfiguration, EventProcessingConfigurer) - Constructor for class org.axonframework.spring.config.EventHandlerRegistrar
Initialize the registrar to register beans discovered with the given eventProcessing.
eventHandlers(Object...) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Sets the eventHandlers this EventHandlerInvoker will forward all its events to.
eventHandlers(List<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Sets the eventHandlers this EventHandlerInvoker will forward all its events to.
eventHandlers() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
Gets the list of Event Handler delegates.
eventIdentifierColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event identifier column.
eventIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing 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.
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.eventsourcing.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.
EventMessageHandler - Interface in org.axonframework.eventhandling
Interface to be implemented by classes that can handle events.
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
 
eventProcessing() - Method in interface org.axonframework.config.Configurer
Retrieve the EventProcessingConfigurer registered as a module with this Configurer.
eventProcessing(Consumer<EventProcessingConfigurer>) - Method in interface org.axonframework.config.Configurer
Locates the EventProcessingConfigurer registered as a module with this Configurer and provides it to the given consumer for configuration.
eventProcessing() - Method in class org.axonframework.config.DefaultConfigurer
 
EventProcessingAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration for EventProcessingModule.
EventProcessingAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.EventProcessingAutoConfiguration
 
eventProcessingConfiguration() - Method in interface org.axonframework.config.Configuration
Returns the EventProcessingConfiguration defined in this Configuration.
EventProcessingConfiguration - Interface in org.axonframework.config
Defines a contract for accessor methods regarding event processing configuration.
eventProcessingConfiguration() - Method in class org.axonframework.spring.config.AxonConfiguration
 
EventProcessingConfigurer - Interface in org.axonframework.config
Defines a contract for configuring event processing.
EventProcessingConfigurer.EventProcessorBuilder - Interface in org.axonframework.config
Contract which defines how to build an event processor.
EventProcessingConfigurer.PooledStreamingProcessorConfiguration - Interface in org.axonframework.config
Contract defining PooledStreamingEventProcessor.Builder based configuration when constructing a PooledStreamingEventProcessor.
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.
EventProcessingModule - Class in org.axonframework.config
Event processing module configuration.
EventProcessingModule() - Constructor for class org.axonframework.config.EventProcessingModule
 
eventProcessingModule() - Method in class org.axonframework.springboot.autoconfig.EventProcessingAutoConfiguration
 
EventProcessingStrategy - Interface in org.axonframework.eventhandling
Interface describing a strategy for the processing of a batch of events.
eventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Obtains an EventProcessor through the given name.
eventProcessor(String, Class<T>) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the EventProcessor with the given name if present, matching the given expectedType.
eventProcessor() - Method in interface org.axonframework.config.SagaConfiguration
Gets the EventProcessor responsible for delivering events to this Saga.
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.
eventProcessorByProcessingGroup(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Obtains an EventProcessor by it's processingGroup.
eventProcessorByProcessingGroup(String, Class<T>) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns an EventProcessor by the given processingGroup if present, matching the given expectedType.
eventProcessorByProcessingGroup(String) - Method in class org.axonframework.config.EventProcessingModule
 
EventProcessorControlService - Class in org.axonframework.axonserver.connector.processor
Service that listens to PlatformOutboundInstructions to control EventProcessors when for example requested by Axon Server.
EventProcessorControlService(AxonServerConnectionManager, EventProcessingConfiguration, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.processor.EventProcessorControlService
Initialize a EventProcessorControlService which adds Consumers to the given AxonServerConnectionManager on PlatformOutboundInstructions.
EventProcessorControlService(AxonServerConnectionManager, EventProcessingConfiguration, String) - Constructor for class org.axonframework.axonserver.connector.processor.EventProcessorControlService
Initialize a EventProcessorControlService which adds Consumers to the given AxonServerConnectionManager on PlatformOutboundInstructions.
EventProcessorInfoConfiguration - Class in org.axonframework.axonserver.connector.event.axon
Module Configuration implementation that defines the components needed to control and monitor the EventProcessors with AxonServer.
EventProcessorInfoConfiguration() - Constructor for class org.axonframework.axonserver.connector.event.axon.EventProcessorInfoConfiguration
Create an default EventProcessorInfoConfiguration, which uses the Configuration as a means to retrieve the EventProcessingConfiguration, AxonServerConnectionManager and AxonServerConfiguration.
EventProcessorInfoConfiguration(Function<Configuration, EventProcessingConfiguration>, Function<Configuration, AxonServerConnectionManager>, Function<Configuration, AxonServerConfiguration>) - Constructor for class org.axonframework.axonserver.connector.event.axon.EventProcessorInfoConfiguration
Creates an EventProcessorInfoConfiguration using the provided functions to retrieve the EventProcessingConfiguration, AxonServerConnectionManager and AxonServerConfiguration.
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
EventProcessorLatencyMonitor(Clock) - Constructor for class org.axonframework.metrics.EventProcessorLatencyMonitor
Construct an EventProcessorLatencyMonitor using the given clock.
EventProcessorLatencyMonitor - Class in org.axonframework.micrometer
Measures the difference in message timestamps between the last ingested and the last processed message.
EventProcessorLatencyMonitor(EventProcessorLatencyMonitor.Builder) - Constructor for class org.axonframework.micrometer.EventProcessorLatencyMonitor
Instantiate a EventProcessorLatencyMonitor based on the fields contained in the EventProcessorLatencyMonitor.Builder.
EventProcessorLatencyMonitor.Builder - Class in org.axonframework.micrometer
Builder class to instantiate a EventProcessorLatencyMonitor.
EventProcessorProperties - Class in org.axonframework.springboot
Properties describing the settings for Event Processors.
EventProcessorProperties() - Constructor for class org.axonframework.springboot.EventProcessorProperties
 
EventProcessorProperties.Mode - Enum in org.axonframework.springboot
The processing modes of an EventProcessor.
EventProcessorProperties.ProcessorSettings - Class in org.axonframework.springboot
 
eventProcessors() - Method in interface org.axonframework.config.EventProcessingConfiguration
Obtains all registered EventProcessors.
eventProcessors() - Method in class org.axonframework.config.EventProcessingModule
 
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.messaging
Exception indication that an error occurred while publishing an event to an AMQP Broker
EventPublicationFailedException(String, Throwable) - Constructor for exception org.axonframework.messaging.EventPublicationFailedException
Initialize the exception using given descriptive message and cause
EventPublisher - Class in org.axonframework.disruptor.commandhandling
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.disruptor.commandhandling.EventPublisher
Initializes the EventPublisher to publish Events to the given eventStore and eventBus for aggregate of given aggregateType.
eventScheduler() - Method in interface org.axonframework.config.Configuration
Returns the EventScheduler defined in this Configuration.
EventScheduler - Interface in org.axonframework.eventhandling.scheduling
Interface towards a mechanism capable of scheduling the publication of events.
eventScheduler(Serializer, AxonServerConnectionManager) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
EventSchedulerValidator - Class in org.axonframework.test.eventscheduler
Helper class for validating events scheduled in a given event scheduler.
EventSchedulerValidator(StubEventScheduler) - Constructor for class org.axonframework.test.eventscheduler.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.
eventSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
Sets the Serializer used to de-/serialize events.
eventSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Sets the Serializer used to serialize and deserialize the Event Message's payload and Meta Data with.
eventSerializer() - Method in interface org.axonframework.config.Configuration
Returns the Serializer defined in this Configuration to be used for serializing Event Message payload and their metadata.
eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
Sets the Serializer used to serialize and deserialize the Event Message's payload and MetaData with.
eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
 
eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
 
eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
 
eventSerializer() - Method in class org.axonframework.spring.config.AxonConfiguration
 
eventSerializer(Serializer, Serializer, RevisionResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
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(T, AggregateModel<T>, EventBus, RepositoryProvider, 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.
EventSourcedAggregate(AggregateModel<T>, EventBus, RepositoryProvider, 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(EventSourcingRepository.Builder<T>) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
Instantiate a EventSourcingRepository based on the fields contained in the EventSourcingRepository.Builder.
EventSourcingRepository.Builder<T> - Class in org.axonframework.eventsourcing
Builder class to instantiate a EventSourcingRepository.
EventStorageEngine - Interface in org.axonframework.eventsourcing.eventstore
Provides a mechanism to append as well as retrieve events from an underlying storage like a database.
eventStorageEngine(Serializer, PersistenceExceptionResolver, Serializer, AxonConfiguration, ConnectionProvider, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
 
eventStorageEngine(Serializer, PersistenceExceptionResolver, Serializer, AxonConfiguration, EntityManagerProvider, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.JpaEventStoreAutoConfiguration
 
eventStore() - Method in interface org.axonframework.config.Configuration
Returns the Event Store in this Configuration, if it is defined.
eventStore(EventStore) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
Sets the EventStore instance which this AbstractSnapshotter implementation will store snapshots in.
eventStore(EventStore) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
 
eventStore - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
eventStore(EventStore) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Sets the EventStore that holds the event stream this repository needs to event source an Aggregate.
EventStore - Interface in org.axonframework.eventsourcing.eventstore
Provides a mechanism to open streams from events in the the underlying event storage.
eventStore(EventStore) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
 
eventStore(EventStorageEngine, AxonConfiguration) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
eventStore(AxonServerConfiguration, AxonConfiguration, AxonServerConnectionManager, Serializer, Serializer) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
EventStoreClientException - Exception in org.axonframework.axonserver.connector.event.util
Deprecated.
in through use of the AxonServer java connector
EventStoreClientException(String, String) - Constructor for exception org.axonframework.axonserver.connector.event.util.EventStoreClientException
Deprecated.
Constructs a EventStoreClientException using the given code and message.
EventStoreClientException(String, String, Throwable) - Constructor for exception org.axonframework.axonserver.connector.event.util.EventStoreClientException
Deprecated.
Constructs a EventStoreClientException using the given code, message and cause.
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
eventStreamFilter - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
eventStreamFilter(Predicate<? super DomainEventMessage<?>>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Sets the Predicate used to filter events when reading from the EventStore.
EventStreamUtils - Class in org.axonframework.eventsourcing
Utility class for dealing with event streams.
eventTable(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the domain events table.
EventTableFactory - Interface in org.axonframework.eventsourcing.eventstore.jdbc
Interface describing a factory for JDBC to create the Domain and Snapshot Event tables.
EventTrackerStatus - Interface in org.axonframework.eventhandling
Interface describing the status of a Segment of a TrackingEventProcessor.
EventTrackerStatusChangeListener - Interface in org.axonframework.eventhandling
Represent a listener that is notified whenever the Map of EventTrackerStatus' in the TrackingEventProcessor this component is registered to has changed.
EventTypeUpcaster - Class in org.axonframework.serialization.upcasting.event
A SingleEventUpcaster implementation which allows for type upcasting only.
EventTypeUpcaster(String, String, String, String) - Constructor for class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
Instantiate an EventTypeUpcaster using the given expected and upcasted payload types and revisions.
EventTypeUpcaster.Builder - Class in org.axonframework.serialization.upcasting.event
Builder class to instantiate an EventTypeUpcaster.
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.eventhandling
Utility class for dealing with events.
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<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.
exceedsThreshold() - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
This method is used to determine if a new snapshot should be created
EXCEPTION_RESULT_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the exception result type the handler can handle.
exceptionDetails() - Method in interface org.axonframework.messaging.ResultMessage
If the this message contains an exception result, returns the details provided in the exception, if available.
ExceptionHandler - Annotation Type in org.axonframework.messaging.interceptors
Annotation marking a Handler as an interceptor for other handlers that is only interested in handling exception results.
exceptionResult() - Method in interface org.axonframework.messaging.ResultMessage
Returns the exception result.
exceptionRevision - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
ExceptionSerializer - Class in org.axonframework.axonserver.connector.util
Utility class used to serializer Throwables into ErrorMessages.
exceptionType - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
ExceptionUtils - Class in org.axonframework.common
Exception utility methods.
execute(Runnable) - Method in class org.axonframework.common.DirectExecutor
Executes the given command immediately in the current thread.
execute(JobExecutionContext) - Method in class org.axonframework.deadline.quartz.DeadlineJob
 
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.
execute(Consumer<T>) - Method in interface org.axonframework.modelling.command.Aggregate
Execute a method on the underlying aggregate or one of its instances.
execute(Runnable) - Method in class org.axonframework.modelling.command.AggregateLifecycle
Executes the given task.
execute(Consumer<T>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
execute(Consumer<AR>) - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
execute(Consumer<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
 
execute(Consumer<T>) - Method in interface org.axonframework.modelling.saga.Saga
Execute the given invocation against the root object of this Saga instance.
execute(Runnable) - Method in class org.axonframework.modelling.saga.SagaLifecycle
SagaLifecycle instance method to execute given task in the context of this SagaLifeCycle.
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.
executeQuery(Connection, JdbcUtils.SqlFunction, JdbcUtils.SqlResultConverter<R>, Function<SQLException, RuntimeException>, boolean) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Execute the query given by the sqlFunction.
executeUpdate(Connection, JdbcUtils.SqlFunction, Function<SQLException, RuntimeException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Execute the update statement produced by the given updateFunction.
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.disruptor.commandhandling.DisruptorUnitOfWork
Execute the given task in the context of this Unit of Work.
executeWithResult(Callable<V>) - Method in class org.axonframework.messaging.Scope
Scope instance method to execute given task of type Callable in the context of this Scope.
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.
executeWithRetry(Runnable, Predicate<RuntimeException>, long, TimeUnit, long) - Static method in class org.axonframework.common.ProcessUtils
Executes an action, with potential retry in case of an exception.
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(ResultMessage<?>) - Constructor for class org.axonframework.messaging.unitofwork.ExecutionResult
Initializes an ExecutionResult from the given result.
executor(Executor) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
Sets the Executor which processes the Command dispatching threads.
executor(Executor) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the Executor that provides the processing resources (Threads) for the components of the DisruptorCommandBus.
executor(Executor) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
Sets the Executor which handles the actual snapshot creation process.
executor(Executor) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
 
executor(Executor) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
 
executorServiceBuilder(ExecutorServiceBuilder) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the ExecutorServiceBuilder which builds an ExecutorService based on a given AxonServerConfiguration and BlockingQueue of Runnable.
executorServiceBuilder(ExecutorServiceBuilder) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the ExecutorServiceBuilder which builds an ExecutorService based on a given AxonServerConfiguration and BlockingQueue of Runnable.
ExecutorServiceBuilder - Interface in org.axonframework.axonserver.connector.util
A Functional Interface towards a BiFunction which ingests both an AxonServerConfiguration and a BlockingQueue of Runnable, and outputs an ExecutorService.
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
 
expectDeadlinesMet(Object...) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that given expected deadlines have been met (which have passed in time).
expectDeadlinesMet(Object...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectDeadlinesMet(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that given expected deadlines have been met (which have passed in time).
expectDeadlinesMet(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that deadlines match given matcher have been met (which have passed in time) on this aggregate.
expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that deadlines match given matcher have been met (which have passed in time) on this saga.
expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - 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
 
expectedResponseType - Variable in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
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
 
expectedVersion() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
The expected version, as indicated when loading the aggregate
expectedVersion() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
 
expectEvents(Object...) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the given set of events to have been published.
expectEvents(EventMessage<?>...) - 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
 
expectEvents(EventMessage<?>...) - 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
 
expectExceptionMessage(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect an exception message to occur during command handler execution that matches with the given matcher.
expectExceptionMessage(String) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the given exceptionMessage to occur during command handler execution.
expectExceptionMessage(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectExceptionMessage(String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectMarkedDeleted() - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that the Aggregate has been marked for deletion.
expectMarkedDeleted() - 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.
expectNoScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline equal to the given deadline has been scheduled after the given durationToScheduledTime.
expectNoScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline equal to the given deadline has been scheduled at the given scheduledTime.
expectNoScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline equal to the given deadline has been scheduled after the given durationToScheduledTime.
expectNoScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline equal to the given deadline has been scheduled at the given scheduledTime.
expectNoScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline matching the given matcher is scheduled.
expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline matching the given matcher should be scheduled after the given durationToScheduledTime.
expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline matching the given matcher has been scheduled at the given scheduledTime.
expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline matching the given matcher is scheduled.
expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline matching the given matcher should be scheduled after the given durationToScheduledTime.
expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline matching the given matcher has been scheduled at the given scheduledTime.
expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline of the given deadlineType has been scheduled after the given durationToScheduledTime.
expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline with the given deadlineType has been scheduled at the given scheduledTime.
expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline of the given deadlineType has been scheduled at the given durationToScheduledTime.
expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline with the given deadlineType has been scheduled at the given scheduledTime.
expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlines() - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadlines are scheduled.
expectNoScheduledDeadlines() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlines() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadlines are scheduled.
expectNoScheduledDeadlines() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline with the given deadlineName has been scheduled after the given durationToScheduledTime.
expectNoScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that no deadline with the given deadlineName has been scheduled at the given scheduledTime.
expectNoScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectNoScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline with the given deadlineName has been scheduled after the given durationToScheduledTime.
expectNoScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no deadline with the given deadlineName has been scheduled at the given scheduledTime.
expectNoScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEvent(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no event equal to the given event has been scheduled after the given durationToScheduledTime.
expectNoScheduledEvent(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no event equal to the given event has been scheduled at the given scheduledTime.
expectNoScheduledEvent(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEvent(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no event matching the given matcher has been scheduled to be published after the given durationToScheduledTime.
expectNoScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no event matching the given matcher has been scheduled at the given scheduledTime.
expectNoScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEventOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no event of the given eventType has been scheduled after the given durationToScheduledTime.
expectNoScheduledEventOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that no event with the given eventType has been scheduled at the given scheduledTime.
expectNoScheduledEventOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEventOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNoScheduledEvents() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that no events are scheduled for publication.
expectNoScheduledEvents() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectNotMarkedDeleted() - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that the Aggregate has NOT been marked for deletion.
expectNotMarkedDeleted() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectPublishedEvents(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Assert that the saga published events on the EventBus in the exact sequence of the given expected events.
expectPublishedEvents(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectPublishedEventsMatching(Matcher<? extends 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
 
expectResultMessage(CommandResultMessage<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the command handler to return the given expectedResultMessage after execution.
expectResultMessage(CommandResultMessage<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectResultMessageMatching(Matcher<? super CommandResultMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the command handler to return a value that matches the given matcher after execution.
expectResultMessageMatching(Matcher<? super CommandResultMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectResultMessagePayload(Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the command handler to return the given expectedPayload after execution.
expectResultMessagePayload(Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectResultMessagePayloadMatching(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Expect the command handler to return a payload that matches the given matcher after execution.
expectResultMessagePayloadMatching(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline equal to the given deadline has been scheduled after the given duration.
expectScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline equal to the given deadline has been scheduled at the given scheduledTime.
expectScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline equal to the given deadline has been scheduled after the given duration.
expectScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline equal to the given deadline has been scheduled at the given scheduledTime.
expectScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline scheduled after given duration matches the given matcher.
expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline matching the given matcher has been scheduled at the given scheduledTime.
expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline scheduled after given duration matches the given matcher.
expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline matching the given matcher has been scheduled at the given scheduledTime.
expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline of the given deadlineType has been scheduled after the given duration.
expectScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline of the given deadlineType has been scheduled at the given scheduledTime.
expectScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline of the given deadlineType has been scheduled after the given duration.
expectScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline of the given deadlineType has been scheduled at the given scheduledTime.
expectScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline with the given deadlineName has been scheduled after the given duration.
expectScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
Asserts that a deadline with the given deadlineName has been scheduled at the given scheduledTime.
expectScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
expectScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline with the given deadlineName has been scheduled after the given duration.
expectScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that a deadline with the given deadlineName has been scheduled at the given scheduledTime.
expectScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
 
expectScheduledEvent(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
Asserts that an event equal to the given event 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 event 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
 
expectState(Consumer<T>) - Method in interface org.axonframework.test.aggregate.ResultValidator
Provides access the the state of the Aggregate as it was stored in the repository, allowing for validation of the state of the aggregate, as it was left in the repository.
expectState(Consumer<T>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
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
 
explicitFlush(boolean) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the explicitFlush field specifying whether to explicitly call EntityManager.flush() after inserting the Events published in this Unit of Work.
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.
ExponentialBackOffIntervalRetryScheduler - Class in org.axonframework.commandhandling.gateway
A RetryScheduler that uses a backoff strategy, retrying commands at increasing intervals when they fail because of an exception that is not explicitly non-transient.
ExponentialBackOffIntervalRetryScheduler(ExponentialBackOffIntervalRetryScheduler.Builder) - Constructor for class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler
ExponentialBackOffIntervalRetryScheduler.Builder - Class in org.axonframework.commandhandling.gateway
Builder class to instantiate an ExponentialBackOffIntervalRetryScheduler.
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.
extendedGapCheckEnabled(boolean) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Indicates whether an extra query should be performed to verify for gaps in the globalSequence larger than the configured batch size.
EXTERNAL_CONNECTIONS - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown all external connections.
extract(ResultSet, int, Class<T>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Returns the object read from the resultSet, which object can be null, at the given column (base 1).
extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
Extracts the AssociationValues from the given event as relevant for a Saga of given sagaType.
extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager
 
extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
Extracts the Child Entity contained in the given declaringEntity as an EntityModel.
extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
 
extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
 
extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
 
extractCommandHandlerRoutingKeys(Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
Retrieves the routing keys of every command handler on the given childEntityModel to be able to correctly route commands to Entities.

F

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
 
FailingDuplicateCommandHandlerResolver - Class in org.axonframework.commandhandling
Implementation of DuplicateCommandHandlerResolver that throws a DuplicateCommandHandlerSubscriptionException when a duplicate registration is detected.
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).
fallbackRoutingStrategy(RoutingStrategy) - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.Builder
Sets the fallback RoutingStrategy to use when the intended routing key resolution was unsuccessful.
fallbackRoutingStrategy(RoutingStrategy) - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.Builder
Sets the fallback RoutingStrategy to use when the intended routing key resolution was unsuccessful.
fallbackSequencingPolicy(SequencingPolicy<EventMessage>) - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy.Builder
Defines the fallback sequencing policy, the sequencing policy which is applied if the event message payload is not of a supported type.
fetchAndRemove(String) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
Fetches and removes a callback.
fetchDelay(long) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
Sets the time to wait before fetching new events from the backing storage engine while tracking after a previous stream was fetched and read.
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
 
fetchForAggregateUntilEmpty() - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
Specifies whether the BatchingEventStorageEngine.readEventData(String, long) should proceed fetching events for an aggregate until an empty batch is returned.
fetchForAggregateUntilEmpty() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
fetchInTransaction(Supplier<T>) - Method in interface org.axonframework.common.transaction.TransactionManager
Invokes the given supplier in a transaction managed by the current TransactionManager.
fetchSegments(String) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
fetchSegments(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
fetchSegments(String) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
fetchSegments(String) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Returns an array of known segments for a given processorName.
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(FetchTrackedEventsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Set the PreparedStatement to be used on JdbcEventStorageEngine.fetchTrackedEvents(Connection, long).
fetchTrackedEvents(Connection, long) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
fetchTrackedEvents(TrackingToken, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
fetchTrackedEvents(Connection, EventSchema, long) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.fetchTrackedEvents(TrackingToken, int).
fetchTrackedEvents(TrackingToken, int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
FetchTrackedEventsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.fetchTrackedEvents(TrackingToken, int)
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.
fieldsOf(Class<?>, boolean) - Static method in class org.axonframework.common.ReflectionUtils
Returns an Iterable of all the fields declared on the given class.
filter(Predicate<? super DomainEventMessage<?>>) - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
Returns a stream that provides the items of this stream that match the given filter.
filterByAggregateType() - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Configures a filter that rejects events with a different Aggregate type than the one specified by this Repository's AggregateModel.
filterCandidates(T, Stream<E>) - Method in interface org.axonframework.modelling.command.ForwardingMode
Filter the given Stream of candidates which are to handle the supplied message.
filterCandidates(T, Stream<E>) - Method in class org.axonframework.modelling.command.ForwardMatchingInstances
 
filterCandidates(T, Stream<E>) - Method in class org.axonframework.modelling.command.ForwardNone
 
filterCandidates(T, Stream<E>) - Method in class org.axonframework.modelling.command.ForwardToAll
 
FilteringDomainEventStream - Class in org.axonframework.eventsourcing.eventstore
DomainEventStream implementation that filters a stream.
FilteringDomainEventStream(DomainEventStream, Predicate<? super DomainEventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.eventstore.FilteringDomainEventStream
Initialize the stream, filter the given stream with the given filter.
FilteringEventStorageEngine - Class in org.axonframework.eventsourcing
Implementation of EventStorageEngine that delegates to another implementation, while filtering events as they are appended.
FilteringEventStorageEngine(EventStorageEngine, Predicate<? super EventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.FilteringEventStorageEngine
Initializes the FilteringEventStorageEngine delegating all event messages matching the given filter to the given delegate.
find(AssociationValue) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
 
find(AssociationValue) - Method in interface org.axonframework.modelling.saga.SagaRepository
Find saga instances of the given type that have been associated with the given associationValue.
findAnnotationAttribute(AnnotatedElement, Class<? extends Annotation>, String) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Find the attributeName of an annotation of type annotationType 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.
findAnnotationAttributes(AnnotatedElement, Class<? extends Annotation>, boolean) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Find the attributes of an annotation of type annotationType on the given 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, String, boolean) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Find the attributes of an annotation with given annotationName 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.
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.modelling.saga.metamodel.SagaModel
Returns a List of MessageHandlingMember that can handle the given event.
findModules(Class<T>) - Method in interface org.axonframework.config.Configuration
Finds all configuration modules of given moduleType within this configuration.
findResource(Class<R>) - Method in class org.axonframework.config.ConfigurationResourceInjector
 
findResource(Class<R>) - Method in class org.axonframework.modelling.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.modelling.saga.SimpleResourceInjector
 
findSagas(String, AssociationValue) - Method in class org.axonframework.modelling.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.modelling.saga.repository.CachingSagaStore
 
findSagas(Class<?>, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
 
findSagas(Class<?>, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
 
findSagas(Class<?>, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
 
findSagas(Class<? extends T>, AssociationValue) - Method in interface org.axonframework.modelling.saga.repository.SagaStore
Returns identifiers of saga instances of the given sagaType that have been associated with the given associationValue.
FireEventJob - Class in org.axonframework.eventhandling.scheduling.quartz
Quartz Job that publishes an event on an Event Bus.
FireEventJob() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
 
FIRST - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should be the very first
FixedValueParameterResolver<T> - Class in org.axonframework.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
 
flowControl(int, int, int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
FlowControlConfiguration() - Constructor for class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
 
FlowControlConfiguration(Integer, Integer, Integer) - Constructor for class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
FlowControllingStreamObserver<T> - Class in org.axonframework.axonserver.connector.util
Deprecated.
in through use of the AxonServer java connector
FlowControllingStreamObserver(StreamObserver<T>, AxonServerConfiguration, Function<FlowControl, T>, Predicate<T>) - Constructor for class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
Deprecated.
FlowControllingStreamObserver(StreamObserver<T>, String, AxonServerConfiguration.FlowControlConfiguration, Function<FlowControl, T>, Predicate<T>) - Constructor for class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
Deprecated.
FORCE_NEW_SAGA - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing whether the handler forces the creation of a new saga instance.
forceReadFromLeader(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
forClass(Class<?>) - Static method in class org.axonframework.messaging.annotation.ClasspathHandlerDefinition
Creates an instance for the given clazz.
forClass(Class<?>) - Static method in class org.axonframework.messaging.annotation.ClasspathHandlerEnhancerDefinition
Creates an instance for the given clazz.
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.ClasspathHandlerDefinition
Creates an instance using the given classLoader.
forClassLoader(ClassLoader) - Static method in class org.axonframework.messaging.annotation.ClasspathHandlerEnhancerDefinition
Creates an instance using the given classLoader.
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 three positions for milliseconds.
forParallelProcessing(int) - Static method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Initialize a configuration instance with the given threadCount.
forSerialization() - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
 
forSerialization() - Method in interface org.axonframework.messaging.responsetypes.ResponseType
Returns the ResponseType instance that should be used when serializing responses.
forSingleThreadedProcessing() - Static method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Initialize a configuration with single threaded processing.
forType(Class<T>) - Static method in class org.axonframework.config.SagaConfigurer
Retrieve the SagaConfigurer for given sagaType.
ForwardingMode<T extends Message<?>> - Interface in org.axonframework.modelling.command
Interface describing the required functionality to forward a message.
ForwardMatchingInstances<T extends Message<?>> - Class in org.axonframework.modelling.command
Only forward messages of type T if the routing key of the message matches that of the entity.
ForwardMatchingInstances() - Constructor for class org.axonframework.modelling.command.ForwardMatchingInstances
 
ForwardNone<T extends Message<?>> - Class in org.axonframework.modelling.command
Forward no messages T regardless of their set up.
ForwardNone() - Constructor for class org.axonframework.modelling.command.ForwardNone
 
ForwardToAll<T extends Message<?>> - Class in org.axonframework.modelling.command
Forward all messages T regardless of their set up.
ForwardToAll() - Constructor for class org.axonframework.modelling.command.ForwardToAll
 
from(Map<String, ?>) - Static method in class org.axonframework.messaging.MetaData
Creates a new MetaData instance from the given metaDataEntries.
from(Class<?>, String) - Static method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
Instantiate a EventTypeUpcaster.Builder which should upcast "from" the given payloadType and revision.
from(String, String) - Static method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
Instantiate a EventTypeUpcaster.Builder which should upcast "from" the given payloadType and revision.
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
Note that this function is able to retrieve an Event Message in two formats.
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.eventhandling
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.
GapAwareTrackingToken(long, Collection<Long>) - Constructor for class org.axonframework.eventhandling.GapAwareTrackingToken
This constructor is mean't to be used for deserialization.
GapAwareTrackingToken - Class in org.axonframework.eventsourcing.eventstore
Deprecated.
in favor of the GapAwareTrackingToken
GapAwareTrackingToken(long, Collection<Long>) - Constructor for class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
Deprecated.
 
gapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken.
gapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken.
gapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out.
gapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out.
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.
GenericAggregateFactory(AggregateModel<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
Initialize the AggregateFactory for creating instances of the given aggregateModel.
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.
GenericCommandResultMessage<R> - Class in org.axonframework.commandhandling
Generic implementation of CommandResultMessage.
GenericCommandResultMessage(R) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
Creates a Command Result Message with the given commandResult as the payload.
GenericCommandResultMessage(Throwable) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
Creates a Command Result Message with the given exception.
GenericCommandResultMessage(R, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
Creates a Command Result Message with the given commandResult as the payload and metaData as the meta data.
GenericCommandResultMessage(Throwable, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
Creates a Command Result Message with the given exception and metaData.
GenericCommandResultMessage(Message<R>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
Creates a new Command Result Message with given delegate message.
GenericCommandResultMessage(Message<R>, Throwable) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
Creates a Command Result Message with given delegate message and exception.
GenericDeadlineMessage<T> - Class in org.axonframework.deadline
Generic implementation of the DeadlineMessage.
GenericDeadlineMessage(String) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
Instantiate a GenericDeadlineMessage with the given deadlineName, a null payload and en empty MetaData.
GenericDeadlineMessage(String, T) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
Instantiate a GenericDeadlineMessage with the given deadlineName, a payload of type T and en empty MetaData.
GenericDeadlineMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
Instantiate a GenericDeadlineMessage with the given deadlineName, a payload of type T and the given metaData.
GenericDeadlineMessage(String, String, T, Map<String, ?>, Instant) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
Constructor to reconstructs a DeadlineMessage using existing data.
GenericDeadlineMessage(String, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
Constructor to reconstruct a DeadlineMessage using existing data.
GenericDomainEventEntry<T> - Class in org.axonframework.eventhandling
Generic implementation of a serialized domain event entry.
GenericDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventhandling.GenericDomainEventEntry
Reconstruct an event entry from a stored object.
GenericDomainEventMessage<T> - Class in org.axonframework.eventhandling
Generic implementation of a DomainEventMessage.
GenericDomainEventMessage(String, String, long, T) - Constructor for class org.axonframework.eventhandling.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.eventhandling.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.eventhandling.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate using existing data.
GenericDomainEventMessage(String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate using existing data.
GenericDomainEventMessage(String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.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.modelling.command
Generic repository implementation that stores JPA annotated aggregates.
GenericJpaRepository(GenericJpaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.command.GenericJpaRepository
Instantiate a GenericJpaRepository based on the fields contained in the GenericJpaRepository.Builder.
GenericJpaRepository.Builder<T> - Class in org.axonframework.modelling.command
Builder class to instantiate a GenericJpaRepository for aggregate type T.
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(Class<T>, 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.
GenericMessage(String, Class<T>, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
Constructor to reconstruct a Message using existing data.
GenericQueryMessage<T,R> - Class in org.axonframework.queryhandling
Generic implementation of the QueryMessage.
GenericQueryMessage(T, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
Initializes the message with the given payload and expected responseType.
GenericQueryMessage(T, String, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
Initializes the message with the given payload, queryName and expected responseType.
GenericQueryMessage(Message<T>, String, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
Initialize the Query Message, using given delegate as the carrier of payload and metadata and given queryName and expecting the given responseType.
GenericQueryResponseMessage<R> - Class in org.axonframework.queryhandling
QueryResponseMessage implementation that takes all properties as constructor parameters.
GenericQueryResponseMessage(R) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Initialize the response message with given result.
GenericQueryResponseMessage(Class<R>, R) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Initialize a response message with given result and declaredResultType.
GenericQueryResponseMessage(Class<R>, Throwable) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Initialize the response message with given declaredResultType and exception.
GenericQueryResponseMessage(R, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Initialize the response message with given result and metaData.
GenericQueryResponseMessage(Class<R>, R, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Initialize the response message with a specific declaredResultType, the given result as payload and metaData.
GenericQueryResponseMessage(Class<R>, Throwable, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Initialize the response message with given declaredResultType, exception and metaData.
GenericQueryResponseMessage(Message<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Copy-constructor that takes the payload, meta data and message identifier of the given delegate for this message.
GenericQueryResponseMessage(Message<R>, Throwable) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
Copy-constructor that takes the payload, meta data and message identifier of the given delegate for this message and given exception as a cause for the failure.
GenericResetContext<T> - Class in org.axonframework.eventhandling.replay
Generic implementation of the ResetContext.
GenericResetContext(T) - Constructor for class org.axonframework.eventhandling.replay.GenericResetContext
Instantiate a GenericResetContext containing the given payload and en empty MetaData instance.
GenericResetContext(T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.replay.GenericResetContext
Instantiate a GenericResetContext containing the given payload and MetaData.
GenericResetContext(Message<T>) - Constructor for class org.axonframework.eventhandling.replay.GenericResetContext
 
GenericResultMessage<R> - Class in org.axonframework.messaging
Generic implementation of ResultMessage.
GenericResultMessage(R) - Constructor for class org.axonframework.messaging.GenericResultMessage
Creates a ResultMessage with the given result as the payload.
GenericResultMessage(Throwable) - Constructor for class org.axonframework.messaging.GenericResultMessage
Creates a ResultMessage with the given exception.
GenericResultMessage(R, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericResultMessage
Creates a ResultMessage with the given result as the payload and metaData as the meta data.
GenericResultMessage(Throwable, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericResultMessage
Creates a ResultMessage with the given exception and metaData.
GenericResultMessage(Message<R>) - Constructor for class org.axonframework.messaging.GenericResultMessage
Creates a new ResultMessage with given delegate message.
GenericResultMessage(Message<R>, Throwable) - Constructor for class org.axonframework.messaging.GenericResultMessage
Creates a ResultMessage with given delegate message and exception.
GenericSagaSqlSchema - Class in org.axonframework.modelling.saga.repository.jdbc
Generic SagaSqlSchema implementation, for use in most databases.
GenericSagaSqlSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
Initialize a GenericSagaSqlSchema using default settings.
GenericSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
Initialize a GenericSagaSqlSchema.
genericSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the generic Serializer used to de-/serialize incoming and outgoing query ResponseType implementations.
GenericSubscriptionQueryMessage<Q,I,U> - Class in org.axonframework.queryhandling
Generic implementation of the SubscriptionQueryMessage.
GenericSubscriptionQueryMessage(Q, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
Initializes the message with the given payload, expected responseType and expected updateResponseType.
GenericSubscriptionQueryMessage(Q, String, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
Initializes the message with the given payload, queryName, expected responseType and expected updateResponseType.
GenericSubscriptionQueryMessage(Message<Q>, String, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
Initializes the message, using given delegate as the carrier of payload and metadata and given queryName, expected responseType and expected updateResponseType.
GenericSubscriptionQueryUpdateMessage<U> - Class in org.axonframework.queryhandling
Generic SubscriptionQueryUpdateMessage which holds incremental update of an subscription query.
GenericSubscriptionQueryUpdateMessage(U) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
Initializes GenericSubscriptionQueryUpdateMessage with incremental update.
GenericSubscriptionQueryUpdateMessage(Class<U>, U) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
Initializes GenericSubscriptionQueryUpdateMessage with incremental update of provided declaredType.
GenericSubscriptionQueryUpdateMessage(Class<U>, U, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
Initializes GenericSubscriptionQueryUpdateMessage with incremental update of provided declaredType and metaData.
GenericSubscriptionQueryUpdateMessage(Class<U>, Throwable, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
Initialize the subscription query update message with given declaredType, exception and metaData.
GenericSubscriptionQueryUpdateMessage(Message<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
Initializes a new decorator with given delegate message.
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
 
GenericTrackedDomainEventMessage<T> - Class in org.axonframework.eventhandling
Generic implementation of a DomainEventMessage that is also a TrackedEventMessage.
GenericTrackedDomainEventMessage(TrackingToken, DomainEventMessage<T>) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
Initialize a DomainEventMessage originating from an aggregate.
GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
Initialize a DomainEventMessage originating from an Aggregate using existing data.
GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.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(String, Case) - Method in class org.axonframework.axonserver.connector.DefaultHandlers
Deprecated.
 
get(String) - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
Retrieve the column information referring to the given name.
get(String, Case) - Method in interface org.axonframework.axonserver.connector.Handlers
Gets all handlers that match given context and requestCase.
get() - Method in class org.axonframework.axonserver.connector.util.GrpcMetaData
 
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(String) - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
Retrieves the value of the configuration element for the given key.
get(String) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
get(String) - Method in interface org.axonframework.messaging.HandlerAttributes
Retrieve the attribute for the given attributeKey.
get(Object) - Method in class org.axonframework.messaging.MetaData
 
get(String) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
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
 
get() - Method in class org.axonframework.util.MavenArtifactVersionResolver
Returns the specified jar version.
getActualVersion() - Method in exception org.axonframework.modelling.command.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
 
getAdapterInterfaces() - Method in class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
 
getAdditionalEntries() - Method in class org.axonframework.test.matchers.MapEntryMatcher
 
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 class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
 
getAggregateIdentifier() - Method in exception org.axonframework.disruptor.commandhandling.AggregateStateCorruptedException
Returns the identifier of the blacklisted aggregate.
getAggregateIdentifier() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Returns the identifier of the aggregate to recover.
getAggregateIdentifier() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
 
getAggregateIdentifier() - Method in interface org.axonframework.eventhandling.DomainEventData
Returns the Identifier of the Aggregate to which the Event was applied.
getAggregateIdentifier() - Method in interface org.axonframework.eventhandling.DomainEventMessage
Returns the identifier of the Aggregate that generated this DomainEvent.
getAggregateIdentifier() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
 
getAggregateIdentifier() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
 
getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
 
getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.AggregateNotFoundException
Returns the identifier of the aggregate that could not be found.
getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.AggregateRolledBackException
Returns the identifier of the compromised aggregate.
getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.ConflictingAggregateVersionException
Returns the identifier of the aggregate which version is not as expected.
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.modelling.command.inspection.AnnotatedAggregate
Get the annotated aggregate instance.
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.modelling.command.AbstractRepository
Returns the aggregate type stored by this repository.
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
 
getAll() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
getAll() - Method in interface org.axonframework.messaging.HandlerAttributes
Retrieve all attributes stored in this HandlerAttributes object.
getAll() - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
getAllHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Gets all handlers per type for inspected entity.
getAllInspectedTypes() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Returns a Set of all types which have been inspected for handlers.
getAllInterceptors() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Returns a Map of all registered interceptor methods per inspected type.
getAppliedEventPayloads() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
Returns the payloads of the Events applied while this lifecycle instance was active.
getAppliedEvents() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
Returns the list of applied Events for this lifecycle instance.
getAssociationValue() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
Returns the association value contained in this entry.
getAssociationValue(EventMessage<?>) - Method in class org.axonframework.modelling.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.modelling.saga.AnnotatedSaga
 
getAssociationValues() - Method in interface org.axonframework.modelling.saga.Saga
Returns a view on the Association Values for this saga instance.
getAutoConfiguration() - Method in class org.axonframework.springboot.MetricsProperties
Retrieves the AutoConfiguration settings for Metrics
getBatchSize() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
 
getBatchSize() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the maximum size of a processing batch.
getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.spring.config.annotation.SpringContextHandlerDefinitionBuilder
Create, if necessary, a bean definition for a HandlerDefinition and returns the reference to bean for use in other Bean Definitions.
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.springboot.DistributedCommandBusProperties.JGroupsProperties
Returns the Address to bind the JGroups client to.
getBindPort() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Returns the port to listen to JGroups connections (default 7800).
getCallback() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Returns the CommandCallback instance for the executed command.
getCertFile() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getChannel() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Deprecated.
getChannel(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Deprecated.
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.
getClientId() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getClusterName() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Returns the Cluster Name of the JGroups Cluster to connect with (defaults to "Axon").
getCode() - Method in exception org.axonframework.axonserver.connector.event.util.EventStoreClientException
Deprecated.
Returns the error code of this exception.
getColumns() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
The list of columns returned by the query.
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.
getCommandBus() - Method in interface org.axonframework.test.saga.FixtureConfiguration
Returns the command bus used by this fixture.
getCommandBus() - Method in class org.axonframework.test.saga.SagaTestFixture
 
getCommandFilter() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
Returns this member's filter describing the commands it supports
getCommandFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.
getCommandLoadFactor() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getCommandMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the CommandMessage wrapped in this Message.
getCommandName() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
 
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
 
getCommandResultMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns a CommandResultMessage containg the result of command processing.
getCommandThreads() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getCommitTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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
 
getComponentName() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.
getConfig() - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
Returns the properties contained in this token as a Map.
getConfigurationFile() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Returns the path to the configuration file to use to configure the Groups instance.
getConfigurationPhase() - Method in class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
 
getConflictResolver() - Static method in class org.axonframework.eventsourcing.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 class org.axonframework.axonserver.connector.AxonServerConnectionManager
Retrieves the AxonServerConnection used for the default context of this application.
getConnection(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Retrieves the AxonServerConnection used for the given context of this application.
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
 
getConnectTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getContentType() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
 
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
 
getContext() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getConverter() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
 
getConverter() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Returns the Converter used by this serialized.
getConverter() - Method in class org.axonframework.serialization.JavaSerializer
Deprecated.
 
getConverter() - Method in class org.axonframework.serialization.json.JacksonSerializer
 
getConverter() - Method in interface org.axonframework.serialization.Serializer
Returns the Converter used by this Serializer to convert between serialized representations.
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.
getCounter() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
Retrieve the counter used to differentiate two deadlines scheduled at the same time.
getCreationPolicy() - Method in class org.axonframework.modelling.saga.SagaInitializationPolicy
Returns the creation policy
getCreationPolicy() - Method in class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
Returns the creation policy of the inspected method.
getCurrentDateTime() - Method in class org.axonframework.test.deadline.StubDeadlineManager
Return the current date and time as an Instant as is being used by this DeadlineManager.
getCurrentDateTime() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Returns the "Current Date Time" as used by the scheduler.
getCurrentPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Return the estimated relative current token position this Segment represents.
getCurrentPosition() - Method in class org.axonframework.eventhandling.TrackerStatus
 
getCurrentPosition() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
getCurrentScope() - Static method in class org.axonframework.messaging.Scope
Retrieve the current Scope.
getCurrentToken() - Method in class org.axonframework.eventhandling.ReplayToken
Gets the current token.
getData() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
 
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
 
getDeadlineName() - Method in interface org.axonframework.deadline.DeadlineMessage
Retrieve a String representing the name of this DeadlineMessage.
getDeadlineName() - Method in class org.axonframework.deadline.GenericDeadlineMessage
 
getDeadlineName() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
Retrieve a String denoting the name of the deadline; can be used together with the scheduleId to cancel the deadline.
getDeadlineScope() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
Retrieve a description of the Scope in which the deadline is scheduled.
getDeadlinesMet() - Method in class org.axonframework.test.deadline.StubDeadlineManager
Return all deadlines which have been met.
getDefaultContext() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Returns the name of the default context of this application.
getDefaultCorrelationKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
Returns the default metadata key for the correlation id of a message.
getDefaultFlowControlConfiguration() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.MultiHandlerDefinition
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
getDelegates() - Method in class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
getDelegates() - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
getDescriptions() - Method in class org.axonframework.messaging.RemoteExceptionDescription
Returns the List of Strings describing the causes of the exception on the remote end.
getDetails() - Method in exception org.axonframework.messaging.HandlerExecutionException
Returns an Optional containing application-specific details of the exception, if any were provided.
getDispatchedCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
Returns a list with all commands that have been dispatched by this command bus.
getDomainEventData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Extracts the next domain event entry from the given resultSet.
getEligibleMembers(String) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the collection of nodes, represented as ConsistentHash.ConsistentHashMember, in the order they would be considered for the given routing key.
getEntityManager() - Method in interface org.axonframework.common.jpa.EntityManagerProvider
Returns the EntityManager instance to use.
getEntityManager() - Method in class org.axonframework.common.jpa.SimpleEntityManagerProvider
 
getEntityManager() - Method in class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
 
getError() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Returns the exception that caused processing to fail, if present.
getError() - Method in class org.axonframework.eventhandling.TrackerStatus
 
getError() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
getErrorCode() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
Returns the error code as reported by the server.
getErrorCode() - Method in exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
Returns the error code as reported by the server.
getErrorCode() - Method in exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
Return a String defining the error code.
getEvent() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
The Event scheduled for publication.
getEvent() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
 
getEventAvailabilityTimeout() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
 
getEventBus() - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
Returns the EventBus used by this EventGateway.
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.
getEventBus() - Method in interface org.axonframework.test.saga.FixtureConfiguration
Returns the event bus used by this fixture.
getEventBus() - Method in class org.axonframework.test.saga.SagaTestFixture
 
getEventCipher() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getEventFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getEventIdentifier() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
 
getEventIdentifier() - Method in class org.axonframework.eventhandling.AbstractEventEntry
 
getEventIdentifier() - Method in interface org.axonframework.eventhandling.EventData
Returns the identifier of the serialized event.
getEventIdentifier() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
 
getEvents() - Method in class org.axonframework.springboot.SerializerProperties
The type of serializer to use to serialize the payload and meta data of Event Messages.
getEventSerializer() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Get the serializer used by this storage engine when storing and retrieving events.
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.
getEventTrackerStatusChangeListener() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Returns the EventTrackerStatusChangeListener defined in this configuration, to be called whenever an EventTrackerStatus change occurs.
getExactSuperType(Type, Class<?>) - Static method in class org.axonframework.common.TypeReflectionUtils
Finds the most specific supertype of type whose erasure is searchClass.
getExceptionDescriptions() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
Returns a List of Strings describing the remote exception.
getExceptionDescriptions() - Method in exception org.axonframework.messaging.RemoteHandlingException
Returns a List of Strings describing the remote exception.
getExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
Get the execution result in case the result is an exception.
getExceptionRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the exception revision of the serialized reply message.
getExceptionType() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the exception type of the serialized reply message.
getExecutionResult() - Method in class org.axonframework.disruptor.commandhandling.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.eventsourcing.AbstractSnapshotter
Returns the executor that executes snapshot taking tasks.
getExpectedResponseType() - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
getExpectedResponseType() - Method in interface org.axonframework.messaging.responsetypes.ResponseType
Gets actual response type or generic placeholder.
getExpectedVersion() - Method in exception org.axonframework.modelling.command.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.
getFallbackUrl() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
Returns the URL relative to the host's root to retrieve Instance Meta Data from.
getFieldValue(Field, Object) - Static method in class org.axonframework.common.ReflectionUtils
Returns the value of the given field in the given object.
getFor(String) - Method in interface org.axonframework.axonserver.connector.command.CommandLoadFactorProvider
Returns the load factor value for the specific command
getFromCode(String) - Static method in enum org.axonframework.axonserver.connector.ErrorCode
 
getGaps() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
Get a SortedSet of this token's gaps.
getGeneral() - Method in class org.axonframework.springboot.SerializerProperties
The type of serializer to use to serialize any type of object, for which no more specific serializer is configured.
getGlobalIndex() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
Get the global sequence number of the event
getGossip() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Returns the DistributedCommandBusProperties.JGroupsProperties.Gossip configuration in case the Gossip protocol is configured for JGroups (default).
getGroupIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Returns the Quartz group identifier.
getHandlerEnhancerDefinition() - Method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
Returns handler enhancer definition used to wrap handlers.
getHandlerInterceptors() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
 
getHandlerInterceptors() - Method in interface org.axonframework.eventhandling.EventProcessor
Return the list of already registered MessageHandlerInterceptors for this event processor.
getHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
getHandlers(Class<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Returns a list of detected members of given type that are capable of handling certain messages.
getHeartbeat() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getHosts() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
Returns the host names and ports of the DistributedCommandBusProperties.JGroupsProperties.Gossip Routers to connect to.
getId() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
The unique identifier of this entry.
getIdentifier() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
 
getIdentifier() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
getIdentifier() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
getIdentifier() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
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
 
getIdentifier() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
getIdentifier() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
The identifier of the Aggregate targeted with this scope
getIdentifier(T) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Get the identifier of the given target entity.
getIdentifier() - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
Returns the identifier of the targeted Aggregate.
getIdentifier() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
The identifier of the Saga targeted with this scope
getIdentifiers() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
Returns the identifiers that uniquely identify this result entry.
getIndex() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
Get the highest global sequence of events seen up until the point of this tracking token.
getInitialAssociationValue() - Method in class org.axonframework.modelling.saga.SagaInitializationPolicy
Returns the initial association value for a newly created saga.
getInitialNrOfPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
 
getInitialNrOfPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getInitialSegmentCount() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the number of initial segments that should be created, if no segments are already present.
getInitialSegmentsCount() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
 
getInitialTrackingToken() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
 
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.modelling.command.AggregateLifecycle
Get the current AggregateLifecycle instance for the current thread.
getInstance() - Static method in class org.axonframework.modelling.saga.SagaLifecycle
Get the current SagaLifecycle instance for the current thread.
getInternalTrackingToken() - Method in class org.axonframework.eventhandling.TrackerStatus
Return the TrackingToken this EventTrackerStatus portrays the status of.
getInterval() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
 
getInvocationInterceptorChain() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Returns the InterceptorChain for the invocation process registered with this entry, or null if none is available.
getInvokerId() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Returns the Identifier of the invoker that is chosen to handle this entry.
getIsLive() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
getIsLive() - Method in class org.axonframework.modelling.command.AggregateLifecycle
Indicates whether this Aggregate instance is 'live'.
getIsLive() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
getIsLive() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
 
getJgroups() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Returns the JGroups configuration to use (if JGroups is on the classpath).
getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
Returns the Quartz job identifier.
getKeepAliveTime() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getKeepAliveTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getKey() - Method in class org.axonframework.modelling.saga.AssociationValue
Returns the key of this association value.
getLastSeparator() - Method in class org.axonframework.test.matchers.ListMatcher
The separator to use between the two last events.
getLastSeparator() - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
 
getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
 
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.FilteringDomainEventStream
 
getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
getListenerInvocationErrorHandler() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
getLoadFactor() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Returns the current load factor of this node.
getLoadFactor() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Returns the load factor for this instance of the Distributed Command Bus (default 100).
getMask() - Method in class org.axonframework.eventhandling.Segment
Getter for the segment mask.
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.
getMatchOutcome(ConditionContext, AnnotatedTypeMetadata) - Method in class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
 
getMaxGrpcBufferedMessages() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getMaxMessageSize() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getMaxThreadCount() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
 
getMeasurements() - Method in class org.axonframework.micrometer.reservoir.SlidingTimeWindowReservoir
Retrieve the measurements
getMember(String, CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the member instance to which the given message should be routed.
getMemberGenericString(Member) - Static method in class org.axonframework.common.ReflectionUtils
Returns the generic string of the given member.
getMemberGenericType(Member) - Static method in class org.axonframework.common.ReflectionUtils
Returns the generic type of value of the given member, either by returning the generic type of Field or generic return type of a Method.
getMembers() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the set of members registered with this consistent hash instance.
getMemberValue(Member, Object) - Static method in class org.axonframework.common.ReflectionUtils
Returns the value of the given member in the given object, either by returning Field value or invoking the method.
getMemberValueType(Member) - Static method in class org.axonframework.common.ReflectionUtils
Returns the type of value of the given member, either by returning the type of Field or type of the return value of a Method.
getMessage() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
Returns the command message that was sent.
getMessage() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
 
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
 
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.
getMessages() - Method in class org.axonframework.springboot.SerializerProperties
The type of serializer to use to serialize the payload and meta data of Messages.
getMessageSource() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
Returns the message source from which this processor receives its events
getMessageSource() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Returns the StreamableMessageSource this processor is using
getMetaData() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
 
getMetaData() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
Returns the serialized data of the MetaData of the serialized Event.
getMetaData() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
getMetaData() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
getMetaData() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
getMetaData() - Method in class org.axonframework.domain.GenericMessage
Deprecated.
Get the message's metadata.
getMetaData() - Method in class org.axonframework.eventhandling.AbstractEventEntry
 
getMetaData() - Method in interface org.axonframework.eventhandling.EventData
Returns the serialized data of the MetaData of the serialized Event.
getMetaData() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
 
getMetaData() - Method in class org.axonframework.messaging.GenericMessage
 
getMetaData() - Method in interface org.axonframework.messaging.Message
Returns the meta data for this message.
getMetaData() - Method in class org.axonframework.messaging.MessageDecorator
 
getMetaData() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
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
 
getMicrometer() - Method in class org.axonframework.springboot.MetricsProperties
Retrieves the Micrometer specific settings for Metrics
getMissingEntries() - Method in class org.axonframework.test.matchers.MapEntryMatcher
 
getMode() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the type of processor to configure.
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 interface org.axonframework.serialization.SerializedType
Returns the name of the serialized type.
getName() - Method in class org.axonframework.serialization.SimpleSerializedType
 
getNewPermitsThreshold() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
 
getNewPermitsThreshold() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.
getNrOfNewPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
 
getNrOfNewPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
De-serializes the object and returns the result.
getObject() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
 
getObject() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
 
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.ConfigurerFactoryBean
 
getObject() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
 
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.config.annotation.SpringHandlerDefinitionBean
 
getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
 
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.ConfigurerFactoryBean
 
getObjectType() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
 
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(String, Case, Collection<Handler>) - Method in interface org.axonframework.axonserver.connector.Handlers
The same as Handlers.get(String, Object) but if no handler is found it returns provided def collection of handlers.
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.
getOrDefault(I, Function<I, T>, T) - Static method in class org.axonframework.common.ObjectUtils
Returns the result of the given valueProvider by ingesting the given instance, if the instance is not null.
getOrDefaultResource(String, R) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns the resource attached under given name.
getOriginServer() - Method in exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
Returns the name of the server that reported the error.
getOverflowStrategy() - Method in class org.axonframework.queryhandling.SubscriptionQueryBackpressure
Deprecated.
Gets the overflow strategy.
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.axonserver.connector.command.GrpcBackedCommandMessage
 
getPayload() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
 
getPayload() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
getPayload() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
getPayload() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
getPayload() - Method in class org.axonframework.domain.GenericMessage
Deprecated.
Get the payload of this message.
getPayload() - Method in class org.axonframework.eventhandling.AbstractEventEntry
 
getPayload() - Method in interface org.axonframework.eventhandling.EventData
Returns the serialized data of the Event Message's payload.
getPayload() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
 
getPayload() - Method in class org.axonframework.messaging.GenericMessage
 
getPayload() - Method in class org.axonframework.messaging.GenericResultMessage
 
getPayload() - Method in interface org.axonframework.messaging.Message
Returns the payload of this message.
getPayload() - Method in class org.axonframework.messaging.MessageDecorator
 
getPayload() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
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.
getPayloadRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the payload revision of the serialized reply message.
getPayloadType() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
 
getPayloadType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
getPayloadType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
getPayloadType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
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.commandhandling.distributed.ReplyMessage
Returns the payload type of the serialized reply message.
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.messaging.responsetypes.ConvertingResponseMessage
 
getPayloadType() - Method in class org.axonframework.serialization.SerializedMessage
 
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.QueryHandlerSubscriber
 
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
 
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.springboot.EventProcessorProperties
Returns the settings for each of the configured processors, by name.
getProcessorsNotificationInitialDelay() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getProcessorsNotificationRate() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.disruptor.commandhandling.CommandHandlingEntry
Returns the Identifier of the publisher that is chosen to handle this entry.
getPublisherInterceptorChain() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Returns the InterceptorChain for the publication process registered with this entry, or null if none is available.
getQueryFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getQueryName() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
getQueryName() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
getQueryName() - Method in interface org.axonframework.queryhandling.annotation.QueryHandlingMember
Returns the name of the query the handler can handle
getQueryName() - Method in class org.axonframework.queryhandling.GenericQueryMessage
 
getQueryName() - Method in interface org.axonframework.queryhandling.QueryMessage
Returns the name identifying the query to be executed.
getQueryResultEntry() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
Returns the wrapped entry as returned by the AxonServer Java Connector.
getQueryThreads() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getReader(Class<?>) - Method in class org.axonframework.serialization.json.JacksonSerializer
Provides the ObjectReader, with which objects are read from the JSON form.
getRegistration() - Method in class org.axonframework.queryhandling.UpdateHandlerRegistration
Gets the registration.
getRegistry() - Method in class org.axonframework.metrics.GlobalMetricRegistry
Returns the global MetricRegistry to which components are registered.
getRegistry() - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Returns the global MeterRegistry to which components are registered.
getRemainingOfDeadline(long) - Static method in class org.axonframework.common.ObjectUtils
Gets number of millis which are remaining of current deadline to be reached by System.currentTimeMillis().
getRepository(Class<?>) - Static method in class org.axonframework.disruptor.commandhandling.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.
getRequestStream() - Method in class org.axonframework.axonserver.connector.util.UpstreamAwareStreamObserver
Returns the request stream observer which allows interaction with the client stream.
getResetPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Return the relative position at which a reset was triggered for this Segment.
getResetPosition() - Method in class org.axonframework.eventhandling.TrackerStatus
 
getResetPosition() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
getResolver() - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
 
getResolver() - Method in class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory
 
getResolver() - Method in class org.axonframework.eventhandling.TimestampParameterResolverFactory
 
getResolver() - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
 
getResolver() - Method in class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
 
getResolver() - Method in class org.axonframework.messaging.annotation.SourceIdParameterResolverFactory
 
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.
getResponseType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
getResponseType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
getResponseType() - Method in class org.axonframework.queryhandling.GenericQueryMessage
 
getResponseType() - Method in interface org.axonframework.queryhandling.QueryMessage
The type of response expected by the sender of the query
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.disruptor.commandhandling.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
Return the execution result message.
getResultType() - Method in interface org.axonframework.queryhandling.annotation.QueryHandlingMember
Returns the return type declared by the handler
getRevision() - Method in class org.axonframework.modelling.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.
getRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
 
getRoutingKey(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.RoutingStrategy
Generates a routing key for the given command.
getRoutingKey(CommandMessage<?>) - Method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
 
getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
Returns the Saga Initialization Policy for a Saga of the given sagaType and event.
getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager
 
getSagaId() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
Returns the identifier of the saga contained in this entry
getSagaIdentifier() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
 
getSagaIdentifier() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
Returns the Saga Identifier contained in this entry.
getSagaIdentifier() - Method in interface org.axonframework.modelling.saga.Saga
Returns the unique identifier of this saga.
getSagaIdentifier() - Method in class org.axonframework.modelling.saga.SagaLifecycle
Retrieve a String denoting the identifier of this Saga.
getSagaType() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
Returns the class of Saga managed by this SagaManager
getSagaType() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
Returns the type identifier of the serialized saga
getSagaType() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
Returns the type (fully qualified class name) of the Saga this association value belongs to
getScheduledDeadlines() - Method in class org.axonframework.test.deadline.StubDeadlineManager
Return all scheduled deadlines which have not been met (yet).
getScheduledItems() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Returns a view of all the scheduled Events at the time this method is called.
getScheduleId() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
Retrieve a String identifier representing the scheduled deadline; can be used together with the deadlineName to cancel the deadline.
getScheduleTime() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
Retrieve the time as an Instant at which the deadline is scheduled.
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 interface org.axonframework.eventhandling.EventTrackerStatus
The segment for which this status is valid.
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
 
getSegment() - Method in class org.axonframework.eventhandling.TrackerStatus
 
getSegment() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
getSegmentId() - Method in class org.axonframework.eventhandling.Segment
Getter for the segment identifier.
getSequenceIdentifierFor(EventMessage<?>) - Method in class org.axonframework.eventhandling.async.FullConcurrencyPolicy
 
getSequenceIdentifierFor(EventMessage) - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy
 
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 class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
 
getSequenceNumber() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
 
getSequenceNumber() - Method in interface org.axonframework.eventhandling.DomainEventData
Returns the sequence number of the event in the aggregate.
getSequenceNumber() - Method in interface org.axonframework.eventhandling.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.eventhandling.GenericDomainEventMessage
 
getSequenceNumber() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
 
getSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
 
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
 
getSequencingPolicy() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
getSequencingPolicy() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the name of the bean that defines the SequencingPolicy for this processor.
getSerializedException() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the serialized exception of the serialized reply message.
getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
Returns the serialized metadata of the command carried by this instance.
getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the serialized meta data of the serialized reply message.
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.
getSerializedPayload() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
Returns the serialized payload of the serialized reply message.
getSerializedSaga() - Method in class org.axonframework.modelling.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.serialization.LazyDeserializingObject
Returns the serializer to deserialize this object
getServer() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
Returns the name of the server that reported the error.
getServer() - Method in exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
Return a String defining the location where the error originated.
getServers() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getSnapshotData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Extracts the next snapshot entry from the given resultSet.
getSnapshotPrefetch() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getSnapshotSerializer() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Get the serializer used by this storage engine when storing and retrieving snapshots.
getSnapshotTrigger() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
The trigger instance that monitors this aggregate to trigger a snapshot
getSortValues() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
Returns the list of values to use to compare the order of this entry to other entries.
getSource() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the name of the bean that should be used as source for Event Messages.
getSpringCloud() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Returns the Spring Cloud configuration to use (if Spring Cloud is on the classpath).
getState() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Get the state of the event processor.
getSubscriptions() - Method in class org.axonframework.queryhandling.SimpleQueryBus
Returns the subscriptions for this query bus.
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.
getSuppressDownloadMessage() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getTags() - Method in class org.axonframework.config.TagsConfiguration
Gets tags.
getTags() - Method in class org.axonframework.springboot.TagsConfigurationProperties
Gets tags.
getTargetType() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
 
getTargetType() - Method in interface org.axonframework.messaging.MessageHandler
Returns the instance type that this handler delegates 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
 
getThreadCount() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the number of threads to use to process Events, when using a StreamingEventProcessor implementation.
getThreadFactory(String) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Provides the ThreadFactory to use to construct Threads for the processor with given processorName
getTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
 
getTimestamp() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
 
getTimestamp() - Method in class org.axonframework.eventhandling.AbstractEventEntry
 
getTimestamp() - Method in interface org.axonframework.eventhandling.EventData
Returns the timestamp at which the event was first created.
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.eventhandling.TrackedDomainEventData
 
getTimestamp() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
Deprecated.
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() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
getToken(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the token, deserializing it with given serializer
getTokenAtReset(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
Return the relative position at which a reset was triggered for this Segment.
getTokenAtReset() - Method in class org.axonframework.eventhandling.ReplayToken
Gets the token representing the position at which the reset was triggered.
getTokenClaimInterval() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Returns the time, in milliseconds, the processor should wait after a failed attempt to claim any segments for processing.
getTokenClaimInterval() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the interval between attempts to claim tokens by a StreamingEventProcessor.
getTokenClaimIntervalTimeUnit() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Returns the time unit used to define tokens claim interval.
getTokenForStream(String) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
Return the tracking token for an individual stream
getTokenId() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
Returns the identifier of the scheduled task.
getTokenStoreIdentifier() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
getTokenStoreIdentifier() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Returns the unique identifier of the TokenStore used by this StreamingEventProcessor.
getTokenStoreIdentifier() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
getTokenType() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
Returns the SerializedType of the serialized token, or null if no token is stored by this entry.
getTrackedEventData(ResultSet, GapAwareTrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Extracts the next tracked event entry from the given resultSet.
getTrackedEvents() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
Deprecated.
Gets tracked events.
getTrackingToken() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
The tracking token of the last event that has been seen by this Segment.
getTrackingToken() - Method in class org.axonframework.eventhandling.TrackerStatus
 
getTrackingToken() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
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
 
getTrackingTokens() - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
Returns the map containing the constituent tokens.
getType() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
 
getType() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
 
getType() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
 
getType() - Method in interface org.axonframework.eventhandling.DomainEventData
Returns the type identifier of the aggregate.
getType() - Method in interface org.axonframework.eventhandling.DomainEventMessage
Returns the type of the Aggregate that generated this DomainEvent.
getType() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
 
getType() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
 
getType() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
 
getType() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
Returns the type of Aggregate, as String, targeted by this scope
getType() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
The type of Saga described by this scope
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
 
getUpcasters() - Method in class org.axonframework.serialization.upcasting.GenericUpcasterChain
Returns the list of upcasters that makes up this chain.
getUpdateResponseType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
getUpdateResponseType() - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
 
getUpdateResponseType() - Method in interface org.axonframework.queryhandling.SubscriptionQueryMessage
Returns the type of incremental responses.
getUpdates() - Method in class org.axonframework.queryhandling.UpdateHandlerRegistration
Gets the updates.
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.modelling.saga.AssociationValue
Returns the value of this association.
getValues() - Method in class org.axonframework.domain.MetaData
Deprecated.
Get this metadata's mappings.
getVersion() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
Gets the version of the aggregate.
getVersion(T) - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
Get the current version number of the given aggregate.
getVersion() - Method in class org.axonframework.modelling.command.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.
getWrappedAggregate() - Method in class org.axonframework.modelling.command.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.
givenCurrentTime(Instant) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
givenCurrentTime(Instant) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start of the given state.
givenCurrentTime(Instant) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start of the given state.
givenCurrentTime(Instant) - Method in class org.axonframework.test.saga.SagaTestFixture
 
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
 
givenState(Supplier<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
givenState(Supplier<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Sets the aggregate instance as supplied by given aggregateState as the initial state for a test case.
globalIndexColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the global index column.
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.
GlobalMetricRegistry - Class in org.axonframework.micrometer
Registry for application metrics with convenient ways to register Axon components.
GlobalMetricRegistry() - Constructor for class org.axonframework.micrometer.GlobalMetricRegistry
Initializes a new GlobalMetricRegistry delegating to a new MeterRegistry with default settings.
GlobalMetricRegistry(MeterRegistry) - Constructor for class org.axonframework.micrometer.GlobalMetricRegistry
Initializes a GlobalMetricRegistry delegating to the given meterRegistry.
globalMetricRegistry(MetricRegistry) - Static method in class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
 
globalMetricRegistry(MeterRegistry) - Static method in class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
 
GlobalSequenceTrackingToken - Class in org.axonframework.eventhandling
Tracking token based on the global sequence number of an event.
GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventhandling.GlobalSequenceTrackingToken
Initializes a GlobalSequenceTrackingToken from the given globalIndex of the event.
GlobalSequenceTrackingToken - Class in org.axonframework.eventsourcing.eventstore
Deprecated.
GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
Deprecated.
Initializes a GlobalSequenceTrackingToken from the given globalIndex of the event.
Gossip() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
 
GrpcBackedCommandMessage<C> - Class in org.axonframework.axonserver.connector.command
Wrapper that allows clients to access a gRPC Command as a CommandMessage.
GrpcBackedCommandMessage(Command, Serializer) - Constructor for class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
Instantiate a GrpcBackedCommandMessage with the given command and using the provided Serializer to be able to retrieve the payload and MetaData from it.
GrpcBackedDomainEventData - Class in org.axonframework.axonserver.connector.event.axon
DomainEventData implementation that retrieves its raw data from a protobuf Event message.
GrpcBackedDomainEventData(Event) - Constructor for class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
Initialize using the given event as the source of raw data.
GrpcBackedQueryMessage<Q,R> - Class in org.axonframework.axonserver.connector.query
Wrapper that allows clients to access a gRPC QueryRequest as a QueryMessage.
GrpcBackedQueryMessage(QueryRequest, Serializer, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
Instantiate a GrpcBackedResponseMessage with the given queryRequest, using the provided messageSerializer to be able to retrieve the payload and MetaData from it.
GrpcBackedResponseMessage<R> - Class in org.axonframework.axonserver.connector.query
Wrapper that allows clients to access a gRPC QueryResponse as a QueryResponseMessage.
GrpcBackedResponseMessage(QueryResponse, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
Instantiate a GrpcBackedResponseMessage with the given queryResponse, using the provided Serializer to be able to retrieve the payload and MetaData from it.
GrpcBackedSubscriptionQueryMessage<Q,I,U> - Class in org.axonframework.axonserver.connector.query.subscription
Wrapper that allows clients to access a gRPC SubscriptionQuery message as a SubscriptionQueryMessage.
GrpcBackedSubscriptionQueryMessage(SubscriptionQuery, Serializer, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
Instantiate a GrpcBackedSubscriptionQueryMessage with the given subscriptionQuery, using the provided messageSerializer to be able to retrieve the payload and MetaData from it.
GrpcBufferingInterceptor - Class in org.axonframework.axonserver.connector.util
Deprecated.
in through use of the AxonServer java connector
GrpcBufferingInterceptor(int) - Constructor for class org.axonframework.axonserver.connector.util.GrpcBufferingInterceptor
Deprecated.
Initialize the interceptor to ask for additionalBuffer amount of messages from the server.
GrpcExceptionParser - Class in org.axonframework.axonserver.connector.event.util
Converts GRPC Exceptions to RuntimeExceptions.
GrpcExceptionParser() - Constructor for class org.axonframework.axonserver.connector.event.util.GrpcExceptionParser
 
GrpcHeartbeatSource - Class in org.axonframework.axonserver.connector.heartbeat.source
Deprecated.
in through use of the AxonServer java connector
GrpcHeartbeatSource(AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.heartbeat.source.GrpcHeartbeatSource
Deprecated.
Creates a GrpcHeartbeatSource which uses an AxonServerConnectionManager to send heartbeats messages to AxonServer.
GrpcMetaData - Class in org.axonframework.axonserver.connector.util
Implementation that provides access to a Map of gRPC MetaDataValues in the form of MetaData.
GrpcMetaData(Map<String, MetaDataValue>, Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetaData
Instantiate a wrapper around the given metaDataValues providing access to them as a MetaData object.
GrpcMetaDataAwareSerializer - Class in org.axonframework.axonserver.connector.event.axon
Wrapper around standard Axon Framework serializer that can deserialize Metadata from AxonServer events.
GrpcMetaDataAwareSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
Constructs a GrpcMetaDataAwareSerializer, using the given delegate to delegate serialization to
GrpcMetaDataConverter - Class in org.axonframework.axonserver.connector.util
Utility class for converting gRPC MetaData entries into a Java Map and vice versa.
GrpcMetaDataConverter(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
Initialize the converter, using the given serializer to serialize Objects.
GrpcMetadataSerializer - Class in org.axonframework.axonserver.connector.util
Mapping that translates a MetaData into a map of GRPC MetaDataValue.
GrpcMetadataSerializer(GrpcMetaDataConverter) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetadataSerializer
Constructs a GrpcMetadataSerializer using the given metaDataConverter.
GrpcObjectSerializer<O> - Class in org.axonframework.axonserver.connector.util
Mapping that translates an object into a GRPC SerializedObject.
GrpcObjectSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcObjectSerializer
Constructs a GrpcObjectSerializer using the given serializer to serialize the payload and type of given objects with.
GrpcObjectSerializer.Serializer<A> - Interface in org.axonframework.axonserver.connector.util
Contract towards serializing an object of type A.
GrpcPayloadSerializer - Class in org.axonframework.axonserver.connector.util
Mapping that translates a Message into a GRPC SerializedObject.
GrpcPayloadSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcPayloadSerializer
Constructs a GrpcPayloadSerializer using the given serializer to serialize messages with
GrpcSerializedObject - Class in org.axonframework.axonserver.connector.util
Wrapper that allows clients to access a gRPC SerializedObject message as a SerializedObject.
GrpcSerializedObject(SerializedObject) - Constructor for class org.axonframework.axonserver.connector.util.GrpcSerializedObject
Initialize a GrpcSerializedObject, wrapping a SerializedObject as a SerializedObject.

H

handle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
Invokes the @CommandHandler annotated method that accepts the given command.
handle(CommandMessage<C>, MessageHandler<? super CommandMessage<?>>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
 
handle(CommandMessage<C>, MessageHandler<? super CommandMessage<?>>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Performs the actual handling logic.
handle(EventMessage<?>) - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
 
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<?>, Segment) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
Handle the given message for the given segment.
handle(EventMessage<?>) - Method in interface org.axonframework.eventhandling.EventMessageHandler
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<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
 
handle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
 
handle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
handle(Message<?>, T) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
handle(Message<?>, T, MessageHandlingMember<? super T>) - Method in interface org.axonframework.messaging.annotation.MessageHandlerInterceptorMemberChain
Handle the given message by passing it through the interceptors and ultimately to the given handler on the given target instance.
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<? extends T>) - Method in class org.axonframework.messaging.interceptors.BeanValidationInterceptor
 
handle(UnitOfWork<? extends T>, InterceptorChain) - Method in class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
 
handle(List<? extends T>) - Method in class org.axonframework.messaging.interceptors.LoggingInterceptor
 
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<? extends 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(Message<?>) - Method in interface org.axonframework.modelling.command.Aggregate
Handle the given message on the aggregate root or one of its child entities.
handle(CommandMessage<?>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
 
handle(Message<?>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
handle(UnitOfWork<? extends CommandMessage<?>>, InterceptorChain) - Method in class org.axonframework.modelling.command.inspection.AnnotatedCommandHandlerInterceptor
 
handle(Message<?>, P) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
handle(Message<?>) - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
handle(EventMessage<?>, Segment) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
 
handle(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
 
handle(Message<?>, T) - Method in class org.axonframework.modelling.saga.EndSagaMessageHandlerDefinition.EndSageMessageHandlingMember
 
handle(Message<?>, T) - Method in class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
 
handle(QueryMessage<?, ?>) - Method in class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
 
handle(Consumer<? super I>, Consumer<? super U>) - Method in interface org.axonframework.queryhandling.SubscriptionQueryResult
Delegates handling of initial result and incremental updates to the provided consumers.
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
 
handleDeadline(ScopeDescriptor, DeadlineMessage<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
Handles the given deadlineMessage in the aggregate described by the given aggregateDescriptor.
handleDeadline(ScopeDescriptor, DeadlineMessage<?>) - Method in class org.axonframework.test.saga.SagaTestFixture
Handles the given deadlineMessage in the saga described by the given sagaDescriptor.
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.
HANDLER_INTERCEPTORS - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
The key under which the MessageHandlerInterceptors are stored within the SchedulerContext.
HandlerAttributes - Interface in org.axonframework.messaging
Container for message handler attributes.
HandlerComparator - Class in org.axonframework.messaging.annotation
Comparator used by AnnotatedHandlerInspector to sort MessageHandlingMember entity members.
handlerDefinition(Class<?>) - Method in interface org.axonframework.config.Configuration
Returns the Handler Definition defined in this Configuration for the given inspectedType.
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Sets the HandlerDefinition used to create concrete handlers in the annotated handlers in the AnnotationEventHandlerAdapter this EventHandlerInvoker instantiates.
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Sets the HandlerDefinition used to create concrete handlers in the snapshot aggregate this snapshotter creates.
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
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.
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
Sets the HandlerDefinition used to create concrete handlers for the given aggregateType.
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Sets the HandlerDefinition used to create concrete handlers for the given aggregateType.
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
 
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
 
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
Sets the HandlerDefinition used to create concrete handlers for the given sagaType.
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Sets the HandlerDefinition used to create concrete handlers for the given sagaType.
handlerDefinition(Class<?>) - Method in class org.axonframework.spring.config.AxonConfiguration
 
handlerDefinition(HandlerDefinition) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
 
HandlerEnhancerDefinition - Interface in org.axonframework.messaging.annotation
Interface describing objects that are capable of enhancing a MessageHandler, giving it additional functionality.
HandlerExecutionException - Exception in org.axonframework.messaging
Base exception for exceptions raised by Handler methods.
HandlerExecutionException(String) - Constructor for exception org.axonframework.messaging.HandlerExecutionException
Initializes an execution exception with given message.
HandlerExecutionException(String, Throwable) - Constructor for exception org.axonframework.messaging.HandlerExecutionException
Initializes an execution exception with given message and cause.
HandlerExecutionException(String, Throwable, Object) - Constructor for exception org.axonframework.messaging.HandlerExecutionException
Initializes an execution exception with given message, cause and application-specific details.
handlerInterceptors() - Method in class org.axonframework.deadline.AbstractDeadlineManager
Provides a list of registered handler interceptors.
Handlers<Case,Handler> - Interface in org.axonframework.axonserver.connector
Handler registry - gives possibility of registering handlers for specific cases and contexts.
handleSnapshotReadingError(String, Throwable) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
 
handleSnapshotReadingError(String, Throwable) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Invoked when an error (Exception or LinkageError) occurs while attempting to read a snapshot event.
hasAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
hasAnnotation(Class<? extends Annotation>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
hasAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
hasAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
hasDelegate() - Method in class org.axonframework.disruptor.commandhandling.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.eventhandling.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.
HasHandlerAttributes - Annotation Type in org.axonframework.messaging.annotation
Meta-annotation indicating the meta-annotated annotation is used for MessageHandlingMembers.
hasHandlerMethod(EventMessage<?>) - Method in interface org.axonframework.modelling.saga.metamodel.SagaModel
Indicates whether the Saga described by this model has a handler for the given eventMessage
hashCode() - Method in class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
 
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.commandfilter.NegateCommandMessageFilter
 
hashCode() - Method in class org.axonframework.commandhandling.distributed.commandfilter.OrCommandMessageFilter
 
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.eventhandling.GapAwareTrackingToken
 
hashCode() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
 
hashCode() - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
hashCode() - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
 
hashCode() - Method in class org.axonframework.eventhandling.ReplayToken
 
hashCode() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
 
hashCode() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
 
hashCode() - Method in class org.axonframework.eventhandling.Segment
 
hashCode() - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
 
hashCode() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
 
hashCode() - Method in class org.axonframework.eventhandling.TrackerStatus
 
hashCode() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
hashCode() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
 
hashCode() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
hashCode() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
hashCode() - Method in class org.axonframework.messaging.MetaData
 
hashCode() - Method in class org.axonframework.messaging.RemoteExceptionDescription
 
hashCode() - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
hashCode() - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
hashCode() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
 
hashCode() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
 
hashCode() - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
 
hashCode() - Method in class org.axonframework.modelling.saga.AssociationValue
 
hashCode() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
 
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.deadline.ScheduledDeadlineInfo
 
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.
hasNext() - Method in interface org.axonframework.axonserver.connector.event.axon.QueryResultStream
Validates whether there is a following entry in this stream to consume.
hasNext(int, TimeUnit) - Method in interface org.axonframework.axonserver.connector.event.axon.QueryResultStream
Validates whether there is a following entry in this stream to consume.
hasNext(int, TimeUnit) - Method in class org.axonframework.axonserver.connector.event.axon.QueryResultStreamAdapter
 
hasNext() - Method in class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
 
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.FilteringDomainEventStream
 
hasNext() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
hasNextAvailable(int, TimeUnit) - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
 
hasNextAvailable() - Method in interface org.axonframework.common.stream.BlockingStream
Checks whether or not the next message in the stream is available.
hasNextAvailable(int, TimeUnit) - Method in interface org.axonframework.common.stream.BlockingStream
Checks whether or not the next message in the stream is available.
Headers - Class in org.axonframework.messaging
Default headers to include when publishing a message on a broker.
HeartbeatConfiguration() - Constructor for class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
 
HeartbeatConfiguration - Class in org.axonframework.axonserver.connector.heartbeat
Deprecated.
in through use of the AxonServer java connector
HeartbeatConfiguration() - Constructor for class org.axonframework.axonserver.connector.heartbeat.HeartbeatConfiguration
Deprecated.
Default constructor for HeartbeatConfiguration, that uses Configuration in order to retrieve the registered AxonServerConnectionManager and AxonServerConfiguration.
HeartbeatConfiguration(Function<Configuration, AxonServerConnectionManager>, Function<Configuration, AxonServerConfiguration>) - Constructor for class org.axonframework.axonserver.connector.heartbeat.HeartbeatConfiguration
Deprecated.
Creates a HeartbeatConfiguration using the provided functions to retrieve the AxonServerConnectionManager and AxonServerConfiguration.
HeartbeatConnectionChecker - Class in org.axonframework.axonserver.connector.heartbeat.connection.checker
Deprecated.
in through use of the AxonServer java connector
HeartbeatConnectionChecker(AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.heartbeat.connection.checker.HeartbeatConnectionChecker
Deprecated.
Constructs an instance of HeartbeatConnectionChecker using the specified parameters.
HeartbeatConnectionChecker(Consumer<Runnable>, ConnectionSanityChecker) - Constructor for class org.axonframework.axonserver.connector.heartbeat.connection.checker.HeartbeatConnectionChecker
Deprecated.
Constructs an instance of HeartbeatConnectionChecker using a default timeout of 5 seconds and the system clock.
HeartbeatConnectionChecker(long, Consumer<Runnable>, ConnectionSanityChecker, Clock) - Constructor for class org.axonframework.axonserver.connector.heartbeat.connection.checker.HeartbeatConnectionChecker
Deprecated.
Primary constructor of HeartbeatConnectionChecker.
HeartbeatMonitor - Class in org.axonframework.axonserver.connector.heartbeat
Deprecated.
in through use of the AxonServer java connector
HeartbeatMonitor(Runnable, ConnectionSanityChecker, Scheduler, long, long) - Constructor for class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
Deprecated.
Primary constructor of HeartbeatMonitor.
HeartbeatSource - Interface in org.axonframework.axonserver.connector.heartbeat
Deprecated.
in through use of the AxonServer java connector
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.modelling.saga.repository.jdbc
Specialization of the GenericSagaSqlSchema for use in the HSQL database.
HsqlSagaSqlSchema() - Constructor for class org.axonframework.modelling.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.modelling.command.Aggregate
Get the unique identifier of this aggregate
identifier() - Method in class org.axonframework.modelling.command.AggregateLifecycle
Retrieve a Object denoting the identifier of this Aggregate.
identifier() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
identifier() - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
identifier() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
 
identifierAsString() - Method in interface org.axonframework.modelling.command.Aggregate
Get the unique identifier of this aggregate, represented as a String.
identifierConverter(Function<String, ?>) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
Sets the Function which converts a String based identifier to the Identifier object used in the Entity.
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.
identity() - Static method in interface org.axonframework.axonserver.connector.ManagedChannelCustomizer
Returns a no-op ManagedChannelCustomizer.
ifShuttingDown(String) - Method in class org.axonframework.lifecycle.ShutdownLatch
Check whether this ShutdownLatch is shutting down.
ifShuttingDown(Supplier<RuntimeException>) - Method in class org.axonframework.lifecycle.ShutdownLatch
Check whether this ShutdownLatch is shutting down.
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.
ignoringResultParameters(Supplier<T>) - Static method in class org.axonframework.messaging.annotation.ResultParameterResolverFactory
Performs the given action ignoring any parameters expecting a result type.
IllegalPayloadAccessException - Exception in org.axonframework.messaging
Indicates situations when access to the Payload of a Message is not allowed.
IllegalPayloadAccessException(String) - Constructor for exception org.axonframework.messaging.IllegalPayloadAccessException
Creates the exception with given message.
IllegalPayloadAccessException(String, Throwable) - Constructor for exception org.axonframework.messaging.IllegalPayloadAccessException
Creates the exception with given message and cause.
ImportSelector() - Constructor for class org.axonframework.spring.config.SpringAxonAutoConfigurer.ImportSelector
 
INBOUND_COMMAND_CONNECTOR - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown inbound command connectors.
INBOUND_EVENT_CONNECTORS - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown inbound event connectors.
INBOUND_QUERY_CONNECTOR - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown inbound query connectors.
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.
infoSupplier(EventProcessor) - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
 
InfraConfiguration - Class in org.axonframework.springboot.autoconfig
 
InfraConfiguration() - Constructor for class org.axonframework.springboot.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 class org.axonframework.eventsourcing.AbstractSnapshotTrigger
 
initializationFinished() - Method in interface org.axonframework.eventsourcing.SnapshotTrigger
Invoked when the initialization of the aggregate based on passed events is completed.
initialize(Configuration) - Method in class org.axonframework.axonserver.connector.event.axon.EventProcessorInfoConfiguration
 
initialize(Configuration) - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatConfiguration
Deprecated.
Initializes the GrpcHeartbeatSource component, needed to send heartbeats to AxonServer, any time the client will receive an heartbeat from the server.
initialize(Configuration) - Method in class org.axonframework.config.AggregateConfigurer
 
initialize(Configuration) - Method in class org.axonframework.config.EventProcessingModule
 
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.SagaConfigurer
Initializes Saga Configuration by using the main Configuration.
initialize(ConflictResolver) - Static method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
Initialize conflict resolution in the context of the current Unit of Work dealing with a command on an event sourced aggregate.
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(T, AggregateModel<T>, EventBus, RepositoryProvider, 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.
initialize(Callable<T>, AggregateModel<T>, EventBus, RepositoryProvider, 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.
initialize() - Method in class org.axonframework.lifecycle.ShutdownLatch
Initialize this ShutdownLatch.
initialize(InterceptorChain) - Static method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
initialize(Member, EntityModel) - Method in interface org.axonframework.modelling.command.ForwardingMode
Initializes an instance of a ForwardingMode.
initialize(Member, EntityModel) - Method in class org.axonframework.modelling.command.ForwardMatchingInstances
 
initialize(Callable<T>, AggregateModel<T>, EventBus) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Initialize an aggregate created by the given aggregateFactory which is described in the given aggregateModel.
initialize(Callable<T>, AggregateModel<T>, EventBus, RepositoryProvider) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Initialize an aggregate created by the given aggregateFactory which is described in the given aggregateModel.
initialize(Callable<T>, AggregateModel<T>, EventBus, boolean) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Initialize an aggregate created by the given aggregateFactory which is described in the given aggregateModel.
initialize(Callable<T>, AggregateModel<T>, EventBus, RepositoryProvider, boolean) - Static method in class org.axonframework.modelling.command.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.modelling.command.inspection.AnnotatedAggregate
Initialize an aggregate with the given aggregateRoot which is described in the given aggregateModel.
initialize(T, AggregateModel<T>, EventBus, RepositoryProvider) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Initialize an aggregate with the given aggregateRoot which is described in the given aggregateModel.
initializeAdapterFor(Object, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
Create an AnnotationEventListenerAdapter instance of the given bean.
initializeAdapterFor(Object, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
 
initializeAdapterFor(Object, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
 
initializeAt(TemporalAccessor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
Resets the initial "current time" of this manager.
initializeAt(TemporalAccessor) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
Resets the initial "current time" of this SubEventScheduler.
initializeSegment(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
initializeSegment(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
initializeSegment(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
initializeSegment(TrackingToken, String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Initializes a segment with given segment for the processor with given processorName to contain the given token.
initializeState(DomainEventStream) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
Initialize the state of this Event Sourced Aggregate with the events from the given eventStream.
initializeTokenSegments(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
initializeTokenSegments(String, int, TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
initializeTokenSegments(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
initializeTokenSegments(String, int, TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
initializeTokenSegments(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
initializeTokenSegments(String, int, TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
initializeTokenSegments(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Initializes the given segmentCount number of segments for the given processorName to track its tokens.
initializeTokenSegments(String, int, TrackingToken) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Initializes the given segmentCount number of segments for the given processorName to track its tokens.
initialResult() - Method in class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
 
initialResult() - Method in class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
Deprecated.
 
initialResult() - Method in class org.axonframework.axonserver.connector.query.subscription.DisposableResult
Deprecated.
 
initialResult() - Method in class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
 
initialResult() - Method in interface org.axonframework.queryhandling.SubscriptionQueryResult
Subscribing to this mono will trigger invocation of query handler.
initialSegmentCount(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Sets the initial segment count used to create segments on start up.
initialToken(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies the Function used to generate the initial TrackingTokens.
initiateShutdown() - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Initiate the shutdown of a CommandBusConnector.
initiateShutdown() - Method in class org.axonframework.lifecycle.ShutdownLatch
Initiate the shutdown of this latch.
initSequence() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Enable sequences on this Aggregate, causing it to emit DomainEventMessages, starting at sequence 0.
initSequence(long) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Enable sequences on this Aggregate, causing it to emit DomainEventMessages based on the given lastKnownSequenceNumber.
injectorAnnotationNames() - Method in class org.axonframework.modelling.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.modelling.saga.AbstractResourceInjector
 
injectResources(Object) - Method in enum org.axonframework.modelling.saga.repository.NoResourceInjector
 
injectResources(Object) - Method in interface org.axonframework.modelling.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
Initializes an InMemoryEventStorageEngine.
InMemoryEventStorageEngine(long) - Constructor for class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
Initializes an InMemoryEventStorageEngine using given offset to initialize the tokens with.
InMemorySagaStore - Class in org.axonframework.modelling.saga.repository.inmemory
SagaRepository implementation that stores all Saga instances in memory.
InMemorySagaStore() - Constructor for class org.axonframework.modelling.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
 
insertSaga(Class<? extends T>, String, T, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
 
insertSaga(Class<?>, String, Object, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
 
insertSaga(Class<?>, String, Object, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
 
insertSaga(Class<?>, String, Object, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
 
insertSaga(Class<? extends T>, String, T, Set<AssociationValue>) - Method in interface org.axonframework.modelling.saga.repository.SagaStore
Adds a new Saga and its initial association values to the store.
insertTokenEntry(Connection, 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<T>) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Shorthand to create a factory instance and inspect the model for the given aggregateType.
inspectAggregate(Class<T>, Set<Class<? extends T>>) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Shorthand to create a factory instance and inspect the model for the given aggregateType and its subtypes.
inspectAggregate(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Shorthand to create a factory instance and inspect the model for the given aggregateType, using given parameterResolverFactory to resolve parameter values for annotated handlers.
inspectAggregate(Class<T>, ParameterResolverFactory, HandlerDefinition) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Shorthand to create a factory instance and inspect the model for the given aggregateType, using given parameterResolverFactory to resolve parameter values for annotated handlers and handlerDefinition to create concrete handlers.
inspectAggregate(Class<T>, ParameterResolverFactory, HandlerDefinition, Set<Class<? extends T>>) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
Shorthand to create a factory instance and inspect the model for the given aggregateType and its subytpes, using given parameterResolverFactory to resolve parameter values for annotated handlers and handlerDefinition to create concrete handlers.
inspectType(Class<? extends T>) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Create an inspector for given handlerType that uses a ClasspathParameterResolverFactory to resolve method parameters and ClasspathHandlerDefinition to create handlers.
inspectType(Class<? extends 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.
inspectType(Class<? extends T>, ParameterResolverFactory, HandlerDefinition) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Create an inspector for given handlerType that uses given parameterResolverFactory to resolve method parameters and given handlerDefinition to create handlers.
inspectType(Class<? extends T>, ParameterResolverFactory, HandlerDefinition, Set<Class<? extends T>>) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
Create an inspector for given handlerType and its declaredSubtypes that uses given parameterResolverFactory to resolve method parameters and given handlerDefinition to create handlers.
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 method in class org.axonframework.commandhandling.FailingDuplicateCommandHandlerResolver
Returns a DuplicateCommandHandlerResolver that throws an exception when a duplicate registration is detected
instance() - Static method in class org.axonframework.commandhandling.LoggingDuplicateCommandHandlerResolver
Returns an instance that logs duplicate registrations.
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 class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
Return a singleton instance of the this Sequencing Policy.
instance() - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
Singleton instance of a PropagatingErrorHandler.
INSTANCE - Static variable in class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
Creates a singleton reference the the GenericTokenTableFactory implementation.
INSTANCE - Static variable in class org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory
Creates a singleton reference the the Oracle11TokenTableFactory implementation.
INSTANCE - Static variable in class org.axonframework.eventhandling.tokenstore.jdbc.PostgresTokenTableFactory
Creates a singleton reference the the PostgresTokenTableFactory implementation.
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 variable in class org.axonframework.messaging.NoScopeDescriptor
A statically available instance of the NoScopeDescriptor.
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.NonStaticFieldsFilter
 
instance() - Static method in class org.axonframework.test.matchers.NonTransientFieldsFilter
Returns the (singleton) instance of the AllFieldsFilter
instanceOf(Class<R>) - Static method in class org.axonframework.messaging.responsetypes.ResponseTypes
Specify the desire to retrieve a single instance of type R when performing a query.
InstanceResponseType<R> - Class in org.axonframework.messaging.responsetypes
A ResponseType implementation that will match with query handlers which return a single instance of the expected response type.
InstanceResponseType(Class<R>) - Constructor for class org.axonframework.messaging.responsetypes.InstanceResponseType
Instantiate a InstanceResponseType with the given expectedResponseType as the type to be matched against and to which the query response should be converted to.
INSTRUCTION_COMPONENTS - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown components which send/receive/handle instructions for/to other connectors.
InstructionAckSource<T> - Interface in org.axonframework.axonserver.connector
Responsible for sending instruction acknowledgements.
instructionAckSource(InstructionAckSource<QueryProviderOutbound>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Deprecated.
in through use of the AxonServer java connector
InstructionResultPublisher - Interface in org.axonframework.axonserver.connector
Deprecated.
in through use of the AxonServer java connector
intercept(T) - Method in class org.axonframework.axonserver.connector.DispatchInterceptors
 
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.
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.axonframework.axonserver.connector.util.ContextAddingInterceptor
Deprecated.
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.axonframework.axonserver.connector.util.GrpcBufferingInterceptor
Deprecated.
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.axonframework.axonserver.connector.util.TokenAddingInterceptor
Deprecated.
 
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.
InterceptorChainParameterResolverFactory - Class in org.axonframework.messaging.annotation
Parameter resolver factory that adds support for resolving current InterceptorChain.
InterceptorChainParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
 
interceptorsFor(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns a List of MessageHandlerInterceptors for a processor with given processorName.
interceptorsFor(String) - Method in class org.axonframework.config.EventProcessingModule
 
IntermediateEventRepresentation - Interface in org.axonframework.serialization.upcasting.event
Interface describing the intermediate representation of an event during upcasting.
intersect(Collection<? extends T>, Collection<? extends T>, Supplier<C>) - Static method in class org.axonframework.common.CollectionUtils
Returns a collection containing the elements that are in both given collections collection1 and collection2, using the given collectionBuilder to create an instance for the new collection.
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(IntervalRetryScheduler.Builder) - Constructor for class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
Instantiate a IntervalRetryScheduler based on the fields contained in the IntervalRetryScheduler.Builder.
IntervalRetryScheduler.Builder - Class in org.axonframework.commandhandling.gateway
Builder class to instantiate a IntervalRetryScheduler.
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.modelling.command.Aggregate
Invoke a method on the underlying aggregate root or one of its instances.
invoke(Function<T, R>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
invoke(Function<AR, R>) - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
invoke(Function<T, R>) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
 
invoke(Function<T, R>) - Method in interface org.axonframework.modelling.saga.Saga
Execute the given invocation against the root object of this Saga instance.
invokeAndGetMethodValue(Method, Object) - Static method in class org.axonframework.common.ReflectionUtils
Invokes and returns the return value of the given method in the given object.
invokeInitHandlers() - Method in class org.axonframework.config.DefaultConfigurer
Calls all registered init handlers.
invokerInterceptors(List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Set the MessageHandlerInterceptor of generic type CommandMessage to use with the DisruptorCommandBus during in the invocation thread.
invokerThreadCount(int) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the number of Threads that should be used to invoke the Command 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 interface org.axonframework.messaging.unitofwork.UnitOfWork
Indicates whether this UnitOfWork is started.
isActive() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
 
isActive() - Method in interface org.axonframework.modelling.saga.Saga
Indicates whether or not this saga is active.
isAfter(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Check if this Phase comes after given other phase.
isAnnotatedWith(Class<? extends Annotation>, Class<? extends Annotation>, Set<Class<? extends Annotation>>, Set<Class<? extends Annotation>>) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Validate whether the given target annotation Class is meta-annotated with the given subject.
isAnnotationPresent(AnnotatedElement, Class<? extends Annotation>) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Indicates whether an annotation of given annotationType is present on the given element, considering that the given annotationType may be present as a meta annotation on any other annotation on that element.
isAnnotationPresent(AnnotatedElement, String) - Static method in class org.axonframework.common.annotation.AnnotationUtils
Indicates whether an annotation with given annotationType is present on the given element, considering that the given annotationType may be present as a meta annotation on any other annotation on that element.
isArray(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isArrayOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isAssignableFrom(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isAutoStart() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
Whether the embedded DistributedCommandBusProperties.JGroupsProperties.Gossip Server should be automatically started.
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.QueryHandlerSubscriber
 
isBefore(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Check if this Phase comes before given other phase.
isCaughtUp() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Whether the Segment of this status has caught up with the head of the event stream.
isCaughtUp() - Method in class org.axonframework.eventhandling.TrackerStatus
 
isCaughtUp() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
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.
isConnected(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Returns true if a gRPC channel for the specific context is opened between client and AxonServer.
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.modelling.command.Aggregate
Check if this aggregate has been deleted.
isDeleted() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
isDeleted() - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
isDeserialized() - Method in class org.axonframework.serialization.LazyDeserializingObject
Indicates whether this object has already been deserialized.
isDifferent(EventTrackerStatus) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Check whether this EventTrackerStatus is different from that.
isDifferent(EventTrackerStatus, boolean) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Check whether this EventTrackerStatus is different from that.
isDimensional() - Method in class org.axonframework.springboot.MetricsProperties.Micrometer
Indicates whether the Micrometer Tags/Dimensions will be used
isDisableEventBlacklisting() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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
 
isEmpty() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
isEmpty() - Method in interface org.axonframework.messaging.HandlerAttributes
Validate whether zero attributes are present in this object.
isEmpty() - Method in class org.axonframework.messaging.MetaData
 
isEmpty() - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
isEmpty() - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
Indicates whether any elements are contained within this map.
isEmptyType(SerializedType) - Static method in interface org.axonframework.serialization.SerializedType
Check whether the serializedType equals SerializedType#emptyType#getName() and returns a corresponding true or false whether this is the case or not.
isEnabled() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
 
isEnabled() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
isEnabled() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Indicates whether the (auto-configuration) of the Distributed Command Bus is enabled.
isEnabled() - Method in class org.axonframework.springboot.MetricsProperties.AutoConfiguration
Indicates whether the auto-configuration of Metrics is enabled
isError() - Method in interface org.axonframework.eventhandling.EventProcessor
Indicates whether the processor has been shut down due to an error.
isError() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
isError() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
 
isError() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
isErrorState() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Indicates whether this status represents an error.
isErrorState() - Method in class org.axonframework.eventhandling.TrackerStatus
 
isErrorState() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
isExceptional() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
isExceptional() - Method in class org.axonframework.messaging.GenericResultMessage
 
isExceptional() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
isExceptional() - Method in interface org.axonframework.messaging.ResultMessage
Indicates whether the ResultMessage represents unsuccessful execution.
isExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
Check if the result of the execution yielded an exception.
isExpectedPayloadType(String) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
Check whether the given payloadType matches the outcome of expectedPayloadType.
isExpectedRevision(String) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
Check whether the given revision matches the outcome of expectedRevision.
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.AbstractRetryScheduler
Indicates whether the given failure is clearly non-transient.
isFactoryHandler() - Method in interface org.axonframework.commandhandling.CommandMessageHandlingMember
Check if this message handler creates a new instance of the entity of type T to handle this command.
isFactoryHandler() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
isFallbackToHttpGet() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
Indicates whether to fall back to HTTP GET when retrieving Instance Meta Data from the Discovery Server fails.
isFalse(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
Asserts that the given expression is false.
isFieldTypeSupported(Field) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
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.
isForceReadFromLeader() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
isGenericArrayOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isGenericArrayType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isGenericAssignableFrom(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isHeld() - Method in interface org.axonframework.common.lock.Lock
Indicates whether the lock is still owned true, or whether it has been released false.
isInitialized() - Method in class org.axonframework.config.Component
Checks if the component is already initialized.
isIterableOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
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.modelling.command.AggregateLifecycle
Indicates whether this Aggregate instance is 'live'.
isLockHeld() - Method in class org.axonframework.modelling.command.LockAwareAggregate
Check if the aggregate currently holds a lock.
isLowerSegmentAdvanced() - Method in class org.axonframework.eventhandling.MergedTrackingToken
Indicates whether the last call to MergedTrackingToken.advancedTo(TrackingToken) caused the lower segment to advance
isMarkedDeleted() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
Indicates whether an Aggregate has invoked "markDeleted" while this lifecycle was active.
isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
Check whether the given Member is of a type supported by this definition.
isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
 
isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
 
isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
 
isMergeableWith(Segment) - Method in class org.axonframework.eventhandling.Segment
Indicates whether this segment can be merged with the given other segment.
isMergeInProgress(TrackingToken) - Static method in class org.axonframework.eventhandling.MergedTrackingToken
Indicates whether the given trackingToken represents a token that is part of a merge.
isMerging() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Indicates whether this Segment is still merging two (or more) Segments.
isMerging() - Method in class org.axonframework.eventhandling.TrackerStatus
 
isMerging() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
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.
isParameterizedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isParameterizedTypeOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
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
 
isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
 
isQualifierMatch(String, ConfigurableListableBeanFactory, String) - Static method in class org.axonframework.spring.SpringUtils
Match if the given qualifier can be found on the BeanDefinition of the given beanName.
isRecoverEntry() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Indicates whether this entry is a recovery entry.
isReplay() - Method in enum org.axonframework.eventhandling.ReplayStatus
Indicates whether this status represents a replay.
isReplay(Message<?>) - Static method in class org.axonframework.eventhandling.ReplayToken
Indicates whether the given message is "redelivered", as a result of a previous reset.
isReplay(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
Indicates whether the given trackingToken represents a position that is part of a replay.
isReplaying() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Indicates whether this Segment is still replaying previously processed Events.
isReplaying() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Returns the overall replay status of this StreamingEventProcessor.
isReplaying() - Method in class org.axonframework.eventhandling.TrackerStatus
 
isReplaying() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
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 interface org.axonframework.eventhandling.EventProcessor
Indicates whether this processor is currently running (i.e.
isRunning() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
isRunning() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
 
isRunning() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
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.QueryHandlerSubscriber
 
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(Object, Class).
isShuttingDown() - Method in class org.axonframework.lifecycle.ShutdownLatch
Check whether this ShutdownLatch is shutting down.
isSingleton() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
 
isSingleton() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
 
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.ConfigurerFactoryBean
 
isSingleton() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
 
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
 
isSnapshot() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
 
isSslEnabled() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.
isStreamOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
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.
isSuppressHandlerErrors() - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
Indicates whether the handlers triggered for this phase should have their exceptions suppressed.
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.
isType(Class<?>) - Method in interface org.axonframework.config.ModuleConfiguration
Checks whether this Module Configuration is of the given type.
isTypeVariable(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isUpperSegmentAdvanced() - Method in class org.axonframework.eventhandling.MergedTrackingToken
Indicates whether the last call to MergedTrackingToken.advancedTo(TrackingToken) caused the upper segment to advance
isValid() - Method in class org.axonframework.axonserver.connector.heartbeat.connection.checker.ActiveGrpcChannelChecker
Deprecated.
Returns true if the connection is still alive, false otherwise.
isValid() - Method in class org.axonframework.axonserver.connector.heartbeat.connection.checker.HeartbeatConnectionChecker
Deprecated.
Returns true if the connection is still alive, false otherwise.
isValid() - Method in interface org.axonframework.axonserver.connector.heartbeat.ConnectionSanityChecker
Deprecated.
Returns true if the connection is still alive, false otherwise.
isValidIdentifier(Class<?>) - Method in class org.axonframework.common.IdentifierValidator
Indicates whether or not the given identifierType is safe to use as aggregate identifier
isWildcardType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
isWildcardTypeWithMatchingUpperBound(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
 
iterator() - Method in class org.axonframework.modelling.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(JacksonSerializer.Builder) - Constructor for class org.axonframework.serialization.json.JacksonSerializer
Instantiate a JacksonSerializer based on the fields contained in the JacksonSerializer.Builder.
JacksonSerializer.Builder - Class in org.axonframework.serialization.json
Builder class to instantiate a JacksonSerializer.
JavaSerializer - Class in org.axonframework.serialization
Deprecated.
in favor of the XStreamSerializer and JacksonSerializer, as direct Java serialization is relatively error prone. We hence strongly encourage to use either the XStream or Jackson solution in favor of this Serializer implementation.
JavaSerializer(JavaSerializer.Builder) - Constructor for class org.axonframework.serialization.JavaSerializer
Deprecated.
Instantiate a JavaSerializer based on the fields contained in the JavaSerializer.Builder.
JavaSerializer.Builder - Class in org.axonframework.serialization
Deprecated.
Builder class to instantiate a JavaSerializer.
JCacheAdapter - Class in org.axonframework.common.caching
Cache adapter implementation that allows providers implementing the JCache abstraction to be used.
JCacheAdapter(Cache<Object, Object>) - Constructor for class org.axonframework.common.caching.JCacheAdapter
Initialize the adapter to forward call to the given jCache instance
JdbcAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration class for Axon's JDBC specific infrastructure components.
JdbcAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
 
JdbcEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore.jdbc
An EventStorageEngine implementation that uses JDBC to store and fetch events.
JdbcEventStorageEngine(JdbcEventStorageEngine.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Instantiate a JdbcEventStorageEngine based on the fields contained in the JdbcEventStorageEngine.Builder.
JdbcEventStorageEngine.Builder - Class in org.axonframework.eventsourcing.eventstore.jdbc
Builder class to instantiate a JdbcEventStorageEngine.
JdbcEventStorageEngineStatements - Class in org.axonframework.eventsourcing.eventstore.jdbc.statements
Class which holds the default PreparedStatement builder methods for use in the JdbcEventStorageEngine.
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.modelling.saga.repository.jdbc
A SagaStore implementation that uses JDBC to store and find Saga instances.
JdbcSagaStore(JdbcSagaStore.Builder) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
Instantiate a JdbcSagaStore based on the fields contained in the JdbcSagaStore.Builder.
JdbcSagaStore.Builder - Class in org.axonframework.modelling.saga.repository.jdbc
Builder class to instantiate a JdbcSagaStore.
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
 
jdbcSQLErrorCodesResolver() - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
 
JdbcTokenStore - Class in org.axonframework.eventhandling.tokenstore.jdbc
A TokenStore implementation that uses JDBC to save and load TrackingToken instances.
JdbcTokenStore(JdbcTokenStore.Builder) - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Instantiate a JdbcTokenStore based on the fields contained in the JdbcTokenStore.Builder.
JdbcTokenStore.Builder - Class in org.axonframework.eventhandling.tokenstore.jdbc
Builder class to instantiate a JdbcTokenStore.
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.
JGroupsProperties() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
 
JOB_DATA_SERIALIZER - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
The key under which the Serializer is stored within the SchedulerContext.
jobDataBinder(EventJobDataBinder) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
Sets the EventJobDataBinder instance which reads / writes the event message to publish to the JobDataMap.
JpaAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration class for Axon's JPA specific infrastructure components.
JpaAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
 
jpaConfiguration(EntityManagerProvider, TransactionManager) - 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.
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(JpaEventStorageEngine.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
Instantiate a JpaEventStorageEngine based on the fields contained in the JpaEventStorageEngine.Builder.
JpaEventStorageEngine.Builder - Class in org.axonframework.eventsourcing.eventstore.jpa
Builder class to instantiate a JpaEventStorageEngine.
JpaEventStoreAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration class for Axon's JPA specific event store components.
JpaEventStoreAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.JpaEventStoreAutoConfiguration
 
jpaMappedConfiguration(Class<A>) - 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 obtained from the main configuration.
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.modelling.saga.repository.jpa
JPA implementation of the SagaStore.
JpaSagaStore(JpaSagaStore.Builder) - Constructor for class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
Instantiate a JpaSagaStore based on the fields contained in the JpaSagaStore.Builder.
JpaSagaStore.Builder - Class in org.axonframework.modelling.saga.repository.jpa
Builder class to instantiate a JpaSagaStore.
JpaTokenStore - Class in org.axonframework.eventhandling.tokenstore.jpa
Implementation of a token store that uses JPA to save and load tokens.
JpaTokenStore(JpaTokenStore.Builder) - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
Instantiate a JpaTokenStore based on the fields contained in the JpaTokenStore.Builder.
JpaTokenStore.Builder - Class in org.axonframework.eventhandling.tokenstore.jpa
Builder class to instantiate a JpaTokenStore.
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.
lastSequence() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Returns the last sequence of any event published, or null if no events have been published yet.
lastSequenceNumberFor(String) - Method in interface org.axonframework.eventhandling.DomainEventSequenceAware
Returns the last known sequence number of an Event for the given aggregateIdentifier.
lastSequenceNumberFor(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
 
lastSequenceNumberFor(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
Returns the last known sequence number for the given aggregateIdentifier.
lastSequenceNumberFor(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
 
lastSequenceNumberFor(LastSequenceNumberForStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
lastSequenceNumberFor(Connection, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to be used at JdbcEventStorageEngine.lastSequenceNumberFor(String).
lastSequenceNumberFor(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
lastSequenceNumberFor(Connection, EventSchema, String) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.lastSequenceNumberFor(String).
lastSequenceNumberFor(String) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
lastSequenceNumberFor(String) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
lastSequenceNumberFor(String) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
LastSequenceNumberForStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.lastSequenceNumberFor(String)
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.
lenientDeserialization() - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Configures the underlying XStream instance to be lenient when deserializing data into Java objects.
lenientDeserialization() - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Configures the underlying ObjectMapper to be lenient when deserializing JSON into Java objects.
lenientDeserialization() - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
 
LifecycleHandler - Interface in org.axonframework.config
Functional interface towards a lifecycle handler used during start up or shutdown of an application.
LifecycleHandlerInspector - Class in org.axonframework.config
Utility class used to resolve LifecycleHandlers to be registered to the Configuration.
LifecycleHandlerInvocationException - Exception in org.axonframework.lifecycle
Exception indicating a failure occurred during a lifecycle handler method invocation.
LifecycleHandlerInvocationException(String) - Constructor for exception org.axonframework.lifecycle.LifecycleHandlerInvocationException
Instantiates an exception using the given message indicating a failure during a lifecycle handler method invocation.
LifecycleHandlerInvocationException(Method, Object, Throwable) - Constructor for exception org.axonframework.lifecycle.LifecycleHandlerInvocationException
Instantiates an exception using the given lifecycleComponent, lifecycleHandler and cause, indicating a failure during a lifecycle handler method invocation.
LifecycleHandlerInvocationException(String, Throwable) - Constructor for exception org.axonframework.lifecycle.LifecycleHandlerInvocationException
Instantiates an exception using the given message and cause indicating a failure during a lifecycle handler method invocation.
listenerInvocationErrorHandler(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the ListenerInvocationErrorHandler tied to the given processingGroup.
listenerInvocationErrorHandler(String) - Method in class org.axonframework.config.EventProcessingModule
 
listenerInvocationErrorHandler() - Method in interface org.axonframework.config.SagaConfiguration
Retrieve the Saga's ListenerInvocationErrorHandler.
ListenerInvocationErrorHandler - Interface in org.axonframework.eventhandling
Interface of an error handler that is invoked when an exception is triggered as result of an EventMessageHandler handling an event.
listenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Sets the ListenerInvocationErrorHandler which deals with any Exceptions being thrown by the EventListeners.
listenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
Sets the ListenerInvocationErrorHandler invoked when an error occurs.
listenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
 
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.
ListUtils - Class in org.axonframework.common
Utility methods for operations on lists.
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.modelling.command.AbstractRepository
 
load(String) - Method in class org.axonframework.modelling.command.AbstractRepository
 
load(String) - Method in interface org.axonframework.modelling.command.Repository
Load the aggregate with the given unique identifier.
load(String, Long) - Method in interface org.axonframework.modelling.command.Repository
Load the aggregate with the given unique identifier.
load(String) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
Loads a known Saga instance by its unique identifier.
load(String) - Method in interface org.axonframework.modelling.saga.SagaRepository
Loads a known Saga instance by its unique identifier.
loadAssociationValues(EntityManager, Class<?>, String) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
Loads the association values of the saga with given sagaIdentifier and sagaType.
loadFactorProvider(CommandLoadFactorProvider) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the CommandLoadFactorProvider which provides the load factor values for all commands this client can handle.
loadingLockMode(LockModeType) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
The LockModeType to use when loading tokens from the underlying database.
loadOrCreate(String, Callable<T>) - Method in class org.axonframework.modelling.command.AbstractRepository
 
loadOrCreate(String, Callable<T>) - Method in interface org.axonframework.modelling.command.Repository
Loads an aggregate from the repository.
loadSaga(Class<S>, String) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
 
loadSaga(Class<S>, String) - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
 
loadSaga(Class<S>, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
 
loadSaga(Class<S>, String) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
 
loadSaga(Class<S>, String) - Method in interface org.axonframework.modelling.saga.repository.SagaStore
Loads a known saga SagaStore.Entry instance with given sagaType and unique sagaIdentifier.
loadToken(Connection, 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.
loadToken(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.
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
 
LOCAL_MEMBER - Static variable in class org.axonframework.commandhandling.distributed.SimpleMember
Denotes that a SimpleMember is a representation of a Local Member, thus a representation of the instance itself.
LOCAL_MESSAGE_HANDLER_REGISTRATIONS - Static variable in class org.axonframework.lifecycle.Phase
Phase to register or cancel the registration of any local message handler.
localSegment(CommandBus) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the local CommandBus used to dispatch incoming commands to the local environment.
localSegment() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
 
localSegment(QueryBus) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the local QueryBus used to dispatch incoming queries to the local environment.
localSegment() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
localSegment() - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
Return an Optional containing the CommandBus which is used by this CommandBusConnector to dispatch local and incoming CommandMessages on.
localSegment() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Return the message bus of type MessageBus which is regarded as the local segment for this implementation.
localSegment() - Method in interface org.axonframework.messaging.Distributed
Return the message bus of type MessageBus which is regarded as the local segment for this implementation.
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.
lockAttemptTimeout(int) - Method in class org.axonframework.common.lock.PessimisticLockFactory.Builder
The duration of a single attempt to acquire the internal lock.
LockAwareAggregate<AR,A extends Aggregate<AR>> - Class in org.axonframework.modelling.command
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.modelling.command.LockAwareAggregate
Initializes a new LockAwareAggregate for given wrappedAggregate and lock.
LockAwareAggregate(A, Supplier<Lock>) - Constructor for class org.axonframework.modelling.command.LockAwareAggregate
Initializes a new LockAwareAggregate for given wrappedAggregate and a supplier of the lock.
LockFactory - Interface in org.axonframework.common.lock
Interface to the lock factory.
lockFactory(LockFactory) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Sets the LockFactory used to lock an aggregate.
lockFactory(LockFactory) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
 
lockFactory(LockFactory) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
Sets the LockFactory used to lock an aggregate.
lockFactory(LockFactory) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
 
lockFactory(LockFactory) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository.Builder
Sets the LockFactory used to lock a saga.
LockingRepository<T,A extends Aggregate<T>> - Class in org.axonframework.modelling.command
Implementation of the Repository interface that takes provides a locking mechanism to prevent concurrent modifications of persisted aggregates.
LockingRepository(LockingRepository.Builder<T>) - Constructor for class org.axonframework.modelling.command.LockingRepository
Instantiate a LockingRepository based on the fields contained in the LockingRepository.Builder.
LockingRepository.Builder<T> - Class in org.axonframework.modelling.command
Abstract Builder class to instantiate LockingRepository implementations.
LockingSagaRepository<T> - Class in org.axonframework.modelling.saga.repository
Abstract implementation of a saga repository that locks access to a saga while the saga is being operated on.
LockingSagaRepository(LockingSagaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.saga.repository.LockingSagaRepository
Instantiate a LockingSagaRepository based on the fields contained in the LockingSagaRepository.Builder.
LockingSagaRepository.Builder<T> - Class in org.axonframework.modelling.saga.repository
Abstract Builder class to instantiate LockingSagaRepository implementations.
logAndOverride() - Static method in class org.axonframework.commandhandling.DuplicateCommandHandlerResolution
A DuplicateCommandHandlerResolver implementation which logs a warning message and resolve to returning the duplicate handler and overriding the existing command handler.
logger(Logger) - Method in class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler.Builder
Sets the Logger to log errors with from query handlers.
LoggingCallback - Class in org.axonframework.commandhandling.callbacks
CommandCallback implementation that simply logs the results of a command.
LoggingDuplicateCommandHandlerResolver - Class in org.axonframework.commandhandling
Implementation of the DuplicateCommandHandlerResolver that allows registrations to be overridden by new handlers, but logs this (on WARN level) to a given logger.
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
MessageDispatchInterceptor and MessageHandlerInterceptor implementation that logs dispatched and 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.
LoggingQueryInvocationErrorHandler - Class in org.axonframework.queryhandling
Implementation of the QueryInvocationErrorHandler that logs all errors to a given Logger.
LoggingQueryInvocationErrorHandler(LoggingQueryInvocationErrorHandler.Builder) - Constructor for class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler
Instantiate a LoggingQueryInvocationErrorHandler based on the fields contained in the LoggingQueryInvocationErrorHandler.Builder.
LoggingQueryInvocationErrorHandler.Builder - Class in org.axonframework.queryhandling
Builder class to instantiate a LoggingQueryInvocationErrorHandler.
longPollingSource(String) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource.Builder
Select the message source which is most suitable for long polling.
LOW - Static variable in annotation type org.axonframework.common.Priority
Value indicating the annotated member should be placed at the "lower half".
lowerBound(TrackingToken) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
 
lowerBound(TrackingToken) - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
 
lowerBound(TrackingToken) - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
lowerBound() - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
lowerBound(TrackingToken) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
Compares this token to other by comparing each member token with its counterpart in the other token.
lowerBound(TrackingToken) - Method in class org.axonframework.eventhandling.ReplayToken
 
lowerBound() - Method in class org.axonframework.eventhandling.ReplayToken
 
lowerBound(TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
 
lowerBound(TrackingToken) - Method in interface org.axonframework.eventhandling.TrackingToken
Returns a token that represents the lower bound between this and the other token.
lowerBound() - Method in interface org.axonframework.eventhandling.WrappedToken
Returns the token representing the current position in the stream.
lowerSegmentToken() - Method in class org.axonframework.eventhandling.MergedTrackingToken
Returns the token indicating the progress of the lower half (the half with the lower segmentId) of the merged segment represented by this token
lowestGlobalSequence(long) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the lowestGlobalSequence specifying the first expected auto generated sequence number.
lowestGlobalSequence(long) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the lowestGlobalSequence specifying the first expected auto generated sequence number.

M

managedAggregates(UnitOfWork<?>) - Method in class org.axonframework.modelling.command.AbstractRepository
Returns the map of aggregates currently managed by this repository under the given unit of work.
ManagedChannelCustomizer - Interface in org.axonframework.axonserver.connector
Customizer to add more customizations to a managed channel to Axon Server.
managedChannelCustomizer() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
manager() - Method in interface org.axonframework.config.SagaConfiguration
Retrieve the Saga Manager in this Configuration.
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.
MapEntryMatcher - Class in org.axonframework.test.matchers
Matcher that will match an Object if that object is a Map of which all keys-values pairs are equal to pairs of the expected instance.
MapEntryMatcher(Map<String, Object>) - Constructor for class org.axonframework.test.matchers.MapEntryMatcher
 
markConsumed(Integer) - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
Deprecated.
Notifies the stream observer that [@code consumed} messages are processed by the client.
markDeleted() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
Marks this aggregate as deleted, instructing a repository to remove that aggregate at an appropriate time.
markError(Throwable) - Method in class org.axonframework.eventhandling.TrackerStatus
Return a new TrackerStatus based on this status, setting the given error as the errorState.
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.CurrentUnitOfWorkParameterResolverFactory
 
matches(CommandMessage<?>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
 
matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
matches(CommandMessage<?>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.NegateCommandMessageFilter
 
matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.OrCommandMessageFilter
 
matches(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.CommandMessageFilter
Indicates whether the given commandMessage matches this filter.
matches(Message<?>) - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
 
matches(int) - Method in class org.axonframework.eventhandling.Segment
Returns true when the mask applied to the given value, matches the segment id.
matches(Object) - Method in class org.axonframework.eventhandling.Segment
Indicates whether the given value matches this segment.
matches(Message) - Method in class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
 
matches(Message<?>) - Method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
 
matches(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
 
matches(Message<?>) - Method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
 
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(Type) - Method in class org.axonframework.messaging.responsetypes.InstanceResponseType
Match the query handler its response Type with this implementation its responseType R.
matches(Type) - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
Match the query handler its response Type with this implementation its responseType R.
matches(Type) - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
Match the query handler its response Type with this implementation its responseType R.
matches(Type) - Method in interface org.axonframework.messaging.responsetypes.ResponseType
Match the query handler its response Type with the ResponseType implementation its expected response type R.
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.EqualsMatcher
 
matchesSafely(Map<String, Object>) - Method in class org.axonframework.test.matchers.MapEntryMatcher
 
matchesSafely(T) - Method in class org.axonframework.test.matchers.PredicateMatcher
 
matchesSegment(Segment, String) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
Checks whether the given sagaId matches with the given segment.
matchPositions(EventTrackerStatus) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Match the position fields of this and that.
matchRemainder(Iterator<Matcher<? super T>>) - Method in class org.axonframework.test.matchers.ListMatcher
Matches all the remaining Matchers in the given matcherIterator against null.
matchStates(EventTrackerStatus) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Match the boolean state fields of this and that.
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.
MavenArtifactVersionResolver - Class in org.axonframework.util
Artifact version resolver that uses Maven meta data to retrieve the jar version.
MavenArtifactVersionResolver(String, String, ClassLoader) - Constructor for class org.axonframework.util.MavenArtifactVersionResolver
Creates an instance to look for the version in the Meta Data of the artifact with given groupId and artifactId.
maxCapacity() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
Specifies the maximum amount of segments this EventProcessor can process at the same time.
maxCapacity() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Specifies the maximum amount of segments this EventProcessor can process at the same time.
maxCapacity() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
maxClaimedSegments(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Defines the maximum number of segment this StreamingEventProcessor may claim.
maxGapOffset(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the maxGapOffset specifying the maximum distance in sequence numbers between a missing event and the event with the highest known index.
maxGapOffset(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the maxGapOffset specifying the maximum distance in sequence numbers between a missing event and the event with the highest known index.
maxMessageSize(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
maxRetryCount(int) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
Sets the maximum number of retries allowed for a single command.
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.
merge(T, T, Supplier<T>) - Static method in class org.axonframework.common.CollectionUtils
Merge two collections into a new collection instance.
mergeableSegmentId() - Method in class org.axonframework.eventhandling.Segment
Returns the segmentId of the segment this one can be merged with
mergeCompletedPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Return the estimated relative token position this Segment will have after a merge operation is complete.
mergeCompletedPosition() - Method in class org.axonframework.eventhandling.TrackerStatus
 
mergeCompletedPosition() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
merged(TrackingToken, TrackingToken) - Static method in class org.axonframework.eventhandling.MergedTrackingToken
Create a merged token using the given lowerSegmentToken and upperSegmentToken.
MergedTrackingToken - Class in org.axonframework.eventhandling
Special Wrapped Token implementation that keeps track of two separate tokens, of which the streams have been merged into a single one.
MergedTrackingToken(TrackingToken, TrackingToken) - Constructor for class org.axonframework.eventhandling.MergedTrackingToken
Initialize a Merged Token, with the lowerSegmentToken representing the progress of the segment with the lower segmentId, and upperSegmentToken representing the progress of the segment with the higher segmentId.
MergedTrackingToken(TrackingToken, TrackingToken, boolean, boolean) - Constructor for class org.axonframework.eventhandling.MergedTrackingToken
Initialize a Merged Token, with the lowerSegmentToken representing the progress of the segment with the lower segmentId, and upperSegmentToken representing the progress of the segment with the higher segmentId, additionally indicating if either of these segments were advanced by the latest call to MergedTrackingToken.advancedTo(TrackingToken)
mergedWith(Segment) - Method in class org.axonframework.eventhandling.Segment
Calculates the Segment that represents the merger of this segment with the given other segment.
mergedWith(HandlerAttributes) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
mergedWith(HandlerAttributes) - Method in interface org.axonframework.messaging.HandlerAttributes
Returns a HandlerAttributes, merging the attributes in this instance with the given attributes.
mergedWith(Map<String, ?>) - Method in class org.axonframework.messaging.MetaData
Returns a MetaData instance containing values of this, combined with the given additionalEntries.
mergedWith(HandlerAttributes) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
mergePosition(TrackingToken) - Static method in class org.axonframework.eventhandling.MergedTrackingToken
Return the estimated relative token position this Segment will have after a merge operation is complete.
mergeSegment(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
mergeSegment(int) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Instruct the processor to merge the segment with given segmentId back with the segment that it was originally split from.
mergeSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
Message<T> - Interface in org.axonframework.messaging
Representation of a Message, containing a Payload and MetaData.
MESSAGE_ID - Static variable in class org.axonframework.messaging.Headers
Key pointing to a message identifier.
MESSAGE_METADATA - Static variable in class org.axonframework.messaging.Headers
Key pointing to the MetaData of a message.
MESSAGE_REVISION - Static variable in class org.axonframework.messaging.Headers
Key pointing to the revision of a message.
MESSAGE_TIMESTAMP - Static variable in class org.axonframework.messaging.Headers
Key pointing to the timestamp of a message.
MESSAGE_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the Message type being handled by the handler.
MESSAGE_TYPE - Static variable in class org.axonframework.messaging.Headers
Key pointing to the payload type of a message.
MessageCountingMonitor - Class in org.axonframework.metrics
Counts the number of ingested, successful, failed and processed messages
MessageCountingMonitor() - Constructor for class org.axonframework.metrics.MessageCountingMonitor
 
MessageCountingMonitor - Class in org.axonframework.micrometer
Counts the number of ingested, successful, failed and processed messages
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.
MessageDispatchInterceptorSupport<T extends Message<?>> - Interface in org.axonframework.messaging
Interface marking components capable of registering Dispatch Interceptors.
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 - Annotation Type in org.axonframework.messaging.interceptors
Annotation marking an handler method as an interceptor handler.
MessageHandlerInterceptor<T extends Message<?>> - Interface in org.axonframework.messaging
Workflow interface that allows for customized message handler invocation chains.
MessageHandlerInterceptorDefinition - Class in org.axonframework.messaging.annotation
HandlerEnhancerDefinition that marks methods (meta-)annotated with MessageHandlerInterceptor as interceptors.
MessageHandlerInterceptorDefinition() - Constructor for class org.axonframework.messaging.annotation.MessageHandlerInterceptorDefinition
 
MessageHandlerInterceptorMemberChain<T> - Interface in org.axonframework.messaging.annotation
Interface to interact with a MessageHandlingMember instance through a chain of interceptors, which were used to build up this chain.
MessageHandlerInterceptorSupport<T extends Message<?>> - Interface in org.axonframework.messaging
Interface marking components capable of registering Handler Interceptors.
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.
MessageHandlerRegistrar - Class in org.axonframework.config
The MessageHandlerRegistrar manages the lifecycle of a message handling component, by defining a MessageHandlerRegistrar.start() and MessageHandlerRegistrar.shutdown() method and keeping hold of the message handler's Registration.
MessageHandlerRegistrar(Supplier<Configuration>, Function<Configuration, Object>, BiFunction<Configuration, Object, Registration>) - Constructor for class org.axonframework.config.MessageHandlerRegistrar
Instantiate a MessageHandlerRegistrar, using the provided configSupplier to supply the Configuration needed to build and register the message handler.
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.
MessageInterceptingMember<T> - Interface in org.axonframework.messaging.annotation
Marker interface for MessageHandlingMember instances that need to be treated as interceptors, rather than regular members.
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
 
messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
 
messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
Sets the MessageMonitor for generic types implementing CommandMessage, which is used to monitor incoming messages and their execution result.
messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
Sets the MessageMonitor of generic type CommandMessage used the to monitor the command bus.
messageMonitor(Class<?>, String) - Method in interface org.axonframework.config.Configuration
Returns the message monitor configured for a component of given componentType and componentName.
messageMonitor(Class<?>, String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the MessageMonitor set to the given componentType and componentName registered within this configuration.
messageMonitor(Class<?>, String) - Method in class org.axonframework.config.EventProcessingModule
 
messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the MessageMonitor of generic type CommandMessage used the to monitor the command bus.
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus.Builder
Sets the MessageMonitor to monitor ingested EventMessages.
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
Sets the MessageMonitor to monitor EventMessages before and after they're processed.
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
 
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.SimpleEventBus.Builder
 
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
 
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
 
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
 
messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
 
MessageMonitor<T extends Message<?>> - Interface in org.axonframework.monitoring
Specifies a mechanism to monitor message processing.
messageMonitor(MessageMonitor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
Sets the MessageMonitor used to monitor query messages.
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
MessageMonitorFactory - Interface in org.axonframework.config
Interface describing a factory for a Message Monitor.
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.
messageOriginProvider() - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
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(Serializer) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the message Serializer used to de-/serialize incoming and outgoing queries and query responses.
messageSerializer() - Method in interface org.axonframework.config.Configuration
Returns the Serializer defined in this Configuration to be used for serializing Message payloads and metadata.
messageSerializer() - Method in class org.axonframework.spring.config.AxonConfiguration
 
messageSerializer(Serializer, RevisionResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
messageSource(StreamableMessageSource<TrackedEventMessage<?>>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
messageSource(SubscribableMessageSource<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
messageSource(StreamableMessageSource<TrackedEventMessage<?>>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
MessageTimerMonitor - Class in org.axonframework.metrics
A MessageMonitor which creates Timer instances for the overall, success, failure and ignored time an ingested Message takes.
MessageTimerMonitor(MessageTimerMonitor.Builder) - Constructor for class org.axonframework.metrics.MessageTimerMonitor
Instantiate a MessageTimerMonitor based on the fields contained in the MessageTimerMonitor.Builder.
MessageTimerMonitor() - Constructor for class org.axonframework.metrics.MessageTimerMonitor
Deprecated.
MessageTimerMonitor(Clock) - Constructor for class org.axonframework.metrics.MessageTimerMonitor
Deprecated.
MessageTimerMonitor - Class in org.axonframework.micrometer
A MessageMonitor which introduces a Timer for the overall timer of all Messages being ingested, as well as a success, failure and ignored Timer.
MessageTimerMonitor(MessageTimerMonitor.Builder) - Constructor for class org.axonframework.micrometer.MessageTimerMonitor
Instantiate a MessageTimerMonitor based on the fields contained in the MessageTimerMonitor.Builder.
MessageTimerMonitor.Builder - Class in org.axonframework.metrics
Builder class to instantiate a MessageTimerMonitor.
MessageTimerMonitor.Builder - Class in org.axonframework.micrometer
Builder class to instantiate a MessageTimerMonitor.
messageWithPayload(Matcher<?>) - Static method in class org.axonframework.test.matchers.Matchers
Matches a single Message if the given payloadMatcher matches that message's payload.
META_DATA_TAGGER_FUNCTION - Static variable in class org.axonframework.micrometer.TagsUtil
The function for creating the Micrometer Tags based on the message metadata.
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.
MetaDataAssociationResolver - Class in org.axonframework.modelling.saga
Used to derive the value of an association property by looking it up the event message's MetaData.
MetaDataAssociationResolver() - Constructor for class org.axonframework.modelling.saga.MetaDataAssociationResolver
 
metaDataColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event metadata column.
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.modelling.command
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.modelling.command.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.modelling.command.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
 
metaDataKey(String) - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.Builder
Sets the metaDataKey searched for by this routing strategy on a CommandMessage's MetaData to base the routing key on.
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(MetaDataRoutingStrategy.Builder) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Instantiate a MetaDataRoutingStrategy based on the fields contained in the give builder.
MetaDataRoutingStrategy(String) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Deprecated.
MetaDataRoutingStrategy(String, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
Deprecated.
MetaDataRoutingStrategy.Builder - Class in org.axonframework.commandhandling.distributed
Builder class to instantiate a AnnotationRoutingStrategy.
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.
meterNamePrefix(String) - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
Sets the name used to prefix the names of the Gauge instances created by this MessageMonitor.
meterNamePrefix(String) - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
Sets the name used to prefix the names of the Timer instances created by this MessageMonitor.
meterRegistry(MeterRegistry) - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
Specifies the MeterRegistry used to registered the Gauge instances to.
meterRegistry(MeterRegistry) - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
Specifies the MeterRegistry used to registered the Timer instances to.
meterRegistry() - Static method in class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
 
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
Implementation of a HandlerEnhancerDefinition that is used for CommandHandler annotated methods.
MethodCommandHandlerDefinition() - Constructor for class org.axonframework.commandhandling.MethodCommandHandlerDefinition
 
MethodCommandHandlerInterceptorDefinition - Class in org.axonframework.modelling.command.inspection
Implementation of HandlerEnhancerDefinition used for CommandHandlerInterceptor annotated methods.
MethodCommandHandlerInterceptorDefinition() - Constructor for class org.axonframework.modelling.command.inspection.MethodCommandHandlerInterceptorDefinition
 
MethodCreationPolicyDefinition - Class in org.axonframework.modelling.command.inspection
Implementation of HandlerEnhancerDefinition used for CreationPolicy annotated methods.
MethodCreationPolicyDefinition() - Constructor for class org.axonframework.modelling.command.inspection.MethodCreationPolicyDefinition
 
methodOf(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
Utility function which returns a Method matching the given methodName and parameterTypes in the clazz.
MethodQueryMessageHandlerDefinition - Class in org.axonframework.queryhandling.annotation
Definition of handlers that can handle QueryMessages.
MethodQueryMessageHandlerDefinition() - Constructor for class org.axonframework.queryhandling.annotation.MethodQueryMessageHandlerDefinition
 
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.
methodsOf(Class<?>, boolean) - Static method in class org.axonframework.common.ReflectionUtils
Returns an Iterable of all the methods declared on the given class.
metricRegistry() - Static method in class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
 
MetricsAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration to set up Metrics for the infrastructure components.
MetricsAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
 
MetricsConfigurerModule - Class in org.axonframework.metrics
Implementation of the ConfigurerModule which uses the GlobalMetricRegistry to register several Metrics Modules to the given Configurer.
MetricsConfigurerModule(GlobalMetricRegistry) - Constructor for class org.axonframework.metrics.MetricsConfigurerModule
 
MetricsConfigurerModule - Class in org.axonframework.micrometer
Implementation of the ConfigurerModule which uses the GlobalMetricRegistry to register several Metrics Modules to the given Configurer.
MetricsConfigurerModule(GlobalMetricRegistry) - Constructor for class org.axonframework.micrometer.MetricsConfigurerModule
 
MetricsConfigurerModule(GlobalMetricRegistry, boolean) - Constructor for class org.axonframework.micrometer.MetricsConfigurerModule
 
metricsConfigurerModule(GlobalMetricRegistry) - Static method in class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
 
metricsConfigurerModule(GlobalMetricRegistry, MetricsProperties) - Static method in class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
 
MetricsProperties - Class in org.axonframework.springboot
Properties describing the settings for Metrics.
MetricsProperties() - Constructor for class org.axonframework.springboot.MetricsProperties
 
MetricsProperties.AutoConfiguration - Class in org.axonframework.springboot
Auto configuration specific properties around Metrics.
MetricsProperties.Micrometer - Class in org.axonframework.springboot
 
Micrometer() - Constructor for class org.axonframework.springboot.MetricsProperties.Micrometer
 
MicrometerMetricsAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration to set up Micrometer Metrics for the infrastructure components.
MicrometerMetricsAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
 
modelFactory() - Method in interface org.axonframework.modelling.saga.metamodel.SagaModel
Returns the factory that created this model.
modelOf(Class<? extends C>) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Get the EntityModel of an entity of type childEntityType in case it is the child of the modeled entity.
modelOf(Class<T>) - Method in class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
 
modelOf(Class<T>) - Method in interface org.axonframework.modelling.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.
MongoTrackingToken - Class in org.axonframework.mongo.eventsourcing.eventstore
Deprecated.
this class is available for backward compatibility with instances that were serialized with Axon 3. Use org.axonframework.extensions.mongo.eventsourcing.eventstore.MongoTrackingToken instead.
MongoTrackingToken() - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
Deprecated.
 
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.
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.
MultiEventHandlerInvoker - Class in org.axonframework.eventhandling
Implementation of EventHandlerInvoker with capabilities to invoke several different invokers.
MultiEventHandlerInvoker(EventHandlerInvoker...) - Constructor for class org.axonframework.eventhandling.MultiEventHandlerInvoker
Initializes multi invoker with different invokers.
MultiEventHandlerInvoker(List<EventHandlerInvoker>) - Constructor for class org.axonframework.eventhandling.MultiEventHandlerInvoker
Initializes multi invoker with different invokers.
MultiHandlerDefinition - Class in org.axonframework.messaging.annotation
HandlerDefinition instance that delegates to multiple other instances, in the order provided.
MultiHandlerDefinition(HandlerDefinition...) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerDefinition
Initializes an instance that delegates to the given delegates, in the order provided.
MultiHandlerDefinition(List<HandlerDefinition>) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerDefinition
Initializes an instance that delegates to the given delegates, in the order provided.
MultiHandlerDefinition(List<HandlerDefinition>, HandlerEnhancerDefinition) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerDefinition
Initializes an instance that delegates to the given delegates, in the order provided.
MultiHandlerEnhancerDefinition - Class in org.axonframework.messaging.annotation
HandlerEnhancerDefinition instance that delegates to multiple other instances, in the order provided.
MultiHandlerEnhancerDefinition(HandlerEnhancerDefinition...) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
Initializes an instance that delegates to the given delegates, in the order provided.
MultiHandlerEnhancerDefinition(Collection<HandlerEnhancerDefinition>) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
Initializes an instance that delegates to the given delegates, in the order provided.
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.
multipleInstancesOf(Class<R>) - Static method in class org.axonframework.messaging.responsetypes.ResponseTypes
Specify the desire to retrieve a collection of instances of type R when performing a query.
MultipleInstancesResponseType<R> - Class in org.axonframework.messaging.responsetypes
A ResponseType implementation that will match with query handlers which return a multiple instances of the expected response type.
MultipleInstancesResponseType(Class<R>) - Constructor for class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
Instantiate a MultipleInstancesResponseType with the given expectedCollectionGenericType as the type to be matched against and which the convert function will use as the generic for the List return value.
MultiSourceTrackingToken - Class in org.axonframework.eventhandling
Combined tracking token used when processing from multiple event sources
MultiSourceTrackingToken(Map<String, TrackingToken>) - Constructor for class org.axonframework.eventhandling.MultiSourceTrackingToken
Construct a new MultiSourceTrackingToken from a map of existing tokens.
MultiStreamableMessageSource - Class in org.axonframework.eventsourcing
Implementation which allows for tracking processors to process messages from an arbitrary number of sources.
MultiStreamableMessageSource(MultiStreamableMessageSource.Builder) - Constructor for class org.axonframework.eventsourcing.MultiStreamableMessageSource
Instantiate a MultiStreamableMessageSource based on the fields contained in the MultiStreamableMessageSource.Builder.
MultiStreamableMessageSource.Builder - Class in org.axonframework.eventsourcing
Builder class to instantiate a MultiStreamableMessageSource.
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
 
name - Variable in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
 
name(String) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
Sets the name of this EventProcessor implementation.
name(String) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
 
name() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Returns the name of this PooledStreamingEventProcessor.
name(String) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
 
name(String) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
 
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
 
negate() - Method in interface org.axonframework.commandhandling.distributed.CommandMessageFilter
Returns a filter that matches when this instance doesn't, and vice versa.
NegateCommandMessageFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
A CommandMessageFilter implementation that negates the result of another CommandMessageFilter instance.
NegateCommandMessageFilter(CommandMessageFilter) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.NegateCommandMessageFilter
Initialize a CommandMessageFilter that negates results of the the given filter.
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(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.eventhandling.GapAwareTrackingToken
Returns a new GapAwareTrackingToken instance based on the given index and collection of gaps.
newInstance(Callable<T>) - Method in class org.axonframework.modelling.command.AbstractRepository
 
newInstance(Callable<T>) - Method in interface org.axonframework.modelling.command.Repository
Creates a new managed instance for the aggregate, using the given factoryMethod to instantiate the aggregate's root.
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.axonserver.connector.event.axon.QueryResultStream
Returns the following QueryResult from this stream.
next() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResultStreamAdapter
 
next() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
Returns a new GlobalSequenceTrackingToken instance with sequence number incremented by 1.
next() - Method in class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
 
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.FilteringDomainEventStream
 
next() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
next(T) - Method in interface org.axonframework.queryhandling.SinkWrapper
Wrapper around Sink next(Object).
nextAndExtract(ResultSet, int, Class<T>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
Moves the resultSet courser forward and then read the object at the given column (base 1).
nextAvailable() - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
 
nextAvailable() - Method in interface org.axonframework.common.stream.BlockingStream
Returns the next available message in the stream.
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.eventsourcing.conflictresolution
Implementation of a ConflictResolver that does nothing.
nodeId(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Sets the nodeId to identify ownership of the tokens.
nodeId(String) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
Sets the nodeId to identify ownership of the tokens.
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.
NoHandlerForCommandException(CommandMessage<?>) - Constructor for exception org.axonframework.commandhandling.NoHandlerForCommandException
Initialize a NoHandlerForCommandException with a message describing the given CommandMessage.
NoHandlerForQueryException - Exception in org.axonframework.queryhandling
Exception indicating a query for a single result was executed, but no handlers were found that could provide an answer.
NoHandlerForQueryException(String) - Constructor for exception org.axonframework.queryhandling.NoHandlerForQueryException
Initialize the exception with given message
NONE - Static variable in class org.axonframework.modelling.saga.SagaInitializationPolicy
Value indicating there is no Initialization required
nonEmptyOrNull(String) - Static method in class org.axonframework.common.StringUtils
Validate whether the given String s is not null and not empty (where empty is defined as "".
nonNull(T, Supplier<String>) - Static method in class org.axonframework.common.Assert
Assert that the given value is not null.
NonStaticFieldsFilter - Class in org.axonframework.test.matchers
FieldFilter implementation that only accepts non-static Fields.
NonTransientFieldsFilter - Class in org.axonframework.test.matchers
FieldFilter implementation that only accepts non-transient Fields.
noOp() - Static method in interface org.axonframework.axonserver.connector.TargetContextResolver
Returns a no-op TargetContextResolver.
noOp() - Static method in interface org.axonframework.commandhandling.distributed.ConsistentHashChangeListener
Returns a No-op version of the functional interface ConsistentHashChangeListener.
noOp() - Static method in interface org.axonframework.config.EventProcessingConfigurer.PooledStreamingProcessorConfiguration
noOp() - Static method in interface org.axonframework.eventhandling.EventTrackerStatusChangeListener
Returns a no-op implementation of the EventTrackerStatusChangeListener.
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.springboot.autoconfig
 
NoOpTransactionAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.NoOpTransactionAutoConfiguration
 
NoResourceInjector - Enum in org.axonframework.modelling.saga.repository
ResourceInjector that does not inject anything.
NoScopeDescriptor - Class in org.axonframework.messaging
A ScopeDescriptor describing no active scope.
NoSnapshotTriggerDefinition - Enum in org.axonframework.eventsourcing
Implementation of SnapshotTriggerDefinition that doesn't trigger snapshots at all.
NOT_RECURSIVE - Static variable in class org.axonframework.common.ReflectionUtils
Specifying a reflection operation should not be performed recursive.
nothing() - Static method in class org.axonframework.test.matchers.Matchers
Matches against null or void.
notifyHandlers(UnitOfWork.Phase) - Method in class org.axonframework.disruptor.commandhandling.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
 
nullSafeTypeOf(T) - Static method in class org.axonframework.common.ObjectUtils
Returns the type of the given instance, if it is not null.
numberOfResults(List<ProcessingInstruction>) - Static method in class org.axonframework.axonserver.connector.util.ProcessingInstructionHelper
Retrieve the desired 'number of results' as a long from the given processingInstructions, by searching for the ProcessingInstruction who's key equals the ProcessingKey.NR_OF_RESULTS.

O

objectMapper(ObjectMapper) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Sets the ObjectMapper used to serialize and parse the objects to JSON.
ObjectMapperAutoConfiguration - Class in org.axonframework.springboot.autoconfig
 
ObjectMapperAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.ObjectMapperAutoConfiguration
 
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(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.eventhandling.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.
onCompleted() - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
Deprecated.
 
onCompleted() - Method in class org.axonframework.axonserver.connector.util.ResubscribableStreamObserver
Deprecated.
 
onConsistentHashChanged(ConsistentHash) - Method in interface org.axonframework.commandhandling.distributed.ConsistentHashChangeListener
Notification that a consistent hash has changed.
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(Throwable) - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
Deprecated.
 
onError(Throwable) - Method in class org.axonframework.axonserver.connector.util.ResubscribableStreamObserver
Deprecated.
 
onError(Exception, EventMessage<?>, EventMessageHandler) - Method in interface org.axonframework.eventhandling.ListenerInvocationErrorHandler
Invoked after given eventListener failed to handle given event.
onError(Exception, EventMessage<?>, EventMessageHandler) - Method in class org.axonframework.eventhandling.LoggingErrorHandler
 
onError(Exception, EventMessage<?>, EventMessageHandler) - Method in enum org.axonframework.eventhandling.PropagatingErrorHandler
 
onError(Throwable, QueryMessage<?, ?>, MessageHandler) - Method in class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler
 
onError(Throwable, QueryMessage<?, ?>, MessageHandler) - Method in interface org.axonframework.queryhandling.QueryInvocationErrorHandler
Invoked when an error occurred while invoking a message handler in a scatter-gather query.
onEvent(CommandHandlingEntry, long, boolean) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
 
onEvent(CommandHandlingEntry, long, boolean) - Method in class org.axonframework.disruptor.commandhandling.EventPublisher
 
onEventTrackerStatusChange(Map<Integer, EventTrackerStatus>) - Method in interface org.axonframework.eventhandling.EventTrackerStatusChangeListener
Notification that an EventTrackerStatus has changed.
onInitialize(Consumer<Configuration>) - Method in interface org.axonframework.config.Configurer
Register an initialization handler which should be invoked prior to starting this Configurer.
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(Message<?>) - Method in class org.axonframework.micrometer.CapacityMonitor
 
onMessageIngested(EventMessage<?>) - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor
 
onMessageIngested(Message<?>) - Method in class org.axonframework.micrometer.MessageCountingMonitor
 
onMessageIngested(Message<?>) - Method in class org.axonframework.micrometer.MessageTimerMonitor
 
onMessageIngested(Message<?>) - Method in class org.axonframework.micrometer.PayloadTypeMessageMonitorWrapper
Deprecated.
 
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
 
onMessagesIngested(Collection<? extends T>) - Method in interface org.axonframework.monitoring.MessageMonitor
Takes a collection of messages and returns a map containing events along with their callbacks
OnMissingQualifiedBeanCondition - Class in org.axonframework.springboot.util
Condition implementation to check for a bean instance of a specific class *and* a specific qualifier on it, matching if no such bean can be found.
OnMissingQualifiedBeanCondition() - Constructor for class org.axonframework.springboot.util.OnMissingQualifiedBeanCondition
 
onNext(T) - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
Deprecated.
 
onNext(V) - Method in class org.axonframework.axonserver.connector.util.ResubscribableStreamObserver
Deprecated.
 
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.
OnQualifiedBeanCondition - Class in org.axonframework.springboot.util
Condition implementation to check for a bean instance of a specific class *and* a specific qualifier on it.
OnQualifiedBeanCondition() - Constructor for class org.axonframework.springboot.util.OnQualifiedBeanCondition
 
onResult(CommandMessage<? extends C>, CommandResultMessage<? extends R>) - Method in class org.axonframework.commandhandling.callbacks.FailureLoggingCallback
 
onResult(CommandMessage<? extends C>, CommandResultMessage<? extends R>) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
 
onResult(CommandMessage, CommandResultMessage) - Method in class org.axonframework.commandhandling.callbacks.LoggingCallback
 
onResult(CommandMessage<?>, CommandResultMessage<?>) - Method in class org.axonframework.commandhandling.callbacks.NoOpCallback
Invoked when command handling execution is completed.
onResult(CommandMessage<? extends C>, CommandResultMessage<? extends R>) - Method in interface org.axonframework.commandhandling.CommandCallback
Invoked when command handling execution is completed.
onResult(CommandMessage<? extends C>, CommandResultMessage<? extends R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
 
onResult(CommandMessage<? extends C>, CommandResultMessage<? extends R>) - Method in class org.axonframework.commandhandling.gateway.RetryingCallback
 
onResult(CommandMessage<? extends C>, CommandResultMessage<? extends R>) - Method in class org.axonframework.commandhandling.MonitorAwareCallback
 
onResult(CommandMessage<? extends C>, CommandResultMessage<? extends R>) - Method in class org.axonframework.disruptor.commandhandling.BlacklistDetectingCallback
 
onResult(CommandMessage<?>, CommandResultMessage<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
 
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(Runnable) - Method in interface org.axonframework.config.Configuration
Registers a shutdownHandler to be executed in the default phase 0 when the Configuration is shut down.
onShutdown(int, Runnable) - Method in interface org.axonframework.config.Configuration
Registers a shutdownHandler to be executed in the given phase when the Configuration is shut down.
onShutdown(int, LifecycleHandler) - Method in interface org.axonframework.config.Configuration
Registers an asynchronous shutdownHandler to be executed in the given phase when the Configuration is shut down.
onShutdown() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
 
onShutdown(int, LifecycleHandler) - Method in class org.axonframework.spring.config.AxonConfiguration
 
onStart(Runnable) - Method in interface org.axonframework.config.Configuration
Registers a startHandler to be executed in the default phase 0 when this Configuration is started.
onStart(int, Runnable) - Method in interface org.axonframework.config.Configuration
Registers a startHandler to be executed in the given phase when this Configuration is started.
onStart(int, LifecycleHandler) - Method in interface org.axonframework.config.Configuration
Registers an asynchronous startHandler to be executed in the given phase when this Configuration is started.
onStart() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
 
onStart(int, LifecycleHandler) - Method in class org.axonframework.spring.config.AxonConfiguration
 
openStream(TrackingToken) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
 
openStream(TrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
 
openStream(TrackingToken) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
Opens a stream for each event source at the specified token position.
openStream(TrackingToken) - Method in interface org.axonframework.messaging.StreamableMessageSource
Open a stream containing all messages since given tracking token.
optimizeEventConsumption(boolean) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
Sets whether event consumption should be optimized between Event Stream.
optionalExceptionResult() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
optionalExceptionResult() - Method in class org.axonframework.messaging.GenericResultMessage
 
optionalExceptionResult() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
optionalExceptionResult() - Method in interface org.axonframework.messaging.ResultMessage
Returns the Exception in case of exceptional result message or an empty Optional in case of successful execution.
optionalInstanceOf(Class<R>) - Static method in class org.axonframework.messaging.responsetypes.ResponseTypes
Specify the desire to retrieve an Optional<R> when performing a query.
OptionalResponseType<R> - Class in org.axonframework.messaging.responsetypes
A ResponseType implementation that will match with query handlers which return a single instance of the expected response type, but returns that as an Optional containing the result.
OptionalResponseType(Class<R>) - Constructor for class org.axonframework.messaging.responsetypes.OptionalResponseType
Instantiate a OptionalResponseType with the given expectedResponseType as the type to be matched against and to which the query response should be converted to.
or(CommandMessageFilter) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
or(CommandMessageFilter) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
 
or(CommandMessageFilter) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
 
or(CommandMessageFilter) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
 
or(CommandMessageFilter) - Method in interface org.axonframework.commandhandling.distributed.CommandMessageFilter
Returns a filter that matches when either this instance or the given other matches.
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.modelling.saga.repository.jdbc
Oracle 11 does not support AUTO_INCREMENT.
Oracle11SagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.modelling.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.
OrCommandMessageFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
A CommandMessageFilter implementation that matches whenever either of the supplied CommandMessageFilter instances match.
OrCommandMessageFilter(CommandMessageFilter, CommandMessageFilter) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.OrCommandMessageFilter
Initialize the filter to match when either the first or the second filter matches.
order() - Method in class org.axonframework.axonserver.connector.ServerConnectorConfigurerModule
 
order() - Method in interface org.axonframework.config.ConfigurerModule
Returns the relative order this configurer should be invoked, compared to other intstances.
ordered(HandlerDefinition...) - Static method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
Creates a MultiHandlerDefinition instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
ordered(HandlerEnhancerDefinition, HandlerDefinition...) - Static method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
Creates a MultiHandlerDefinition instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
ordered(List<HandlerDefinition>) - Static method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
Creates a MultiHandlerDefinition instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
ordered(List<HandlerDefinition>, HandlerEnhancerDefinition) - Static method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
Creates a MultiHandlerDefinition instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
ordered(HandlerEnhancerDefinition...) - Static method in class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
Creates a MultiHandlerEnhancerDefinition instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
ordered(List<HandlerEnhancerDefinition>) - Static method in class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
Creates a MultiHandlerEnhancerDefinition instance with the given delegates, which are automatically ordered based on the @Priority annotation on their respective classes.
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.
orElse(TargetContextResolver<? super T>) - Method in interface org.axonframework.axonserver.connector.TargetContextResolver
Returns a TargetContextResolver that uses this instance to resolve a context for a given message and if it returns null, returns the results of the other resolver instead.
org.axonframework.axonserver.connector - package org.axonframework.axonserver.connector
 
org.axonframework.axonserver.connector.command - package org.axonframework.axonserver.connector.command
 
org.axonframework.axonserver.connector.event.axon - package org.axonframework.axonserver.connector.event.axon
 
org.axonframework.axonserver.connector.event.util - package org.axonframework.axonserver.connector.event.util
 
org.axonframework.axonserver.connector.heartbeat - package org.axonframework.axonserver.connector.heartbeat
 
org.axonframework.axonserver.connector.heartbeat.connection.checker - package org.axonframework.axonserver.connector.heartbeat.connection.checker
 
org.axonframework.axonserver.connector.heartbeat.source - package org.axonframework.axonserver.connector.heartbeat.source
 
org.axonframework.axonserver.connector.processor - package org.axonframework.axonserver.connector.processor
 
org.axonframework.axonserver.connector.query - package org.axonframework.axonserver.connector.query
 
org.axonframework.axonserver.connector.query.subscription - package org.axonframework.axonserver.connector.query.subscription
 
org.axonframework.axonserver.connector.util - package org.axonframework.axonserver.connector.util
 
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.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.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.stream - package org.axonframework.common.stream
 
org.axonframework.common.transaction - package org.axonframework.common.transaction
 
org.axonframework.config - package org.axonframework.config
 
org.axonframework.deadline - package org.axonframework.deadline
 
org.axonframework.deadline.annotation - package org.axonframework.deadline.annotation
 
org.axonframework.deadline.quartz - package org.axonframework.deadline.quartz
 
org.axonframework.disruptor.commandhandling - package org.axonframework.disruptor.commandhandling
 
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.gateway - package org.axonframework.eventhandling.gateway
 
org.axonframework.eventhandling.interceptors - package org.axonframework.eventhandling.interceptors
 
org.axonframework.eventhandling.pooled - package org.axonframework.eventhandling.pooled
 
org.axonframework.eventhandling.replay - package org.axonframework.eventhandling.replay
 
org.axonframework.eventhandling.saga - package org.axonframework.eventhandling.saga
 
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.conflictresolution - package org.axonframework.eventsourcing.conflictresolution
 
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.jdbc.statements - package org.axonframework.eventsourcing.eventstore.jdbc.statements
 
org.axonframework.eventsourcing.eventstore.jpa - package org.axonframework.eventsourcing.eventstore.jpa
JPA Implementation of the EventStore.
org.axonframework.eventsourcing.snapshotting - package org.axonframework.eventsourcing.snapshotting
 
org.axonframework.lifecycle - package org.axonframework.lifecycle
 
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.responsetypes - package org.axonframework.messaging.responsetypes
 
org.axonframework.messaging.unitofwork - package org.axonframework.messaging.unitofwork
 
org.axonframework.metrics - package org.axonframework.metrics
 
org.axonframework.micrometer - package org.axonframework.micrometer
 
org.axonframework.micrometer.reservoir - package org.axonframework.micrometer.reservoir
 
org.axonframework.modelling.command - package org.axonframework.modelling.command
 
org.axonframework.modelling.command.inspection - package org.axonframework.modelling.command.inspection
 
org.axonframework.modelling.saga - package org.axonframework.modelling.saga
 
org.axonframework.modelling.saga.metamodel - package org.axonframework.modelling.saga.metamodel
 
org.axonframework.modelling.saga.repository - package org.axonframework.modelling.saga.repository
 
org.axonframework.modelling.saga.repository.inmemory - package org.axonframework.modelling.saga.repository.inmemory
 
org.axonframework.modelling.saga.repository.jdbc - package org.axonframework.modelling.saga.repository.jdbc
 
org.axonframework.modelling.saga.repository.jpa - package org.axonframework.modelling.saga.repository.jpa
 
org.axonframework.mongo.eventsourcing.eventstore - package org.axonframework.mongo.eventsourcing.eventstore
 
org.axonframework.monitoring - package org.axonframework.monitoring
 
org.axonframework.queryhandling - package org.axonframework.queryhandling
 
org.axonframework.queryhandling.annotation - package org.axonframework.queryhandling.annotation
 
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 - package org.axonframework.spring
 
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.springboot - package org.axonframework.springboot
 
org.axonframework.springboot.autoconfig - package org.axonframework.springboot.autoconfig
 
org.axonframework.springboot.util - package org.axonframework.springboot.util
 
org.axonframework.springboot.util.jpa - package org.axonframework.springboot.util.jpa
 
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.deadline - package org.axonframework.test.deadline
 
org.axonframework.test.eventscheduler - package org.axonframework.test.eventscheduler
 
org.axonframework.test.matchers - package org.axonframework.test.matchers
 
org.axonframework.test.saga - package org.axonframework.test.saga
 
org.axonframework.test.utils - package org.axonframework.test.utils
A collection of classes which may prove useful when testing Axon-based classes.
org.axonframework.util - package org.axonframework.util
 
OUTBOUND_COMMAND_CONNECTORS - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown outbound command and/or query connectors.
OUTBOUND_EVENT_CONNECTORS - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown outbound event connectors.
OUTBOUND_QUERY_CONNECTORS - Static variable in class org.axonframework.lifecycle.Phase
Phase to start or shutdown outbound command and/or query connectors.
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.
OVERRIDE_ONLY - Static variable in class org.axonframework.common.annotation.AnnotationUtils
Boolean specifying that a AnnotationUtils.findAnnotationAttributes(AnnotatedElement, String, boolean) invocation should only contain the exact attributes of the target annotation, overridden by identical attributes on meta-annotated annotations.
ownerColum() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
Deprecated.
ownerColumn() - 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

packageOfObject(Object) - Static method in class org.axonframework.config.EventProcessingModule
Gets the package name from the class of the given object.
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(ParameterResolverFactory) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Sets the ParameterResolverFactory used to resolve parameter values for annotated handlers in the AnnotationEventHandlerAdapter this EventHandlerInvoker instantiates.
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Sets the ParameterResolverFactory used to resolve parameter values for annotated handlers in the snapshot aggregate this snapshotter creates.
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
ParameterResolverFactory - Interface in org.axonframework.messaging.annotation
Interface for objects capable of creating Parameter Resolver instances for annotated handler methods.
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
Sets the ParameterResolverFactory used to resolve parameters for annotated handlers contained in the Aggregate.
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Sets the ParameterResolverFactory used to resolve parameters for annotated handlers contained in the Aggregate.
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
 
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
 
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
Sets the ParameterResolverFactory used to resolve parameters for annotated handlers for the given sagaType.
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Sets the ParameterResolverFactory used to resolve parameters for annotated handlers for the given sagaType.
parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
 
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.disruptor.commandhandling.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.
parse(Throwable) - Static method in class org.axonframework.axonserver.connector.event.util.GrpcExceptionParser
Convert the give exception into a RuntimeException.
parseInstant(CharSequence) - Static method in class org.axonframework.common.DateTimeUtils
Parse the given timestamp into an Instant.
pause() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
Pause this Unit of Work by unregistering it with the CurrentUnitOfWork.
PAYLOAD_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the payload type contained in the Message.
PAYLOAD_TYPE_TAG - Static variable in class org.axonframework.micrometer.TagsUtil
The micrometer Tag key that represents the Axon message payload type
PAYLOAD_TYPE_TAGGER_FUNCTION - Static variable in class org.axonframework.micrometer.TagsUtil
The function for creating the Micrometer Tags based on the message payload type.
PayloadAssociationResolver - Class in org.axonframework.modelling.saga
Used to derive the value of an association property by looking it up the event message's payload.
PayloadAssociationResolver() - Constructor for class org.axonframework.modelling.saga.PayloadAssociationResolver
 
payloadColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event payload column.
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.eventsourcing.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.eventsourcing.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.
payloadRevision - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
payloadRevision - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
payloadRevisionColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event payload revision column.
payloadRevisionColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get the name of the column containing the revision number of the serialized payload.
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 - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
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
 
payloadType() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
payloadTypeColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event payload type column.
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>) - Constructor for class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
Create a PayloadTypeMessageMonitorWrapper which builds monitors through a given monitorSupplier for every message payload type encountered.
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.
PayloadTypeMessageMonitorWrapper<T extends MessageMonitor<Message<?>>> - Class in org.axonframework.micrometer
Deprecated.
As of release 4.4, replaced by using Tags on the monitor implementations. Use {@link org.axonframework.micrometer.GlobalMetricRegistry#registerWithConfigurerWithDefaultTags(Configurer) to achieve the same behavior as this implementation.
PayloadTypeMessageMonitorWrapper(Function<String, T>) - Constructor for class org.axonframework.micrometer.PayloadTypeMessageMonitorWrapper
Deprecated.
Create a PayloadTypeMessageMonitorWrapper which builds monitors through a given monitorSupplier for every message payload type encountered.
PayloadTypeMessageMonitorWrapper(Function<String, T>, Function<Class<?>, String>) - Constructor for class org.axonframework.micrometer.PayloadTypeMessageMonitorWrapper
Deprecated.
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.eventsourcing.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.
peek() - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
 
peek() - Method in interface org.axonframework.common.stream.BlockingStream
Checks whether or not the next message in the stream is immediately available.
peek() - Method in class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
 
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.FilteringDomainEventStream
 
peek() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
 
performReset() - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
Performs any activities that are required to reset the state managed by handlers assigned to this invoker.
performReset(R) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
Performs any activities that are required to reset the state managed by handlers assigned to this invoker.
performReset() - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
 
performReset(R) - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
 
performReset() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
performReset(R) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
performReset() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
 
performReset(Object) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
 
PersistenceExceptionResolver - Interface in org.axonframework.common.jdbc
The PersistenceExceptionResolver is used to find out if an exception is caused by duplicate keys.
persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
Sets the PersistenceExceptionResolver used to detect concurrency exceptions from the backing database.
persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
 
persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the PersistenceExceptionResolver used to detect concurrency exceptions from the backing database.
persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
 
persistenceExceptionResolver(DataSource) - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
 
PessimisticLockFactory - Class in org.axonframework.common.lock
Implementation of a LockFactory that uses a pessimistic locking strategy.
PessimisticLockFactory(PessimisticLockFactory.Builder) - Constructor for class org.axonframework.common.lock.PessimisticLockFactory
Creates an instance of the lock factory using the given builder containing the configuration properties to use.
PessimisticLockFactory.Builder - Class in org.axonframework.common.lock
Builder class for the PessimisticLockFactory.
phase() - Method in interface org.axonframework.config.ModuleConfiguration
Deprecated.
a ModuleConfiguration's phase is no longer used, as distinct phases might be necessary for any of the start or shutdown processes added in the ModuleConfiguration.initialize(Configuration) method
Phase - Class in org.axonframework.lifecycle
Utility class containing constants which can be used as input for the StartHandler and ShutdownHandler annotations.
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.
platformConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Sets the AxonServerConnectionManager managing the connections to the AxonServer platform.
platformConnectionManager(AxonServerConfiguration, TagsConfigurationProperties, ManagedChannelCustomizer) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
PooledStreamingEventProcessor - Class in org.axonframework.eventhandling.pooled
A StreamingEventProcessor implementation which pools it's resources to enhance processing speed.
PooledStreamingEventProcessor(PooledStreamingEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
Instantiate a PooledStreamingEventProcessor based on the fields contained in the PooledStreamingEventProcessor.Builder.
PooledStreamingEventProcessor.Builder - Class in org.axonframework.eventhandling.pooled
Builder class to instantiate a PooledStreamingEventProcessor.
position() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
 
position() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
 
position() - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
position() - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
Returns the sum of all positions of the constituent tracking tokens.
position() - Method in class org.axonframework.eventhandling.ReplayToken
 
position() - Method in interface org.axonframework.eventhandling.TrackingToken
Return the estimated relative position this token represents.
postDelete(A) - Method in class org.axonframework.modelling.command.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.modelling.saga.repository.jdbc
SQL schema supporting postgres databases.
PostgresSagaSqlSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
Initialize a PostgresSagaSqlSchema using the default schema configuration.
PostgresSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.modelling.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.modelling.command.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.modelling.command.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.modelling.command.LockingRepository
 
prepareMessageHandlerRegistrars() - Method in class org.axonframework.config.DefaultConfigurer
Prepare the registered message handlers MessageHandlerRegistrar for initialization.
prepareModules() - Method in class org.axonframework.config.DefaultConfigurer
Prepare the registered modules for initialization.
prepareReset() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
 
prepareReset(R) - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
 
prepareReset() - Method in interface org.axonframework.eventhandling.EventMessageHandler
Performs any activities that are required to reset the state managed by handlers assigned to this handler.
prepareReset(R) - Method in interface org.axonframework.eventhandling.EventMessageHandler
Performs any activities that are required to reset the state managed by handlers assigned to this handler.
prepareReset() - Method in interface org.axonframework.modelling.saga.Saga
 
prepareReset(Object) - Method in interface org.axonframework.modelling.saga.Saga
 
prepareTrigger(Class<?>) - Method in class org.axonframework.eventsourcing.AggregateLoadTimeSnapshotTriggerDefinition
 
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(List<ProcessingInstruction>) - Static method in class org.axonframework.axonserver.connector.util.ProcessingInstructionHelper
Retrieve the priority as a long from the given processingInstructions, by searching for the ProcessingInstruction who's key equals the ProcessingKey.PRIORITY.
Priority - Annotation Type in org.axonframework.common
Indicates the relative priority of the annotated component.
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 interface org.axonframework.messaging.annotation.MessageInterceptingMember
 
priority() - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
 
priority() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
PriorityAnnotationComparator<T> - Class in org.axonframework.common.annotation
Comparator that compares objects based on the value on an @Priority annotation.
priorityCalculator(CommandPriorityCalculator) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the CommandPriorityCalculator used to deduce the priority of an incoming command among other commands, to give precedence over high(er) valued queries for example.
priorityCalculator(QueryPriorityCalculator) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the QueryPriorityCalculator used to deduce the priority of an incoming query among other queries, to give precedence over high(er) valued queries for example.
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.SubscribingEventProcessor
Process the given messages.
processDispatchInterceptors(DeadlineMessage<T>) - Method in class org.axonframework.deadline.AbstractDeadlineManager
Applies registered MessageDispatchInterceptors to the given message.
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.
processingGroup() - Method in interface org.axonframework.config.SagaConfiguration
Gets the Processing Group this Saga is assigned to.
ProcessingInstructionHelper - Class in org.axonframework.axonserver.connector.util
Utility class contain helper methods to extract information from ProcessingInstructions.
processingLoop(Segment) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Fetch and process event batches continuously for as long as the processor is not shutting down.
processingSegments(TrackingToken, Segment) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Indicates whether the eventMessage identified with given token should be processed as part of the given segment.
processingStatus() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
processingStatus() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Returns the status for each of the segments processed by this processor as EventTrackerStatus instances.
processingStatus() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
processingStrategy(EventProcessingStrategy) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
Sets the EventProcessingStrategy determining whether events are processed directly or asynchronously.
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.
processInterceptors(EventMessage<E>) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
Invokes all the dispatch interceptors and returns the EventMessage instance that should be dispatched.
processInUnitOfWork(List<? extends EventMessage<?>>, UnitOfWork<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
Process a batch of events.
processInUnitOfWork(List<? extends EventMessage<?>>, UnitOfWork<? extends EventMessage<?>>, Collection<Segment>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
Process a batch of events.
PROCESSOR_NAME_TAG - Static variable in class org.axonframework.micrometer.TagsUtil
The micrometer Tag key that represents the Axon event processor name
processorInfoConfiguration(EventProcessingConfiguration, AxonServerConnectionManager, AxonServerConfiguration) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
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.springboot.EventProcessorProperties.ProcessorSettings
 
ProcessUtils - Class in org.axonframework.common
Processing utilities.
producerType(ProducerType) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the ProducerType to use by the Disruptor.
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
 
propertyExtractor(Function<T, K>) - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy.Builder
Defines the property extractor, a function which is applied to the event message payload to extract the sequence identifier.
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.
propertyName(String) - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy.Builder
Defines the name of the property to be extracted as sequence identifier.
PropertySequencingPolicy<T,K> - Class in org.axonframework.eventhandling.async
A SequencingPolicy implementation that extracts the sequence identifier from the event message payload based on a given property or property extractor.
PropertySequencingPolicy(PropertySequencingPolicy.Builder) - Constructor for class org.axonframework.eventhandling.async.PropertySequencingPolicy
Instantiate a PropertySequencingPolicy based on the fields contained in the PropertySequencingPolicy.Builder.
PropertySequencingPolicy.Builder<T,K> - Class in org.axonframework.eventhandling.async
Builder class to instantiate a PropertySequencingPolicy.
provideScopeAwareStream(ScopeDescriptor) - Method in class org.axonframework.config.ConfigurationScopeAwareProvider
 
provideScopeAwareStream(ScopeDescriptor) - Method in interface org.axonframework.messaging.ScopeAwareProvider
Retrieve a Stream of ScopeAware components, by performing a check whether that component is able to handle a Scope described by a ScopeDescriptor.
publish(M) - Method in interface org.axonframework.axonserver.connector.Publisher
Deprecated.
Publishes the given message
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(Object) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
Publishes (dispatches) an event.
publish(List<?>) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway
 
publish(Object...) - Method in interface org.axonframework.eventhandling.gateway.EventGateway
Publish a collection of events on this bus (one, or multiple).
publish(List<?>) - Method in interface org.axonframework.eventhandling.gateway.EventGateway
Publish a collection of events on this bus (one, or multiple).
publish(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
publish(EventMessage<?>) - Method in class org.axonframework.modelling.command.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.modelling.command.inspection.AnnotatedChildEntity
 
publish(EventMessage<?>, T) - Method in interface org.axonframework.modelling.command.inspection.ChildEntity
Publish the given msg to the appropriate handlers on the given declaringInstance.
publish(EventMessage<?>, T) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
Publish given event message on the given target entity.
published(Object...) - Method in interface org.axonframework.test.saga.GivenAggregateEventPublisher
Register the given events as being published somewhere in the past.
Publisher<M> - Interface in org.axonframework.axonserver.connector
Deprecated.
in through use of the AxonServer java connector
publisherInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Configures the MessageHandlerInterceptor of generic type CommandMessage to use with the DisruptorCommandBus during the publication of changes.
publisherThreadCount(int) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the number of Threads that should be used to store and publish the generated Events.
publishes(Object) - Method in interface org.axonframework.test.saga.WhenAggregateEventPublisher
Register the given event to be published on behalf of an aggregate.
publishes(Object, Map<String, ?>) - Method in interface org.axonframework.test.saga.WhenAggregateEventPublisher
Register the given event to be published on behalf of an aggregate, with given additional metaData.
publishFailureFor(String, Throwable) - Method in interface org.axonframework.axonserver.connector.InstructionResultPublisher
Deprecated.
Notifies to Axon Server a failure during the execution of the specified instruction.
publishFailureFor(String, String) - Method in interface org.axonframework.axonserver.connector.InstructionResultPublisher
Deprecated.
Notifies to Axon Server a failure during the execution of the specified instruction.
publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Publish an event to external event handlers using the given event bus.
publishSuccessFor(String) - Method in interface org.axonframework.axonserver.connector.InstructionResultPublisher
Deprecated.
Notifies to Axon Server a successful execution of the specified instruction.
pulse() - Method in interface org.axonframework.axonserver.connector.heartbeat.HeartbeatSource
Deprecated.
Send an heartbeat to AxonServer
pulse() - Method in class org.axonframework.axonserver.connector.heartbeat.source.GrpcHeartbeatSource
Deprecated.
Send an heartbeat to AxonServer
put(Object, Object) - Method in interface org.axonframework.common.caching.Cache
Stores the given value in the cache, under given key.
put(Object, Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
put(Object, Object) - Method in class org.axonframework.common.caching.JCacheAdapter
 
put(Object, Object) - Method in class org.axonframework.common.caching.NoCache
 
put(Object, Object) - 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(Object, Object) - 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(Object, Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.JCacheAdapter
 
putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.NoCache
 
putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.WeakReferenceCache
 

Q

QuartzDeadlineManager - Class in org.axonframework.deadline.quartz
Implementation of DeadlineManager that delegates scheduling and triggering to a Quartz Scheduler.
QuartzDeadlineManager(QuartzDeadlineManager.Builder) - Constructor for class org.axonframework.deadline.quartz.QuartzDeadlineManager
Instantiate a QuartzDeadlineManager based on the fields contained in the QuartzDeadlineManager.Builder.
QuartzDeadlineManager.Builder - Class in org.axonframework.deadline.quartz
Builder class to instantiate a QuartzDeadlineManager.
QuartzEventScheduler - Class in org.axonframework.eventhandling.scheduling.quartz
EventScheduler implementation that delegates scheduling and triggering to a Quartz Scheduler.
QuartzEventScheduler(QuartzEventScheduler.Builder) - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Instantiate a QuartzEventScheduler based on the fields contained in the QuartzEventScheduler.Builder.
QuartzEventScheduler.Builder - Class in org.axonframework.eventhandling.scheduling.quartz
Builder class to instantiate a QuartzEventScheduler.
QuartzEventScheduler.DirectEventJobDataBinder - Class in org.axonframework.eventhandling.scheduling.quartz
Binds an EventMessage to the JobDataMap by serializing the payload and metadata with a Serializer.
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.
query(String, boolean) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
 
query(QueryMessage<Q, R>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
query(String, Q, ResponseType<R>) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
 
query(QueryMessage<Q, R>) - Method in interface org.axonframework.queryhandling.QueryBus
Dispatch the given query to a single QueryHandler subscribed to the given query's queryName and responseType.
query(Q, Class<R>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus, expecting a response with the given responseType from a single source.
query(String, Q, Class<R>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus, expecting a response with the given responseType from a single source.
query(Q, ResponseType<R>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus, expecting a response in the form of responseType from a single source.
query(String, Q, ResponseType<R>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus, expecting a response in the form of responseType from a single source.
query(QueryMessage<Q, R>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
 
QUERY_NAME - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the name of the QueryMessage the handler can handle.
queryBus() - Method in interface org.axonframework.config.Configuration
 
queryBus(QueryBus) - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
Sets the QueryBus to deliver QueryMessages on received in this QueryGateway implementation.
QueryBus - Interface in org.axonframework.queryhandling
The mechanism that dispatches Query objects to their appropriate QueryHandlers.
queryBus() - Method in class org.axonframework.spring.config.AxonConfiguration
 
queryBus(AxonConfiguration, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
queryBus(AxonConfiguration, TransactionManager, QueryInvocationErrorHandler) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
queryBus(AxonServerConnectionManager, AxonServerConfiguration, AxonConfiguration, TransactionManager, Serializer, Serializer, QueryPriorityCalculator, QueryInvocationErrorHandler, TargetContextResolver<? super QueryMessage<?, ?>>) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
QueryExecutionException - Exception in org.axonframework.queryhandling
Exception indicating that the execution of a Query Handler has resulted in an exception
QueryExecutionException(String, Throwable) - Constructor for exception org.axonframework.queryhandling.QueryExecutionException
Initializes the exception with given message and cause
QueryExecutionException(String, Throwable, Object) - Constructor for exception org.axonframework.queryhandling.QueryExecutionException
Initializes the exception with given message and cause and details.
queryFlowControl(int, int, int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
queryGateway() - Method in interface org.axonframework.config.Configuration
Returns the Query Gateway defined in this Configuration.
QueryGateway - Interface in org.axonframework.queryhandling
Interface towards the Query Handling components of an application.
queryGateway(QueryBus) - Method in class org.axonframework.spring.config.AxonConfiguration
 
queryGateway(QueryBus) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
QueryHandler - Annotation Type in org.axonframework.queryhandling
Marker annotation to mark any method on an object as being a QueryHandler.
QueryHandlerAdapter - Interface in org.axonframework.queryhandling
Describes a class capable of subscribing to the query bus.
QueryHandlerSubscriber - Class in org.axonframework.spring.config
Registers Spring beans that implement QueryHandlerAdapter with the query bus.
QueryHandlerSubscriber() - Constructor for class org.axonframework.spring.config.QueryHandlerSubscriber
 
QueryHandlingMember<T> - Interface in org.axonframework.queryhandling.annotation
Interface indicating that a MessageHandlingMember is capable of handling specific query messages.
QueryInvocationErrorHandler - Interface in org.axonframework.queryhandling
Interface describing a mechanism for the QueryMessage components to report errors.
queryInvocationErrorHandler() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
QueryMessage<T,R> - Interface in org.axonframework.queryhandling
Message type that carries a Query: a request for information.
queryName(Object) - Static method in interface org.axonframework.queryhandling.QueryMessage
Extracts the queryName from the given payloadOrMessage, with three possible outcomes: The payloadOrMessage is an instance of QueryMessage - QueryMessage.getQueryName() is returned. The payloadOrMessage is an instance of Message - the name of Message.getPayloadType() is returned. The payloadOrMessage is the query payload - Class.getName() is returned.
QueryPriorityCalculator - Interface in org.axonframework.axonserver.connector.query
Calculate the priority of QueryMessage based on its content.
queryPriorityCalculator() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
QueryResponseMessage<T> - Interface in org.axonframework.queryhandling
Message that contains the results of a Query.
QueryResult - Class in org.axonframework.axonserver.connector.event.axon
Single result row from a Query to the AxonServer.
QueryResult(EventQueryResultEntry) - Constructor for class org.axonframework.axonserver.connector.event.axon.QueryResult
Constructs a QueryResult from the given entry.
QueryResultStream - Interface in org.axonframework.axonserver.connector.event.axon
Iterator to process the results of a query.
QueryResultStreamAdapter - Class in org.axonframework.axonserver.connector.event.axon
Adapter for the QueryResultStream, wrapping a ResultStream of EventQueryResultEntry.
QueryResultStreamAdapter(ResultStream<EventQueryResultEntry>) - Constructor for class org.axonframework.axonserver.connector.event.axon.QueryResultStreamAdapter
Construct a QueryResultStreamAdapter deferring calls to the given resultStream.
QuerySerializer - Class in org.axonframework.axonserver.connector.query
Converter between Axon Framework QueryMessage and QueryResponseMessage and Axon Server gRPC Query and QueryResponse messages.
QuerySerializer(Serializer, Serializer, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.query.QuerySerializer
Instantiate a serializer used to convert Axon QueryMessages and QueryResponseMessages into Axon Server gRPC messages and vice versa.
queryUpdateEmitter() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
queryUpdateEmitter() - Method in interface org.axonframework.config.Configuration
Returns the Query Update Emitter in this Configuration.
queryUpdateEmitter() - Method in interface org.axonframework.queryhandling.QueryBus
Gets the QueryUpdateEmitter associated with this QueryBus.
QueryUpdateEmitter - Interface in org.axonframework.queryhandling
Component which informs subscription queries about updates, errors and when there are no more updates.
queryUpdateEmitter(QueryUpdateEmitter) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
queryUpdateEmitter() - Method in class org.axonframework.queryhandling.SimpleQueryBus
 
queryUpdateEmitter() - Method in class org.axonframework.spring.config.AxonConfiguration
 
queryUpdateHandlerRegistered(SubscriptionQueryMessage<?, ?, ?>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Checks whether there is a query update handler for a given query.
queryUpdateHandlerRegistered(SubscriptionQueryMessage<?, ?, ?>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
 
queuedMessages() - Method in class org.axonframework.eventhandling.AbstractEventBus
Returns a list of all the events staged for publication in this Unit of Work.
queueLengthThreshold(int) - Method in class org.axonframework.common.lock.PessimisticLockFactory.Builder
Defines the maximum number of queued threads to allow for this lock.

R

readAssociationValues(ResultSet) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
readAssociationValues(ResultSet) - Method in interface org.axonframework.modelling.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).
readData(Class<T>) - Method in class org.axonframework.serialization.UnknownSerializedType
Returns the data contained in the serialized object in the given desiredFormat, if supported.
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
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.
readEventDataForAggregate(ReadEventDataForAggregateStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
readEventDataForAggregate(Connection, EventSchema, String, long, int) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.fetchDomainEvents(String, long, int)

"SELECT [trackedEventFields] FROM [domainEventTable] WHERE [aggregateIdentifierColumn] = ?1 AND [sequenceNumberColumn] >= ?2 AND [sequenceNumberColumn] < ?3 ORDER BY [sequenceNumberColumn] ASC"

NOTE: "?1" is the identifier, "?2" is the firstSequenceNumber and "?3" is based on batchSize parameters from JdbcEventStorageEngine.fetchDomainEvents(String, long, int) and they should always be present for the PreparedStatement to work.

ReadEventDataForAggregateStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.fetchDomainEvents(String, long, int)
readEventDataWithGaps(ReadEventDataWithGapsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
readEventDataWithGaps(Connection, long, int, List<Long>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
readEventDataWithGaps(Connection, EventSchema, long, int, List<Long>) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.fetchTrackedEvents(TrackingToken, int) when there are gaps on the GapAwareTrackingToken.
ReadEventDataWithGapsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.fetchTrackedEvents(TrackingToken, int)
readEventDataWithoutGaps(ReadEventDataWithoutGapsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
readEventDataWithoutGaps(Connection, long, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
readEventDataWithoutGaps(Connection, EventSchema, long, int) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.fetchTrackedEvents(TrackingToken, int) when there is no gaps on the GapAwareTrackingToken.
ReadEventDataWithoutGapsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on JdbcEventStorageEngine.fetchTrackedEvents(TrackingToken, int)
readEvents(String) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
Reads the events for the given aggregateIdentifier from the eventStore.
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
 
readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
readEvents(String) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
readEvents(String, long) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
readSerializedSaga(ResultSet) - Method in interface org.axonframework.modelling.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
 
readSnapshot(String) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
Returns a stream of serialized event entries for given aggregateIdentifier if the backing database contains a snapshot of the aggregate.
readSnapshotData(ReadSnapshotDataStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Set the PreparedStatement to be used on JdbcEventStorageEngine.readSnapshotData(Connection, String).
readSnapshotData(Connection, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Creates a statement to be used at JdbcEventStorageEngine.readSnapshotData(String).
readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
 
readSnapshotData(Connection, EventSchema, String) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
Set the PreparedStatement to be used on JdbcEventStorageEngine.readSnapshotData(String).
readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
 
ReadSnapshotDataStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Contract which defines how to build a PreparedStatement for use on {@link JdbcEventStorageEngine#readSnapshotData(String)
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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
readToken(ResultSet) - Method in interface org.axonframework.modelling.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.
reconfigure(Class<?>, SnapshotTrigger) - Method in class org.axonframework.eventsourcing.AggregateLoadTimeSnapshotTriggerDefinition
 
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.
reconstruct(T, AggregateModel<T>, long, boolean, EventBus, RepositoryProvider, 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
 
recreateAggregate(AggregateModel<T>, EventStore, SnapshotTriggerDefinition) - Method in class org.axonframework.eventsourcing.AggregateCacheEntry
 
recreateAggregate(AggregateModel<T>, EventStore, RepositoryProvider, SnapshotTriggerDefinition) - Method in class org.axonframework.eventsourcing.AggregateCacheEntry
 
recreateWithNewMessage(DeadlineMessage<?>) - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
Creates a new instance of scheduled deadline info with new deadlineMessage.
RECURSIVE - Static variable in class org.axonframework.common.ReflectionUtils
Specifying a reflection operation should be performed recursive.
REFIRE_IMMEDIATELY_POLICY - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
The key under which a Predicate is stored within the SchedulerContext.
refireImmediatelyPolicy(Predicate<Throwable>) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
Sets a Predicate taking a Throwable to decided whether a failed DeadlineJob should be 'refired' immediately.
ReflectionUtils - Class in org.axonframework.common
Utility class for working with Java Reflection API.
register(BiPredicate<String, Case>, Handler) - Method in class org.axonframework.axonserver.connector.DefaultHandlers
Deprecated.
 
register(Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
Registers a handler that can handle instructions regardless of context or request case.
register(String, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
Registers a handler that can handle instructions for given context regardless of request case.
register(Case, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
Registers a handler that can handle instructions for given requestCase regardless of context.
register(String, Case, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
Registers a handler that can handle instructions for given context and requestCase.
register(BiPredicate<String, Case>, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
Registers a handler that can handle instructions matching given handlerSelector predicate.
register(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
Registers a PropertyAccessStrategy implementation at runtime.
registerActivity() - Method in class org.axonframework.lifecycle.ShutdownLatch
Add an activity this latch should wait on before opening up.
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.disruptor.commandhandling.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.
registerAnnotationQueryHandlerBeanPostProcessor(BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.AnnotationDrivenRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.AnnotationDrivenRegistrar
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer
 
registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.springboot.util.DefaultEntityRegistrar
 
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.
registerCommandBus(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor a CommandBus.
registerCommandBus(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor a CommandBus using Tags through the given tagsBuilder.
registerCommandCallback(CommandCallback<C, R>, ResponseType<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<? super CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerCommandDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Register a MessageDispatchInterceptor for CommandMessages which will be invoked before any command is dispatched on the CommandBus 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 Configurer.
registerCommandHandler(int, Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
Deprecated.
in favor of Configurer.registerCommandHandler(Function), since the phase of an annotated handler should be defined through the StartHandler/ShutdownHandler annotation.
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<? super CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerCommandHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Register a MessageHandlerInterceptor for CommandMessages which will be invoked before or after the command has been dispatched on the CommandBus to perform a task specified in the interceptor.
registerCommandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerCommandTargetResolver(CommandTargetResolver) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers the CommandTargetResolver within this fixture.
registerComponent(Class<C>, Function<Configuration, ? extends C>) - Method in interface org.axonframework.config.Configurer
Registers 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 MetricRegistry to monitor a component of given componentType.
registerComponent(Class<?>, String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor a component of the given componentType.
registerComponentWithDefaultTags(Class<?>, String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor a component of the given componentType.
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.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.
registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a deadline dispatch interceptor which will always be invoked before a deadline is dispatched (scheduled) on the DeadlineManager to perform a task specified in the interceptor.
registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a deadline dispatch interceptor which will always be invoked before a deadline is dispatched (scheduled) on the DeadlineManager to perform a task specified in the interceptor.
registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a deadline handler interceptor which will always be invoked before a deadline is handled to perform a task specified in the interceptor.
registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a deadline handler interceptor which will always be invoked before a deadline is handled to perform a task specified in the interceptor.
registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.SagaTestFixture
 
RegisterDefaultEntities - Annotation Type in org.axonframework.springboot.util
 
registerDefaultErrorHandler(Function<Configuration, ErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that builds the default ErrorHandler.
registerDefaultErrorHandler(Function<Configuration, ErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
 
registerDefaultHandlerInterceptor(BiFunction<Configuration, String, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Register the given interceptorBuilder as a default to build a MessageHandlerInterceptor for EventProcessors created in this configuration.
registerDefaultHandlerInterceptor(BiFunction<Configuration, String, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
registerDefaultListenerInvocationErrorHandler(Function<Configuration, ListenerInvocationErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that builds the default ListenerInvocationErrorHandler.
registerDefaultListenerInvocationErrorHandler(Function<Configuration, ListenerInvocationErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
 
registerDefaultSequencingPolicy(Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers the SequencingPolicy created by given policyBuilder to the processing groups for which no explicit policy is defined (using EventProcessingConfigurer.registerSequencingPolicy(String, Function)).
registerDefaultSequencingPolicy(Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super M>) - Method in class org.axonframework.axonserver.connector.DispatchInterceptors
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
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<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
Registers a command dispatch interceptor within a CommandGateway.
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.gateway.DefaultCommandGateway
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
Registers the given list of dispatch interceptors to the command bus.
registerDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.deadline.AbstractDeadlineManager
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
Register the given interceptor with this bus.
registerDispatchInterceptor(MessageDispatchInterceptor<? super EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventBus
Register the given interceptor with this bus.
registerDispatchInterceptor(MessageDispatchInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
Registers an event dispatch interceptor within an EventGateway.
registerDispatchInterceptor(MessageDispatchInterceptor<? super T>) - Method in interface org.axonframework.messaging.MessageDispatchInterceptorSupport
Register the given DispatchInterceptor.
registerDispatchInterceptor(MessageDispatchInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
Registers an interceptor that intercepts Queries as they are sent.
registerDispatchInterceptor(MessageDispatchInterceptor<? super SubscriptionQueryUpdateMessage<?>>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.deadline.StubDeadlineManager
 
registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
registerErrorHandler(String, Function<Configuration, ErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that builds an ErrorHandler for the given eventProcessorName.
registerErrorHandler(String, Function<Configuration, ErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
 
registerEventBus(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventBus.
registerEventBus(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventBus.
registerEventBus(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventBus using Tags through the given tagsBuilder.
registerEventHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
Registers a Function that builds an Event Handler instance.
registerEventHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that builds an Event Handler instance.
registerEventHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.EventProcessingModule
 
registerEventProcessor(String, EventProcessingConfigurer.EventProcessorBuilder) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers an EventProcessingConfigurer.EventProcessorBuilder for the given processor name.
registerEventProcessor(String, EventProcessingConfigurer.EventProcessorBuilder) - Method in class org.axonframework.config.EventProcessingModule
 
registerEventProcessor(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventProcessor.
registerEventProcessor(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventProcessor.
registerEventProcessor(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor an EventProcessor using Tags through the given tagsBuilder.
registerEventProcessorFactory(EventProcessingConfigurer.EventProcessorBuilder) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a factory that builds the default EventProcessor.
registerEventProcessorFactory(EventProcessingConfigurer.EventProcessorBuilder) - Method in class org.axonframework.config.EventProcessingModule
 
registerEventUpcaster(Function<Configuration, EventUpcaster>) - Method in interface org.axonframework.config.Configurer
Registers an upcaster to be used to upcast Events to a newer version
registerEventUpcaster(Function<Configuration, EventUpcaster>) - Method in class org.axonframework.config.DefaultConfigurer
 
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
 
registerHandlerDefinition(BiFunction<Configuration, Class, HandlerDefinition>) - Method in interface org.axonframework.config.Configurer
Registers the definition of a Handler class.
registerHandlerDefinition(BiFunction<Configuration, Class, HandlerDefinition>) - Method in class org.axonframework.config.DefaultConfigurer
 
registerHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerHandlerDefinition(HandlerDefinition) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a HandlerDefinition within this fixture.
registerHandlerDefinition(HandlerDefinition) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a HandlerDefinition within this fixture.
registerHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a HandlerEnhancerDefinition within this fixture.
registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a HandlerEnhancerDefinition within this fixture.
registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
 
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 interface org.axonframework.config.EventProcessingConfigurer
Register the given interceptorBuilder to build a MessageHandlerInterceptor for the EventProcessor with given processorName.
registerHandlerInterceptor(String, Function<Configuration, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.deadline.AbstractDeadlineManager
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super T>) - Method in interface org.axonframework.messaging.MessageHandlerInterceptorSupport
Register the given handlerInterceptor.
registerHandlerInterceptor(MessageHandlerInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
Registers an interceptor that is used to intercept Queries before they are passed to their respective handlers.
registerHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.deadline.StubDeadlineManager
 
registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
 
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.
registerLifecycleHandlers(Configuration, Object) - Static method in class org.axonframework.config.LifecycleHandlerInspector
Resolve any StartHandler and ShutdownHandler annotated lifecycle handlers in the given component.
registerListenerInvocationErrorHandler(String, Function<Configuration, ListenerInvocationErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that builds a ListenerInvocationErrorHandler for the given processingGroup.
registerListenerInvocationErrorHandler(String, Function<Configuration, ListenerInvocationErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
 
registerListenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a ListenerInvocationErrorHandler to be set for the Saga to deal with exceptions being thrown from within Saga Event Handlers.
registerListenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerMessageHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
Registers a message handler bean with this configuration.
registerMessageHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.DefaultConfigurer
 
registerMessageMonitor(String, Function<Configuration, MessageMonitor<Message<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a builder Function to create the MessageMonitor for a EventProcessor of the given name.
registerMessageMonitorFactory(String, MessageMonitorFactory) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers the factory to create the MessageMonitor for a EventProcessor of the given name.
registerMessageMonitorFactory(String, MessageMonitorFactory) - Method in class org.axonframework.config.EventProcessingModule
 
registerModule(ModuleConfiguration) - Method in interface org.axonframework.config.Configurer
Registers an Axon module with this configuration.
registerModule(ModuleConfiguration) - Method in class org.axonframework.config.DefaultConfigurer
 
registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerParameterResolverFactory(ParameterResolverFactory) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers a ParameterResolverFactory within this fixture.
registerParameterResolverFactory(ParameterResolverFactory) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a ParameterResolverFactory within this fixture.
registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerPooledStreamingEventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfigurer
registerPooledStreamingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
registerPooledStreamingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer
registerPooledStreamingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in class org.axonframework.config.EventProcessingModule
 
registerPooledStreamingEventProcessorConfiguration(EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer
registerPooledStreamingEventProcessorConfiguration(String, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer
registerPooledStreamingEventProcessorConfiguration(String, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in class org.axonframework.config.EventProcessingModule
 
registerPooledStreamingEventProcessorConfiguration(EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in class org.axonframework.config.EventProcessingModule
 
registerQueryBus(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers new metrics to the registry to monitor a QueryBus.
registerQueryBus(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor a QueryBus.
registerQueryBus(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers new metrics to the registry to monitor a QueryBus using Tags through the given tagsBuilder.
registerQueryHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
Registers a query handler bean with this Configurer.
registerQueryHandler(int, Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
Deprecated.
in favor of Configurer.registerQueryHandler(Function), since the phase of an annotated handler should be defined through the StartHandler/ShutdownHandler annotation.
registerQueryHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.DefaultConfigurer
 
registerRepository(Repository<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerRepository(Repository<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers an arbitrary repository with the fixture.
registerRepositoryProvider(RepositoryProvider) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
registerRepositoryProvider(RepositoryProvider) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers repository provider 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
 
registerResourceInjector(ResourceInjector) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a ResourceInjector within this fixture.
registerResourceInjector(ResourceInjector) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerRollbackConfiguration(String, Function<Configuration, RollbackConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that builds the RollbackConfiguration for given processor name.
registerRollbackConfiguration(String, Function<Configuration, RollbackConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
 
registerRoot(Callable<T>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
Registers the aggregate root created by the given aggregateFactory with this aggregate.
registerSaga(Class<T>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Saga with default configuration within this Configurer.
registerSaga(Class<T>, Consumer<SagaConfigurer<T>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Saga, allowing specific configuration to use for this Saga type.
registerSaga(Class<T>, Consumer<SagaConfigurer<T>>) - Method in class org.axonframework.config.EventProcessingModule
 
registerSagaStore(Function<Configuration, SagaStore>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a Function that builds a SagaStore.
registerSagaStore(Function<Configuration, SagaStore>) - Method in class org.axonframework.config.EventProcessingModule
 
registerSequencingPolicy(String, Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers the SequencingPolicy created by the given policyBuilder to the processing group with given processingGroup.
registerSequencingPolicy(String, Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
registerStartRecordingCallback(Runnable) - Method in interface org.axonframework.test.saga.FixtureConfiguration
Registers a callback to be invoked when the fixture execution starts recording.
registerStartRecordingCallback(Runnable) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
Registers a callback to be invoked when the fixture execution starts recording.
registerStartRecordingCallback(Runnable) - Method in class org.axonframework.test.saga.SagaTestFixture
 
registerSubscribingEventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a SubscribingEventProcessor with given name within this Configurer.
registerSubscribingEventProcessor(String, Function<Configuration, SubscribableMessageSource<? extends EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a SubscribingEventProcessor with given name and messageSource within this Configuration.
registerSubscribingEventProcessor(String, Function<Configuration, SubscribableMessageSource<? extends EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
registerTokenStore(String, Function<Configuration, TokenStore>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Register a Function that builds a TokenStore for the given processorName.
registerTokenStore(Function<Configuration, TokenStore>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Register a Function that builds a TokenStore to use as the default in case no explicit token store was configured for a processor.
registerTokenStore(String, Function<Configuration, TokenStore>) - Method in class org.axonframework.config.EventProcessingModule
 
registerTokenStore(Function<Configuration, TokenStore>) - Method in class org.axonframework.config.EventProcessingModule
 
registerTrackingEventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a TrackingEventProcessor with given name within this Configurer.
registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a TrackingEventProcessor with given name and source within this Configurer.
registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a TrackingEventProcessor with given name, source and processorConfiguration within this Configurer.
registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
 
registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
 
registerTrackingEventProcessorConfiguration(String, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Register a Function that builds a TrackingEventProcessorConfiguration to be used by the EventProcessor corresponding to the given name.
registerTrackingEventProcessorConfiguration(Function<Configuration, TrackingEventProcessorConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Register a Function that builds a TrackingEventProcessorConfiguration to use as the default.
registerTrackingEventProcessorConfiguration(String, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
 
registerTrackingEventProcessorConfiguration(Function<Configuration, TrackingEventProcessorConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
 
registerTransactionManager(String, Function<Configuration, TransactionManager>) - Method in interface org.axonframework.config.EventProcessingConfigurer
Registers a TransactionManager for a EventProcessor of the given name.
registerTransactionManager(String, Function<Configuration, TransactionManager>) - Method in class org.axonframework.config.EventProcessingModule
 
registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, int) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
Registers an Update Handler for given query with given updateBufferSize.
registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, int) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
 
registerWithConfigurer(Configurer) - Method in class org.axonframework.metrics.GlobalMetricRegistry
Registers the configured MetricRegistry with the given configurer via Configurer.configureMessageMonitor(Function).
registerWithConfigurer(Configurer) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers the MeterRegistry with the given configurer via Configurer.configureMessageMonitor(Function).
registerWithConfigurerWithDefaultTags(Configurer) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
Registers the MeterRegistry with the given configurer via Configurer.configureMessageMonitor(Function).
Registration - Interface in org.axonframework.common
Interface that provides a mechanism to cancel a registration.
rejectAll() - Static method in interface org.axonframework.eventsourcing.snapshotting.SnapshotFilter
A SnapshotFilter implementation which rejects all snapshots.
rejectDuplicates() - Static method in class org.axonframework.commandhandling.DuplicateCommandHandlerResolution
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.
releaseSegment(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
releaseSegment(int, long, TimeUnit) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
releaseSegment(int) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Instructs the processor to release the segment with given segmentId.
releaseSegment(int, long, TimeUnit) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Instructs the processor to release the segment with given segmentId.
releaseSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Instructs the processor to release the segment with given segmentId.
releaseSegment(int, long, TimeUnit) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
REMOTE_MEMBER - Static variable in class org.axonframework.commandhandling.distributed.SimpleMember
Denotes that a SimpleMember is a representation of a Remote Member.
RemoteExceptionDescription - Class in org.axonframework.messaging
Description of an Exception received from a remote source.
RemoteExceptionDescription(List<String>) - Constructor for class org.axonframework.messaging.RemoteExceptionDescription
Initialize a RemoteExceptionDescription with given descriptions describing the exception chain on the remote end of communication
RemoteHandlingException - Exception in org.axonframework.messaging
Exception indicating that an error has occurred while remotely handling a message.
RemoteHandlingException(RemoteExceptionDescription) - Constructor for exception org.axonframework.messaging.RemoteHandlingException
Initializes the exception using the given exceptionDescription describing the remote cause-chain.
remove(Object) - Method in interface org.axonframework.common.caching.Cache
Removes the entry stored under given key.
remove(Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
 
remove(Object) - Method in class org.axonframework.common.caching.JCacheAdapter
 
remove(Object) - Method in class org.axonframework.common.caching.NoCache
 
remove(Object) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
remove() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
 
remove(Object) - Method in class org.axonframework.messaging.MetaData
This operation is not supported.
remove(AssociationValue) - Method in interface org.axonframework.modelling.saga.AssociationValues
Removes the given associationValue, if it is contained by this instance.
remove(AssociationValue) - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
remove(AssociationValue, String, String) - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
Removes an association between the given associationValue and sagaIdentifier.
removeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.modelling.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.modelling.saga.SagaLifecycle
Removes the given association from the currently active Saga.
removeAssociationWith(String, Number) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
Removes the given association from the currently active Saga.
removedAssociations() - Method in interface org.axonframework.modelling.saga.AssociationValues
Returns the Set of association values that have been removed since the last AssociationValues.commit().
removedAssociations() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
RemovedTrackerStatus - Class in org.axonframework.eventhandling
References an EventTrackerStatus which no active work is occurring on.
RemovedTrackerStatus(EventTrackerStatus) - Constructor for class org.axonframework.eventhandling.RemovedTrackerStatus
Initializes the RemovedTrackerStatus using the given removedTrackerStatus.
ReplayAwareMessageHandlerWrapper - Class in org.axonframework.eventhandling.replay
An implementation of the HandlerEnhancerDefinition that is used for AllowReplay annotated message handling methods.
ReplayAwareMessageHandlerWrapper() - Constructor for class org.axonframework.eventhandling.replay.ReplayAwareMessageHandlerWrapper
 
ReplayParameterResolverFactory - Class in org.axonframework.eventhandling.replay
An implementation of the ParameterResolverFactory which resolves the ReplayStatus parameter.
ReplayParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.replay.ReplayParameterResolverFactory
 
ReplayStatus - Enum in org.axonframework.eventhandling
Type that can be used as parameter of Event Handler methods that indicates whether a message is delivered as part of a replay, or in regular operations.
ReplayToken - Class in org.axonframework.eventhandling
Token keeping track of the position before a reset was triggered.
ReplayToken(TrackingToken) - Constructor for class org.axonframework.eventhandling.ReplayToken
Initialize a ReplayToken, using the given tokenAtReset to represent the position at which a reset was triggered.
ReplayToken(TrackingToken, TrackingToken) - Constructor for class org.axonframework.eventhandling.ReplayToken
Initializes a ReplayToken with tokenAtReset which represents the position at which a reset was triggered and the newRedeliveryToken which represents current token.
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, CommandResultMessage<?>, Serializer) - Constructor for class org.axonframework.commandhandling.distributed.ReplyMessage
Initializes a ReplyMessage containing a reply to the command with given {commandIdentifier} and given commandResultMessage.
reportDifferentMetaData(Class<?>, Map<String, Object>, Map<String, Object>) - Method in class org.axonframework.test.aggregate.Reporter
Report an error due to a difference in the metadata of a message
reportDifferentPayloads(Class<?>, Field, Object, Object) - Method in class org.axonframework.test.aggregate.Reporter
Report an error due to a difference in one of the fields of the message payload.
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(EventMessage<?>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
Report the given eventMessage as ignored.
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(LockAwareAggregate<T, EventSourcedAggregate<T>>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
reportIllegalState(A) - Method in class org.axonframework.modelling.command.AbstractRepository
Invoked when an the given aggregate instance has been detected that has been part of a rolled back Unit of Work.
reportIncorrectDeletedState(boolean) - Method in class org.axonframework.test.aggregate.Reporter
Report an error due to a difference in the expected state of the `isDeleted` marker on the Aggregate.
reportResult(CommandResultMessage<R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
Invokes CommandCallback.onResult(CommandMessage, CommandResultMessage) with given result on the wrapped callback.
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.
reportWrongExceptionMessage(Throwable, Description) - Method in class org.axonframework.test.aggregate.Reporter
Report an error due to a difference in exception message.
reportWrongResult(Object, Object) - Method in class org.axonframework.test.aggregate.Reporter
Reports an error due to a wrong return value.
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<A>) - Method in interface org.axonframework.config.Configuration
Returns the Repository configured for the given aggregateType.
repository() - Method in interface org.axonframework.config.SagaConfiguration
Retrieve the SagaRepository in this Configuration.
repository(Repository<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Sets the Repository used to add and load Aggregate instances of generic type T upon handling commands for it.
Repository<T> - Interface in org.axonframework.modelling.command
The repository provides an abstraction of the storage of aggregates.
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.
RepositoryFactoryBean<T> - Class in org.axonframework.spring.config
Spring Factory bean that allows registration of a Repository for an Aggregate in the Spring Application Context based on a given AggregateConfiguration
RepositoryFactoryBean(AggregateConfiguration<T>) - Constructor for class org.axonframework.spring.config.RepositoryFactoryBean
Initialize the Factory Bean using given aggregateConfiguration to locate the configured Repository instance.
repositoryFor(Class<T>) - Method in interface org.axonframework.modelling.command.RepositoryProvider
Provides a repository for given aggregate type.
repositoryProvider(RepositoryProvider) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Sets the RepositoryProvider provided to the snapshot aggregates this snapshotter creates for correct instantiation.
repositoryProvider - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
repositoryProvider(RepositoryProvider) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Sets the RepositoryProvider which services repositories for specific aggregate types.
repositoryProvider(RepositoryProvider) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
Sets the RepositoryProvider which services repositories for specific aggregate types.
RepositoryProvider - Interface in org.axonframework.modelling.command
Provides a repository for given aggregate type.
repositoryProvider(RepositoryProvider) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
 
requestStreamFactory(Function<UpstreamAwareStreamObserver<QueryProviderInbound>, StreamObserver<QueryProviderOutbound>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Deprecated.
in through use of the AxonServer java connector
requestTimeout(long, TimeUnit) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
Sets the timeout in which a confirmation of the scheduling interaction is expected.
requiresExplicitSegmentInitialization() - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
requiresExplicitSegmentInitialization() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
requiresExplicitSegmentInitialization() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
requiresExplicitSegmentInitialization() - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Indicates whether this TokenStore instance requires segments to be explicitly initialized, before any tokens can be claimed for that segment.
reschedule(ScheduleToken, Duration, Object) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
Changes the trigger time for a scheduled event.
reschedule(ScheduleToken, Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Cancel a scheduled event and schedule another in its place.
reschedule(ScheduleToken, Instant, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Cancel a scheduled event and schedule another in its place.
rescheduleCommandsOnCorruptState(boolean) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Set the indicator specifying whether commands that failed because they were executed against potentially corrupted aggregate state should be automatically rescheduled.
reservoirFactory(Supplier<Reservoir>) - Method in class org.axonframework.metrics.MessageTimerMonitor.Builder
Sets factory method creating a Reservoir to be used by the Timer instances created by this MessageMonitor.
reset(CommandMessage<?>, MessageHandler<? super CommandMessage<?>>, int, int, BlacklistDetectingCallback, List<MessageHandlerInterceptor<? super CommandMessage<?>>>, List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Resets this entry, preparing it for use for another command.
reset(T) - Method in class org.axonframework.disruptor.commandhandling.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() - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
This method is used to reset all the variables that are used to check if a threshold has been exceeded
reset(T) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
Reset the processing context.
resetAsCallable(Callable<Object>, int, int, BlacklistDetectingCallback<Object, Object>) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Resets this entry, preparing it to run given callable from within the invocationInterceptorChain.
resetAsRecoverEntry(String) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Resets this entry, preparing it for use as a recovery entry.
ResetContext<T> - Interface in org.axonframework.eventhandling.replay
Represents a Message initiating the reset of an Event Handling Component.
ResetHandler - Annotation Type in org.axonframework.eventhandling
Annotation that can be placed on a method that is to be invoked when a reset is being prepared.
ResetNotSupportedException - Exception in org.axonframework.eventhandling
Exception indicating that a reset is not supported by a component.
ResetNotSupportedException(String) - Constructor for exception org.axonframework.eventhandling.ResetNotSupportedException
Initialize the exception with given message
ResetNotSupportedException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.ResetNotSupportedException
Initialize the exception with given message and cause.
resetTokens() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
resetTokens(R) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>, R) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
resetTokens(TrackingToken) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
resetTokens(TrackingToken, R) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
resetTokens() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Resets tokens to their initial state.
resetTokens(R) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Resets tokens to their initial state.
resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Reset tokens to the position as return by the given initialTrackingTokenSupplier.
resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>, R) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Reset tokens to the position as return by the given initialTrackingTokenSupplier.
resetTokens(TrackingToken) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Resets tokens to the given startPosition.
resetTokens(TrackingToken, R) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Resets tokens to the given startPosition.
resetTokens() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
resetTokens(R) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>, R) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
resetTokens(TrackingToken) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
resetTokens(TrackingToken, R) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
resolve(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.DuplicateCommandHandlerResolver
Chooses what to do when a duplicate handler is registered, returning the handler that should be selected for command handling, or otherwise throwing an exception to reject registration altogether.
resolve(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.FailingDuplicateCommandHandlerResolver
 
resolve(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.LoggingDuplicateCommandHandlerResolver
 
resolve(String, EventMessage<?>, MessageHandlingMember<T>) - Method in interface org.axonframework.modelling.saga.AssociationResolver
Resolves the associationPropertyName as a value.
resolve(String, EventMessage<?>, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.MetaDataAssociationResolver
Finds the association property value by looking up the association property name in the event message's MetaData.
resolve(String, EventMessage<?>, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.PayloadAssociationResolver
Finds the association property value in the message's payload.
resolveAssociation(EventMessage<?>) - Method in interface org.axonframework.modelling.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.
resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
Resolve the target of an incoming CommandMessage to the right Child Entity.
resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
 
resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
 
resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
 
resolveContext(T) - Method in interface org.axonframework.axonserver.connector.TargetContextResolver
Provides the context to which a message should be routed.
resolveDetails(Throwable) - Static method in exception org.axonframework.messaging.HandlerExecutionException
Resolve details from the given throwable, taking into account that the details may be available in any of the HandlerExecutionExceptions is the "cause" chain.
resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
Resolve the targets of an incoming EventMessage to the right Child Entities.
resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
 
resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
 
resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
 
resolveGenericType(Field, int) - Static method in class org.axonframework.common.ReflectionUtils
Resolve a generic type parameter from a field declaration
resolveMemberGenericType(Member, int) - Static method in class org.axonframework.common.ReflectionUtils
Resolve a generic type parameter from a member declaration.
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.eventhandling.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
 
resolveParameterValue(Message<?>) - Method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
 
resolveParameterValue(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
 
resolveParameterValue(Message<?>) - Method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
 
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.
resolvePrimitiveWrapperTypeIfPrimitive(Type) - Static method in class org.axonframework.common.ReflectionUtils
Returns the boxed wrapper type for the given type if it is primitive.
resolveReturnValue(CommandMessage<?>, Aggregate<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
Resolves the value to return when the given command has created the given aggregate.
resolveTarget(CommandMessage<?>) - Method in class org.axonframework.modelling.command.AnnotationCommandTargetResolver
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given command should be executed.
resolveTarget(CommandMessage<?>) - Method in interface org.axonframework.modelling.command.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.modelling.command.MetaDataCommandTargetResolver
 
resourceInjector() - Method in interface org.axonframework.config.Configuration
Returns the ResourceInjector used to provide resources to Saga instances.
resourceInjector(ResourceInjector) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Sets the ResourceInjector used to initialize Saga instances after a target instance is created or loaded from the store.
ResourceInjector - Interface in org.axonframework.modelling.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.
responseMessagePayloadType() - Method in class org.axonframework.messaging.responsetypes.InstanceResponseType
 
responseMessagePayloadType() - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
 
responseMessagePayloadType() - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
 
responseMessagePayloadType() - Method in interface org.axonframework.messaging.responsetypes.ResponseType
Returns a Class representing the type of the payload to be contained in the response message.
ResponseType<R> - Interface in org.axonframework.messaging.responsetypes
Specifies the expected response type required when performing a query through the QueryBus/QueryGateway.
ResponseTypes - Class in org.axonframework.messaging.responsetypes
Utility class containing static methods to obtain instances of ResponseType.
ResubscribableStreamObserver<V> - Class in org.axonframework.axonserver.connector.util
Deprecated.
in through use of the AxonServer java connector
ResubscribableStreamObserver(StreamObserver<V>, Consumer<Throwable>) - Constructor for class org.axonframework.axonserver.connector.util.ResubscribableStreamObserver
Deprecated.
Creates the Re-subscribable Stream Observer.
RESULT_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the result type the handler can handle.
ResultHandler - Annotation Type in org.axonframework.messaging.interceptors
Meta-Annotation used to demarcate MessageHandlerInterceptor annotated methods as interceptors that should only act on the result of a handler invocation.
ResultMessage<R> - Interface in org.axonframework.messaging
Message that represents a result of handling some form of request message.
ResultParameterResolverFactory - Class in org.axonframework.messaging.annotation
ParameterResolverFactory that provides support for Parameters where the result of Handler execution is expected to be injected.
ResultParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.ResultParameterResolverFactory
 
ResultValidator<T> - Interface in org.axonframework.test.aggregate
Interface describing the operations available on the "validate result" (a.k.a.
ResultValidatorImpl<T> - Class in org.axonframework.test.aggregate
Implementation of the ResultValidator.
ResultValidatorImpl(List<EventMessage<?>>, FieldFilter, Supplier<Aggregate<T>>, StubDeadlineManager) - Constructor for class org.axonframework.test.aggregate.ResultValidatorImpl
Initialize the ResultValidatorImpl with the given storedEvents and publishedEvents.
resume() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
Resume a paused Unit of Work by registering it with the CurrentUnitOfWork.
retrieveStorageIdentifier() - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
 
retrieveStorageIdentifier() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
 
retrieveStorageIdentifier() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
 
retrieveStorageIdentifier() - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
Returns a unique identifier that uniquely identifies the storage location of the tokens in this store.
retryExecutor(ScheduledExecutorService) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
Sets the ScheduledExecutorService used to schedule a command retry.
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.
retryInterval(int) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler.Builder
Sets the retry interval in milliseconds at which to schedule a retry.
retryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
Sets the RetryScheduler capable of performing retries of failed commands.
retryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
Sets the RetryScheduler which will decide whether to reschedule commands.
retryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
 
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(String) - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
Sets an aggregate revision this SnapshotFilter will allow.
revision - Variable in class org.axonframework.modelling.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(RevisionResolver) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Sets the RevisionResolver used to resolve the revision from an object to be serialized.
revisionResolver(RevisionResolver) - Method in class org.axonframework.serialization.JavaSerializer.Builder
Deprecated.
Sets the RevisionResolver used to resolve the revision from an object to be serialized.
revisionResolver(RevisionResolver) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Sets the RevisionResolver used to resolve the revision from an object to be serialized.
RevisionResolver - Interface in org.axonframework.serialization
Interface towards a mechanism that resolves the revision of a given payload type.
revisionResolver(RevisionResolver) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
 
revisionResolver() - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
RevisionSnapshotFilter - Class in org.axonframework.eventsourcing.snapshotting
A SnapshotFilter implementation which based on a configurable allowed revision will only SnapshotFilter.allow(DomainEventData) DomainEventData containing that revision.
RevisionSnapshotFilter(RevisionSnapshotFilter.Builder) - Constructor for class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter
Instantiate a RevisionSnapshotFilter based on the fields contained in the RevisionSnapshotFilter.Builder.
RevisionSnapshotFilter(String) - Constructor for class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter
Deprecated.
in favor of using the RevisionSnapshotFilter.Builder
RevisionSnapshotFilter.Builder - Class in org.axonframework.eventsourcing.snapshotting
Builder class to instantiate a RevisionSnapshotFilter.
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(RollbackConfiguration) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
 
rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
Sets the RollbackConfiguration which allows you to specify when a UnitOfWork should be rolled back.
rollbackConfiguration(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the RollbackConfiguration tied to the given processorName.
rollbackConfiguration(String) - Method in class org.axonframework.config.EventProcessingModule
 
rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the RollbackConfiguration which allows you to specify when a UnitOfWork should be rolled back.
rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
Sets the RollbackConfiguration specifying the rollback behavior of the UnitOfWork while processing a batch of events.
rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
 
rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
Sets the RollbackConfiguration specifying the rollback behavior of the UnitOfWork while processing a batch of events.
rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
Sets the RollbackConfiguration specifying the rollback behavior of the UnitOfWork while processing a batch of events.
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 interface org.axonframework.messaging.unitofwork.UnitOfWork
Returns the root of this Unit of Work.
root() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
Returns the (annotated) Saga instance.
ROOT_SEGMENT - Static variable in class org.axonframework.eventhandling.Segment
Represents the Segment that matches against all input, but can be split to start processing elements in parallel.
rootType() - Method in interface org.axonframework.modelling.command.Aggregate
Get the class type of the wrapped aggregate root that the Aggregate defers to for command handling.
rootType() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
rootType() - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
routingKey() - Method in interface org.axonframework.commandhandling.CommandMessageHandlingMember
Returns the property of the command that is to be used as routing key towards this command handler instance.
RoutingKey - Annotation Type in org.axonframework.commandhandling
Field or method level annotation that marks a field or method providing the routing key that a command targets.
routingKey() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
routingKey() - Method in interface org.axonframework.modelling.command.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.
routingServers() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
routingStrategy(RoutingStrategy) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the RoutingStrategy used to correctly configure connections between Axon clients and Axon Server.
RoutingStrategy - Interface in org.axonframework.commandhandling.distributed
Interface describing a mechanism that generates a routing key for a given command.
routingStrategy() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
run() - Method in class org.axonframework.common.MemberAccessibilityCallback
 
run() - Method in interface org.axonframework.config.LifecycleHandler
Run the start up or shutdown process this LifecycleHandler represents.
run() - Method in class org.axonframework.eventhandling.async.EventProcessorTask
 
runOnPrepareCommitOrNow(Runnable) - Method in class org.axonframework.deadline.AbstractDeadlineManager
Run a given deadlineCall immediately, or schedule it for the UnitOfWork it's 'prepare commit' phase if a UnitOfWork is active.

S

saga() - Method in interface org.axonframework.modelling.saga.repository.SagaStore.Entry
Returns the Saga instance in unserialized form.
Saga<T> - Interface in org.axonframework.modelling.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.
SAGA_ASSOCIATION_PROPERTY - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the property in the handled EventMessage to associate a saga instance with.
SAGA_ASSOCIATION_PROPERTY_KEY_NAME - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the saga event handler's association property key name used.
SAGA_ASSOCIATION_RESOLVER - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the type of association resolver used by a saga event handler.
sagaCache(Cache) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
Sets the sagaCache of type Cache used to store Sagas with.
sagaConfiguration(Class<T>) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the SagaConfiguration for the given sagaType.
SagaConfiguration<S> - Interface in org.axonframework.config
Represents a set of components needed to configure a Saga.
sagaConfigurations() - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns a List of SagaConfigurations registered within this configuration.
sagaConfigurations() - Method in class org.axonframework.config.EventProcessingModule
 
SagaConfigurer<T> - Class in org.axonframework.config
Provides mechanisms to configure the components used to manage and store Saga.
SagaConfigurer(Class<T>) - Constructor for class org.axonframework.config.SagaConfigurer
Initializes a configurer for the given Saga Type.
SagaCreationException - Exception in org.axonframework.modelling.saga.repository
Exception triggered when a new saga instance could not be instantiated.
SagaCreationException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.repository.SagaCreationException
Initializes the exception using the given message and cause.
SagaCreationPolicy - Enum in org.axonframework.modelling.saga
Enumeration containing the possible Creation Policies for Sagas.
SagaEntry<T> - Class in org.axonframework.modelling.saga.repository.jpa
Java Persistence Entity allowing sagas to be stored in a relational database.
SagaEntry(T, String, Serializer) - Constructor for class org.axonframework.modelling.saga.repository.jpa.SagaEntry
Constructs a new SagaEntry for the given saga.
SagaEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.SagaEntry
Constructor required by JPA.
sagaEntryEntityName() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
Intended for clients to override.
sagaEntryTable() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
Returns the name of the sagaEntry table
SagaEventHandler - Annotation Type in org.axonframework.modelling.saga
Method-level annotation indicating that the annotated method is an event handler method for the saga instance.
sagaEventProcessor(Class<?>) - Method in interface org.axonframework.config.EventProcessingConfiguration
Obtains an Saga EventProcessor implementation for the given sagaType.
SagaExecutionException - Exception in org.axonframework.modelling.saga
Exception triggered by a saga while it is processing an event or processing a task.
SagaExecutionException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaExecutionException
Initializes the exception using the given message and cause.
sagaFactory(Supplier<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
Sets the sagaFactory of type Supplier responsible for creating new Saga instances.
sagaFactory(Supplier<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
 
sagaId - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
 
SagaInitializationPolicy - Class in org.axonframework.modelling.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.modelling.saga.SagaInitializationPolicy
Creates an instance using the given creationPolicy and initialAssociationValue.
SagaInstantiationException - Exception in org.axonframework.modelling.saga
Exception triggered during initialization of a Saga.
SagaInstantiationException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaInstantiationException
Initializes the exception using the given message and cause.
SagaLifecycle - Class in org.axonframework.modelling.saga
Abstract base class of a component that models a saga's life cycle.
SagaLifecycle() - Constructor for class org.axonframework.modelling.saga.SagaLifecycle
 
SagaMetaModelFactory - Interface in org.axonframework.modelling.saga.metamodel
Interface of a factory for a SagaModel for any given saga type.
SagaMethodMessageHandlerDefinition - Class in org.axonframework.modelling.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.modelling.saga.SagaMethodMessageHandlerDefinition
SagaMethodMessageHandlingMember<T> - Class in org.axonframework.modelling.saga
A data holder containing information of SagaEventHandler annotated methods.
SagaMethodMessageHandlingMember(MessageHandlingMember<T>, SagaCreationPolicy, String, String, AssociationResolver) - Constructor for class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
Creates a SagaMethodMessageHandler.
sagaModel(SagaModel<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
Sets the SagaModel of generic type T, describing the structure of the Saga this AbstractSagaManager implementation will manage.
SagaModel<T> - Interface in org.axonframework.modelling.saga.metamodel
Interface of a model that describes a Saga of type T.
sagaModel(SagaModel<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Sets the SagaModel of generic type T, describing the structure of the Saga this SagaRepository implementation will store.
sagaProcessingGroup(Class<?>) - Method in interface org.axonframework.config.EventProcessingConfiguration
Gets the processing group for given sagaType.
sagaProcessingGroup(Class<?>) - Method in class org.axonframework.config.EventProcessingModule
 
sagaRepository(SagaRepository<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
Sets the SagaRepository of generic type T used to save and load Saga instances.
sagaRepository(SagaRepository<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
 
SagaRepository<T> - Interface in org.axonframework.modelling.saga
Interface towards the storage mechanism of Saga instances.
sagaSchema() - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
Returns the SagaSchema used to configure this sql saga schema.
SagaSchema - Class in org.axonframework.modelling.saga.repository.jdbc
SagaSchema allows specification of custom storage locations for the saga repositories.
SagaSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
Initialize SagaSchema with default values.
SagaSchema(String, String) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
Initialize SagaSchema with custom locations for event entry tables.
SagaScopeDescriptor - Class in org.axonframework.eventhandling.saga
Deprecated.
in favor of the SagaScopeDescriptor
SagaScopeDescriptor(String, Object) - Constructor for class org.axonframework.eventhandling.saga.SagaScopeDescriptor
Deprecated.
Instantiate a SagaScopeDescriptor with the provided type and identifier.
SagaScopeDescriptor - Class in org.axonframework.modelling.saga
Describes the scope of a Saga by means of its type and identifier.
SagaScopeDescriptor(String, Object) - Constructor for class org.axonframework.modelling.saga.SagaScopeDescriptor
Instantiate a SagaScopeDescriptor with the provided type and identifier.
SagaSqlSchema - Interface in org.axonframework.modelling.saga.repository.jdbc
Interface describing the SQL statements that the JdbcSagaRepository needs to execute against the underlying database.
SagaStorageException - Exception in org.axonframework.modelling.saga
Exception indicating that an error has occurred while storing a Saga.
SagaStorageException(String) - Constructor for exception org.axonframework.modelling.saga.SagaStorageException
Initialize a SagaStorageException with the given descriptive message.
SagaStorageException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaStorageException
Initialize a SagaStorageException with the given descriptive message and cause.
sagaStore() - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns a SagaStore registered within this configuration.
sagaStore() - Method in class org.axonframework.config.EventProcessingModule
 
sagaStore(SagaStore<? super T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Sets the SagaStore used to save and load saga instances.
SagaStore<T> - Interface in org.axonframework.modelling.saga.repository
Provides a mechanism to find, load update and delete sagas of type T from an underlying storage like a database.
sagaStore(ConnectionProvider, Serializer) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
 
sagaStore(Serializer, EntityManagerProvider) - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
 
SagaStore.Entry<T> - Interface in org.axonframework.modelling.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.modelling.saga.AbstractSagaManager.Builder
 
sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
Sets the sagaType as a Class managed by this instance.
sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
 
sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Sets the sagaType as a Class, specifying the type of Saga this SagaRepository will store.
sagaType - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
 
sameInstanceSupplier(Supplier<T>) - Static method in class org.axonframework.common.ObjectUtils
Wraps the given supplier to ensure that the same instance is returned on multiple consecutive invocations.
scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
scatterGather(String, Q, ResponseType<R>, long, TimeUnit) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
 
scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryBus
Dispatch the given query to all QueryHandlers subscribed to the given query's queryName/responseType.
scatterGather(Q, ResponseType<R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus, expecting a response in the form of responseType from several sources.
scatterGather(String, Q, ResponseType<R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus, expecting a response in the form of responseType from several sources.
scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in class org.axonframework.queryhandling.SimpleQueryBus
 
schedule(Instant, Object) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
Schedules an event to be published at a given moment.
schedule(Duration, Object) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
Schedules an event to be published after a specified amount of time.
schedule(Instant, String) - Method in interface org.axonframework.deadline.DeadlineManager
Schedules a deadline at given triggerDateTime with given deadlineName.
schedule(Instant, String, Object) - Method in interface org.axonframework.deadline.DeadlineManager
Schedules a deadline at given triggerDateTime with given deadlineName.
schedule(Instant, String, Object, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
Schedules a deadline at given triggerDateTime with provided context.
schedule(Duration, String) - Method in interface org.axonframework.deadline.DeadlineManager
Schedules a deadline after the given triggerDuration with given deadlineName.
schedule(Duration, String, Object) - Method in interface org.axonframework.deadline.DeadlineManager
Schedules a deadline after the given triggerDuration.
schedule(Duration, String, Object, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
Schedules a deadline after the given triggerDuration with provided context.
schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
 
schedule(Duration, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
 
schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.SimpleDeadlineManager
 
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, String, Object, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
 
schedule(Duration, String, Object, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
 
schedule(Instant, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
schedule(Duration, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
 
ScheduledDeadlineInfo - Class in org.axonframework.test.deadline
Holds the data regarding deadline schedule.
ScheduledDeadlineInfo(Instant, String, String, int, DeadlineMessage<?>, ScopeDescriptor) - Constructor for class org.axonframework.test.deadline.ScheduledDeadlineInfo
Instantiates a ScheduledDeadlineInfo.
scheduledExecutorService(ScheduledExecutorService) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
Sets the ScheduledExecutorService used for scheduling and triggering deadlines.
scheduledExecutorService(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
Sets the ScheduledExecutorService used for scheduling and triggering events.
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.
Scheduler - Interface in org.axonframework.axonserver.connector.util
Schedules tasks to be executed in future.
scheduler(Scheduler) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
Sets the Scheduler used for scheduling and triggering purposes of the deadlines.
scheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
Sets the Scheduler used for scheduling and triggering purposes of the deadlines.
Scheduler.ScheduledTask - Interface in org.axonframework.axonserver.connector.util
 
scheduleRetry(Runnable, long) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
Schedule the provided task to run after the given interval.
scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
This is the entrypoint of the RetryScheduler.
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.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.axonframework.axonserver.connector.util.Scheduler
Schedules a command to be executed periodically after initialDelay.
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(TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Sets the schema which describes a JDBC token entry for this TokenStore.
schema(EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the EventSchema describing the database schema of event entries.
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.
Scope - Class in org.axonframework.messaging
Describes functionality off processes which can be 'in scope', like an Aggregate or Saga.
Scope() - Constructor for class org.axonframework.messaging.Scope
 
SCOPE_AWARE_RESOLVER - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
The key under which the ScopeAwareProvider is stored within the SchedulerContext.
ScopeAware - Interface in org.axonframework.messaging
Interface describing components which are Scope aware.
scopeAwareProvider(ScopeAwareProvider) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
Sets the ScopeAwareProvider which is capable of providing a stream of Scope instances for a given ScopeDescriptor.
scopeAwareProvider(ScopeAwareProvider) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
Sets the ScopeAwareProvider which is capable of providing a stream of Scope instances for a given ScopeDescriptor.
ScopeAwareProvider - Interface in org.axonframework.messaging
Contract towards a mechanism to provide a Stream of components which are ScopeAware.
scopeDescription() - Method in class org.axonframework.messaging.NoScopeDescriptor
 
scopeDescription() - Method in interface org.axonframework.messaging.ScopeDescriptor
Retrieve a String description of a Scope object.
scopeDescription() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
 
scopeDescription() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
 
ScopeDescriptor - Interface in org.axonframework.messaging
Denotes the description of a Scope.
ScopeDescriptorParameterResolverFactory - Class in org.axonframework.messaging.annotation
ScopeDescriptorParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.ScopeDescriptorParameterResolverFactory
 
Segment - Class in org.axonframework.eventhandling
A representation of a segment and corresponding mask with various capabilities.
Segment(int, int) - Constructor for class org.axonframework.eventhandling.Segment
Construct a new Segment instance with given segmentId and mask
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.
select(Connection, String, int, boolean) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Returns a PreparedStatement to select a token entry from the underlying storage, either for updating or just for reading.
selectForSegments(Connection, String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Returns a PreparedStatement to select all segments ids for a given processorName from the underlying storage.
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(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, ? super 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, ? super 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 a CompletableFuture immediately, without waiting for the command to execute.
send(Object, MetaData) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
Sends the given command with the given metaData and returns a CompletableFuture immediately, without waiting for the command to execute.
send(C, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
 
send(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
 
send(Message<?>, ScopeDescriptor) - Method in interface org.axonframework.messaging.ScopeAware
Send a Message to a Scope which is described by the given scopeDescription.
send(Message<?>, ScopeDescriptor) - Method in class org.axonframework.modelling.command.AbstractRepository
 
send(Message<?>, ScopeDescriptor) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
 
sendAck(String, boolean, ErrorMessage, StreamObserver<T>) - Method in class org.axonframework.axonserver.connector.DefaultInstructionAckSource
 
sendAck(String, boolean, ErrorMessage, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
Sends an acknowledgement.
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, MetaData) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
Sends the given command with the given metaData 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, MetaData, long, TimeUnit) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
Sends the given command with the given metaData 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.
sendInitialPermits() - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
Deprecated.
 
sendSuccessfulAck(String, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
Sends successful acknowledgement.
sendUnsuccessfulAck(String, ErrorMessage, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
Sends unsuccessful acknowledgement.
sendUnsupportedInstruction(String, String, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
Sends acknowledgement of unsupported instruction.
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.eventhandling
Annotation indicating that a parameter on an Event Handler method should be injected with the SequenceNumber of a DomainEventMessage.
sequenceNumberColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the event identifier column.
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.eventhandling.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
 
SequenceNumberParameterResolverFactory - Class in org.axonframework.eventhandling
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a Long type annotated with the SequenceNumber annotation and assigns the sequenceNumber of the DomainEventMessage.
SequenceNumberParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory
Initializes a ParameterResolverFactory for SequenceNumber annotated parameters
SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver - Class in org.axonframework.eventhandling
ParameterResolver that resolves SequenceNumber parameters
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(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the SequencingPolicy tied to the given processingGroup.
sequencingPolicy(String) - Method in class org.axonframework.config.EventProcessingModule
 
SequencingPolicy<T> - Interface in org.axonframework.eventhandling.async
Interface to a policy definition for concurrent processing, for example event handling.
sequencingPolicy(SequencingPolicy<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Sets the SequencingPolicy in charge of deciding whether a given event should be handled (through SimpleEventHandlerInvoker.handle(EventMessage, Segment)) by the given Segment.
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 sequential handling of all events delivered to an event handler.
SequentialPolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPolicy
 
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(CommandMessage<?>, String, int) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
Convert a CommandMessage into a Command.
serialize(CommandResultMessage<?>, String) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
Convert a CommandResultMessage into a CommandProviderOutbound.
serialize(Object, Class<T>) - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
 
serialize(SubscriptionQueryUpdateMessage<?>) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Serializes the given subscriptionQueryUpdateMessage into a QueryUpdate.
serialize(SubscriptionQueryMessage<?, ?, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Deprecated.
in through use of the AxonServer java connector
serialize(String, Throwable) - Static method in class org.axonframework.axonserver.connector.util.ExceptionSerializer
Serializes a given Throwable into an ErrorMessage.
serialize(A, Class<T>) - Method in interface org.axonframework.axonserver.connector.util.GrpcObjectSerializer.Serializer
Serialize the given object into an object of the expectedRepresentation.
serialize(Object, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
serialize(Object, Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
Deprecated.
 
serialize(Object, Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
serialize(Object, Class<T>) - Method in interface org.axonframework.serialization.Serializer
Serialize the given object into a Serialized Object containing the given expectedRepresentation.
SERIALIZED_DEADLINE_MESSAGE - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
Deprecated.
in favor of the separate DeadlineMessage keys | only maintained for backwards compatibility
SERIALIZED_DEADLINE_MESSAGE_CLASS_NAME - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
Deprecated.
in favor of the separate DeadlineMessage keys | only maintained for backwards compatibility
SERIALIZED_DEADLINE_SCOPE - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
Key pointing to the serialized deadline ScopeDescriptor in the JobDataMap
SERIALIZED_DEADLINE_SCOPE_CLASS_NAME - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
Key pointing to the class name of the deadline ScopeDescriptor in the JobDataMap
SERIALIZED_MESSAGE_PAYLOAD - Static variable in class org.axonframework.messaging.Headers
Key pointing to the serialized payload of a message.
serializedException - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
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 - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
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.modelling.saga.repository.jpa.JpaSagaStore
Intended for clients to override.
serializedPayload - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
 
serializedPayload - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
 
serializedSaga - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
 
SerializedSaga - Class in org.axonframework.modelling.saga.repository.jpa
Specialization of the SerializedObject for Sagas represented as byte array.
SerializedSaga(byte[], String, String) - Constructor for class org.axonframework.modelling.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.
serializedType() - Method in class org.axonframework.serialization.UnknownSerializedType
Returns the type of the serialized object, for which no class could be resolved.
serializeExceptionResult(Serializer, Class<T>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
serializeExceptionResult(Serializer, Class<T>) - Method in interface org.axonframework.messaging.ResultMessage
Serializes the exception result.
serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.messaging.GenericMessage
 
serializeMetaData(Serializer, Class<R>) - Method in interface org.axonframework.messaging.Message
Serialize the meta data of this message to the expectedRepresentation using given serializer.
serializeMetaData(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
 
serializeMetaData(Serializer, Class<R1>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
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<R>) - Method in class org.axonframework.messaging.GenericMessage
 
serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.GenericResultMessage
 
serializePayload(Serializer, Class<R>) - Method in interface org.axonframework.messaging.Message
Serialize the payload of this message to the expectedRepresentation using given serializer.
serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
 
serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
serializePayload(Serializer, Class<S>) - Method in interface org.axonframework.messaging.ResultMessage
 
serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
 
serializePayload(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
 
serializeQuery(SubscriptionQueryMessage) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Serializes the given subscriptionQueryMessage into a QueryRequest.
serializer(Serializer) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the Serializer used to de-/serialize incoming and outgoing commands and command results.
serializer() - Method in interface org.axonframework.config.Configuration
Returns the serializer defined in this Configuration
serializer(Serializer) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
Sets the Serializer used to de-/serialize the DeadlineMessage and the ScopeDescriptor into the JobDataMap.
serializer(Serializer) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
Sets the Serializer used by the EventJobDataBinder.
serializer(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Sets the Serializer used to de-/serialize TrackingTokens with.
serializer() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Returns the serializer used by the Token Store to serialize tokens.
serializer(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
Sets the Serializer used to de-/serialize TrackingTokens with.
serializer() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
Returns the serializer used by the Token Store to serialize tokens.
serializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
Sets the Serializer used to de-/serialize a Saga instance.
serializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
Sets the Serializer used to de-/serialize a Saga instance.
Serializer - Interface in org.axonframework.serialization
Interface describing a serialization mechanism.
serializer(RevisionResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
serializeRequest(QueryMessage<Q, R>, int, long, int) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
Convert a QueryMessage into a QueryRequest.
serializeResponse(QueryResponseMessage<?>, String) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
Convert a QueryResponseMessage into a QueryResponse.
SerializerProperties - Class in org.axonframework.springboot
A group of properties that allows easy configuration of the serializers used for different types of objects that Axon needs to serialize.
SerializerProperties() - Constructor for class org.axonframework.springboot.SerializerProperties
 
SerializerProperties.SerializerType - Enum in org.axonframework.springboot
Enumerates different possible standard serializers, available in Axon.
serializeUpdateType(SubscriptionQueryMessage<?, ?, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Serializes the given subscriptionQueryMessage into a SerializedObject.
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
 
ServerConnectorConfigurerModule - Class in org.axonframework.axonserver.connector
Configurer module which is auto-loadable by the DefaultConfigurer that sets sensible default to use when the AxonServer connector is available on the classpath.
ServerConnectorConfigurerModule() - Constructor for class org.axonframework.axonserver.connector.ServerConnectorConfigurerModule
 
servers(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
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.
setAdditionalHandlers(List<HandlerDefinition>) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
Defines any additional handler definitions that should be used.
setAdditionalHandlers(List<HandlerEnhancerDefinition>) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
Defines any additional handler enhancer definitions that should be used.
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
 
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.config.ConfigurerFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
 
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
 
setApplicationContext(ApplicationContext) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
setAutoConfiguration(MetricsProperties.AutoConfiguration) - Method in class org.axonframework.springboot.MetricsProperties
Defines the AutoConfiguration settings for Metrics.
setAutoStart(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
Sets whether the embedded DistributedCommandBusProperties.JGroupsProperties.Gossip Server should be automatically started.
setBatchSize(int) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the maximum size of a processing batch.
setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
 
setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
 
setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
setBeanClassLoader(ClassLoader) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
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.eventsourcing.SpringPrototypeAggregateFactory
 
setBindAddr(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Sets the Address to bind the JGroups to.
setBindPort(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Returns the port to listen to JGroups connections (default 7800).
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.
setCertFile(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setClientId(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setClusterName(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Sets the Cluster Name of the JGroups Cluster to connect with (defaults to "Axon").
setCommandBus(CommandBus) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
Sets the command bus to use when subscribing command handlers.
setCommandFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setCommandHandlers(Collection<MessageHandler>) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
Sets the command handlers to subscribe to the bus.
setCommandLoadFactor(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setCommandThreads(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setCommandThreads(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setCommitTimeout(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setComponentName(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setConfigurationFile(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Sets the path to the configuration file to use to configure the Groups instance.
setConfigurerModules(List<ConfigurerModule>) - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
Registers the configurerModules that provide context-sensitive default settings for the Configurer.
setConnectTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setContext(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setDimensional(boolean) - Method in class org.axonframework.springboot.MetricsProperties.Micrometer
Disables (if false, default) or enables (if true) the usage of Micrometer Tags/Dimensions
setDisableEventBlacklisting(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
 
setEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setEnabled(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Enables (if true) or disables (if false, default) the auto-configuration of a Distributed Command Bus instance in the application context.
setEnabled(boolean) - Method in class org.axonframework.springboot.MetricsProperties.AutoConfiguration
Enables (if true, default) or disables (if false) the auto-configuration of Metrics within the application context.
setEntityManager(EntityManager) - Method in class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
Sets the container managed entityManager to use.
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.
setEventFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
Sets the EventJobDataBinder instance which reads / writes the event message to publish to the JobDataMap.
setEvents(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
The type of serializer to use to serialize the payload and meta data of Event Messages.
setEventSecretKey(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
setEventStore(EventStore) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
Sets the Event Store instance to write the snapshots to
setExecutionResult(ExecutionResult) - Method in class org.axonframework.disruptor.commandhandling.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.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.
setFallbackToHttpGet(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
Whether to fall back to HTTP GET when retrieving Instance Meta Data from the Discovery Server fails.
setFallbackUrl(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
Sets the URL relative to the host's root to retrieve Instance Meta Data from.
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.modelling.command.GenericJpaRepository
Indicates whether the EntityManager's state should be flushed each time an aggregate is saved.
setForceReadFromLeader(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
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
Deprecated.
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.
setGeneral(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
Sets the type of serializer to use to serialize any type of object, for which no more specific serializer is configured.
setGossip(DistributedCommandBusProperties.JGroupsProperties.Gossip) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
Sets the DistributedCommandBusProperties.JGroupsProperties.Gossip configuration in case the Gossip protocol is configured for JGroups (default).
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.
setHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
Sets the HandlerDefinition to create concrete handlers.
setHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
Sets handler definition to be able to create concrete handlers.
setHeartbeat(AxonServerConfiguration.HeartbeatConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setHosts(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
Sets the host names and ports of the DistributedCommandBusProperties.JGroupsProperties.Gossip Routers to connect to.
setInitialNrOfPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
 
setInitialNrOfPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setInitialSegmentCount(Integer) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the number of initial segments that should be created, if no segments are already present.
setInterval(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
 
setJgroups(DistributedCommandBusProperties.JGroupsProperties) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Sets the JGroups configuration to use (if JGroups is on the classpath).
setKeepAliveTime(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setKeepAliveTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setLoadFactor(int) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Sets the load factor for this instance of the Distributed Command Bus (default 100).
setMaxGrpcBufferedMessages(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setMaxMessageSize(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setMessages(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
The type of serializer to use to serialize the payload and meta data of Messages.
setMicrometer(MetricsProperties.Micrometer) - Method in class org.axonframework.springboot.MetricsProperties
Defines the Micrometer settings for Metrics.
setMode(EventProcessorProperties.Mode) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the type of processor that should be configured.
setNewPermitsThreshold(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
 
setNewPermitsThreshold(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setNrOfNewPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
 
setNrOfNewPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setOnAvailableCallback(Runnable) - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
 
setOnAvailableCallback(Runnable) - Method in interface org.axonframework.common.stream.BlockingStream
Set a callback to be invoked once new messages are available on this stream.
setOwnerColum(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
setOwnerColumn(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.
setProcessorNameColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the processor name column.
setProcessorsNotificationInitialDelay(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setProcessorsNotificationRate(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setQueryBus(QueryBus) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
 
setQueryFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setQueryHandlers(Collection<QueryHandlerAdapter>) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
 
setQueryThreads(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
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.
setRepositoryProvider(RepositoryProvider) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
Sets repository provider in order to have possibility to spawn new aggregates from THE aggregate.
setResult(CommandResultMessage<?>) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
Registers the result of the command's execution, if successful.
setRollbackCause(Throwable) - Method in class org.axonframework.disruptor.commandhandling.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.SimpleCommandBus
Sets the RollbackConfiguration that allows you to change when the UnitOfWork is rolled back.
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.
setSequencingPolicy(String) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the name of the bean that defines the SequencingPolicy for this processor.
setSerializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
Sets the Serializer instance to serialize Sagas with.
setServers(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setSnapshotPrefetch(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setSnapshotter(Snapshotter) - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
Sets the snapshotter
setSource(String) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the name of the bean that should be used as source for Event Messages.
setSpringCloud(DistributedCommandBusProperties.SpringCloudProperties) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
Sets the Spring Cloud configuration to use (if Spring Cloud is on the classpath).
setSslEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setSuppressDownloadMessage(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setTags(Map<String, String>) - Method in class org.axonframework.springboot.TagsConfigurationProperties
Sets tags.
setThreadCount(int) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the number of threads to use to process Events, when using a StreamingEventProcessor implementation.
setTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
 
setTimestampColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
Sets the name of the timestamp column.
setToken(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
 
setTokenClaimInterval(long) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the time to wait after a failed attempt to claim any token, before making another attempt.
setTokenClaimIntervalTimeUnit(TimeUnit) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
Sets the time unit used to defined tokens claim interval.
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.
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(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.
setUseExplicitFlush(boolean) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
Sets whether or not to do an explicit EntityManager.flush() after each data modifying operation on the backing storage.
shouldInvokeInterceptorChain() - Method in interface org.axonframework.modelling.command.inspection.CommandHandlerInterceptorHandlingMember
Deprecated.
Indicates whether interceptor chain (containing a command handler) should be invoked automatically or command handler interceptor will invoke it manually.
shutdown() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
Stops the Connection Manager, closing any active connections and preventing new connections from being created.
shutdown() - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
Deprecated.
Stops the scheduled task and shutdown the monitor, that cannot be restarted again.
shutdown() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
Shuts down the Executor used to asynchronously dispatch incoming commands.
shutdown() - Method in interface org.axonframework.config.Configuration
Shuts down the components defined in this Configuration
shutdown() - Method in class org.axonframework.config.MessageHandlerRegistrar
Close the message handler registration initialized in phase Phase.LOCAL_MESSAGE_HANDLER_REGISTRATIONS through the MessageHandlerRegistrar.start() method.
shutdown() - Method in interface org.axonframework.config.ModuleConfiguration
Deprecated.
in favor of maintaining shutdown operations in the Component. Any lifecycle operations not covered through the components created by this ModuleConfiguration should be added to the Configuration in ModuleConfiguration.initialize(Configuration) through Configuration.onShutdown(int, LifecycleHandler)
shutdown() - Method in interface org.axonframework.deadline.DeadlineManager
Shuts down this deadline manager.
shutdown() - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
Shuts down this deadline manager.
shutdown() - Method in class org.axonframework.deadline.SimpleDeadlineManager
Shuts down this deadline manager.
shutDown() - Method in interface org.axonframework.eventhandling.EventProcessor
Stops processing events.
shutDown() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
shutdown() - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
Shuts down this event scheduler.
shutdown() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
Shuts down this event scheduler.
shutdown() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
Shuts down this event scheduler.
shutDown() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
Shut down this processor.
shutDown() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Shuts 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
 
SHUTDOWN_PHASE - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the Phase to invoke a shutdown handler in.
shutdownAsync() - Method in interface org.axonframework.eventhandling.EventProcessor
Initiates a shutdown, providing a CompletableFuture that completes when the shutdown process is finished.
shutdownAsync() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
shutdownAsync() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Initiates a shutdown, providing a CompletableFuture that completes when the shutdown process is finished.
shutdownDispatching() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
Shutdown the command bus asynchronously for dispatching commands to Axon Server.
shutdownDispatching() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
Shuts down the Axon Server EventScheduler implementation.
shutdownDispatching() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
Shutdown the query bus asynchronously for dispatching queries to Axon Server.
shutdownDispatching() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
Shutdown the command bus asynchronously for dispatching commands to other instances.
ShutdownHandler - Annotation Type in org.axonframework.lifecycle
Annotation indicating that a member method should be a part of the shutdown cycle of an Axon application.
ShutdownInProgressException - Exception in org.axonframework.lifecycle
Exception indicating a process tried to register an activity whilst the application is shutting down.
ShutdownInProgressException() - Constructor for exception org.axonframework.lifecycle.ShutdownInProgressException
Construct this exception with the default message "Cannot start the activity, shutdown in progress".
ShutdownInProgressException(String) - Constructor for exception org.axonframework.lifecycle.ShutdownInProgressException
Constructs this exception with given message explaining the cause.
ShutdownLatch - Class in org.axonframework.lifecycle
A latch implementation to be used in shutdown scenarios.
ShutdownLatch() - Constructor for class org.axonframework.lifecycle.ShutdownLatch
 
ShutdownLatch.ActivityHandle - Class in org.axonframework.lifecycle
A handle for an activity registered to a ShutdownLatch.
shutdownNow() - Method in interface org.axonframework.axonserver.connector.util.Scheduler
Cancels all scheduled tasks.
signature() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
Returns the signature of the member.
silentOverride() - Static method in class org.axonframework.commandhandling.DuplicateCommandHandlerResolution
A DuplicateCommandHandlerResolver implementation that allows handlers to silently override previous registered handlers for the same command.
SimpleCommandBus - Class in org.axonframework.commandhandling
Implementation of the CommandBus that dispatches commands to the handlers subscribed to that specific command's name.
SimpleCommandBus(SimpleCommandBus.Builder) - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
Instantiate a SimpleCommandBus based on the fields contained in the SimpleCommandBus.Builder.
SimpleCommandBus.Builder - Class in org.axonframework.commandhandling
Builder class to instantiate a SimpleCommandBus.
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.
SimpleDeadlineManager - Class in org.axonframework.deadline
Implementation of DeadlineManager which uses Java's ScheduledExecutorService as scheduling and triggering mechanism.
SimpleDeadlineManager(SimpleDeadlineManager.Builder) - Constructor for class org.axonframework.deadline.SimpleDeadlineManager
Instantiate a SimpleDeadlineManager based on the fields contained in the SimpleDeadlineManager.Builder to handle the process around scheduling and triggering a DeadlineMessage.
SimpleDeadlineManager.Builder - Class in org.axonframework.deadline
Builder class to instantiate a SimpleDeadlineManager.
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 dispatches events in the thread the publishes them.
SimpleEventBus(SimpleEventBus.Builder) - Constructor for class org.axonframework.eventhandling.SimpleEventBus
Instantiate a SimpleEventBus based on the fields contained in the SimpleEventBus.Builder.
SimpleEventBus.Builder - Class in org.axonframework.eventhandling
Builder class to instantiate a SimpleEventBus.
SimpleEventHandlerInvoker - Class in org.axonframework.eventhandling
Implementation of an EventHandlerInvoker that forwards events to a list of registered EventMessageHandler.
SimpleEventHandlerInvoker(SimpleEventHandlerInvoker.Builder) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
Instantiate a SimpleEventHandlerInvoker based on the fields contained in the SimpleEventHandlerInvoker.Builder.
SimpleEventHandlerInvoker.Builder - Class in org.axonframework.eventhandling
Builder class to instantiate a SimpleEventHandlerInvoker.
SimpleEventScheduler - Class in org.axonframework.eventhandling.scheduling.java
An EventScheduler implementation that uses Java's ScheduledExecutorService as scheduling and triggering mechanism.
SimpleEventScheduler(SimpleEventScheduler.Builder) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
Instantiate a SimpleEventScheduler based on the fields contained in the SimpleEventScheduler.Builder.
SimpleEventScheduler.Builder - Class in org.axonframework.eventhandling.scheduling.java
Builder class to instantiate a SimpleEventScheduler.
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
 
SimpleHandlerAttributes - Class in org.axonframework.messaging
Simple implementation of the HandlerAttributes which is given the attributes in the constructor.
SimpleHandlerAttributes(Map<String, Object>) - Constructor for class org.axonframework.messaging.SimpleHandlerAttributes
Constructs a SimpleHandlerAttributes using the given attributes.
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
SimpleQueryBus - Class in org.axonframework.queryhandling
Implementation of the QueryBus that dispatches queries to the handlers within the JVM.
SimpleQueryBus(SimpleQueryBus.Builder) - Constructor for class org.axonframework.queryhandling.SimpleQueryBus
Instantiate a SimpleQueryBus based on the fields contained in the SimpleQueryBus.Builder.
SimpleQueryBus.Builder - Class in org.axonframework.queryhandling
Builder class to instantiate a SimpleQueryBus.
SimpleQueryUpdateEmitter - Class in org.axonframework.queryhandling
Implementation of QueryUpdateEmitter that uses Project Reactor to implement Update Handlers.
SimpleQueryUpdateEmitter(SimpleQueryUpdateEmitter.Builder) - Constructor for class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
Instantiate a SimpleQueryUpdateEmitter based on the fields contained in the SimpleQueryUpdateEmitter.Builder.
SimpleQueryUpdateEmitter.Builder - Class in org.axonframework.queryhandling
Builder class to instantiate a SimpleQueryUpdateEmitter.
SimpleResourceInjector - Class in org.axonframework.modelling.saga
A resource injector that checks for @Inject annotated fields and setter methods to inject resources.
SimpleResourceInjector(Object...) - Constructor for class org.axonframework.modelling.saga.SimpleResourceInjector
Initializes the resource injector to inject to given resources.
SimpleResourceInjector(Collection<?>) - Constructor for class org.axonframework.modelling.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
 
SinkWrapper<T> - Interface in org.axonframework.queryhandling
Abstraction interface to bridge old FluxSink and Sinks.Many API with a common API.
size() - Method in class org.axonframework.messaging.MetaData
 
size() - Method in interface org.axonframework.modelling.saga.AssociationValues
Returns the number of AssociationValue instances available in this container
size() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
 
size() - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
Returns an approximation of the size of this map.
size() - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
Returns the number of Sagas currently contained in this repository.
skipMessagesWithPayloadTypeOf(TrackedEventMessage<?>) - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
Report the stream that a specific message was ignored by the consumer.
skipMessagesWithPayloadTypeOf(M) - Method in interface org.axonframework.common.stream.BlockingStream
Report the stream that a specific message was ignored by the consumer.
SlidingTimeWindowReservoir - Class in org.axonframework.micrometer.reservoir
A reservoir of measurements constrained by a sliding window that stores only the measurements made in the last N seconds (or other time unit).
SlidingTimeWindowReservoir(long, TimeUnit, Clock) - Constructor for class org.axonframework.micrometer.reservoir.SlidingTimeWindowReservoir
Creates a new SlidingTimeWindowReservoir with the given clock and window of time.
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.
snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
snapshotFilter(SnapshotFilter) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Sets the SnapshotFilter used to filter snapshots when returning aggregate events.
snapshotFilter() - Method in interface org.axonframework.config.AggregateConfiguration
Returns the SnapshotFilter defined in this configuration.
snapshotFilter() - Method in class org.axonframework.config.AggregateConfigurer
 
snapshotFilter() - Method in interface org.axonframework.config.Configuration
Returns the SnapshotFilter combining all defined filters per AggregateConfigurer in an SnapshotFilter.combine(SnapshotFilter) operation.
snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
Sets the snapshotFilter deciding whether to take a snapshot into account.
snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
 
snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
 
snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
 
SnapshotFilter - Interface in org.axonframework.eventsourcing.snapshotting
Functional interface defining an SnapshotFilter.allow(DomainEventData) method to take snapshot data into account when loading an aggregate.
snapshotPrefetch(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
snapshotSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Sets the Serializer used to serialize and deserialize snapshots.
snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
Sets the Serializer used to serialize and deserialize snapshots.
snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
 
snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
 
snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
 
snapshotTable(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the snapshot events table.
snapshotTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Returns the name of the snapshot event table.
snapshotter() - Method in interface org.axonframework.config.Configuration
Returns the Snapshotter defined in this Configuration.
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 - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
snapshotTriggerDefinition(SnapshotTriggerDefinition) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
Sets the SnapshotTriggerDefinition specifying when to trigger a snapshot for an Aggregate contained in this repository.
SnapshotTriggerDefinition - Interface in org.axonframework.eventsourcing
Interface describing the mechanism for triggering Snapshots.
source() - Method in exception org.axonframework.axonserver.connector.AxonServerException
 
source() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
Return a String defining the source where the error originated.
SourceId - Annotation Type in org.axonframework.messaging.annotation
Annotation indication that a parameter on a Message Handler method should be injected with the aggregate identifier of a DomainEventMessage.
SourceIdParameterResolverFactory - Class in org.axonframework.messaging.annotation
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a String type that are annotated with the SourceId annotation and assigns the aggregate identifier of the DomainEventMessage.
SourceIdParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.SourceIdParameterResolverFactory
Initialize a ParameterResolverFactory for SourceId annotated parameters
split() - Method in class org.axonframework.eventhandling.Segment
Returns an array with two segments with a corresponding mask.

The first entry contains the original segmentId, with the newly calculated mask.
split() - Method in class org.axonframework.eventhandling.TrackerStatus
Splits the current status object to reflect the status of their underlying segments being split.
split(Segment, TrackingToken) - Static method in class org.axonframework.eventhandling.TrackerStatus
Split the given segment and trackingToken in two.
splitBalanced(Segment, int) - Static method in class org.axonframework.eventhandling.Segment
Split a given Segment n-times in round robin fashion.
splitSegment(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
splitSegment(int) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Instruct the processor to split the segment with given segmentId into two segments, allowing an additional process to start processing events from it.
splitSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
splitSegmentId() - Method in class org.axonframework.eventhandling.Segment
Returns the segmentId of the counterpart of this segment, if this segment were to be split.
SpringAggregateSnapshotter - Class in org.axonframework.spring.eventsourcing
Snapshotter implementation that uses the AggregateRoot as state for the snapshot.
SpringAggregateSnapshotter(SpringAggregateSnapshotter.Builder) - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
Instantiate a SpringAggregateSnapshotter based on the fields contained in the SpringAggregateSnapshotter.Builder.
SpringAggregateSnapshotter.Builder - Class in org.axonframework.spring.eventsourcing
Builder class to instantiate a SpringAggregateSnapshotter.
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
 
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.
SpringBeanDependencyResolverFactory - Class in org.axonframework.spring.config.annotation
ParameterResolverFactory implementation that resolves parameters using Spring dependency resolution.
SpringBeanDependencyResolverFactory(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringBeanDependencyResolverFactory
Default constructor requiring an application context, for use internally by Axon.
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.
SpringCloudProperties() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
 
SpringContextHandlerDefinitionBuilder - Class in org.axonframework.spring.config.annotation
Creates and registers a bean definition for a Spring Context aware HandlerDefinition.
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.
SpringHandlerDefinitionBean - Class in org.axonframework.spring.config.annotation
Spring factory bean that creates a HandlerDefinition instance that is capable of resolving parameter values as Spring Beans, in addition to the default behavior defined by Axon.
SpringHandlerDefinitionBean() - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
Initializes definition bean with assumption that application context will be injected.
SpringHandlerDefinitionBean(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
Initializes definition bean with given application context.
SpringHandlerEnhancerDefinitionBean - Class in org.axonframework.spring.config.annotation
Spring factory bean that creates a HandlerEnhancerDefinition instance that is capable of resolving parameter values as Spring Beans, in addition to the default behavior defined by Axon.
SpringHandlerEnhancerDefinitionBean() - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
Initializes definition bean with assumption that application context will be injected.
SpringHandlerEnhancerDefinitionBean(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
Initializes definition bean with given application context.
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(String) - Constructor for class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
Initializes the factory to create beans instances for the bean with given prototypeBeanName.
SpringPrototypeAggregateFactory(String, Map<Class<? extends T>, String>) - Constructor for class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
Initializes the factory to create beans instances for the bean with given prototypeBeanName and its subtypes.
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.
SpringUtils - Class in org.axonframework.spring
Utility class for Spring specific helper functions.
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.HsqlSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.Oracle11SagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
 
sql_createTableAssocValueEntry(Connection) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.Oracle11SagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
 
sql_createTableSagaEntry(Connection) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that creates the table for storing Sagas.
sql_deleteAssociationEntries(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_deleteAssociationEntries(Connection, String) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_deleteSagaEntry(Connection, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
Creates a PreparedStatement that deletes a Saga with given sagaIdentifier.
sql_findAssociations(Connection, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_findAssociations(Connection, String, String) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_loadSaga(Connection, String) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_removeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_storeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_storeSaga(Connection, String, String, String, byte[]) - Method in interface org.axonframework.modelling.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.modelling.saga.repository.jdbc.GenericSagaSqlSchema
 
sql_updateSaga(Connection, String, byte[], String, String) - Method in interface org.axonframework.modelling.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.
sqlSchema(SagaSqlSchema) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
Sets the SagaSqlSchema defining the SQL operations to execute for this SagaStore implementation.
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.
ssl(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
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.axonserver.connector.AxonServerConnectionManager
start() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
Start the Axon Server CommandBus implementation.
start() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
Start the Axon Server EventScheduler implementation.
start() - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
Deprecated.
Schedule a task that verifies that the connection is still alive and, if it is not, invoke a callback in order to react to the disconnection.
start() - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
Add Consumers to the AxonServerConnectionManager for several PlatformOutboundInstructions.
start() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
Start the Axon Server QueryBus implementation.
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.MessageHandlerRegistrar
Start the message handler registration process by building the message handler in the Phase.LOCAL_MESSAGE_HANDLER_REGISTRATIONS phase.
start() - Method in interface org.axonframework.config.ModuleConfiguration
Deprecated.
in favor of maintaining start operations in the Component. Any lifecycle operations not covered through the components created by this ModuleConfiguration should be added to the Configuration in ModuleConfiguration.initialize(Configuration) through Configuration.onStart(int, LifecycleHandler)
start() - Method in interface org.axonframework.eventhandling.EventProcessor
Start processing events.
start() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
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.config.AxonConfiguration
 
start() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
 
start() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
 
START_PHASE - Static variable in interface org.axonframework.messaging.HandlerAttributes
Attribute key referencing the Phase to invoke a start handler in.
startAndGet(T) - Static method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork.
StartHandler - Annotation Type in org.axonframework.lifecycle
Annotation indicating that a member method should be a part of the start cycle of an Axon application.
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.modelling.saga
Indicates that the annotated SagaEventHandler method can trigger the creation of a new Saga instance.
startScope() - Method in class org.axonframework.messaging.Scope
Start a Scope by adding this to a Deque contained in a ThreadLocal.
startSegmentWorkers() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Starts workers for a number of segments.
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.disruptor.commandhandling.DisruptorCommandBus
Shuts down the command bus.
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.QueryHandlerSubscriber
 
stop() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
 
storageEngine(EventStorageEngine) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
 
storageEngine() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
 
storageEngine - Variable in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
 
storageEngine(EventStorageEngine) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
Sets the EventStorageEngine used to store and load events.
storageEngine() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
Returns the EventStorageEngine used by the event store.
storageEngine(EventStorageEngine) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
 
store(String, CommandCallbackWrapper<E, C, R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
Stores a callback
store() - Method in interface org.axonframework.config.SagaConfiguration
Retrieve the SagaStore in this Configuration.
storeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
Stores the given associationValue of the saga with given sagaIdentifier and sagaType.
storeSaga(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.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<?>) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
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.
storeUpdate(Connection, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
Returns a PreparedStatement which updates the given token for the given processorName and segment combination.
storingTokensAfterProcessing() - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
Set this processor to store Tracking Tokens only at the end of processing.
StreamableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
Interface for a source of messages that processors can track.
StreamingEventProcessor - Interface in org.axonframework.eventhandling
An EventProcessor which processes an event stream in segments.
StreamingEventProcessorInfoMessage - Class in org.axonframework.axonserver.connector.processor
Supplier of PlatformInboundInstruction that represent the status of a StreamingEventProcessor.
StreamUtils - Class in org.axonframework.common.stream
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
 
StringUtils - Class in org.axonframework.common
Utility methods for when dealing with Strings.
StubAggregateLifecycle - Class in org.axonframework.test.aggregate
Stub implementation of an AggregateLifecycle that registers all applied events for verification later.
StubAggregateLifecycle() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycle
 
StubAggregateLifecycleExtension - Class in org.axonframework.test.aggregate
Implementation of StubAggregateLifecycle that can be used as an RegisterExtension annotated method or field in a test class.
StubAggregateLifecycleExtension() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycleExtension
 
StubAggregateLifecycleRule - Class in org.axonframework.test.aggregate
Deprecated.
in favor of StubAggregateLifecycleExtension to be used in combination with Junit 5
StubAggregateLifecycleRule() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycleRule
Deprecated.
 
StubDeadlineManager - Class in org.axonframework.test.deadline
Stub implementation of DeadlineManager.
StubDeadlineManager() - Constructor for class org.axonframework.test.deadline.StubDeadlineManager
Initializes the manager with ZonedDateTime.now() as current time.
StubDeadlineManager(TemporalAccessor) - Constructor for class org.axonframework.test.deadline.StubDeadlineManager
Initializes the manager with provided currentDateTime as current time.
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(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
 
subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
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 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(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
 
subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
 
subscribe(Consumer<List<? extends M>>) - Method in interface org.axonframework.messaging.SubscribableMessageSource
Subscribe the given messageProcessor to this message source.
subscribe(CommandBus) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
Subscribe this command handler to the given commandBus.
subscribe(QueryBus) - Method in class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
 
subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in interface org.axonframework.queryhandling.QueryBus
Subscribe the given handler to queries with the given queryName and responseType.
subscribe(QueryBus) - Method in interface org.axonframework.queryhandling.QueryHandlerAdapter
Subscribes the query handlers of this QueryHandlerAdapter to the given QueryBus.
subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
 
subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
 
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(SubscribingEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
Instantiate a SubscribingEventProcessor based on the fields contained in the SubscribingEventProcessor.Builder.
SubscribingEventProcessor.Builder - Class in org.axonframework.eventhandling
Builder class to instantiate a SubscribingEventProcessor.
SubscriptionMessageSerializer - Class in org.axonframework.axonserver.connector.query.subscription
Converter between Axon Framework SubscriptionQueryMessage, the initial QueryResponseMessage and the subsequent SubscriptionQueryUpdateMessage's and Axon Server gRPC SubscriptionQuery and SubscriptionQueryResponse.
SubscriptionMessageSerializer(Serializer, Serializer, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
Instantiate a serializer used to convert Axon SubscriptionQueryMessages, the initial QueryResponseMessage and the subsequent SubscriptionQueryUpdateMessages into Axon Server gRPC messages and vice versa.
subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, int) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
 
subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, int) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
 
subscriptionQuery(SubscriptionQueryMessage<Q, I, U>) - Method in interface org.axonframework.queryhandling.QueryBus
Dispatch the given query to a single QueryHandler subscribed to the given query's queryName/initialResponseType/updateResponseType.
subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryBus
subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, int) - Method in interface org.axonframework.queryhandling.QueryBus
Dispatch the given query to a single QueryHandler subscribed to the given query's queryName/initialResponseType/updateResponseType.
subscriptionQuery(Q, Class<I>, Class<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus and returns result containing initial response and incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by the emitting side).
subscriptionQuery(String, Q, Class<I>, Class<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus and returns result containing initial response and incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by the emitting side).
subscriptionQuery(Q, ResponseType<I>, ResponseType<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus and returns result containing initial response and incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by the emitting side).
subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure) - Method in interface org.axonframework.queryhandling.QueryGateway
Deprecated.
in favour of using {QueryGateway.subscriptionQuery(String, Object, ResponseType, ResponseType)}. To set a backpressure strategy, use one of the onBackpressure.. operators on the updates flux directly. Example: result.updates().onBackpressureBuffer(100)
subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus and returns result containing initial response and incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by the emitting side).
subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryGateway
Deprecated.
in favour of using {QueryGateway.subscriptionQuery(String, Object, ResponseType, ResponseType, int)}. To set a backpressure strategy, use one of the onBackpressure.. operators on the updates flux directly. Example: result.updates().onBackpressureBuffer(100)
subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, int) - Method in interface org.axonframework.queryhandling.QueryGateway
Sends given query over the QueryBus and returns result containing initial response and incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by the emitting side).
subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.SimpleQueryBus
subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, int) - Method in class org.axonframework.queryhandling.SimpleQueryBus
 
SubscriptionQueryBackpressure - Class in org.axonframework.queryhandling
Deprecated.
since 3.4.0 Reactor version, Sinks API does not use FluxSink.OverflowStrategy
SubscriptionQueryBackpressure(FluxSink.OverflowStrategy) - Constructor for class org.axonframework.queryhandling.SubscriptionQueryBackpressure
Deprecated.
Initializes backpressure with reactor's overflow strategy.
SubscriptionQueryMessage<Q,I,U> - Interface in org.axonframework.queryhandling
Message type that carries a Subscription Query: a request for information.
SubscriptionQueryResult<I,U> - Interface in org.axonframework.queryhandling
Result of the subscription query.
SubscriptionQueryUpdateMessage<U> - Interface in org.axonframework.queryhandling
Message which holds incremental update of an subscription query.
subset(String...) - Method in class org.axonframework.messaging.MetaData
Returns a MetaData instance containing a subset of the keys in this instance.
supplyException(String, long, long) - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictExceptionSupplier
Creates an instance of an exception indicating a conflict in an aggregate with given aggregateIdentifier, the given expectedVersion and actualVersion.
supplyException(ConflictDescription) - Method in interface org.axonframework.eventsourcing.conflictresolution.ContextAwareConflictExceptionSupplier
Creates an instance of an exception indicating a conflict described by the given conflictDescription.
supportedCommandNames() - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
 
supportedCommandNames() - Method in interface org.axonframework.commandhandling.CommandMessageHandler
Returns the set of command names this handler supports.
supportedCommandNames() - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
 
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
 
supportsFormat(Class<T>) - Method in class org.axonframework.serialization.UnknownSerializedType
Indicates whether the given desiredFormat is supported as a representation for this type.
supportsReset() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
 
supportsReset() - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
Indicates whether the handlers managed by this invoker support a reset.
supportsReset() - Method in interface org.axonframework.eventhandling.EventMessageHandler
Indicates whether the handlers managed by this invoker support a reset.
supportsReset() - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
 
supportsReset() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
supportsReset() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
 
supportsReset() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Indicates whether this StreamingEventProcessor supports a "reset".
supportsReset() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
 
supportsReset() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
 
supportsReset() - Method in interface org.axonframework.modelling.saga.Saga
 
suppressDownloadMessage() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
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
 

T

tags() - Method in interface org.axonframework.config.Configuration
Returns the Tags Configuration defined in this Configuration.
tagsBuilder(Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
Configures the Function used to deduce what the Tags should be for a message being monitored.
tagsBuilder(Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
Configures the Function used to deduce what the Tags should be for a message being monitored.
tagsConfiguration(TagsConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
Sets the TagsConfiguration used to add the tags of this Axon instance as client information when setting up a channel.
TagsConfiguration - Class in org.axonframework.config
Tags configuration labeling Axon Node represented by key-value pairs.
TagsConfiguration() - Constructor for class org.axonframework.config.TagsConfiguration
The default constructor.
TagsConfiguration(Map<String, String>) - Constructor for class org.axonframework.config.TagsConfiguration
Initializes tags configuration with key-value pairs.
tagsConfiguration() - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
 
TagsConfigurationProperties - Class in org.axonframework.springboot
Spring Configuration properties for TagsConfiguration.
TagsConfigurationProperties() - Constructor for class org.axonframework.springboot.TagsConfigurationProperties
 
TagsUtil - Class in org.axonframework.micrometer
Utility class for micrometer tag management.
TargetAggregateIdentifier - Annotation Type in org.axonframework.modelling.command
Field or method level annotation that marks a field or method providing the identifier of the aggregate that a command targets.
targetAggregateIdentifierAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.modelling.command.AnnotationCommandTargetResolver.Builder
Sets the annotation, that marks the target aggregate identifier.
TargetAggregateVersion - Annotation Type in org.axonframework.modelling.command
Field or method level annotation that marks a field or method providing the expected version of the aggregate that a command targets.
targetAggregateVersionAnnotation(Class<? extends Annotation>) - Method in class org.axonframework.modelling.command.AnnotationCommandTargetResolver.Builder
Sets the annotation, that marks the target aggregate version.
targetContextResolver(TargetContextResolver<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Sets the TargetContextResolver used to resolve the target (bounded) context of an ingested CommandMessage.
targetContextResolver(TargetContextResolver<? super QueryMessage<?, ?>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the TargetContextResolver used to resolve the target (bounded) context of an ingested QueryMessage.
TargetContextResolver<T extends Message<?>> - Interface in org.axonframework.axonserver.connector
Interface towards a mechanism that is capable of resolving the context name to which a Message should be routed.
targetContextResolver() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
 
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(DomainEventData<?>) - Method in class org.axonframework.eventsourcing.eventstore.EqualRevisionPredicate
 
test(DomainEventData<?>) - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter
 
TestExecutor<T> - Interface in org.axonframework.test.aggregate
Interface describing the operations available on a test fixture in the execution stage.
THREAD_KEEP_ALIVE_TIME - Static variable in interface org.axonframework.axonserver.connector.util.ExecutorServiceBuilder
 
threadFactory(ThreadFactory) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
Sets the ThreadFactory used to create threads for consuming, producing and cleaning up.
timeout(List<ProcessingInstruction>) - Static method in class org.axonframework.axonserver.connector.util.ProcessingInstructionHelper
Retrieve the desired 'number of results' as a long from the given processingInstructions, by searching for the ProcessingInstruction who's key equals the ProcessingKey.NR_OF_RESULTS.
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.
timerCustomization(UnaryOperator<Timer.Builder>) - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
Allows for specifying a customization which will be added during the creation of the Timer.
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(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the timestamp column.
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
timestampType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
Returns the sql to describe the type of timestamp column.
TimestampWriter - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
Writer interface for writing a formatted timestamp to a PreparedStatement during updates of the database.
timeUnit(TimeUnit) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
to(Class<?>, String) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster.Builder
Create an EventTypeUpcaster which upcasts "to" the given payloadType and revision.
to(String, String) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster.Builder
Create an EventTypeUpcaster which upcasts "to" the given payloadType and revision.
toJobData(Serializer, DeadlineMessage, ScopeDescriptor) - Static method in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
Serializes the provided deadlineMessage and deadlineScope and puts them in a JobDataMap.
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
 
token(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
 
TokenAddingInterceptor - Class in org.axonframework.axonserver.connector.util
Deprecated.
in through use of the AxonServer java connector
TokenAddingInterceptor(String) - Constructor for class org.axonframework.axonserver.connector.util.TokenAddingInterceptor
Deprecated.
Constructs a TokenAddingInterceptor to attach the given token.
tokenClaimInterval(long) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies the time in milliseconds the processor's coordinator should wait after a failed attempt to claim any segments for processing.
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(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the TokenStore tied to the given processorName.
tokenStore(String) - Method in class org.axonframework.config.EventProcessingModule
 
tokenStore(TokenStore) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Sets the TokenStore used to store and fetch event tokens that enable this EventProcessor to track its progress.
TokenStore - Interface in org.axonframework.eventhandling.tokenstore
Describes a component capable of storing and retrieving event tracking tokens.
tokenStore(TokenStore) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
Sets the TokenStore used to store and fetch event tokens that enable this EventProcessor to track its progress.
tokenStore(ConnectionProvider, Serializer) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
 
tokenStore(Serializer, EntityManagerProvider) - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
 
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 exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
 
toString() - Method in exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
 
toString() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
 
toString() - Method in exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
 
toString() - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
 
toString() - Method in class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
 
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.commandfilter.NegateCommandMessageFilter
 
toString() - Method in class org.axonframework.commandhandling.distributed.commandfilter.OrCommandMessageFilter
 
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.AddedTrackerStatus
 
toString() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
 
toString() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
 
toString() - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
toString() - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
 
toString() - Method in class org.axonframework.eventhandling.RemovedTrackerStatus
 
toString() - Method in class org.axonframework.eventhandling.ReplayToken
 
toString() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
 
toString() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
 
toString() - Method in class org.axonframework.eventhandling.Segment
 
toString() - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
 
toString() - Method in class org.axonframework.eventhandling.TrackerStatus
 
toString() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
 
toString() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
toString() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
 
toString() - Method in class org.axonframework.messaging.Headers
 
toString() - Method in class org.axonframework.messaging.MessageDecorator
 
toString() - Method in class org.axonframework.messaging.MetaData
 
toString() - Method in class org.axonframework.messaging.RemoteExceptionDescription
 
toString() - Method in class org.axonframework.messaging.responsetypes.InstanceResponseType
 
toString() - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
 
toString() - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
 
toString() - Method in class org.axonframework.messaging.SimpleHandlerAttributes
 
toString() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
 
toString() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
 
toString() - Method in class org.axonframework.modelling.command.AnnotationCommandTargetResolver
 
toString() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
 
toString() - Method in class org.axonframework.serialization.SimpleSerializedObject
 
toString() - Method in class org.axonframework.serialization.SimpleSerializedType
 
toTagsConfiguration() - Method in class org.axonframework.springboot.TagsConfigurationProperties
 
TrackedDomainEventData<T> - Class in org.axonframework.eventhandling
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.eventhandling.TrackedDomainEventData
Initialize the TrackingDomainEventData with given trackingToken and domainEventEntry.
trackedEventComparator(Comparator<Map.Entry<String, TrackedEventMessage<?>>>) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource.Builder
Overrides the default trackedEventComparator.
TrackedEventData<T> - Interface in org.axonframework.eventhandling
Interface describing the properties of serialized Event Messages containing a TrackingToken.
trackedEventFields(Function<EventSchema, String>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Set a comma separated list of tracked domain event column names to select from an event entry.
trackedEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
Get a comma separated list of tracked domain event column names to select from an event entry.
trackedEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
Deprecated.
TrackedEventMessage<T> - Interface in org.axonframework.eventhandling
Represents an EventMessage containing a TrackingToken.
trackerAdded() - Method in class org.axonframework.eventhandling.AddedTrackerStatus
 
trackerAdded() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Returns a boolean describing whether this EventTrackerStatus is starting it's progress for the first time.
trackerAdded() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
trackerRemoved() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
Returns a boolean describing whether this EventTrackerStatus has just stopped it's progress.
trackerRemoved() - Method in class org.axonframework.eventhandling.RemovedTrackerStatus
 
trackerRemoved() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
 
TrackerStatus - Class in org.axonframework.eventhandling
Implementation of the EventTrackerStatus, providing simply modification methods to switch from one EventTrackerStatus value object to another.
TrackerStatus(Segment, TrackingToken) - Constructor for class org.axonframework.eventhandling.TrackerStatus
Construct a EventTrackerStatus to portray the status of the given segment and trackingToken.
TrackerStatus(Segment, boolean, TrackingToken, Throwable) - Constructor for class org.axonframework.eventhandling.TrackerStatus
Construct a EventTrackerStatus to portray the status of the given segment and trackingToken.
TrackingEventProcessor - Class in org.axonframework.eventhandling
EventProcessor implementation that tracks events from a StreamableMessageSource.
TrackingEventProcessor(TrackingEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.TrackingEventProcessor
Instantiate a TrackingEventProcessor based on the fields contained in the TrackingEventProcessor.Builder.
TrackingEventProcessor.Builder - Class in org.axonframework.eventhandling
Builder class to instantiate a TrackingEventProcessor.
TrackingEventProcessor.State - Enum in org.axonframework.eventhandling
Enum representing the possible states of the Processor
trackingEventProcessorConfiguration(TrackingEventProcessorConfiguration) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
Sets the TrackingEventProcessorConfiguration containing the fine grained configuration options for a TrackingEventProcessor.
TrackingEventProcessorConfiguration - Class in org.axonframework.eventhandling
Configuration object for the TrackingEventProcessor.
TrackingEventStream - Interface in org.axonframework.eventhandling
Describes a stream of TrackedEventMessages.
trackingToken() - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
 
trackingToken() - Method in class org.axonframework.eventhandling.GenericTrackedEventMessage
 
trackingToken() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
 
trackingToken() - Method in interface org.axonframework.eventhandling.TrackedEventData
Returns the TrackingToken of the serialized event.
trackingToken() - Method in interface org.axonframework.eventhandling.TrackedEventMessage
Returns the TrackingToken of the event message.
TrackingToken - Interface in org.axonframework.eventhandling
Tag interface identifying a token that is used to identify the position of an event in an event stream.
TrackingTokenParameterResolverFactory - Class in org.axonframework.eventhandling
Implementation of a ParameterResolverFactory that resolves the TrackingToken of an event message if that message is a TrackedEventMessage.
TrackingTokenParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.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.deadline.quartz.DeadlineJob
The key under which the TransactionManager is stored within the SchedulerContext.
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.springboot.autoconfig
 
TransactionAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.TransactionAutoConfiguration
 
transactionManager(TransactionManager) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
 
transactionManager(TransactionManager) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
Sets the TransactionManager used to manage transactions.
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.

transactionManager(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
Returns the TransactionManager tied to the given processorName.
transactionManager(String) - Method in class org.axonframework.config.EventProcessingModule
 
transactionManager(TransactionManager) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
Sets the TransactionManager used to build transactions and ties them to deadline.
transactionManager(TransactionManager) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
Sets the TransactionManager used to build transactions and ties them to deadline.
transactionManager(TransactionManager) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the TransactionManager to use to manage a transaction around the storage and publication of events.
transactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Sets the TransactionManager used when processing EventMessages.
transactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
Sets the TransactionManager used to build transactions and ties them on event publication.
transactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
Sets the TransactionManager used to build transactions and ties them on event publication.
transactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
Sets the TransactionManager used when processing EventMessages.
transactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
Sets the TransactionManager used when processing EventMessages.
transactionManager(TransactionManager) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
Sets the TransactionManager used to manage the transaction around storing the snapshot.
transactionManager(TransactionManager) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
 
transactionManager(TransactionManager) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Sets the TransactionManager used to manage transactions around fetching event data.
transactionManager(TransactionManager) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Sets the TransactionManager used to manage transaction around fetching event data.
transactionManager(TransactionManager) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
Sets the TransactionManager used to manage the query handling transactions.
transactionManager(TransactionManager) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
 
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.disruptor.commandhandling.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.config.SagaConfiguration
Gets the Saga Type.
type(Class<?>) - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
Sets the aggregate type this SnapshotFilter will allow using the outcome of Class.getName() on the given type.
type(String) - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
Sets the aggregate type this SnapshotFilter will allow.
type() - Method in interface org.axonframework.modelling.command.Aggregate
Get the String representation of the aggregate's type.
type() - Method in class org.axonframework.modelling.command.AggregateLifecycle
Retrieve a String denoting the type of this Aggregate.
type() - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
Get the String representation of the modeled aggregate's type.
type(String) - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
Gets the aggregate class based on given declaredType.
type() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
type() - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
type() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
 
type() - Method in class org.axonframework.modelling.saga.SagaLifecycle
Retrieve a String denoting the type of this Saga.
type() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
 
typeColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
Sets the name of the aggregate type column.
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.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
 
typeForClass(Class) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
 
typeForClass(Class) - Method in class org.axonframework.serialization.JavaSerializer
Deprecated.
 
typeForClass(Class) - Method in class org.axonframework.serialization.json.JacksonSerializer
 
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.
TypeReflectionUtils - Class in org.axonframework.common
Utility class for doing reflection on types.
types() - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
Gets all types (concrete aggregate classes) of this aggregate.

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.
UnableToClaimTokenException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.tokenstore.UnableToClaimTokenException
Initialize the exception with given message and cause.
UnableToInitializeTokenException - Exception in org.axonframework.eventhandling.tokenstore
Exception indicating that the TokenStore was unable to initialize a Token for a tracking processor and Segment.
UnableToInitializeTokenException(String) - Constructor for exception org.axonframework.eventhandling.tokenstore.UnableToInitializeTokenException
Initialize the exception with given message
UnableToInitializeTokenException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.tokenstore.UnableToInitializeTokenException
Initialize the exception with given message and underlying cause.
UnableToRetrieveIdentifierException - Exception in org.axonframework.eventhandling.tokenstore
Exception indicating that a TokenStore implementation was unable determine its identifier based on the underlying storage.
UnableToRetrieveIdentifierException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.tokenstore.UnableToRetrieveIdentifierException
Initialize the exception using given message and cause.
unexpectedEvents() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
The list of events that have been registered with this aggregate since the expected version.
unexpectedEvents() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
 
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.
UnknownSerializedType - Class in org.axonframework.serialization
Class representing a serialized object of which there is no class available in the current class loader.
UnknownSerializedType(Serializer, SerializedObject<?>) - Constructor for class org.axonframework.serialization.UnknownSerializedType
Initialize the unknown type, using given serializer and serializedObject.
unmarkError() - Method in class org.axonframework.eventhandling.TrackerStatus
Return a new TrackerStatus based on this status, removing the errorState.
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
Set of simple RoutingStrategy implementations.
unsavedSagaResource(UnitOfWork<?>) - Method in class org.axonframework.modelling.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() - Method in interface org.axonframework.config.ModuleConfiguration
Returns the actual module configuration instance.
unwrap(Class<R>) - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
unwrap(Class<R>) - Method in class org.axonframework.eventhandling.ReplayToken
 
unwrap(TrackingToken, Class<R>) - Static method in interface org.axonframework.eventhandling.WrappedToken
Unwrap the given token until a token of given tokenType is exposed.
unwrap(Class<R>) - Method in interface org.axonframework.eventhandling.WrappedToken
Retrieve a token of given tokenType if it is wrapped by this token.
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
 
unwrap(Class<HT>) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
unwrapIfType(Type, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
Unwrap the given type if is wrapped by any of the given wrapperTypes.
unwrapIfTypeFuture(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
unwrapLowerBound(TrackingToken) - Static method in interface org.axonframework.eventhandling.WrappedToken
Extracts a raw token describing the current processing position of the given token.
unwrapUpperBound(TrackingToken) - Static method in interface org.axonframework.eventhandling.WrappedToken
Extracts a raw token describing the current processing position of the given token.
upcast(Stream<T>) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
 
upcast(Stream<T>) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
 
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) - Static method in class org.axonframework.eventsourcing.EventStreamUtils
Upcasts and deserializes the given eventEntryStream using the given serializer and upcasterChain.
upcastAndDeserializeTrackedEvents(Stream<? extends TrackedEventData<?>>, Serializer, EventUpcaster) - Static method in class org.axonframework.eventhandling.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.
upcastedType() - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
Retrieve the upcasted event SerializedType.
Upcaster<T> - Interface in org.axonframework.serialization.upcasting
Interface for Upcasters.
upcasterChain(EventUpcaster) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Sets the EventUpcaster used to deserialize events of older revisions.
upcasterChain() - Method in interface org.axonframework.config.Configuration
Returns the EventUpcasterChain with all registered upcasters.
upcasterChain - Variable in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
 
upcasterChain(EventUpcaster) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
Sets the EventUpcaster used to deserialize events of older revisions.
upcasterChain - Variable in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
 
upcasterChain(EventUpcaster) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
 
upcasterChain(EventUpcaster) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
 
upcasterChain(EventUpcaster) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
 
upcasterChain() - Method in class org.axonframework.spring.config.AxonConfiguration
 
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.
update(long) - Method in class org.axonframework.micrometer.reservoir.SlidingTimeWindowReservoir
Add new measurement value
updateEmitter(QueryUpdateEmitter) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Sets the QueryUpdateEmitter which can be used to emit updates to queries.
UpdateHandlerRegistration<U> - Class in org.axonframework.queryhandling
Result of registering an Update Handler.
UpdateHandlerRegistration(Registration, Flux<SubscriptionQueryUpdateMessage<U>>, Runnable) - Constructor for class org.axonframework.queryhandling.UpdateHandlerRegistration
Constructs a UpdateHandlerRegistration with given registration and updates.
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, CommandMessageFilter) - 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.
updateMessageMonitor(MessageMonitor<? super SubscriptionQueryUpdateMessage<?>>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter.Builder
Sets the MessageMonitor used to monitor SubscriptionQueryUpdateMessages being processed.
updates() - Method in class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
 
updates() - Method in class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
Deprecated.
 
updates() - Method in class org.axonframework.axonserver.connector.query.subscription.DisposableResult
Deprecated.
 
updates() - Method in class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
 
updates() - Method in interface org.axonframework.queryhandling.SubscriptionQueryResult
When there is an update to the subscription query, it will be emitted to this flux.
updateSaga(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
Update a stored Saga, by replacing it with the given saga instance.
updateSaga(Class<? extends T>, String, T, AssociationValues) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
 
updateSaga(Class<?>, String, Object, AssociationValues) - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
 
updateSaga(Class<?>, String, Object, AssociationValues) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
 
updateSaga(Class<?>, String, Object, AssociationValues) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
 
updateSaga(Class<? extends T>, String, T, AssociationValues) - Method in interface org.axonframework.modelling.saga.repository.SagaStore
Updates a given Saga after its state was modified.
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(Connection, ResultSet, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
If the given resultSet has an entry, attempts to replace the token in the entry with the given token and claim ownership.
updateToken(TrackingToken, Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
 
upperBound(TrackingToken) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
 
upperBound(TrackingToken) - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
 
upperBound(TrackingToken) - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
upperBound() - Method in class org.axonframework.eventhandling.MergedTrackingToken
 
upperBound(TrackingToken) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
Compares this token to other by comparing each member token with its counterpart in the other token.
upperBound(TrackingToken) - Method in class org.axonframework.eventhandling.ReplayToken
 
upperBound() - Method in class org.axonframework.eventhandling.ReplayToken
 
upperBound(TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
 
upperBound(TrackingToken) - Method in interface org.axonframework.eventhandling.TrackingToken
Returns the token that represents the furthest possible position in a stream that either this token or the given other represents.
upperBound() - Method in interface org.axonframework.eventhandling.WrappedToken
Returns the token representing the furthest position in the stream described by this token.
upperSegmentToken() - Method in class org.axonframework.eventhandling.MergedTrackingToken
Returns the token indicating the progress of the upper half (the half with the higher segmentId) of the merged segment represented by this token
UpstreamAwareStreamObserver<ResT> - Class in org.axonframework.axonserver.connector.util
Convenience implementation of a StreamObserver that provides access to the request stream, which allows cancellation of the call, flow control, etc.
UpstreamAwareStreamObserver() - Constructor for class org.axonframework.axonserver.connector.util.UpstreamAwareStreamObserver
 
usingDefaults() - Static method in class org.axonframework.common.lock.PessimisticLockFactory
Creates an instance using default values, as defined in the properties of the PessimisticLockFactory.Builder.
usingPooledStreamingEventProcessors() - Method in interface org.axonframework.config.EventProcessingConfigurer
Defaults Event Processors builders to use PooledStreamingEventProcessor.
usingPooledStreamingEventProcessors() - Method in class org.axonframework.config.EventProcessingModule
 
usingSubscribingEventProcessors() - Method in interface org.axonframework.config.EventProcessingConfigurer
Defaults Event Processors builders to use SubscribingEventProcessor.
usingSubscribingEventProcessors() - Method in class org.axonframework.config.EventProcessingModule
 
usingTrackingEventProcessors() - Method in interface org.axonframework.config.EventProcessingConfigurer
Defaults Event Processors builders to use TrackingEventProcessor.
usingTrackingEventProcessors() - Method in class org.axonframework.config.EventProcessingModule
 
UTF8 - Static variable in class org.axonframework.common.io.IOUtils
Represents the UTF-8 character set.

V

validate() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
 
validate() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
Validate the fields.
validate() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.eventhandling.AbstractEventBus.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
 
validate() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.SimpleEventBus.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
 
validate() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.metrics.MessageTimerMonitor.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
Validate whether the fields contained in this Builder as set accordingly.
validate() - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
 
validate() - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate(String, MessageHandlingMember<T>) - Method in interface org.axonframework.modelling.saga.AssociationResolver
Validates that the associationPropertyName supplied is compatible with the handler.
validate(String, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.MetaDataAssociationResolver
Does nothing because we can only check for existence of property in the metadata during event handling.
validate(String, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.PayloadAssociationResolver
Validates that the association property name exists as checked with the payload type.
validate() - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
Validate whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.serialization.JavaSerializer.Builder
Deprecated.
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
Validates whether the fields contained in this Builder are set accordingly.
validate() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
Validates whether the fields contained in this Builder are set accordingly.
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.eventsourcing.CachingEventSourcingRepository
 
validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
 
validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.modelling.command.AbstractRepository
Checks the aggregate for concurrent changes.
validatePositions() - Method in interface org.axonframework.eventhandling.EventTrackerStatusChangeListener
Flag dictating whether an EventTrackerStatus's positions (e.g.
valueOf(String) - Static method in enum org.axonframework.axonserver.connector.ErrorCode
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.ReplayStatus
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.conflictresolution.NoConflictResolver
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.modelling.command.AggregateCreationPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.modelling.saga.repository.NoResourceInjector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.modelling.saga.SagaCreationPolicy
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.
valueOf(String) - Static method in enum org.axonframework.springboot.EventProcessorProperties.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.axonframework.springboot.SerializerProperties.SerializerType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.axonframework.axonserver.connector.ErrorCode
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.ReplayStatus
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.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.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.modelling.command.AggregateCreationPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.axonframework.modelling.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.modelling.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.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.
values() - Static method in enum org.axonframework.springboot.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.springboot.SerializerProperties.SerializerType
Returns an array containing the constants of this enum type, in the order they are declared.
version() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
Returns the version of this consistent hash instance.
version() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
 
version() - Method in interface org.axonframework.modelling.command.Aggregate
Get the aggregate's version.
version() - Method in class org.axonframework.modelling.command.AggregateLifecycle
Gets the version of the aggregate.
version() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
 
version() - Method in class org.axonframework.modelling.command.LockAwareAggregate
 
version() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
 
VersionedAggregateIdentifier - Class in org.axonframework.modelling.command
Structure that holds an Aggregate Identifier and an expected version of an aggregate.
VersionedAggregateIdentifier(String, Long) - Constructor for class org.axonframework.modelling.command.VersionedAggregateIdentifier
Initializes a VersionedAggregateIdentifier with the given identifier and version.

W

waitStrategy(WaitStrategy) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
Sets the WaitStrategy which is used to make dependent threads wait for tasks to be completed.
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, Map<String, ?>) - 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.
whenPublishingA(Object, Map<String, ?>) - Method in interface org.axonframework.test.saga.WhenState
Use this method to indicate an application is published with given additional metaData, 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.
whenThenTimeAdvancesTo(Instant) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
whenThenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.aggregate.TestExecutor
Simulates the time advancing in the current given state using an Instant as the unit of time.
whenThenTimeElapses(Duration) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
whenThenTimeElapses(Duration) - Method in interface org.axonframework.test.aggregate.TestExecutor
Simulates the time elapsing in the current given state using a Duration as the unit of time.
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, CommandMessageFilter) - 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.
withGapsTruncatedAt(long) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
Returns a copy of the current token, with gaps truncated at the given truncationPoint.
withMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
 
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 interface org.axonframework.commandhandling.CommandResultMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandResultMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.deadline.DeadlineMessage
Returns a copy of this DeadlineMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.deadline.GenericDeadlineMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.DomainEventMessage
Returns a copy of this DomainEventMessage with the given metaData.
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.GenericDomainEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.replay.GenericResetContext
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.replay.ResetContext
Returns a copy of this ResetContext with the given metaData.
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 class org.axonframework.messaging.GenericResultMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.Message
Returns a copy of this Message with the given metaData.
withMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.ResultMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryResponseMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
 
withMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.QueryMessage
Returns a copy of this QueryMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.QueryResponseMessage
Returns a copy of this QueryResponseMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.SubscriptionQueryMessage
Returns a copy of this SubscriptionQueryMessage with the given metaData.
withMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.SubscriptionQueryUpdateMessage
 
withMetaData(MetaData) - Method in class org.axonframework.serialization.SerializedMessage
 
withMetaData(Map<String, ?>) - Method in class org.axonframework.serialization.SerializedMessage
 
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.
withSubtypes(Class<? extends A>...) - Method in class org.axonframework.config.AggregateConfigurer
Registers subtypes of this aggregate to support aggregate polymorphism.
withSubtypes(Collection<Class<? extends A>>) - Method in class org.axonframework.config.AggregateConfigurer
Registers subtypes of this aggregate to support aggregate polymorphism.
withSubtypes(Class<? extends T>...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
 
withSubtypes(Class<? extends T>...) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
Registers subtypes of this aggregate to support aggregate polymorphism.
withTrackingToken(TrackingToken) - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
 
withTrackingToken(TrackingToken) - Method in class org.axonframework.eventhandling.GenericTrackedEventMessage
 
withTrackingToken(TrackingToken) - Method in interface org.axonframework.eventhandling.TrackedEventMessage
Creates a copy of this message with the given trackingToken to replace the one in this message.
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
 
workerExecutor(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies the ScheduledExecutorService to be provided to the WorkPackages created by this PooledStreamingEventProcessor.
workerExecutor(Function<String, ScheduledExecutorService>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
Specifies a builder to construct a ScheduledExecutorService to be provided to the WorkPackages created by this PooledStreamingEventProcessor.
workerExecutorService(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.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).
wrapEventMessageHandler(Object) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
Wrap a given eventHandler in an AnnotationEventHandlerAdapter to allow this EventHandlerInvoker to correctly pass EventMessages to it.
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.commandhandling.MethodCommandHandlerDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.deadline.annotation.DeadlineMethodMessageHandlerDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.eventhandling.replay.ReplayAwareMessageHandlerWrapper
 
wrapHandler(MessageHandlingMember<T>) - Method in interface org.axonframework.messaging.annotation.HandlerEnhancerDefinition
Enhance the given original handler.
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.messaging.annotation.MessageHandlerInterceptorDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.modelling.command.inspection.MethodCommandHandlerInterceptorDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.modelling.command.inspection.MethodCreationPolicyDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.EndSagaMessageHandlerDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.SagaMethodMessageHandlerDefinition
 
wrapHandler(MessageHandlingMember<T>) - Method in class org.axonframework.queryhandling.annotation.MethodQueryMessageHandlerDefinition
 
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.
WrappedToken - Interface in org.axonframework.eventhandling
Interface marking a token that wraps another token.
WrappedTrackerStatus - Class in org.axonframework.eventhandling
Wrapper around an EventTrackerStatus, delegating all calls to a delegate.
WrappedTrackerStatus(EventTrackerStatus) - Constructor for class org.axonframework.eventhandling.WrappedTrackerStatus
Initializes the EventTrackerStatus 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.
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.
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.
writeTimestamp(PreparedStatement, int, Instant) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.statements.TimestampWriter
Write a timestamp from a Instant to a data value suitable for the database scheme.

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
 
xStream(XStream) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
Sets the XStream used to perform the serialization of objects to XML, and vice versa.
xStream(XStream) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
Sets the XStream used to perform the serialization of objects to XML, and vice versa.
XStreamAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Autoconfigures an XStream instance in absence of an existing XStream bean.
XStreamAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.XStreamAutoConfiguration
 
XStreamSecurityTypeUtility - Class in org.axonframework.springboot.util
Utility class exposing an operation that searches the ApplicationContext for auto-configuration base packages.
XStreamSerializer - Class in org.axonframework.serialization.xml
Serializer that uses XStream to serialize and deserialize arbitrary objects.
XStreamSerializer(XStreamSerializer.Builder) - Constructor for class org.axonframework.serialization.xml.XStreamSerializer
Instantiate a XStreamSerializer based on the fields contained in the XStreamSerializer.Builder.
XStreamSerializer.Builder - Class in org.axonframework.serialization.xml
Builder class to instantiate a XStreamSerializer.
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–2022. All rights reserved.