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
Deprecated.
Replaced by the MessageHandlerLookup and MessageHandlerConfigurer, eliminating the need of an abstract implementation used for command and query registration.
AbstractAnnotationHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
Deprecated.
 
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
Deprecated.
since moving to jakarta, as the generic serializedSaga was not handled well. There is a SagaEntry not extending from this abstract class anymore, you might be able to use instead.
AbstractSagaEntry(Object, String, Serializer, Class<T>) - Constructor for class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
Deprecated.
Constructs a new SagaEntry for the given saga.
AbstractSagaEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
Deprecated.
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 how many 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.
addAttribute(String, String) - Method in class org.axonframework.tracing.NoOpSpanFactory.NoOpSpan
 
addAttribute(String, String) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpan
 
addAttribute(String, String) - Method in interface org.axonframework.tracing.Span
Adds an attribute to the span.
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.
addConverter(DeadLetterJpaConverter<EventMessage<?>>) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
Adds a DeadLetterJpaConverter to the configuration, which is used to deserialize dead-letter entries from the database.
addConverter(DeadLetterJpaConverter<EventMessage<?>>) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
Deprecated.
Adds a DeadLetterJpaConverter to the configuration, which is used to deserialize dead-letter entries from the database.
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.eventhandling.MultiStreamableMessageSource.Builder
Adds a message source to the list of sources.
addNonTransientFailurePredicate(Predicate<Throwable>) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
Adds additional predicate into the predicate chain for checking non-transiency of a failure.
addNonTransientFailurePredicate(Class<E>, Predicate<? super E>) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
Adds additional predicate into the predicate chain for checking non-transiency of a failure.
addPackageAlias(String, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
Add an alias for a package.
addSpanAttributeProviders(List<SpanAttributesProvider>) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory.Builder
Adds all provided SpanAttributesProviders to the SpanFactory.
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(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore
Deprecated.
 
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
Deprecated.
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
Deprecated.
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
Deprecated.
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.AxonConfiguration
Deprecated.
 
afterPropertiesSet() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
Deprecated.
 
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 registers a set of CommandHandler based on annotations of 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 entity of 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.
aggregateIdAttribute(String) - Method in class org.axonframework.modelling.command.DefaultRepositorySpanFactory.Builder
Sets the attribute name to use for the aggregate id.
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.eventhandling.deadletter.jdbc.DeadLetterSchema
Returns the configured aggregateIdentifier column name.
aggregateIdentifierColumn(String) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema.Builder
Sets the name of the aggregateIdentifier column.
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.
aggregateIdentifierSpanAttributesProvider() - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
 
AggregateIdentifierSpanAttributesProvider - Class in org.axonframework.tracing.attributes
Adds the aggregate identifier to the Span if the current message being handled is a DomainEventMessage.
AggregateIdentifierSpanAttributesProvider() - Constructor for class org.axonframework.tracing.attributes.AggregateIdentifierSpanAttributesProvider
 
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.legacyjpa.GenericJpaRepository.Builder
Deprecated.
 
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, SnapshotterSpanFactory) - 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 - Annotation Type in org.axonframework.messaging.annotation
Annotation indication that a parameter on a Message Handler method should be injected with the aggregate type of a DomainEventMessage.
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.
aggregateTypeColumn() - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema
Returns the configured aggregateType column name.
aggregateTypeColumn(String) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema.Builder
Sets the name of the aggregateType column.
aggregateTypeInSpanName(boolean) - Method in class org.axonframework.eventsourcing.DefaultSnapshotterSpanFactory.Builder
Whether the aggregate type should be included in the span name.
AggregateTypeParameterResolverFactory - Class in org.axonframework.messaging.annotation
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a String type that are annotated with the AggregateType annotation and assigns the aggregate type of the DomainEventMessage.
AggregateTypeParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.AggregateTypeParameterResolverFactory
Initialize a ParameterResolverFactory for MessageIdentifier annotated parameters.
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.
allowReset(boolean) - Method in class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker.Builder
Sets whether this DeadLetteringEventHandlerInvoker supports resets of the provided SequencedDeadLetterQueue.
amountOfSequences() - Method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue
 
amountOfSequences() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
 
amountOfSequences() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
Deprecated.
 
amountOfSequences() - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
 
amountOfSequences() - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
Returns the number of unique sequences contained in this queue.
amountOfSequencesStatement(Connection, String) - Method in interface org.axonframework.eventhandling.deadletter.jdbc.DeadLetterStatementFactory
amountOfSequencesStatement(Connection, String) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory
 
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.
andAutoStart(boolean) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Whether to automatically start the processor when event processing is initialized.
andBatchSize(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Set the maximum number of events that may be processed in a single transaction.
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
Sets the initial number of segments for asynchronous processing.
andInitialTrackingToken(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Sets the builder to use to create the initial TrackingToken.
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.GenericStreamingQueryMessage
 
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.StreamingQueryMessage
 
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(AxonServerEventStoreFactory.AxonServerEventStoreConfiguration) - Method in interface org.axonframework.axonserver.connector.event.axon.AxonServerEventStoreFactory.AxonServerEventStoreConfiguration
Returns a configuration that applies the given other configuration after applying this.
andThen(EventProcessingConfigurer.DeadLetteringInvokerConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer.DeadLetteringInvokerConfiguration
Returns a configuration that applies the given other configuration after applying this.
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
 
andThenApplyIf(Supplier<Boolean>, Supplier<?>) - Method in interface org.axonframework.modelling.command.ApplyMore
Conditionally apply a subsequent event to the aggregate after applying another event.
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
 
andThenIf(Supplier<Boolean>, Runnable) - Method in interface org.axonframework.modelling.command.ApplyMore
Conditionally execute the given runnable after applying the previous event.
andThenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.aggregate.TestExecutor
Deprecated.
in favor of TestExecutor.whenTimeAdvancesTo(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.whenTimeElapses(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.
andWorkerTerminationTimeout(long) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
andWorkerTerminationTimeout(long, TimeUnit) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
Sets the shutdown timeout to terminate active workers.
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>, MessageHandlerInterceptorMemberChain<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
Deprecated.
AnnotationCommandHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
Deprecated.
 
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
Deprecated.
Use Spring Boot autoconfiguration or register the individual beans explicitly. Check the "See also" list for which individual beans to register.
AnnotationDrivenRegistrar - Class in org.axonframework.spring.config
Deprecated.
Use Spring Boot autoconfiguration or register the individual beans explicitly. AnnotationDriven contains a list of look-up and registration components to replace this component with.
AnnotationDrivenRegistrar() - Constructor for class org.axonframework.spring.config.AnnotationDrivenRegistrar
Deprecated.
 
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
Deprecated.
AnnotationQueryHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
Deprecated.
 
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.
ANY_CONNECTION_NAME - Static variable in class org.springframework.boot.testcontainers.service.connection.ContainerConnectionDetailsFactory
 
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<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
Deprecated.
 
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
Deprecated.
Use Spring Boot autoconfiguration or register the individual beans explicitly.
ApplicationContextLookupParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
Deprecated.
Creates an instance, using the given defaultFactories.
apply(Configuration) - Method in class org.axonframework.axonserver.connector.event.axon.PersistentStreamSequencingPolicyProvider
 
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(Connection, int, int) - Method in interface org.axonframework.common.jdbc.PagingJdbcIterable.PagingStatementSupplier
Create a new PreparedStatement using the given connection, paging through the provided offset and maxSize.
apply(String) - Method in interface org.axonframework.eventhandling.pooled.MaxSegmentProvider
Returns the maximum amount of segments to claim for the given processingGroup.
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.
asCause(Throwable) - Static method in exception org.axonframework.messaging.deadletter.ThrowableCause
Return the given cause as a ThrowableCause.
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(Serializer) - Method in class org.axonframework.deadline.dbscheduler.DbSchedulerBinaryDeadlineDetails
Returns the DbSchedulerBinaryDeadlineDetails as an GenericDeadlineMessage, with the timestamp set using the GenericEventMessage.clock.
asDeadLineMessage(Serializer) - Method in class org.axonframework.deadline.dbscheduler.DbSchedulerHumanReadableDeadlineDetails
Returns the DbSchedulerHumanReadableDeadlineDetails as an GenericDeadlineMessage, with the timestamp set using the GenericEventMessage.clock.
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.
asDeadLineMessage(Serializer) - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
Returns the DeadlineDetails as an GenericDeadlineMessage, with the timestamp set using the GenericEventMessage.clock to set to the current time.
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.
asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
Deprecated.
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
assertDeadlinesMetMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
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.
assertNonBlank(String, String) - Static method in class org.axonframework.common.BuilderUtils
Assert that the given string does not equals an empty String.
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.
assertTriggeredDeadlines(Object...) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that the given expected deadlines have been triggered.
assertTriggeredDeadlinesMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that the triggered deadlines match the given matcher.
assertTriggeredDeadlinesOfType(Class<?>...) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that the given expectedDeadlineTypes have been triggered.
assertTriggeredDeadlinesWithName(String...) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
Asserts that the given expectedDeadlineNames have been triggered.
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.
associationKeyColumn() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
Returns the name of the associationKey column
associationKeyColumn(String) - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema.Builder
Sets the name of the association key column.
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.
associationValueColumn() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
Returns the name of the associationValue column
associationValueColumn(String) - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema.Builder
Sets the name of the association value column.
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
associationValueEntryTable(String) - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema.Builder
Sets the name of the association value entry 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.
associationValues() - Static method in class org.axonframework.modelling.saga.SagaLifecycle
Retrieves the AssociationValues that have been associated with the current Saga so far.
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
 
AttributeProviders() - Constructor for class org.axonframework.springboot.TracingProperties.AttributeProviders
 
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.
awaitTermination(long, TimeUnit) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
 
AXON_CONFIGURATION_BEAN - Static variable in class org.axonframework.spring.config.SpringAxonAutoConfigurer
Deprecated.
Name of the AxonConfiguration bean.
AXON_CONFIGURER_BEAN - Static variable in class org.axonframework.spring.config.SpringAxonAutoConfigurer
Deprecated.
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
Deprecated.
AxonConfiguration(Configurer) - Constructor for class org.axonframework.spring.config.AxonConfiguration
Deprecated.
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.
AxonDbSchedulerAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration class for the deadline manager and event scheduler using db-scheduler.
AxonDbSchedulerAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonDbSchedulerAutoConfiguration
 
AxonException - Exception in org.axonframework.common
Base exception for 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.
AxonException(String, Throwable, boolean) - Constructor for exception org.axonframework.common.AxonException
Initializes the exception using the given message, cause and writableStackTrace.
axonFrameworkVersionResolver(Supplier<String>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
Deprecated.
Not ued anymore
AxonIQConsoleModule - Class in org.axonframework.config
Module related to AxonIQ console, for now it's just logging information about AxonIQ console when it's not suppressed and the console-framework-client is not available.
AxonIQConsoleModule() - Constructor for class org.axonframework.config.AxonIQConsoleModule
 
AxonJobRunrAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Auto configuration class for the deadline manager and event scheduler using JobRunr.
AxonJobRunrAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonJobRunrAutoConfiguration
 
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.
AxonNonTransientExceptionClassesPredicate - Class in org.axonframework.commandhandling.gateway
An Axon-specific Predicate, used to check the non-transiency of a failure comparing it against concrete classes.
AxonNonTransientExceptionClassesPredicate() - Constructor for class org.axonframework.commandhandling.gateway.AxonNonTransientExceptionClassesPredicate
 
AxonProcessorInstructionHandler(EventProcessor, String) - Constructor for class org.axonframework.axonserver.connector.processor.EventProcessorControlService.AxonProcessorInstructionHandler
 
AxonServerActuatorAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Autoconfiguration class for Spring Boot Actuator monitoring tools around Axon Server.
AxonServerActuatorAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonServerActuatorAutoConfiguration
 
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
 
AxonServerAutoConfiguration.ConnectionDetailsConnectionManagerConfiguration - Class in org.axonframework.springboot.autoconfig
 
AxonServerAutoConfiguration.DefaultConnectionManagerConfiguration - Class in org.axonframework.springboot.autoconfig
 
AxonServerBusAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Configures Axon Server implementations of the CommandBus, EventStore, and QueryBus.
AxonServerBusAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonServerBusAutoConfiguration
 
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<?>>, CommandBusSpanFactory) - Method in class org.axonframework.springboot.autoconfig.AxonServerBusAutoConfiguration
 
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.Eventhandling - Class in org.axonframework.axonserver.connector
 
AxonServerConfiguration.Eventhandling.ProcessorSettings - Class in org.axonframework.axonserver.connector
 
AxonServerConfiguration.EventStoreConfiguration - 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
 
AxonServerConfiguration.PersistentStreamSettings - Class in org.axonframework.axonserver.connector
 
AxonServerConnectionDetails - Interface in org.axonframework.springboot.service.connection
ConnectionDetails implementation carrying the connection details for an Axon Server instance.
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 - Variable in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
 
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.
AxonServerContainer - Class in org.axonframework.test.server
Constructs an Axon Server container for testing.
AxonServerContainer() - Constructor for class org.axonframework.test.server.AxonServerContainer
Initialize an Axon Server test container using the default image name "axoniq/axonserver".
AxonServerContainer(String) - Constructor for class org.axonframework.test.server.AxonServerContainer
Initialize Axon Server with the given dockerImageName.
AxonServerContainer(DockerImageName) - Constructor for class org.axonframework.test.server.AxonServerContainer
Initialize Axon Server with the given dockerImageName.
AxonServerDockerComposeConnectionDetailsFactory - Class in org.axonframework.springboot.service.connection
ConnectionDetailsFactory implementation that recognizes Spring Boot Docker Compose-managed Docker containers running Axon Server and creates an AxonServerConnectionDetails bean with the details to connect to AxonServer within that container.
AxonServerDockerComposeConnectionDetailsFactory() - Constructor for class org.axonframework.springboot.service.connection.AxonServerDockerComposeConnectionDetailsFactory
Initializes the factory to look for containers running the "axoniq/axonserver" image.
AxonServerEEContainer<SELF extends AxonServerEEContainer<SELF>> - Class in org.axonframework.test.server
Deprecated.
In favor of AxonServerContainer following the merger of Standard and Enterprise edition into a single version.
AxonServerEEContainer(String) - Constructor for class org.axonframework.test.server.AxonServerEEContainer
Deprecated.
Initialize AxonServer EE with a given docker image.
AxonServerEEContainer(DockerImageName) - Constructor for class org.axonframework.test.server.AxonServerEEContainer
Deprecated.
Initialize AxonServer EE with a given docker image.
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.
AxonServerEventStoreFactory - Class in org.axonframework.axonserver.connector.event.axon
A factory towards AxonServerEventStores.
AxonServerEventStoreFactory(AxonServerEventStoreFactory.Builder) - Constructor for class org.axonframework.axonserver.connector.event.axon.AxonServerEventStoreFactory
Instantiate a AxonServerEventStoreFactory based on the fields contained in the AxonServerEventStoreFactory.Builder.
axonServerEventStoreFactory(AxonServerConfiguration, AxonServerConnectionManager, Serializer, Serializer, Configuration) - Method in class org.axonframework.springboot.autoconfig.AxonServerBusAutoConfiguration
 
AxonServerEventStoreFactory.AxonServerEventStoreConfiguration - Interface in org.axonframework.axonserver.connector.event.axon
Contract defining AxonServerEventStore.Builder based configuration when constructing an AxonServerEventStore.
AxonServerEventStoreFactory.Builder - Class in org.axonframework.axonserver.connector.event.axon
Builder class to instantiate an AxonServerEventStoreFactory.
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.
AxonServerHealthIndicator - Class in org.axonframework.actuator.axonserver
An AbstractHealthIndicator implementation exposing the health of the connections made through the AxonServerConnectionManager.
AxonServerHealthIndicator(AxonServerConnectionManager) - Constructor for class org.axonframework.actuator.axonserver.AxonServerHealthIndicator
Constructs this health indicator, extracting health information from the given connectionManager.
axonServerHealthIndicator(AxonServerConnectionManager) - Method in class org.axonframework.springboot.autoconfig.AxonServerActuatorAutoConfiguration
 
AxonServerNonTransientRemoteCommandHandlingException - Exception in org.axonframework.axonserver.connector.command
Exception indicating a non-transient problem that was reported by the remote end of a connection.
AxonServerNonTransientRemoteCommandHandlingException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerNonTransientRemoteCommandHandlingException
Initialize the exception with given errorCode and errorMessage.
AxonServerNonTransientRemoteQueryHandlingException - Exception in org.axonframework.axonserver.connector.query
Exception indicating a non-transient problem that was reported during query handling by the remote end of a connection.
AxonServerNonTransientRemoteQueryHandlingException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerNonTransientRemoteQueryHandlingException
Initialize the exception with given errorCode and errorMessage.
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.
AxonServerRemoteCommandHandlingException(String, ErrorMessage, boolean) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
Initialize the exception with given errorCode, errorMessage and writableStackTrace.
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.
AxonServerRemoteQueryHandlingException(String, ErrorMessage, boolean) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
Initialize a Query Handling exception from a remote source.
AxonServerSEContainer<SELF extends AxonServerSEContainer<SELF>> - Class in org.axonframework.test.server
Deprecated.
In favor of AxonServerContainer following the merger of Standard and Enterprise edition into a single version.
AxonServerSEContainer(String) - Constructor for class org.axonframework.test.server.AxonServerSEContainer
Deprecated.
Initialize AxonServer SE with a given docker image.
AxonServerSEContainer(DockerImageName) - Constructor for class org.axonframework.test.server.AxonServerSEContainer
Deprecated.
Initialize AxonServer SE with a given docker image.
AxonServerStatusAggregator - Class in org.axonframework.actuator.axonserver
A SimpleStatusAggregator implementation determining the overall health of an Axon Framework application using Axon Server.
AxonServerStatusAggregator() - Constructor for class org.axonframework.actuator.axonserver.AxonServerStatusAggregator
Constructs a default Axon Server specific SimpleStatusAggregator.
axonServerStatusAggregator() - Method in class org.axonframework.springboot.autoconfig.AxonServerActuatorAutoConfiguration
 
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
Deprecated.
Deprecated in favor of constructor with a SpanFactory. This constructor defaults to a NoOpSpanFactory.
AxonServerSubscriptionQueryResult(SubscriptionQueryResult, SpanFactory, SubscriptionMessageSerializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
Deprecated.
Deprecated in favor of constructor with a QueryBusSpanFactory. This constructor defaults to a DefaultQueryBusSpanFactory with the provided SpanFactory.
AxonServerSubscriptionQueryResult(SubscriptionQueryMessage<?, ?, ?>, SubscriptionQueryResult, SubscriptionMessageSerializer, QueryBusSpanFactory, Span) - 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.
axonServerSupportsQueryStreaming(List<ProcessingInstruction>) - Static method in class org.axonframework.axonserver.connector.util.ProcessingInstructionHelper
Retrieve whether Axon Server supports streaming from the given processingInstructions, by searching for the value of ProcessingKey.SERVER_SUPPORTS_STREAMING.
AxonServerTestContainerConnectionDetailsFactory - Class in org.axonframework.springboot.service.connection
ConnectionDetailsFactory class that recognizes TestContainer instances running Axon Server.
AxonServerTestContainerConnectionDetailsFactory() - Constructor for class org.axonframework.springboot.service.connection.AxonServerTestContainerConnectionDetailsFactory
 
AxonStartedEvent - Class in org.axonframework.spring.event
Event published after initialization of Axon through the Spring event mechanism.
AxonStartedEvent() - Constructor for class org.axonframework.spring.event.AxonStartedEvent
 
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.
AxonTracingAutoConfiguration - Class in org.axonframework.springboot.autoconfig
Configures common tracing components for Axon Framework.
AxonTracingAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
 
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.
backwardsCompatiblePersistentStreamScheduledExecutorBuilder(ScheduledExecutorService) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
Creates a PersistentStreamScheduledExecutorBuilder defaulting to the same given persistentStreamScheduler on each invocation.
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
 
batchSize(int) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
Deprecated.
 
BeanHelper - Class in org.axonframework.spring.config
Helper class to simplify the creation of bean definitions for components configured in Axon Configuration.
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.
BeanValidationInterceptor<T extends Message<?>> - Class in org.axonframework.messaging.interceptors.legacyvalidation
Deprecated.
in favor of using BeanValidationInterceptor which moved to jakarta.
BeanValidationInterceptor() - Constructor for class org.axonframework.messaging.interceptors.legacyvalidation.BeanValidationInterceptor
Deprecated.
Initializes a validation interceptor using a default ValidatorFactory.
BeanValidationInterceptor(ValidatorFactory) - Constructor for class org.axonframework.messaging.interceptors.legacyvalidation.BeanValidationInterceptor
Deprecated.
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
 
binaryTask(Supplier<DbSchedulerDeadlineManager>) - Static method in class org.axonframework.deadline.dbscheduler.DbSchedulerDeadlineManager
Gives the Task using DbSchedulerBinaryDeadlineDetails to execute a deadline via a Scheduler.
binaryTask(Supplier<DbSchedulerEventScheduler>) - Static method in class org.axonframework.eventhandling.scheduling.dbscheduler.DbSchedulerEventScheduler
Gives the Task using DbSchedulerHumanReadableEventData to publish an event via a Scheduler.
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.event.axon.AxonServerEventStoreFactory.Builder
Initializes an AxonServerEventStoreFactory as specified through this builder.
build(String, PersistentStreamProperties, ScheduledExecutorService, int, String, Configuration) - Method in interface org.axonframework.axonserver.connector.event.axon.PersistentStreamMessageSourceFactory
Builds a new instance of PersistentStreamMessageSource with the specified parameters.
build(Integer, String) - Method in interface org.axonframework.axonserver.connector.event.axon.PersistentStreamScheduledExecutorBuilder
Builds a ScheduledExecutorService using the given threadCount and streamName.
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.DefaultCommandBusSpanFactory.Builder
Initializes a DefaultCommandBusSpanFactory 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.dbscheduler.DbSchedulerDeadlineManager.Builder
Initializes a DbSchedulerDeadlineManager as specified through this Builder.
build() - Method in class org.axonframework.deadline.DefaultDeadlineManagerSpanFactory.Builder
Initializes a DefaultDeadlineManagerSpanFactory as specified through this Builder.
build() - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager.Builder
Initializes a JobRunrDeadlineManager as specified through this Builder.
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.deadletter.DeadLetteringEventHandlerInvoker.Builder
Initializes a DeadLetteringEventHandlerInvoker as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema.Builder
Initializes a DeadLetterSchema as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterJdbcConverter.Builder
Initializes a DefaultDeadLetterJdbcConverter as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory.Builder
Initializes a DefaultDeadLetterStatementFactory as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue.Builder
Initializes a JdbcSequencedDeadLetterQueue as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
Initializes a JpaSequencedDeadLetterQueue as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
Deprecated.
Initializes a JpaSequencedDeadLetterQueue as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.DefaultEventBusSpanFactory.Builder
Initializes a DefaultEventBusSpanFactory as specified through this Builder.
build() - Method in class org.axonframework.eventhandling.DefaultEventProcessorSpanFactory.Builder
Initializes a DefaultEventProcessorSpanFactory 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.MultiStreamableMessageSource.Builder
Initializes a MultiStreamableMessageSource 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.dbscheduler.DbSchedulerEventScheduler.Builder
Initializes a DbSchedulerEventScheduler 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.jobrunr.JobRunrEventScheduler.Builder
Initializes a JobRunrEventScheduler 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.tokenstore.legacyjpa.JpaTokenStore.Builder
Deprecated.
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.DefaultSnapshotterSpanFactory.Builder
Initializes a DefaultSnapshotterSpanFactory 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.eventstore.legacyjpa.EmbeddedEventStore.Builder
Deprecated.
Initializes a EmbeddedEventStore as specified through this Builder.
build() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
Deprecated.
Initializes a JpaEventStorageEngine 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.messaging.deadletter.InMemorySequencedDeadLetterQueue.Builder
Initializes a InMemorySequencedDeadLetterQueue 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.DefaultRepositorySpanFactory.Builder
Initializes a DefaultRepositorySpanFactory 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.command.legacyjpa.GenericJpaRepository.Builder
Deprecated.
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.DefaultSagaManagerSpanFactory.Builder
Initializes a DefaultSagaManagerSpanFactory 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.jdbc.SagaSchema.Builder
Builds a new SagaSchema from builder values.
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.modelling.saga.repository.legacyjpa.JpaSagaStore.Builder
Deprecated.
Initializes a JpaSagaStore as specified through this Builder.
build() - Method in class org.axonframework.queryhandling.DefaultQueryBusSpanFactory.Builder
Initializes a DefaultQueryBusSpanFactory 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.DefaultQueryUpdateEmitterSpanFactory.Builder
Initializes a DefaultQueryUpdateEmitterSpanFactory 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.
build() - Method in class org.axonframework.tracing.NestingSpanFactory.Builder
Deprecated.
Executes the builder's configuration, creating the NestingSpanFactory.
build() - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory.Builder
Initializes the OpenTelemetrySpanFactory.
build() - Method in class org.axonframework.tracing.TracingHandlerEnhancerDefinition.Builder
Initializes the TracingHandlerEnhancerDefinition based on the builder contents.
buildAggregateHierarchy(ListableBeanFactory, String[]) - Static method in class org.axonframework.spring.config.SpringAggregateLookup
Builds a hierarchy model from the given aggregatePrototypes found in the given beanFactory.
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.
buildChainedInterceptor() - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
Instantiate the MessageHandlerInterceptorMemberChain of generic type T as the Saga type to be stored.
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.event.axon.AxonServerEventStoreFactory
Instantiate a builder to construct an AxonServerEventStoreFactory.
Builder() - Constructor for class org.axonframework.axonserver.connector.event.axon.AxonServerEventStoreFactory.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.DefaultCommandBusSpanFactory
Creates a Builder to be able to create a DefaultCommandBusSpanFactory.
Builder() - Constructor for class org.axonframework.commandhandling.DefaultCommandBusSpanFactory.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.dbscheduler.DbSchedulerDeadlineManager
Instantiate a Builder to be able to create a DbSchedulerDeadlineManager.
Builder() - Constructor for class org.axonframework.deadline.dbscheduler.DbSchedulerDeadlineManager.Builder
 
builder() - Static method in class org.axonframework.deadline.DefaultDeadlineManagerSpanFactory
Builder() - Constructor for class org.axonframework.deadline.DefaultDeadlineManagerSpanFactory.Builder
 
builder() - Static method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager
Instantiate a Builder to be able to create a JobRunrDeadlineManager.
Builder() - Constructor for class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager.Builder
 
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() - Static method in class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker
Instantiate a builder to construct a DeadLetteringEventHandlerInvoker.
builder() - Static method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema
Instantiate a builder to construct a DeadLetterSchema.
Builder() - Constructor for class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema.Builder
 
builder() - Static method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterJdbcConverter
Instantiate a builder to construct a DefaultDeadLetterJdbcConverter.
Builder() - Constructor for class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterJdbcConverter.Builder
 
builder() - Static method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory
Instantiate a builder to construct a DefaultDeadLetterStatementFactory.
Builder() - Constructor for class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory.Builder
 
builder() - Static method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue
Instantiate a builder to construct a JdbcSequencedDeadLetterQueue.
Builder() - Constructor for class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue.Builder
 
builder() - Static method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
Creates a new builder, capable of building a JpaSequencedDeadLetterQueue according to the provided configuration.
Builder() - Constructor for class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
 
builder() - Static method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
Deprecated.
Creates a new builder, capable of building a JpaSequencedDeadLetterQueue according to the provided configuration.
Builder() - Constructor for class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
Deprecated.
 
builder() - Static method in class org.axonframework.eventhandling.DefaultEventBusSpanFactory
Builder() - Constructor for class org.axonframework.eventhandling.DefaultEventBusSpanFactory.Builder
 
builder() - Static method in class org.axonframework.eventhandling.DefaultEventProcessorSpanFactory
Builder() - Constructor for class org.axonframework.eventhandling.DefaultEventProcessorSpanFactory.Builder
 
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.MultiStreamableMessageSource
Instantiate a Builder to be able to create an MultiStreamableMessageSource.
Builder() - Constructor for class org.axonframework.eventhandling.MultiStreamableMessageSource.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.dbscheduler.DbSchedulerEventScheduler
Instantiate a Builder to be able to create a DbSchedulerEventScheduler.
Builder() - Constructor for class org.axonframework.eventhandling.scheduling.dbscheduler.DbSchedulerEventScheduler.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.jobrunr.JobRunrEventScheduler
Instantiate a Builder to be able to create a JobRunrEventScheduler.
Builder() - Constructor for class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler.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.tokenstore.legacyjpa.JpaTokenStore
Deprecated.
Instantiate a Builder to be able to create a JpaTokenStore.
Builder() - Constructor for class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore.Builder
Deprecated.
 
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() - Static method in class org.axonframework.eventsourcing.DefaultSnapshotterSpanFactory
Builder() - Constructor for class org.axonframework.eventsourcing.DefaultSnapshotterSpanFactory.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.eventstore.legacyjpa.EmbeddedEventStore
Deprecated.
Instantiate a Builder to be able to create an EmbeddedEventStore.
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore.Builder
Deprecated.
 
builder() - Static method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
Deprecated.
Instantiate a Builder to be able to create a JpaEventStorageEngine.
Builder() - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
Deprecated.
 
builder() - Static method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
Deprecated.
In favor of MultiStreamableMessageSource.builder(). This class belongs in the messaging module instead of the eventsourcing module.
Builder() - Constructor for class org.axonframework.eventsourcing.MultiStreamableMessageSource.Builder
Deprecated.
 
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.messaging.deadletter.InMemorySequencedDeadLetterQueue
Instantiate a builder to construct an InMemorySequencedDeadLetterQueue.
Builder() - Constructor for class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue.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() - Static method in class org.axonframework.modelling.command.DefaultRepositorySpanFactory
Builder() - Constructor for class org.axonframework.modelling.command.DefaultRepositorySpanFactory.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>) - Static method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository
Deprecated.
Instantiate a Builder to be able to create a GenericJpaRepository for aggregate type T.
Builder(Class<T>) - Constructor for class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
Deprecated.
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.DefaultSagaManagerSpanFactory
Builder() - Constructor for class org.axonframework.modelling.saga.DefaultSagaManagerSpanFactory.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.jdbc.SagaSchema
Returns a new SagaSchema.Builder initialized with default settings.
Builder() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.SagaSchema.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() - Static method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
Deprecated.
Instantiate a Builder to be able to create a JpaSagaStore.
Builder() - Constructor for class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore.Builder
Deprecated.
 
Builder() - Constructor for class org.axonframework.modelling.saga.repository.LockingSagaRepository.Builder
 
builder() - Static method in class org.axonframework.queryhandling.DefaultQueryBusSpanFactory
Creates a Builder to be able to create a DefaultQueryBusSpanFactory.
Builder() - Constructor for class org.axonframework.queryhandling.DefaultQueryBusSpanFactory.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.DefaultQueryUpdateEmitterSpanFactory
Creates a Builder to be able to create a DefaultQueryUpdateEmitterSpanFactory.
Builder() - Constructor for class org.axonframework.queryhandling.DefaultQueryUpdateEmitterSpanFactory.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
 
builder() - Static method in class org.axonframework.tracing.NestingSpanFactory
Deprecated.
Creates a new NestingSpanFactory.Builder that can build a NestingSpanFactory.
Builder() - Constructor for class org.axonframework.tracing.NestingSpanFactory.Builder
Deprecated.
 
builder() - Static method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
Instantiate a Builder to create a OpenTelemetrySpanFactory.
Builder() - Constructor for class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory.Builder
 
builder() - Static method in class org.axonframework.tracing.TracingHandlerEnhancerDefinition
Instantiate a builder to create a TracingHandlerEnhancerDefinition.
Builder() - Constructor for class org.axonframework.tracing.TracingHandlerEnhancerDefinition.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.
cachedEvents(int) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore.Builder
Deprecated.
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.
call() - Method in class org.axonframework.axonserver.connector.PriorityCallable
 
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 class org.axonframework.deadline.dbscheduler.DbSchedulerDeadlineManager
 
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.jobrunr.JobRunrDeadlineManager
 
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, ScopeDescriptor) - Method in class org.axonframework.deadline.dbscheduler.DbSchedulerDeadlineManager
 
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.jobrunr.JobRunrDeadlineManager
 
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 class org.axonframework.deadline.dbscheduler.DbSchedulerDeadlineManager
 
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.jobrunr.JobRunrDeadlineManager
 
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 class org.axonframework.eventhandling.scheduling.dbscheduler.DbSchedulerEventScheduler
 
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.jobrunr.JobRunrEventScheduler
 
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(DeadLetterEventEntry) - Method in interface org.axonframework.eventhandling.deadletter.jpa.DeadLetterJpaConverter
Check whether this converter supports the given DeadLetterEventEntry.
canConvert(M) - Method in interface org.axonframework.eventhandling.deadletter.jpa.DeadLetterJpaConverter
Check whether this converter supports the given EventMessage.
canConvert(DeadLetterEventEntry) - Method in class org.axonframework.eventhandling.deadletter.jpa.EventMessageDeadLetterJpaConverter
 
canConvert(EventMessage<?>) - Method in class org.axonframework.eventhandling.deadletter.jpa.EventMessageDeadLetterJpaConverter
 
canConvert(DeadLetterEventEntry) - Method in interface org.axonframework.eventhandling.deadletter.legacyjpa.DeadLetterJpaConverter
Deprecated.
Check whether this converter supports the given DeadLetterEventEntry.
canConvert(M) - Method in interface org.axonframework.eventhandling.deadletter.legacyjpa.DeadLetterJpaConverter
Deprecated.
Check whether this converter supports the given EventMessage.
canConvert(DeadLetterEventEntry) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.EventMessageDeadLetterJpaConverter
Deprecated.
 
canConvert(EventMessage<?>) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.EventMessageDeadLetterJpaConverter
Deprecated.
 
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.
canConvert(Class) - Method in class org.axonframework.serialization.GapAwareTrackingTokenConverter
 
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
 
canForward(CommandMessage<?>, P) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
 
canForward(CommandMessage<?>, T) - Method in interface org.axonframework.modelling.command.inspection.ForwardingCommandMessageHandlingMember
Check if this handler is in a state where it can currently accept the command.
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
 
canHandle(ResponseType<?>) - Method in class org.axonframework.queryhandling.QuerySubscription
Check if this QuerySubscription can handle the given queryResponseType, by calling the ResponseType.matches(Type) function on it and providing the set responseType of this subscription.
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.
cause() - Method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcDeadLetter
 
cause() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
 
cause() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
Deprecated.
 
Cause - Interface in org.axonframework.messaging.deadletter
Contract describing the cause for dead lettering a Message.
cause() - Method in interface org.axonframework.messaging.deadletter.DeadLetter
The cause for the DeadLetter.message() to be dead lettered.
cause() - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
 
causeMessageColumn(String) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema.Builder
Sets the name of the causeMessage column.
causeMessageColumn() - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema
Returns the configured causeMessage column name.
causeTypeColumn(String) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema.Builder
Sets the name of the causeType column.
causeTypeColumn() - Method in class org.axonframework.eventhandling.deadletter.jdbc.DeadLetterSchema
Returns the configured causeType column name.
CBORMapperAutoConfiguration - Class in org.axonframework.springboot.autoconfig
 
CBORMapperAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.CBORMapperAutoConfiguration
 
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.
chainedInterceptor(Class<T>) - Method in class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
 
chainedInterceptor(Class<T>) - Method in interface org.axonframework.modelling.saga.metamodel.SagaMetaModelFactory
Returns an Interceptor Chain of annotated interceptor methods for the given sagaType.
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.
claim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
Attempt to claim ownership of this token.
claimableSequencesStatement(Connection, String, Instant, int, int) - Method in interface org.axonframework.eventhandling.deadletter.jdbc.DeadLetterStatementFactory
Constructs the PreparedStatement used to retrieve the identifiers of the first entries of each sequence with that can be claimed.
claimableSequencesStatement(Connection, String, Instant, int, int) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory
 
claimDuration(Duration) - Method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue.Builder
Sets the claim duration, which is the time a dead-letter gets locked when processing and waiting for it to complete.
claimDuration(Duration) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
Sets the claim duration, which is the time a message gets locked when processing and waiting for it to complete.
claimDuration(Duration) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
Deprecated.
Sets the claim duration, which is the time a message gets locked when processing and waiting for it to complete.
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.
claimSegment(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
 
claimSegment(int) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
Instructs the processor to claim the segment with given segmentId and start processing it as soon as possible.
claimSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
Instructs the processor to claim the segment with given segmentId and start processing it as soon as possible.
claimStatement(Connection, String, Instant, Instant) - Method in interface org.axonframework.eventhandling.deadletter.jdbc.DeadLetterStatementFactory
Constructs the PreparedStatement used to claim a DeadLetter entry.
claimStatement(Connection, String, Instant, Instant) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory
 
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.
claimTimeout(TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore.Builder
Deprecated.
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.
ClasspathResolver - Class in org.axonframework.util
Resolves certain parameters from the classpath.
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.
cleanupDelay(long) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore.Builder
Deprecated.
Sets the delay between two clean ups of lagging event processors.
clear() - Method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue
 
clear() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
 
clear() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
Deprecated.
 
clear() - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
 
clear() - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
Clears out all dead letters present in this queue.
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.
clearConverters() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
Removes all current converters currently configured, including the default EventMessageDeadLetterJpaConverter.
clearConverters() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
Deprecated.
Removes all current converters currently configured, including the default EventMessageDeadLetterJpaConverter.
clearProcessingStarted() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
Releases the message for processing by another thread or process.
clearStatement(Connection, String) - Method in interface org.axonframework.eventhandling.deadletter.jdbc.DeadLetterStatementFactory
Constructs the PreparedStatement used for the clear operation.
clearStatement(Connection, String) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory
 
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
 
clientSupportsQueryStreaming(List<ProcessingInstruction>) - Static method in class org.axonframework.axonserver.connector.util.ProcessingInstructionHelper
Retrieve whether Client (query issuer) supports streaming from the given processingInstructions, by searching for the value of ProcessingKey.CLIENT_SUPPORTS_STREAMING.
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.eventhandling.tokenstore.jpa.TokenEntry
The clock used to persist timestamps in this entry.
clock - Static variable in class org.axonframework.eventsourcing.AggregateLoadTimeSnapshotTriggerDefinition
 
clock - Static variable in class org.axonframework.messaging.deadletter.GenericDeadLetter
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.
clock(Clock) - Method in class org.axonframework.tracing.NestingSpanFactory.Builder
Deprecated.
Configures the Clock to use when determining the time passed since publication of an event and the current time.
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.PersistentStreamConnection
Closes the persistent stream connection to Axon Server.
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.
close() - Method in interface org.axonframework.tracing.SpanScope
Closes the scope of the Span on which it was opened.
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
Deprecated.
 
commandBus(TransactionManager, Configuration, 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
CommandBusProperties() - Constructor for class org.axonframework.springboot.TracingProperties.CommandBusProperties
 
CommandBusSpanFactory - Interface in org.axonframework.commandhandling
Span factory that creates spans for the CommandBus.
commandBusSpanFactory(SpanFactory, TracingProperties) - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
 
CommandCallback<C,R> - Interface in org.axonframework.commandhandling
Interface describing a callback that is invoked when command handler execution has finished.
commandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
Set a CommandCallback on the command bus.
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.
CommandExecutionException(String, Throwable, Object, boolean) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
Initializes the exception with given message, cause, an object providing application-specific details, and writableStackTrace
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
Deprecated.
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 CommandGateway 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
Deprecated.
CommandHandlerSubscriber() - Constructor for class org.axonframework.spring.config.CommandHandlerSubscriber
Deprecated.
 
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(PriorityTask) - Method in interface org.axonframework.axonserver.connector.PriorityTask
 
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
 
computeIfAbsent(Object, Supplier<T>) - Method in interface org.axonframework.common.caching.Cache
Returns the value under the given key in the cache.
computeIfAbsent(Object, Supplier<T>) - Method in class org.axonframework.common.caching.NoCache
 
computeIfAbsent(Object, Supplier<T>) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
computeIfPresent(Object, UnaryOperator<V>) - Method in interface org.axonframework.common.caching.Cache
Perform the update in the value behind the given key.
computeIfPresent(Object, UnaryOperator<V>) - Method in class org.axonframework.common.caching.EhCache3Adapter
 
computeIfPresent(Object, UnaryOperator<V>) - Method in class org.axonframework.common.caching.EhCacheAdapter
Deprecated.
 
computeIfPresent(Object, UnaryOperator<V>) - Method in class org.axonframework.common.caching.JCacheAdapter
 
computeIfPresent(Object, UnaryOperator<V>) - Method in class org.axonframework.common.caching.NoCache
 
computeIfPresent(Object, UnaryOperator<V>) - Method in class org.axonframework.common.caching.WeakReferenceCache
 
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
Parameter 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.event.axon.AxonServerEventStoreFactory.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.
configuration - Variable in class org.axonframework.config.EventProcessingModule
 
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.
configure() - Method in class org.axonframework.test.server.AxonServerContainer
 
configure() - Method in class org.axonframework.test.server.AxonServerEEContainer
Deprecated.
 
configure() - Method in class org.axonframework.test.server.AxonServerSEContainer
Deprecated.
 
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 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
 
configureCreationPolicyAggregateFactory(Function<Configuration, CreationPolicyAggregateFactory<A>>) - Method in class org.axonframework.config.AggregateConfigurer
Defines the factory to create new aggregate instances of the type under configuration when initializing those instances from non-constructor command handlers annotated with CreationPolicy.
configureDeadlineManager(Function<Configuration, DeadlineManager>) - Method in interface org.axonframework.config.Configurer
Registers a DeadlineManager instance with this Configurer.
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.
configureLifecyclePhaseTimeout(long, TimeUnit) - Method in interface org.axonframework.config.Configurer
Configures the timeout of each lifecycle phase.
configureLifecyclePhaseTimeout(long, TimeUnit) - Method in class org.axonframework.config.DefaultConfigurer
 
configureLockFactory(Function<Configuration, LockFactory>) - Method in class org.axonframework.config.AggregateConfigurer
Defines the LockFactory to use in the Repository for the aggregate under configuration.
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
 
configureModule(Configurer) - Method in class org.axonframework.spring.config.MessageHandlerConfigurer
 
configureModule(Configurer) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
 
configureModule(Configurer) - Method in class org.axonframework.spring.config.SpringSagaConfigurer
 
configureModule(Configurer) - Method in class org.axonframework.springboot.util.DeadLetterQueueProviderConfigurerModule
 
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
Deprecated.
Replaced by the SpringConfigurer, which itself is a Configurer implementation.
ConfigurerFactoryBean(Configurer) - Constructor for class org.axonframework.spring.config.ConfigurerFactoryBean
Deprecated.
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.
configurerModuleForTracing(List<SpanAttributesProvider>) - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
 
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.
configureSpanFactory(Function<Configuration, SpanFactory>) - Method in interface org.axonframework.config.Configurer
Registers a SpanFactory instance with this Configurer.
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.
ConnectionDetails - Interface in org.springframework.boot.autoconfigure.service.connection
Dummy implementation of the ConnectionDetails interface to allow classes to compile using JDK 8
ConnectionDetailsConnectionManagerConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration.ConnectionDetailsConnectionManagerConfiguration
 
ConnectionManager - Interface in org.axonframework.axonserver.connector
Interface describing functionality for connection managers.
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.
connectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStoreFactory.Builder
Sets the AxonServerConnectionManager managing the connections to Axon Server.
ConnectionPorts - Interface in org.springframework.boot.docker.compose.core
Copy of the original Spring Boot interface to allow compilation using JDK 8.
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.deadletter.jdbc.JdbcSequencedDeadLetterQueue.Builder
Sets the ConnectionProvider which 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
 
connections() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
 
connections() - Method in interface org.axonframework.axonserver.connector.ConnectionManager
Return the connections this instances manages.
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.
constructFor(String) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStoreFactory
Constructs an AxonServerEventStore connected to the given context.
constructFor(String, AxonServerEventStoreFactory.AxonServerEventStoreConfiguration) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStoreFactory
Constructs an AxonServerEventStore connected to the given context with customization based on the given configuration.
consume(ScopeDescriptor, DeadlineMessage<?>) - Method in interface org.axonframework.test.deadline.DeadlineConsumer
Consumes given deadlineMessage.
ContainerConnectionDetails(ContainerConnectionSource<C>) - Constructor for class org.springframework.boot.testcontainers.service.connection.ContainerConnectionDetailsFactory.ContainerConnectionDetails
 
ContainerConnectionDetailsFactory<C extends org.testcontainers.containers.Container<?>,D extends ConnectionDetails> - Class in org.springframework.boot.testcontainers.service.connection
 
ContainerConnectionDetailsFactory(String, String...) - Constructor for class org.springframework.boot.testcontainers.service.connection.ContainerConnectionDetailsFactory
 
ContainerConnectionDetailsFactory.ContainerConnectionDetails<C extends org.testcontainers.containers.Container<?>> - Class in org.springframework.boot.testcontainers.service.connection
 
ContainerConnectionSource<C extends org.testcontainers.containers.Container<?>> - Class in org.springframework.boot.testcontainers.service.connection
 
ContainerConnectionSource() - Constructor for class org.springframework.boot.testcontainers.service.connection.ContainerConnectionSource
 
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
 
ContainerManagedEntityManagerProvider - Class in org.axonframework.springboot.util.legacyjpa
Deprecated.
in favor of using ContainerManagedEntityManagerProvider which moved to jakarta.
ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.springboot.util.legacyjpa.ContainerManagedEntityManagerProvider
Deprecated.
 
contains(Object) - Method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue
 
contains(Object) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
 
contains(Object) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
Deprecated.
 
contains(String) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
 
contains(Object) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
 
contains(Object) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
Check whether there's a sequence of dead letters for the given sequenceIdentifier.
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.EhCache3Adapter
 
containsKey(Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
Deprecated.
 
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
 
containsStatement(Connection, String, String) - Method in interface org.axonframework.eventhandling.deadletter.jdbc.DeadLetterStatementFactory
containsStatement(Connection, String, String) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterStatementFactory
 
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
 
context - Variable in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
 
context() - Method in class org.axonframework.eventhandling.ReplayToken
Returns the context that was provided when the token was reset.
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
 
contextPropagators(TextMapPropagator) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory.Builder
Sets the propagator to be used.
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(M, Serializer, Serializer) - Method in interface org.axonframework.eventhandling.deadletter.jpa.DeadLetterJpaConverter
Converts an EventMessage implementation to a DeadLetterEventEntry.
convert(DeadLetterEventEntry, Serializer, Serializer) - Method in interface org.axonframework.eventhandling.deadletter.jpa.DeadLetterJpaConverter
Converts a DeadLetterEventEntry to a EventMessage implementation.
convert(EventMessage<?>, Serializer, Serializer) - Method in class org.axonframework.eventhandling.deadletter.jpa.EventMessageDeadLetterJpaConverter
 
convert(DeadLetterEventEntry, Serializer, Serializer) - Method in class org.axonframework.eventhandling.deadletter.jpa.EventMessageDeadLetterJpaConverter
 
convert(M, Serializer, Serializer) - Method in interface org.axonframework.eventhandling.deadletter.legacyjpa.DeadLetterJpaConverter
Deprecated.
Converts an EventMessage implementation to a DeadLetterEventEntry.
convert(DeadLetterEventEntry, Serializer, Serializer) - Method in interface org.axonframework.eventhandling.deadletter.legacyjpa.DeadLetterJpaConverter
Deprecated.
Converts a DeadLetterEventEntry to a EventMessage implementation.
convert(EventMessage<?>, Serializer, Serializer) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.EventMessageDeadLetterJpaConverter
Deprecated.
 
convert(DeadLetterEventEntry, Serializer, Serializer) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.EventMessageDeadLetterJpaConverter
Deprecated.
 
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(Set<ConstraintViolation<Object>>) - Static method in exception org.axonframework.messaging.interceptors.legacyvalidation.JSR303ViolationException
Deprecated.
Convert the violations to a human readable format, sorted by class and property e.g.:
convert(Object) - Method in class org.axonframework.messaging.responsetypes.InstanceResponseType
 
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 class org.axonframework.messaging.responsetypes.PublisherResponseType
 
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(JsonNode) - Method in class org.axonframework.serialization.json.JsonNodeToObjectNodeConverter
 
convert(ObjectNode) - Method in class org.axonframework.serialization.json.ObjectNodeToJsonNodeConverter
 
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(DeadLetterJdbcConverter<E, ? extends JdbcDeadLetter<E>>) - Method in class org.axonframework.eventhandling.deadletter.jdbc.JdbcSequencedDeadLetterQueue.Builder
Sets the DeadLetterJdbcConverter used to convert a ResultSet into a JdbcDeadLetter implementation.
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
 
convertExceptional(Throwable) - Method in class org.axonframework.messaging.responsetypes.PublisherResponseType
 
convertExceptional(Throwable) - Method in interface org.axonframework.messaging.responsetypes.ResponseType
Converts the given Throwable into the type R of this ResponseType instance.
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.
convertToLetter(ResultSet) - Method in interface org.axonframework.eventhandling.deadletter.jdbc.DeadLetterJdbcConverter
Converts the given resultSet in an implementation of JdbcDeadLetter.
convertToLetter(ResultSet) - Method in class org.axonframework.eventhandling.deadletter.jdbc.DefaultDeadLetterJdbcConverter
 
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
Deprecated.
 
correlationDataProvidersConfigurer(List<CorrelationDataProvider>) - Method in class org.axonframework.springboot.autoconfig.InfraConfiguration
 
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) - Method in class org.axonframework.axonserver.connector.event.axon.PersistentStreamMessageSourceDefinition
 
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.
create(Configuration) - Method in interface org.axonframework.config.SubscribableMessageSourceDefinition
Creates a SubscribableMessageSource based on this definition and the provided configuration.
create(Object) - Method in interface org.axonframework.modelling.command.CreationPolicyAggregateFactory
Instantiates the aggregate instance based on the provided identifier.
create(Object) - Method in class org.axonframework.modelling.command.NoArgumentConstructorCreationPolicyAggregateFactory
Creates the aggregate instance based on the previously provided type.
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
 
createBatchSpan(boolean, List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.DefaultEventProcessorSpanFactory
 
createBatchSpan(boolean, List<? extends EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventProcessorSpanFactory
Creates a span for the batch of events that are handled by the event processor.
createCancelAllSpan(String) - Method in interface org.axonframework.deadline.DeadlineManagerSpanFactory
Creates a span that represents the cancellation of all deadlines with a certain name.
createCancelAllSpan(String) - Method in class org.axonframework.deadline.DefaultDeadlineManagerSpanFactory
 
createCancelAllWithinScopeSpan(String, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManagerSpanFactory
Creates a span that represents the cancellation of all deadlines with a certain name within a certain scope.
createCancelAllWithinScopeSpan(String, ScopeDescriptor) - Method in class org.axonframework.deadline.DefaultDeadlineManagerSpanFactory
 
createCancelScheduleSpan(String, String) - Method in interface org.axonframework.deadline.DeadlineManagerSpanFactory
Creates a span that represents the cancellation of a specific deadline.
createCancelScheduleSpan(String, String) - Method in class org.axonframework.deadline.DefaultDeadlineManagerSpanFactory
 
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.
createChildHandlerSpan(Supplier<String>, Message<?>, Message<?>...) - Method in interface org.axonframework.tracing.SpanFactory
Creates a new Span which is part of the current trace.
createCommitEventsSpan() - Method in class org.axonframework.eventhandling.DefaultEventBusSpanFactory
 
createCommitEventsSpan() - Method in interface org.axonframework.eventhandling.EventBusSpanFactory
Creates a span for the committing of events.
createCreateSagaInstanceSpan(EventMessage<?>, Class<?>, String) - Method in class org.axonframework.modelling.saga.DefaultSagaManagerSpanFactory
 
createCreateSagaInstanceSpan(EventMessage<?>, Class<?>, String) - Method in interface org.axonframework.modelling.saga.SagaManagerSpanFactory
Creates a span that represents the creation of a new saga instance.
createCreateSnapshotSpan(String, String) - Method in class org.axonframework.eventsourcing.DefaultSnapshotterSpanFactory
 
createCreateSnapshotSpan(String, String) - Method in interface org.axonframework.eventsourcing.SnapshotterSpanFactory
Creates a new Span that represents the actual creation of a snapshot.
createDispatchCommandSpan(CommandMessage<?>, boolean) - Method in interface org.axonframework.commandhandling.CommandBusSpanFactory
Creates a span for the dispatching of a command.
createDispatchCommandSpan(CommandMessage<?>, boolean) - Method in class org.axonframework.commandhandling.DefaultCommandBusSpanFactory
 
createDispatchSpan(Supplier<String>, Message<?>, Message<?>...) - Method in class org.axonframework.tracing.LoggingSpanFactory
 
createDispatchSpan(Supplier<String>, Message<?>, Message<?>...) - Method in class org.axonframework.tracing.MultiSpanFactory
 
createDispatchSpan(Supplier<String>, Message<?>, Message<?>...) - Method in class org.axonframework.tracing.NestingSpanFactory
Deprecated.
 
createDispatchSpan(Supplier<String>, Message<?>, Message<?>...) - Method in class org.axonframework.tracing.NoOpSpanFactory
 
createDispatchSpan(Supplier<String>, Message<?>, Message<?>...) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
 
createDispatchSpan(Supplier<String>, Message<?>, Message<?>...) - Method in interface org.axonframework.tracing.SpanFactory
Creates a new Span linked to dispatching a Message, for example when sending a command to Axon Server.
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.
createEventEntity(EventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
Deprecated.
Returns a Jpa event entity for given eventMessage.
createExecuteSpan(String, String, DeadlineMessage<?>) - Method in interface org.axonframework.deadline.DeadlineManagerSpanFactory
Creates a span that represents the execution of a deadline.
createExecuteSpan(String, String, DeadlineMessage<?>) - Method in class org.axonframework.deadline.DefaultDeadlineManagerSpanFactory
 
createGateway(Class<T>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
Creates a gateway instance for the given gatewayInterface.
createHandleCommandSpan(CommandMessage<?>, boolean) - Method in interface org.axonframework.commandhandling.CommandBusSpanFactory
Creates a span for the handling of a command.
createHandleCommandSpan(CommandMessage<?>, boolean) - Method in class org.axonframework.commandhandling.DefaultCommandBusSpanFactory
 
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
 
createHandlerSpan(Supplier<String>, Message<?>, boolean, Message<?>...) - Method in class org.axonframework.tracing.LoggingSpanFactory
 
createHandlerSpan(Supplier<String>, Message<?>, boolean, Message<?>...) - Method in class org.axonframework.tracing.MultiSpanFactory
 
createHandlerSpan(Supplier<String>, Message<?>, boolean, Message<?>...) - Method in class org.axonframework.tracing.NestingSpanFactory
Deprecated.
 
createHandlerSpan(Supplier<String>, Message<?>, boolean, Message<?>...) - Method in class org.axonframework.tracing.NoOpSpanFactory
 
createHandlerSpan(Supplier<String>, Message<?>, boolean, Message<?>...) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
 
createHandlerSpan(Supplier<String>, Message<?>, boolean, Message<?>...) - Method in interface org.axonframework.tracing.SpanFactory
Creates a new Span linked to asynchronously handling a Message, for example when handling a command from Axon Server.
createHeadToken() - Method in class org.axonframework.eventhandling.MultiStreamableMessageSource
 
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.legacyjpa.JpaEventStorageEngine
Deprecated.
 
createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
 
createHeadToken() - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
 
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()
createInitializeStateSpan(String, String) - Method in class org.axonframework.modelling.command.DefaultRepositorySpanFactory
 
createInitializeStateSpan(String, String) - Method in interface org.axonframework.modelling.command.