- 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
- 
- 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
- 
- 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
 declaredParameterTypeannotated with the givenannotationType.
 
- AbstractAnnotationHandlerBeanPostProcessor<I,T extends I> - Class in org.axonframework.spring.config
- 
- 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
- 
- AbstractCommandGateway.Builder - Class in org.axonframework.commandhandling.gateway
- 
- 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
- 
- AbstractEventBus.Builder - Class in org.axonframework.eventhandling
- 
- 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
- 
- AbstractEventGateway.Builder - Class in org.axonframework.eventhandling.gateway
- 
- AbstractEventProcessor - Class in org.axonframework.eventhandling
- 
- AbstractEventProcessor(AbstractEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.AbstractEventProcessor
- 
- AbstractEventProcessor.Builder - Class in org.axonframework.eventhandling
- 
- 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
- 
- AbstractEventStorageEngine.Builder - Class in org.axonframework.eventsourcing.eventstore
- 
- AbstractEventStore - Class in org.axonframework.eventsourcing.eventstore
- 
- AbstractEventStore(AbstractEventStore.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore
- 
- AbstractEventStore.Builder - Class in org.axonframework.eventsourcing.eventstore
- 
- 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
- 
- AbstractRepository.Builder<T> - Class in org.axonframework.modelling.command
- 
- 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
- 
- AbstractRetryScheduler(AbstractRetryScheduler.Builder) - Constructor for class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
- 
- AbstractRetryScheduler.Builder<B extends AbstractRetryScheduler.Builder> - Class in org.axonframework.commandhandling.gateway
- 
- 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
- 
- 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
- 
- AbstractSagaManager.Builder<T> - Class in org.axonframework.modelling.saga
- 
- 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
- 
- AbstractSnapshotter.Builder - Class in org.axonframework.eventsourcing
- 
- 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
- 
- 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,processandsegment.
 
- 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
- 
- AbstractXStreamSerializer.Builder - Class in org.axonframework.serialization
- 
- 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 fieldshould 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
- 
- 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
- 
- ActiveGrpcChannelChecker(AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.heartbeat.connection.checker.ActiveGrpcChannelChecker
- 
Deprecated. 
- 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 associationValueandsagaIdentifier.
 
- ADD_ALL - Static variable in class org.axonframework.common.annotation.AnnotationUtils
- 
- addAlias(String, Class) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Adds an alias to use instead of the fully qualified class name. 
- addCachedAssociations(Iterable<AssociationValue>, String, Class<?>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
- 
Registers the associations of a saga with given sagaIdentifierand givensagaTypewith 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
- 
- addedAssociations() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-  
- AddedTrackerStatus - Class in org.axonframework.eventhandling
- 
- AddedTrackerStatus(EventTrackerStatus) - Constructor for class org.axonframework.eventhandling.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 handlerwith 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
- 
- advance(TrackingToken, TrackingToken) - Static method in interface org.axonframework.eventhandling.WrappedToken
- 
- 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
- 
- 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 durationand invokes the givendeadlineConsumerfor each deadline
 scheduled until that time.
 
- advanceTimeBy(Duration, EventConsumer<EventMessage<?>>) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
- 
Advance time by the given durationand invokes the giveneventConsumerfor each
 event scheduled for publication until that time.
 
- advanceTimeTo(Instant, DeadlineConsumer) - Method in class org.axonframework.test.deadline.StubDeadlineManager
- 
Advances time to the given newDateTimeand invokes the givendeadlineConsumerfor each deadline
 scheduled until that time.
 
- advanceTimeTo(Instant, EventConsumer<EventMessage<?>>) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
- 
Advance time to the given newDateTimeand invokes the giveneventConsumerfor each
 event scheduled for publication until that time.
 
- advanceTo(long, int) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
- 
- 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 eventsafter 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 handlerwith 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 Componentis 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
- 
- AggregateAnnotationCommandHandler.Builder<T> - Class in org.axonframework.modelling.command
- 
- 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 explanatorymessageandcause.
 
- 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
- 
- 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
- 
- 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 aggregateIdentifierand
 givenmessage.
 
- AggregateDeletedException(String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
- 
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifierand
 a defaultmessage.
 
- 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 AggregateEntityNotFoundExceptionwith givenmessage.
 
- AggregateEntityNotFoundException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateEntityNotFoundException
- 
Initialize a AggregateEntityNotFoundExceptionwith givenmessageandcause.
 
- aggregateFactories(AggregateFactory<?>...) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
- 
Sets the aggregateFactoriessupported by this snapshotter.
 
- aggregateFactories(List<AggregateFactory<?>>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
- 
Sets the aggregateFactoriessupported by this snapshotter.
 
- aggregateFactory() - Method in interface org.axonframework.config.AggregateConfiguration
- 
- aggregateFactory() - Method in class org.axonframework.config.AggregateConfigurer
-  
- aggregateFactory(Class<A>) - Method in interface org.axonframework.config.Configuration
- 
- 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
- 
- aggregateIdentifier() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
- 
The identifier of the conflicting aggregate, as a String. 
- aggregateIdentifier() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
-  
- AggregateIdentifier - Annotation Type in org.axonframework.modelling.command
- 
Field or  Method annotation that identifies the member containing
 the identifier of the Aggregate. 
- aggregateIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the aggregate identifier of the event. 
- aggregateIdentifierColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the event identifier column. 
- 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 messageandcause.
 
- 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
- 
- AggregateMemberAnnotatedChildEntityCollectionDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-  
- AggregateMemberAnnotatedChildEntityDefinition - Class in org.axonframework.modelling.command.inspection
- 
- AggregateMemberAnnotatedChildEntityDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
-  
- AggregateMemberAnnotatedChildEntityMapDefinition - Class in org.axonframework.modelling.command.inspection
- 
- 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
- 
- aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
- 
- 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 messageexplaining 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 aggregateIdentifierand givenmessage.
 
- AggregateNotFoundException(String, String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateNotFoundException
- 
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifierand
 with the givenmessageandcause.
 
- 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
- 
- AggregateScopeDescriptor(String, Object) - Constructor for class org.axonframework.commandhandling.model.AggregateScopeDescriptor
- 
Deprecated. Instantiate a AggregateScopeDescriptor with the provided typeandidentifier.
 
- 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 typeandidentifierSupplier.
 
- AggregateScopeDescriptor(String, Object) - Constructor for class org.axonframework.modelling.command.AggregateScopeDescriptor
- 
Instantiate an AggregateScopeDescriptor with the provided typeandidentifier.
 
- 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
- 
- aggregateSnapshotter(Configuration, HandlerDefinition, ParameterResolverFactory, EventStore, TransactionManager, SpanFactory) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- AggregateSnapshotter.Builder - Class in org.axonframework.eventsourcing
- 
- 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 aggregateIdentifierand given explanatorymessage.
 
- AggregateStateCorruptedException(String, String, Throwable) - Constructor for exception org.axonframework.disruptor.commandhandling.AggregateStateCorruptedException
- 
Initializes the exception with given aggregateIdentifier, given explanatorymessageandcause.
 
- 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 messageandcause
 
- 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
- 
- 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. 
- 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
- 
- 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
- 
- 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
- 
- 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. 
- 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 othermatch.
 
- and(String, Object) - Method in class org.axonframework.messaging.MetaData
- 
Returns a MetaData instances containing the current entries, and the given keyand givenvalue.
 
- 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
-  
- AndCommandMessageFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
- 
- AndCommandMessageFilter(CommandMessageFilter, CommandMessageFilter) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
- 
Initialize the filter to match when both the firstand thesecondfilter 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
- 
- 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 domainEventsas the "given" events.
 
- andGiven(List<?>) - Method in interface org.axonframework.test.aggregate.TestExecutor
- 
Configures the given domainEventsas 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 commandsas the command that will provide the "given" events.
 
- andGivenCommands(List<?>) - Method in interface org.axonframework.test.aggregate.TestExecutor
- 
Configures the given commandsas 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 keyif it was
 not yet present in this MetaData.
 
- andInitialSegmentsCount(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-  
- andInitialTrackingToken(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
- 
Sets the Builder to use to create the initial tracking token. 
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandMessage
- 
Returns a copy of this CommandMessage with it MetaData merged with the given metaData.
 
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandResultMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandResultMessage
-  
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.deadline.DeadlineMessage
- 
Returns a copy of this DeadlineMessage with its MetaData merged with given additionalMetaData.
 
- andMetaData(Map<String, ?>) - Method in class org.axonframework.deadline.GenericDeadlineMessage
-  
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.DomainEventMessage
- 
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData.
 
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.EventMessage
- 
Returns a copy of this EventMessage with it MetaData merged with the given metaData.
 
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericEventMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.replay.GenericResetContext
-  
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.replay.ResetContext
- 
Returns a copy of this  ResetContext with it MetaData merged with the given  metaData. 
- andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.AbstractMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.GenericResultMessage
-  
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.Message
- 
Returns a copy of this Message with it MetaData merged with the given metaData.
 
- andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.ResultMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryResponseMessage
-  
- andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.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 nullorvoid.
 
- andThen(EventProcessingConfigurer.DeadLetteringInvokerConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer.DeadLetteringInvokerConfiguration
- 
Returns a configuration that applies the given otherconfiguration after applyingthis.
 
- andThen(EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer.PooledStreamingProcessorConfiguration
- 
Returns a configuration that applies the given otherconfiguration after applyingthis.
 
- andThen(Runnable) - Method in interface org.axonframework.modelling.command.ApplyMore
- 
Execute the given runnableafter 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 eventhas been published in the past.
 
- andThenAPublished(Object, Map<String, ?>) - Method in interface org.axonframework.test.saga.ContinuedGivenState
- 
Indicates that the given eventwith givenmetaDatahas 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 runnableafter applying the previous event.
 
- andThenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.aggregate.TestExecutor
- 
- 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
- 
- 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 givenaggregateModelthat will publish events to the giveneventBus.
 
- 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 givenaggregateModelthat will publish events to the giveneventBus.
 
- AnnotatedAggregate(AggregateModel<T>, EventBus) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Initialize an Aggregate instance for the given aggregateRoot, described by the givenaggregateModelthat will publish events to the giveneventBus.
 
- 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 givenaggregateModelthat will publish events to the giveneventBus.
 
- 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 parameterResolverFactoryto detect parameters for annotated
 handlers.
 
- AnnotatedAggregateMetaModelFactory(ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
- 
Initializes an instance which uses the given parameterResolverFactoryto detect parameters for annotated
 handlers andhandlerDefinitionto 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 entityModelto 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
- 
- AnnotatedHandlerInspector<T> - Class in org.axonframework.messaging.annotation
- 
Inspector for a message handling target of type Tthat 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 givenmessageType.
 
- AnnotatedMessageHandlingMemberDefinition - Class in org.axonframework.messaging.annotation
- 
The default HandlerDefinition implementation in Axon. 
- AnnotatedMessageHandlingMemberDefinition() - Constructor for class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
-  
- AnnotatedSaga<T> - Class in org.axonframework.modelling.saga
- 
Implementation of the  interface that allows for a POJO instance with annotated message handlers to act
 as a Saga. 
- AnnotatedSaga(String, Set<AssociationValue>, T, SagaModel<T>) - Constructor for class org.axonframework.modelling.saga.AnnotatedSaga
- 
Creates an AnnotatedSaga instance to wrap the given annotatedSaga, identifier with the givensagaIdand associated with the givenassociationValues.
 
- 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
- 
- AnnotatedSagaManager.Builder<T> - Class in org.axonframework.modelling.saga
- 
- AnnotatedSagaRepository<T> - Class in org.axonframework.modelling.saga.repository
- 
- AnnotatedSagaRepository(AnnotatedSagaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
- 
- AnnotatedSagaRepository.Builder<T> - Class in org.axonframework.modelling.saga.repository
- 
- 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
- 
- 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
- 
- 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
- 
- AnnotationCommandTargetResolver(AnnotationCommandTargetResolver.Builder) - Constructor for class org.axonframework.modelling.command.AnnotationCommandTargetResolver
- 
- AnnotationCommandTargetResolver.Builder - Class in org.axonframework.modelling.command
- 
- AnnotationDriven - Annotation Type in org.axonframework.spring.config
- 
- AnnotationDrivenRegistrar - Class in org.axonframework.spring.config
- 
- AnnotationDrivenRegistrar() - Constructor for class org.axonframework.spring.config.AnnotationDrivenRegistrar
- 
Deprecated. 
- AnnotationEventHandlerAdapter - Class in org.axonframework.eventhandling
- 
- 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
- 
- 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 givenparameterResolverFactory.
 
- 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 givenparameterResolverFactoryand creating handlers usinghandlerDefinition.
 
- AnnotationQueryHandlerBeanPostProcessor - Class in org.axonframework.spring.config.annotation
- 
- 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
- 
- AnnotationRoutingStrategy() - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
- 
- AnnotationRoutingStrategy(Class<? extends Annotation>) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
- 
- AnnotationRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
- 
- AnnotationRoutingStrategy(Class<? extends Annotation>, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
- 
- AnnotationRoutingStrategy.Builder - Class in org.axonframework.commandhandling.distributed
- 
- AnnotationSagaMetaModelFactory - Class in org.axonframework.modelling.saga.metamodel
- 
- AnnotationSagaMetaModelFactory() - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
- 
- AnnotationSagaMetaModelFactory(ParameterResolverFactory) - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
- 
- AnnotationSagaMetaModelFactory(ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
- 
- annotationType(Class<? extends Annotation>) - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.Builder
- 
Sets the  annotationTypeClass searched for by this routing strategy on a  CommandMessage to base the routing key on. 
- AnnotationUtils - Class in org.axonframework.common.annotation
- 
Utility class for locating annotations and attribute values on elements. 
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-  
- appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
- 
Append given eventsto 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
- 
- appendEvents(Connection, EventSchema, Class<?>, List<? extends EventMessage<?>>, Serializer, TimestampWriter) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- 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
- 
- 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
- 
- 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 messageSourceto the application
 context that this bean is part of.
 
- ApplicationContextLookupParameterResolverFactory - Class in org.axonframework.spring.config
- 
- ApplicationContextLookupParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
- 
Deprecated. Creates an instance, using the given defaultFactories.
 
- apply(MetaData) - Method in class org.axonframework.axonserver.connector.util.GrpcMetadataSerializer
-  
- apply(O) - Method in class org.axonframework.axonserver.connector.util.GrpcObjectSerializer
-  
- apply(Message) - Method in class org.axonframework.axonserver.connector.util.GrpcPayloadSerializer
-  
- apply(Connection) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlFunction
- 
- apply(ResultSet) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlResultConverter
- 
Convert the given resultSet to a result of type R.
 
- apply(Object, MetaData) - Static method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Apply a  DomainEventMessage with given payload and metadata (metadata
 from interceptors will be combined with the provided metadata). 
- apply(Object) - Static method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Apply a  DomainEventMessage with given payload without metadata (though
 interceptors can also be used to provide metadata). 
- apply(Statement, Description) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycleRule
- 
Deprecated. 
- applyMessageOrPayload(Object) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Apply a new event message to the aggregate and then publish this message to external systems. 
- ApplyMore - Interface in org.axonframework.modelling.command
- 
Interface that describes a mechanism that enables the application of an additional event after another event is
 applied. 
- asCause(Throwable) - Static method in exception org.axonframework.messaging.deadletter.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
- 
- asCommandResultMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandResultMessage
- 
- asCommandResultMessage(Throwable) - Static method in class org.axonframework.commandhandling.GenericCommandResultMessage
- 
Creates a Command Result Message with the given exceptionresult.
 
- asDeadlineMessage(String, Object) - Static method in class org.axonframework.deadline.GenericDeadlineMessage
- 
- asDeadlineMessage(String, Object, Instant) - Static method in class org.axonframework.deadline.GenericDeadlineMessage
- 
Returns the given deadlineNameandmessageOrPayloadas a DeadlineMessage which expires at the
 givenexpiryTime.
 
- asDeadLineMessage(Serializer) - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
- asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventhandling.EventUtils
- 
- 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 resultwith adeclaredTypeas the result type.
 
- asResetContext(Object) - Static method in class org.axonframework.eventhandling.replay.GenericResetContext
- 
- 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 declaredTypeandexception.
 
- asResultMessage(Object) - Static method in class org.axonframework.messaging.GenericResultMessage
- 
- asResultMessage(Throwable) - Static method in class org.axonframework.messaging.GenericResultMessage
- 
Creates a ResultMessage with the given exceptionresult.
 
- 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 expectedamount of active sagas.
 
- assertAssociationPresent(String, String) - Method in class org.axonframework.test.saga.RepositoryContentValidator
- 
Asserts that an association is present for the given associationKeyandassociationValue.
 
- 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 matcherhas 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 associationKeyandassociationValue.
 
- assertNonBlank(String, String) - Static method in class org.axonframework.common.BuilderUtils
- 
Assert that the given stringdoes not equals an empty String.
 
- assertNonEmpty(String, String) - Static method in class org.axonframework.common.BuilderUtils
- 
Assert that the given stringis 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 valueis non null.
 
- assertNonNull(T, String) - Static method in class org.axonframework.common.BuilderUtils
- 
Assert that the given valueis non null.
 
- assertNoScheduledDeadlineMatching(Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
- 
Asserts that no deadline matching the given matcherhas 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 matcherhas been scheduled after the givenduration.
 
- assertNoScheduledEventMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
- 
Asserts that no event matching the given matcherhas been scheduled at the givenscheduledTime.
 
- 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 valueis positive, meaning greater than, or equal to, zero.
 
- assertPositive(long, String) - Static method in class org.axonframework.common.BuilderUtils
- 
Assert that the given valueis positive, meaning greater than, or equal to, zero.
 
- assertPublishedEvents(Object...) - Method in class org.axonframework.test.saga.EventValidator
- 
Assert that the given expectedevents 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 durationmatches the givenmatcher.
 
- assertScheduledDeadlineMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
- 
Asserts that a deadline scheduled at the given scheduledTimematches the givenmatcher.
 
- assertScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
- 
Asserts that an event matching the given matcheris scheduled for publication after the givenduration.
 
- assertScheduledEventMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
- 
Asserts that an event matching the given matcheris scheduled for publication at the givenscheduledTime.
 
- assertStrictPositive(int, String) - Static method in class org.axonframework.common.BuilderUtils
- 
Assert that the given valueis strictly positive, meaning greater than zero.
 
- assertStrictPositive(long, String) - Static method in class org.axonframework.common.BuilderUtils
- 
Assert that the given valueis 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  assertionPredicate. 
- assertThat(T, Predicate<T>, String) - Static method in class org.axonframework.common.BuilderUtils
- 
Assert that the given  value will result to  true through the  assertionPredicate. 
- assertTriggeredDeadlines(Object...) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
- 
Asserts that the given expecteddeadlines 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 expectedDeadlineTypeshave been triggered.
 
- assertTriggeredDeadlinesWithName(String...) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
- 
Asserts that the given expectedDeadlineNameshave 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 criteriato the Processing Group
 with givenname, 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 criteriato the Processing Group
 with givenname, with givenpriority.
 
- 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 criteriato the Processing Group
 with givenname, 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 criteriato the Processing Group
 with givenname, with givenpriority.
 
- assignHandlerTypesMatching(String, int, Predicate<Class<?>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- assignProcessingGroup(String, String) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
Defines a mapping for assigning processing groups to processors. 
- assignProcessingGroup(Function<String, String>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
Defines a rule for assigning processing groups to processors if processing group to processor name mapping does
 not contain the entry. 
- assignProcessingGroup(String, String) - Method in class org.axonframework.config.EventProcessingModule
-  
- assignProcessingGroup(Function<String, String>) - Method in class org.axonframework.config.EventProcessingModule
-  
- associateWith(String, String) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
- 
Registers a AssociationValue with the currently active saga. 
- associateWith(String, Number) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
- 
Registers a AssociationValue with the currently active saga. 
- associateWith(AssociationValue) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
- 
Registers a AssociationValue with the currently active saga. 
- AssociationResolver - Interface in org.axonframework.modelling.saga
- 
Used to derive the value of an association property as designated by the association property name. 
- associationsCache(Cache) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
- 
Sets the  associationsCache of type  Cache used to store Saga associations with. 
- AssociationValue - Class in org.axonframework.modelling.saga
- 
A combination of key and value by which a Saga can be found. 
- AssociationValue(String, String) - Constructor for class org.axonframework.modelling.saga.AssociationValue
- 
Creates a Association Value instance with the given keyandvalue.
 
- 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 sagaIdentifierandassociationValue.
 
- AssociationValueEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
- 
Constructor required by JPA. 
- associationValueEntryTable() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
- 
Returns the name of the associationValueEntry table 
- AssociationValueMap - Class in org.axonframework.modelling.saga.repository
- 
In-memory storage for AssociationValue to Saga mappings. 
- AssociationValueMap() - Constructor for class org.axonframework.modelling.saga.repository.AssociationValueMap
- 
Initializes a new and empty AssociationValueMap. 
- AssociationValues - Interface in org.axonframework.modelling.saga
- 
- 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
- 
- asUpdateMessage(Object) - Static method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
- 
- asUpdateMessage(Class<T>, Throwable) - Static method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
- 
- 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
- 
- AsynchronousCommandBus.Builder - Class in org.axonframework.commandhandling
- 
- AsynchronousEventProcessingStrategy - Class in org.axonframework.eventhandling.async
- 
- 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
- 
- 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. 
- AXON_CONFIGURER_BEAN - Static variable in class org.axonframework.spring.config.SpringAxonAutoConfigurer
- 
Deprecated. 
- 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
- 
- 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 messageandcause.
 
- 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 messageandcause.
 
- AxonException(String, Throwable, boolean) - Constructor for exception org.axonframework.common.AxonException
- 
Initializes the exception using the given message,causeandwritableStackTrace.
 
- axonFrameworkVersionResolver(Supplier<String>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
- 
- 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 messageandcause.
 
- 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
-  
- AxonServerBusAutoConfiguration - Class in org.axonframework.springboot.autoconfig
- 
- 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
- 
- axonServerCommandBus(AxonServerConnectionManager, AxonServerConfiguration, CommandBus, Serializer, RoutingStrategy, CommandPriorityCalculator, CommandLoadFactorProvider, TargetContextResolver<? super CommandMessage<?>>, SpanFactory) - Method in class org.axonframework.springboot.autoconfig.AxonServerBusAutoConfiguration
-  
- AxonServerCommandBus.Builder - Class in org.axonframework.axonserver.connector.command
- 
- 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 errorCodeanderrorMessage.
 
- 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
- 
- axonServerConfiguration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
- 
- axonServerConfiguration() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- AxonServerConfiguration.Builder - Class in org.axonframework.axonserver.connector
-  
- AxonServerConfiguration.FlowControlConfiguration - Class in org.axonframework.axonserver.connector
- 
Configuration class for Flow Control of specific message types. 
- AxonServerConfiguration.HeartbeatConfiguration - Class in org.axonframework.axonserver.connector
-  
- AxonServerConnectionManager - Class in org.axonframework.axonserver.connector
- 
The component which manages all the connections which an Axon client can establish with an Axon Server instance. 
- AxonServerConnectionManager(AxonServerConnectionManager.Builder, AxonServerConnectionFactory) - Constructor for class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
- axonServerConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
- axonServerConnectionManager - Variable in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
-  
- axonServerConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
- AxonServerConnectionManager.Builder - Class in org.axonframework.axonserver.connector
- 
- AxonServerEEContainer<SELF extends AxonServerEEContainer<SELF>> - Class in org.axonframework.test.server
- 
Constructs a single node AxonServer Enterprise Edition (EE) for testing. 
- AxonServerEEContainer(String) - Constructor for class org.axonframework.test.server.AxonServerEEContainer
- 
Initialize AxonServer EE with a given docker image. 
- AxonServerEEContainer(DockerImageName) - Constructor for class org.axonframework.test.server.AxonServerEEContainer
- 
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
- 
- 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
- 
- AxonServerEventStore.Builder - Class in org.axonframework.axonserver.connector.event.axon
- 
- 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 codeanderrorMessage.
 
- AxonServerException(String, String) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
- 
Initializes the exception using the given codeandmessage.
 
- AxonServerException(String, String, String, List<String>) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
- 
Initializes the exception using the given message,code,sourceanddetails.
 
- AxonServerException(String, String, Throwable) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
- 
Initializes the exception using the given message,code, andcause.
 
- AxonServerHealthIndicator - Class in org.axonframework.actuator.axonserver
- 
- 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 errorCodeanderrorMessage.
 
- 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 errorCodeanderrorMessage.
 
- 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
- 
- AxonServerQueryBus.Builder - Class in org.axonframework.axonserver.connector.query
- 
- 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 codeanderrorMessage.
 
- AxonServerQueryDispatchException(String, String) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
- 
Initializes an AxonServer Query Dispatch Exception using the given codeandmessage.
 
- 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,sourceanddetails.
 
- AxonServerRegistration - Class in org.axonframework.axonserver.connector.command
- 
- AxonServerRegistration(Registration, Runnable) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerRegistration
- 
- 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 errorCodeanderrorMessage.
 
- AxonServerRemoteCommandHandlingException(String, ErrorMessage, boolean) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
- 
Initialize the exception with given errorCode,errorMessageandwritableStackTrace.
 
- 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
- 
Constructs a single node AxonServer Standard Edition (SE) for testing. 
- AxonServerSEContainer(String) - Constructor for class org.axonframework.test.server.AxonServerSEContainer
- 
Initialize AxonServer SE with a given docker image. 
- AxonServerSEContainer(DockerImageName) - Constructor for class org.axonframework.test.server.AxonServerSEContainer
- 
Initialize AxonServer SE with a given docker image. 
- AxonServerStatusAggregator - Class in org.axonframework.actuator.axonserver
- 
A SimpleStatusAggregatorimplementation 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
- 
- AxonServerSubscriptionQueryResult(SubscriptionQueryMessage<?, ?, ?>, SubscriptionQueryResult, SubscriptionMessageSerializer, SpanFactory, Span) - Constructor for class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
- 
- 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 ofProcessingKey.SERVER_SUPPORTS_STREAMING.
 
- 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 groupNamewith
 default priority.
 
- AxonThreadFactory(ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
- 
Initializes a ThreadFactory instance that create each thread in the given groupwith default
 priority.
 
- AxonThreadFactory(int, ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
- 
Initializes a ThreadFactory instance that create each thread in the given groupwith givenpriority.
 
- 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 messageandcause.
 
- 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
- 
- 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
- 
- CachingSagaStore.Builder<T> - Class in org.axonframework.modelling.saga.repository
- 
- 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 sourceTypeto the
 giventargetTypeusing a chain formed with givencandidates.
 
- 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 actionwith the giveninterceptorChainbeing 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 givenresultis available
 for injection as parameter
 
- cancel() - Method in class org.axonframework.axonserver.connector.command.AxonServerRegistration
-  
- cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
-  
- cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
- 
Deprecated. 
- cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.DisposableResult
- 
Deprecated. 
- cancel(boolean) - Method in interface org.axonframework.axonserver.connector.util.Scheduler.ScheduledTask
- 
Cancels the scheduled registration. 
- cancel() - Method in interface org.axonframework.common.Registration
- 
Cancels this Registration. 
- cancel() - Method in class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
-  
- cancelAll(String) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Cancels all the deadlines corresponding to the given deadlineName.
 
- cancelAll(String) - Method in class org.axonframework.deadline.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) - Method in interface org.axonframework.deadline.DeadlineManager
- 
- cancelAllWithinScope(String, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Cancels all deadlines corresponding to the given deadlineNameandscope.
 
- 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 interface org.axonframework.deadline.DeadlineManager
- 
Cancels the deadline corresponding to the given deadlineName/scheduleIdcombination.
 
- 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 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
- 
- 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. 
- 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 sourceContentTypeintotargetContentType, using the givenconverters.
 
- 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 sourceTypeto thetargetType.
 
- 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 eventMessagefor the givensegment.
 
- 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 eventMessagefor a givensegment.
 
- 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 eventMessagefor any of the givensegments.
 
- 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
- 
- 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 messageandcause.
 
- 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.jpa.JpaDeadLetter
-  
- cause() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. 
- Cause - Interface in org.axonframework.messaging.deadletter
- 
- cause() - Method in interface org.axonframework.messaging.deadletter.DeadLetter
- 
- cause() - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
-  
- 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 delegatesto form a chain of converters.
 
- chainedInterceptor(Class<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Returns an Interceptor Chain of annotated interceptor methods defined on the given
 type.
 
- ChainingConverter - Class in org.axonframework.serialization
- 
Converter implementation that will combine converters to form chains of converters to be able to convert
 from one type to another, for which there is no suitable single converter. 
- ChainingConverter() - Constructor for class org.axonframework.serialization.ChainingConverter
- 
Initialize a new ChainingConverter with the context ClassLoader for this thread. 
- ChainingConverter(ClassLoader) - Constructor for class org.axonframework.serialization.ChainingConverter
- 
Initialize a new ChainingConverter. 
- changePhase(UnitOfWork.Phase...) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
- 
Ask the unit of work to transition to the given phasessequentially.
 
- channelCustomizer(UnaryOperator<ManagedChannelBuilder<?>>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
- 
Registers the given channelCustomization, which configures the underlingManagedChannelBuilderused 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
- 
- ChildForwardingCommandMessageHandlingMember(List<MessageHandlingMember<? super C>>, MessageHandlingMember<? super C>, BiFunction<CommandMessage<?>, P, C>) - Constructor for class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
- 
- 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. 
- 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. 
- 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
- 
- cleanGaps(Connection, SortedSet<Long>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- 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
- 
- 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.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
- 
- 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
- 
- clearConverters() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. 
- clearProcessingStarted() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Releases the message for processing by another thread or process. 
- 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 ofProcessingKey.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
- 
- 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
- 
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.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
- 
- 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
- 
- commandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
- 
- 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 
- 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
- 
- 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 messageandcause.
 
- 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 messageandcause.
 
- CommandExecutionException(String, Throwable, Object) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
- 
Initializes the exception with given message,causeand an object providing application-specificdetails.
 
- CommandExecutionException(String, Throwable, Object, boolean) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
- 
Initializes the exception with given message,cause, an object providing application-specificdetails, andwritableStackTrace
 
- 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 Gateway implementations from custom interface definitions. 
- CommandGatewayFactory(CommandGatewayFactory.Builder) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
- 
- CommandGatewayFactory.Builder - Class in org.axonframework.commandhandling.gateway
- 
- 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
- 
- 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 typein 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 segmentandcache.
 
- 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 typein this aggregate hierarchy.
 
- CommandHandlerSubscriber - Class in org.axonframework.spring.config
- 
- 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
- 
- CommandNameFilter(String) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
- 
- CommandPriorityCalculator - Interface in org.axonframework.axonserver.connector.command
- 
- commandPriorityCalculator() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- CommandResultMessage<R> - Interface in org.axonframework.commandhandling
- 
- 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
- 
- 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
- 
- 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 eventswhile 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 sagato the underlying saga store.
 
- commitTransaction(TransactionStatus) - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
- 
Commits the transaction with given statusif 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 configwith givennamecreated by the givenbuilderFunction.
 
- Component(Supplier<Configuration>, String, Function<Configuration, ? extends B>) - Constructor for class org.axonframework.config.Component
- 
Creates a component for the given configwith givennamecreated by the givenbuilderFunction.
 
- 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 keyin 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 updatein the value behind the givenkey.
 
- computeIfPresent(Object, UnaryOperator<V>) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- 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 segmentIdbased on the givenavailableSegmentsIds.
 
- 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 messageandcause.
 
- ConditionalOnMissingQualifiedBean - Annotation Type in org.axonframework.springboot.util
- 
Conditionalthat only matches when for the specified bean class in theBeanFactorythere is an
 instance which has the givenqualifierset on it.
 
- ConditionalOnQualifiedBean - Annotation Type in org.axonframework.springboot.util
- 
Conditionalthat only matches when for the specified bean class in theBeanFactorythere is an
 instance which has the givenqualifierset 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 configproperties.
 
- 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
- 
- configuration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
Sets the  AxonServerConfiguration used to configure several components within the Axon Server Query
 Bus, like setting the client id or the number of query handling threads used. 
- Configuration - Interface in org.axonframework.config
- 
Interface describing the Global Configuration for Axon components. 
- ConfigurationParameterResolverFactory - Class in org.axonframework.config
- 
ParameterResolverFactory implementation that resolves parameters from available components in the Configuration
 instance it was configured with. 
- ConfigurationParameterResolverFactory(Configuration) - Constructor for class org.axonframework.config.ConfigurationParameterResolverFactory
- 
Initialize an instance using given configurationto 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
- 
- ConfigurationScopeAwareProvider(Configuration) - Constructor for class org.axonframework.config.ConfigurationScopeAwareProvider
- 
- configure() - Method in class org.axonframework.test.server.AxonServerEEContainer
-  
- configure() - Method in class org.axonframework.test.server.AxonServerSEContainer
-  
- 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 Aggregates 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
- 
- configureDefaultStreamableMessageSource(Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- configureDefaultStreamableMessageSource(Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- configureDefaultSubscribableMessageSource(Function<Configuration, SubscribableMessageSource<EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- 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
- 
- 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
-  
- 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
- 
- 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
- 
- ConfigurerFactoryBean(Configurer) - Constructor for class org.axonframework.spring.config.ConfigurerFactoryBean
- 
Deprecated. Initialize the factory bean, using the given configurerto 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
- 
- 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
- 
- 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
- 
- 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 messageandcause.
 
- 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 messageandcause.
 
- ConflictResolution - Class in org.axonframework.eventsourcing.conflictresolution
- 
ParameterResolverFactory that add support for the ConflictResolver parameter type in annotated handlers. 
- ConflictResolution() - Constructor for class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
-  
- ConflictResolver - Interface in org.axonframework.eventsourcing.conflictresolution
- 
Interface describing an object that is capable of detecting conflicts between changes to be applied to an aggregate,
 and unseen changes made to the aggregate. 
- Conflicts - Class in org.axonframework.eventsourcing.conflictresolution
- 
Utility class providing common Predicates used to detect conflicts between the actual state of an event sourced
 aggregate and the expected state of the aggregate. 
- ConnectionManager - 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
- 
- ConnectionProvider - Interface in org.axonframework.common.jdbc
- 
Interface towards a mechanism that provides access to a JDBC Connection. 
- connectionProvider(ConnectionProvider) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
- 
- connectionProvider(ConnectionProvider) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- connectionProvider(ConnectionProvider) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
- 
- 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
- 
- 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
- 
- 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
- 
- ConsistentHashChangeListener - Interface in org.axonframework.commandhandling.distributed
- 
Represents a listener that is notified when a ConsistentHash instance of the component it is registered with has
 changed. 
- consume(ScopeDescriptor, DeadlineMessage<?>) - Method in interface org.axonframework.test.deadline.DeadlineConsumer
- 
Consumes given deadlineMessage.
 
- ContainerManagedEntityManagerProvider - Class in org.axonframework.springboot.util.jpa
- 
EntityManagerProvider implementation that expects the container to inject the default container managed
 EntityManager
 instance. 
- ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
-  
- ContainerManagedEntityManagerProvider - Class in org.axonframework.springboot.util.legacyjpa
- 
- ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.springboot.util.legacyjpa.ContainerManagedEntityManagerProvider
- 
Deprecated. 
- 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 attributeKeyis present in this object.
 
- contains(String) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
-  
- contains(AssociationValue) - Method in interface org.axonframework.modelling.saga.AssociationValues
- 
Indicates whether this instance contains the given associationValue.
 
- contains(AssociationValue) - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-  
- containsKey(Object) - Method in interface org.axonframework.common.caching.Cache
- 
Indicates whether there is an item stored under given key.
 
- containsKey(Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- containsKey(Object) - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- containsKey(Object) - Method in class org.axonframework.common.caching.NoCache
-  
- containsKey(Object) - Method in class org.axonframework.common.caching.WeakReferenceCache
-  
- containsKey(Object) - Method in class org.axonframework.messaging.MetaData
-  
- containsValue(Object) - Method in class org.axonframework.messaging.MetaData
-  
- contentType(Class<?>) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
- 
Sets the  contentType to which a  TrackingToken should be serialized. 
- ContentTypeConverter<S,T> - Interface in org.axonframework.serialization
- 
Interface describing a mechanism that converts the data type of IntermediateRepresentations of SerializedObjects for
 Upcasters. 
- context(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- 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
- 
- ContextAddingInterceptor(String) - Constructor for class org.axonframework.axonserver.connector.util.ContextAddingInterceptor
- 
Deprecated. 
- 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 errorMessageto the relevant AxonException
 
- convert(ErrorMessage) - Method in enum org.axonframework.axonserver.connector.ErrorCode
- 
Converts the errorMessageto the relevant AxonException
 
- convert(Throwable) - Method in enum org.axonframework.axonserver.connector.ErrorCode
- 
Converts the throwableto the relevant AxonException
 
- convert(String, Throwable) - Method in enum org.axonframework.axonserver.connector.ErrorCode
- 
Converts the sourceand thethrowableto 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
- 
- convert(DeadLetterEventEntry, Serializer, Serializer) - Method in interface org.axonframework.eventhandling.deadletter.jpa.DeadLetterJpaConverter
- 
- 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. 
- convert(DeadLetterEventEntry, Serializer, Serializer) - Method in interface org.axonframework.eventhandling.deadletter.legacyjpa.DeadLetterJpaConverter
- 
Deprecated. 
- 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
- 
- convert(S, Class<S>, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Convert the given source, of typesourceTypeto the giventargetType.
 
- 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 originalIntermediateRepresentation 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 eventMessageto a Spring ApplicationEvent.
 
- converter(Converter) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
- 
Sets the  Converter used as a converter factory providing converter instances utilized by upcasters to
 convert between different content types. 
- Converter - Interface in org.axonframework.serialization
- 
Interface describing a mechanism that can convert data from one to another type. 
- converter(Converter) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
- 
Sets the  Converter used as a converter factory providing converter instances utilized by upcasters to
 convert between different content types. 
- converter(Converter) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
-  
- convertExceptional(Throwable) - Method in class org.axonframework.messaging.responsetypes.PublisherResponseType
-  
- convertExceptional(Throwable) - Method in interface org.axonframework.messaging.responsetypes.ResponseType
- 
- 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 messageinto an Axon event Message
 
- convertFromMetaDataValue(MetaDataValue) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
- 
Convert the given MetaDataValueto 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 expectedResponseTypeto convert the payload from theresponseMessage, if necessary.
 
- convertToMetaDataValue(Object) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
- 
Convert the given valueinto aMetaDataValue, attempting to maintain the source type as much as
 possible in the returnedMetaDataValue.
 
- convertToOutboundMessage(EventMessage<T>) - Method in class org.axonframework.spring.messaging.DefaultEventMessageConverter
-  
- convertToOutboundMessage(EventMessage<T>) - Method in interface org.axonframework.spring.messaging.EventMessageConverter
- 
Converts Axon eventinto 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
- 
- coordinatorExecutor(Function<String, ScheduledExecutorService>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
- 
- 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
- 
- CorrelationDataInterceptor(CorrelationDataProvider...) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
- 
Initializes the interceptor that registers given correlationDataProviderswith the current Unit of Work.
 
- CorrelationDataInterceptor(Collection<CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
- 
Initializes the interceptor that registers given correlationDataProviderswith 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 otherchecking each member token with its counterpart to see if they are covered
 in theothertoken.
 
- 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 othertoken completely.
 
- create(Configuration, Class<?>, String) - Method in interface org.axonframework.config.MessageMonitorFactory
- 
Function to create a Message Monitor based on the given configuration, component type and component name. 
- 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
-  
- 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 givendeclaringEntityfor 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. 
- 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
-  
- 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.
 
- createGateway(Class<T>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
- 
Creates a gateway instance for the given gatewayInterface.
 
- createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
-  
- createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in interface org.axonframework.messaging.annotation.HandlerDefinition
- 
- 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
-  
- 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
- 
- createHeadToken(Connection) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-  
- createHeadToken(Connection, EventSchema) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- 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
- 
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.config.ConfigurationParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventhandling.replay.ReplayContextParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventhandling.replay.ReplayParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventhandling.TrackingTokenParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.DefaultParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in interface org.axonframework.messaging.annotation.ParameterResolverFactory
- 
If available, creates a ParameterResolver instance that can provide a parameter of type
 parameterTypefor a given message.
 
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.ResultParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.ScopeDescriptorParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.deadletter.DeadLetterParameterResolverFactory
-  
- createInstance(String, Supplier<T>) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
- 
Creates a new Saga instance. 
- createInstance(String, Supplier<T>) - Method in interface org.axonframework.modelling.saga.SagaRepository
- 
Creates a new Saga instance. 
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.spring.config.annotation.SpringBeanDependencyResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
-  
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.test.FixtureResourceParameterResolverFactory
-  
- createInternalSpan(Supplier<String>) - Method in class org.axonframework.tracing.LoggingSpanFactory
-  
- createInternalSpan(Supplier<String>, Message<?>) - Method in class org.axonframework.tracing.LoggingSpanFactory
-  
- createInternalSpan(Supplier<String>) - Method in class org.axonframework.tracing.MultiSpanFactory
-  
- createInternalSpan(Supplier<String>, Message<?>) - Method in class org.axonframework.tracing.MultiSpanFactory
-  
- createInternalSpan(Supplier<String>) - Method in class org.axonframework.tracing.NestingSpanFactory
-  
- createInternalSpan(Supplier<String>, Message<?>) - Method in class org.axonframework.tracing.NestingSpanFactory
-  
- createInternalSpan(Supplier<String>) - Method in class org.axonframework.tracing.NoOpSpanFactory
-  
- createInternalSpan(Supplier<String>, Message<?>) - Method in class org.axonframework.tracing.NoOpSpanFactory
-  
- createInternalSpan(Supplier<String>) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
-  
- createInternalSpan(Supplier<String>, Message<?>) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
-  
- createInternalSpan(Supplier<String>) - Method in interface org.axonframework.tracing.SpanFactory
- 
Creates a new  Span linked to the currently active span. 
- createInternalSpan(Supplier<String>, Message<?>) - Method in interface org.axonframework.tracing.SpanFactory
- 
Creates a new  Span linked to the currently active span. 
- createLinkedHandlerSpan(Supplier<String>, Message<?>, Message<?>...) - Method in interface org.axonframework.tracing.SpanFactory
- 
Creates a new  Span which becomes its own separate trace, linked to the previous span. 
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
- 
Creates an adapter for the given cacheEntryListener.
 
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- createMessage(P, MetaData) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
- createModel(Class<? extends T>) - Method in interface org.axonframework.modelling.command.inspection.AggregateMetaModelFactory
- 
Create an Aggregate meta model for the given aggregateType.
 
- createModel(Class<? extends T>, Set<Class<? extends T>>) - Method in interface org.axonframework.modelling.command.inspection.AggregateMetaModelFactory
- 
Create an Aggregate meta model for the given aggregateTypeand providedsubtypes.
 
- createModel(Class<? extends T>, Set<Class<? extends T>>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
-  
- createNew(Class<T>, Callable<T>) - Static method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Creates a new aggregate instance. 
- createNullStatement(Connection) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
- 
Creates a prepared statement that acts as a null object. 
- createReader(Reader) - Method in class org.axonframework.serialization.xml.CompactDriver
-  
- createReader(InputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
-  
- createReader(URL) - Method in class org.axonframework.serialization.xml.CompactDriver
-  
- createReader(File) - Method in class org.axonframework.serialization.xml.CompactDriver
-  
- createReplayToken(TrackingToken, TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Creates a new TrackingToken that represents the given startPositionof a stream.
 
- createReplayToken(TrackingToken, TrackingToken, Object) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Creates a new TrackingToken that represents the given startPositionof a stream.
 
- createReplayToken(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Creates a new TrackingToken that represents the tail of the stream. 
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
- 
Create a repository instance for an aggregate created by the given aggregateFactory.
 
- createRepository(EventStore, RepositoryProvider, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
- 
Create a repository instance for an aggregate created by the given aggregateFactory.
 
- createRepository(EventStore, AggregateFactory<T>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate that is created by the given eventStoreandaggregateFactory.
 
- createRepository(EventStore, AggregateFactory<T>, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate that is created by the given eventStoreandaggregateFactory.
 
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate, source from given eventStore, that is
 created by the givenaggregateFactory.
 
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate, source from given eventStore, that is
 created by the givenaggregateFactory.
 
- createRepository(EventStore, AggregateFactory<T>, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate that is created by the given aggregateFactoryand sourced from giveneventStore.
 
- createRepository(EventStore, AggregateFactory<T>, ParameterResolverFactory, HandlerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate that is created by the given aggregateFactoryand sourced from giveneventStore.
 
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate, sourced from given eventStore, that is
 created by the givenaggregateFactory.
 
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory, HandlerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Creates a repository instance for an Event Sourced aggregate, sourced from given eventStore, that is
 created by the givenaggregateFactory.
 
- createRootTrace(Supplier<String>) - Method in class org.axonframework.tracing.LoggingSpanFactory
-  
- createRootTrace(Supplier<String>) - Method in class org.axonframework.tracing.MultiSpanFactory
-  
- createRootTrace(Supplier<String>) - Method in class org.axonframework.tracing.NestingSpanFactory
-  
- createRootTrace(Supplier<String>) - Method in class org.axonframework.tracing.NoOpSpanFactory
-  
- createRootTrace(Supplier<String>) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
-  
- createRootTrace(Supplier<String>) - Method in interface org.axonframework.tracing.SpanFactory
- 
Creates a new  Span without any parent trace. 
- createSagaEntry(Object, String, Serializer) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
- 
Intended for clients to override. 
- createSagaEntry(Object, String, Serializer) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. Intended for clients to override. 
- createSagaIdentifier(Segment) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
- 
Creates a Saga identifier that will cause a Saga instance to be considered part of the given segment.
 
- createSchema(TokenTableFactory) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Performs the DDL queries to create the schema necessary for this token store implementation. 
- createSchema(EventTableFactory) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Performs the DDL queries to create the schema necessary for this storage engine implementation. 
- createSchema() - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
- 
Creates the SQL Schema required to store Sagas and their associations. 
- createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
- 
Creates a snapshot event for an aggregate of which passed events are available in the given eventStream.
 
- createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-  
- createSnapshotEntity(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
- 
Returns a Jpa snapshot entity for given snapshotof an aggregate.
 
- createSnapshotEntity(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. Returns a Jpa snapshot entity for given snapshotof an aggregate.
 
- createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-  
- createSnapshotEventTable(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory
- 
Creates a PreparedStatement that allows for the creation of the table to store Snapshots. 
- createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-  
- createSnapshotterTask(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
- 
Creates an instance of a task that contains the actual snapshot creation logic. 
- createSortedSetOf(Collection<Long>, long) - Static method in class org.axonframework.eventhandling.GapAwareTrackingToken
- 
Construct a  SortedSet of the given  gaps to be set in this Tracking Token. 
- createStreamableMessageSourceForContext(String) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
- 
Creates a  StreamableMessageSource that streams events from the given  context, rather than the
 default context the application was configured to connect to. 
- createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
-  
- createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory
-  
- createTable(Connection, TokenSchema) - Method in interface org.axonframework.eventhandling.tokenstore.jdbc.TokenTableFactory
- 
Creates a PreparedStatement that allows for the creation of the table to store tracking token entries. 
- createTailToken() - Method in class org.axonframework.eventhandling.MultiStreamableMessageSource
-  
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-  
- createTailToken() - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
- 
Creates a token that is at the tail of an event stream - that tracks events from the beginning of time. 
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-  
- createTailToken(CreateTailTokenStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- createTailToken(Connection) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-  
- createTailToken(Connection, EventSchema) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-  
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. 
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-  
- createTailToken() - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-  
- createTailToken() - Method in interface org.axonframework.messaging.StreamableMessageSource
- 
Creates the token at the beginning of an event stream. 
- CreateTailTokenStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
- 
- createTokenAt(Instant) - Method in class org.axonframework.eventhandling.MultiStreamableMessageSource
-  
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-  
- createTokenAt(Instant) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
- 
Creates a token that tracks all events after given dateTime.
 
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-  
- createTokenAt(CreateTokenAtStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- createTokenAt(Connection, Instant) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-  
- createTokenAt(Connection, EventSchema, Instant) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-  
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. 
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-  
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-  
- createTokenAt(Instant) - Method in interface org.axonframework.messaging.StreamableMessageSource
- 
Creates a token that tracks all events after given dateTime.
 
- CreateTokenAtStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
- 
- createTokenSince(Duration) - Method in class org.axonframework.eventhandling.MultiStreamableMessageSource
-  
- createTokenSince(Duration) - Method in interface org.axonframework.messaging.StreamableMessageSource
- 
Creates a token that tracks all events since the last duration.
 
- createWriter(Writer) - Method in class org.axonframework.serialization.xml.CompactDriver
-  
- createWriter(OutputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
-  
- CreationPolicy - Annotation Type in org.axonframework.modelling.command
- 
Annotation used to specify the creation policy for a command handler. 
- creationPolicy() - Method in interface org.axonframework.modelling.command.inspection.CreationPolicyMember
- 
- creationPolicyAggregateFactory() - Method in class org.axonframework.config.AggregateConfigurer
- 
- creationPolicyAggregateFactory(CreationPolicyAggregateFactory<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
- 
Sets the CreationPolicyAggregateFactoryfor generic typeT.
 
- CreationPolicyAggregateFactory<A> - Interface in org.axonframework.modelling.command
- 
Interface to describe a way to create Aggregate instances based on an identifier when an instance has to be created
 in order to be used in Command handlers annotated with  CreationPolicy. 
- CreationPolicyMember<T> - Interface in org.axonframework.modelling.command.inspection
- 
Interface specifying a message handler containing a creation policy definition. 
- currentDateTime() - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
- 
- currentInterceptorChain() - Static method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
- 
Returns the current interceptor chain registered for injection as a parameter. 
- currentTime() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- currentTime() - Method in interface org.axonframework.test.aggregate.TestExecutor
- 
Returns the time as "known" by the fixture. 
- currentTime() - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Returns the time as "known" by the fixture. 
- currentTime() - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- CurrentUnitOfWork - Class in org.axonframework.messaging.unitofwork
- 
Default entry point to gain access to the current UnitOfWork. 
- CurrentUnitOfWorkParameterResolverFactory - Class in org.axonframework.commandhandling
- 
ParameterResolverFactory that add support for the UnitOfWork parameter type in annotated handlers. 
- CurrentUnitOfWorkParameterResolverFactory() - Constructor for class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-  
- dataSource(DataSource) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
- dataSource(DataSource) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. 
- dataSource(DataSource) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
- 
- DataSourceConnectionProvider - Class in org.axonframework.common.jdbc
- 
ConnectionProvider implementation that obtains a connection from a given DataSource. 
- DataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.common.jdbc.DataSourceConnectionProvider
- 
Initialize the Connection Provider, using given dataSourceto obtain new connections.
 
- dataType(Class<?>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
Sets the dataTypespecifying the serialized type of the Event Message's payload and Meta Data.
 
- DateTimeUtils - Class in org.axonframework.common
- 
Some utility methods regarding Date and Time. 
- DeadLetter<M extends Message<?>> - Interface in org.axonframework.messaging.deadletter
- 
Interface describing a dead lettered  Message implementation of generic type  M. 
- DeadLetterEntry - Class in org.axonframework.eventhandling.deadletter.jpa
- 
Default DeadLetter JPA entity implementation of dead letters. 
- DeadLetterEntry() - Constructor for class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Constructor required by JPA. 
- DeadLetterEntry(String, String, long, DeadLetterEventEntry, Instant, Instant, Cause, MetaData, Serializer) - Constructor for class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
- DeadLetterEventEntry - Class in org.axonframework.eventhandling.deadletter.jpa
- 
- DeadLetterEventEntry() - Constructor for class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
-  
- DeadLetterEventEntry(String, String, String, String, String, byte[], byte[], String, String, Long, String, byte[]) - Constructor for class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- DeadLetteringEventHandlerInvoker - Class in org.axonframework.eventhandling.deadletter
- 
- DeadLetteringEventHandlerInvoker(DeadLetteringEventHandlerInvoker.Builder) - Constructor for class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker
- 
- DeadLetteringEventHandlerInvoker.Builder - Class in org.axonframework.eventhandling.deadletter
- 
- deadLetteringEventHandlerInvokers - Variable in class org.axonframework.config.EventProcessingModule
-  
- deadLetteringInvokerConfigs - Variable in class org.axonframework.config.EventProcessingModule
-  
- DeadLetterJpaConverter<M extends EventMessage<?>> - Interface in org.axonframework.eventhandling.deadletter.jpa
- 
- DeadLetterJpaConverter<M extends EventMessage<?>> - Interface in org.axonframework.eventhandling.deadletter.legacyjpa
- 
- DeadLetterParameterResolverFactory - Class in org.axonframework.messaging.deadletter
- 
- DeadLetterParameterResolverFactory() - Constructor for class org.axonframework.messaging.deadletter.DeadLetterParameterResolverFactory
-  
- deadLetterPolicies - Variable in class org.axonframework.config.EventProcessingModule
-  
- deadLetterPolicy(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- deadLetterPolicy(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- deadLetterQueue(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- deadLetterQueue(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- DeadLetterQueueOverflowException - Exception in org.axonframework.messaging.deadletter
- 
- DeadLetterQueueOverflowException(String) - Constructor for exception org.axonframework.messaging.deadletter.DeadLetterQueueOverflowException
- 
Constructs an exception based on the given message.
 
- DeadLetterQueueOverflowException(Object) - Constructor for exception org.axonframework.messaging.deadletter.DeadLetterQueueOverflowException
- 
Constructs an exception based on the given identifier.
 
- deadLetterQueues - Variable in class org.axonframework.config.EventProcessingModule
-  
- deadLetters() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- deadLetters() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- deadLetters() - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- deadLetters() - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
- deadLetterSequence(Object) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- deadLetterSequence(Object) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- deadLetterSequence(Object) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- deadLetterSequence(Object) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Return all the  dead letters for the given  sequenceIdentifier in insert order. 
- DEADLINE_NAME - Static variable in class org.axonframework.messaging.Headers
- 
- DeadlineConsumer - Interface in org.axonframework.test.deadline
- 
- DeadlineDetails - Class in org.axonframework.deadline.jobrunr
- 
Pojo that contains the information about a  org.jobrunr.jobs.Job, will be serialized and deserialized using
 the configured  Serializer on the  JobRunrDeadlineManager. 
- DeadlineDetails(String, String, String, String, String, String, String) - Constructor for class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
- DeadlineException - Exception in org.axonframework.deadline
- 
Exception which occurs during deadline message processing. 
- DeadlineException(String) - Constructor for exception org.axonframework.deadline.DeadlineException
- 
Initializes deadline exception with message and no cause. 
- DeadlineException(String, Throwable) - Constructor for exception org.axonframework.deadline.DeadlineException
- 
Initializes deadline exception with message and actual cause. 
- DeadlineHandler - Annotation Type in org.axonframework.deadline.annotation
- 
Annotation used to mark handlers which are capable of handling a  DeadlineMessage. 
- DeadlineHandlingMember<T> - Interface in org.axonframework.deadline.annotation
- 
Interface describing a message handler capable of handling a specific deadline. 
- DeadlineJob - Class in org.axonframework.deadline.quartz
- 
Quartz job which depicts handling of a scheduled deadline message. 
- DeadlineJob() - Constructor for class org.axonframework.deadline.quartz.DeadlineJob
-  
- DeadlineJob.DeadlineJobDataBinder - Class in org.axonframework.deadline.quartz
- 
This binder is used to map deadline message and deadline scopes to the job data and vice versa. 
- DeadlineJobDataBinder() - Constructor for class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
-  
- deadlineManager() - Method in interface org.axonframework.config.Configuration
- 
- DeadlineManager - Interface in org.axonframework.deadline
- 
Contract for deadline managers. 
- DeadlineManagerValidator - Class in org.axonframework.test.deadline
- 
- DeadlineManagerValidator(StubDeadlineManager, FieldFilter) - Constructor for class org.axonframework.test.deadline.DeadlineManagerValidator
- 
Instantiates this validator with deadlineManagerwhich is used for validation purposes andfieldFilter.
 
- DeadlineMessage<T> - Interface in org.axonframework.deadline
- 
Represents a Message for a Deadline, specified by its deadline name and optionally containing a deadline payload. 
- deadlineMessage(Serializer, JobDataMap) - Static method in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
- 
- deadlineMessage() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Retrieve a  DeadlineMessage constructed out of the  deadlineName and  deadlineInfo. 
- DeadlineMethodMessageHandlerDefinition - Class in org.axonframework.deadline.annotation
- 
- DeadlineMethodMessageHandlerDefinition() - Constructor for class org.axonframework.deadline.annotation.DeadlineMethodMessageHandlerDefinition
-  
- deadlineScope(Serializer, JobDataMap) - Static method in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
- 
- DeadlockException - Exception in org.axonframework.common.lock
- 
Exception indicating that a deadlock has been detected while a thread was attempting to acquire a lock. 
- DeadlockException(String) - Constructor for exception org.axonframework.common.lock.DeadlockException
- 
Initializes the exception with given message.
 
- decide(DeadLetter<? extends M>, Throwable) - Method in interface org.axonframework.messaging.deadletter.EnqueuePolicy
- 
- Decisions - Class in org.axonframework.messaging.deadletter
- 
- declaredType(Class<?>) - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
- 
Gets the declared aggregate type based on given class type.
 
- declaringClass(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the class on which the method with given methodNameand parameters of typeparameterTypesis declared.
 
- declaringClass() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
- 
Gets the declaring class of this Message Handling Member. 
- decrypt(EventWithToken) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- decrypt(Event) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- decryptBytes(int, byte[]) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- deepEquals(T) - Static method in class org.axonframework.test.matchers.Matchers
- 
Constructs a deep equals Matcher.
 
- deepEquals(T, FieldFilter) - Static method in class org.axonframework.test.matchers.Matchers
- 
Constructs a deep equals Matcher.
 
- DeepEqualsMatcher<T> - Class in org.axonframework.test.matchers
- 
- DeepEqualsMatcher(T) - Constructor for class org.axonframework.test.matchers.DeepEqualsMatcher
- 
Construct a  DeepEqualsMatcher that will match an  actual value with the given  expected. 
- DeepEqualsMatcher(T, FieldFilter) - Constructor for class org.axonframework.test.matchers.DeepEqualsMatcher
- 
Construct a  DeepEqualsMatcher that will match an  actual value with the given  expected. 
- DEFAULT_VALUE - Static variable in interface org.axonframework.axonserver.connector.command.CommandLoadFactorProvider
- 
The default value for command load factor: 100. 
- defaultAxonObjectMapper() - Method in class org.axonframework.springboot.autoconfig.ObjectMapperAutoConfiguration
-  
- defaultAxonXStream(ApplicationContext) - Method in class org.axonframework.springboot.autoconfig.XStreamAutoConfiguration
-  
- defaultBackpressure() - Static method in class org.axonframework.queryhandling.SubscriptionQueryBackpressure
- 
Deprecated. Creates default backpressure, using Project Reactor's FluxSink.OverflowStrategy ERROR strategy. 
- DefaultCallbackBehavior - Class in org.axonframework.test.utils
- 
Default implementation of the CallbackBehavior interface. 
- DefaultCallbackBehavior() - Constructor for class org.axonframework.test.utils.DefaultCallbackBehavior
-  
- defaultCommandBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
Provides the default CommandBus implementation. 
- defaultCommandBus() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
- defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
-  
- defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
- 
- defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
- 
- defaultCommandCallback(CommandCallback<Object, Object>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- defaultCommandExecutorServiceBuilder() - Static method in interface org.axonframework.axonserver.connector.util.ExecutorServiceBuilder
- 
Create a default ExecutorServiceBuilder used to create a  ThreadPoolExecutor for processing incoming
 commands. 
- DefaultCommandGateway - Class in org.axonframework.commandhandling.gateway
- 
Default implementation of the CommandGateway interface. 
- DefaultCommandGateway(DefaultCommandGateway.Builder) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
- 
- defaultCommandGateway(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- DefaultCommandGateway.Builder - Class in org.axonframework.commandhandling.gateway
- 
- defaultCommandPriorityCalculator() - Static method in interface org.axonframework.axonserver.connector.command.CommandPriorityCalculator
- 
- defaultComponent(Class<T>, Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
Method returning a default component to use for given typefor givenconfiguration, or an empty
 Optional if no default can be provided.
 
- defaultComponent(Class<T>, Configuration) - Method in class org.axonframework.spring.config.SpringConfigurer
-  
- defaultConfiguration(Class<A>) - Static method in class org.axonframework.config.AggregateConfigurer
- 
Creates a default Configuration for an aggregate of the given aggregateType.
 
- defaultConfiguration() - Static method in class org.axonframework.config.DefaultConfigurer
- 
- defaultConfiguration(boolean) - Static method in class org.axonframework.config.DefaultConfigurer
- 
Returns a Configurer instance with default components configured, such as a  SimpleCommandBus and
  SimpleEventBus, indicating whether to  autoLocateConfigurerModules. 
- DefaultConfigurer - Class in org.axonframework.config
- 
Entry point of the Axon Configuration API. 
- DefaultConfigurer() - Constructor for class org.axonframework.config.DefaultConfigurer
- 
Initialize the Configurer. 
- DefaultConflictDescription - Class in org.axonframework.eventsourcing.conflictresolution
- 
- DefaultConflictDescription(String, long, long, List<DomainEventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
- 
Initialize the instance using given values. 
- DefaultConflictResolver - Class in org.axonframework.eventsourcing.conflictresolution
- 
- DefaultConflictResolver(EventStore, String, long, long) - Constructor for class org.axonframework.eventsourcing.conflictresolution.DefaultConflictResolver
- 
Initializes a  DefaultConflictResolver using the given  eventStore to load unseen events since
 given  expectedVersion. 
- defaultContext(String) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
Sets the default context for this command bus to connect to. 
- defaultContext(String) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
- 
Sets the default context for this event store to connect to. 
- defaultContext(String) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
Sets the default context for this event store to connect to. 
- defaultDeadlineManager(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- DefaultEntityRegistrar - Class in org.axonframework.springboot.util
-  
- DefaultEntityRegistrar() - Constructor for class org.axonframework.springboot.util.DefaultEntityRegistrar
-  
- defaultEventBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
Provides the default EventBus implementation. 
- defaultEventBus() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- defaultEventGateway(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- DefaultEventGateway - Class in org.axonframework.eventhandling.gateway
- 
Default implementation of the EventGateway interface. 
- DefaultEventGateway(DefaultEventGateway.Builder) - Constructor for class org.axonframework.eventhandling.gateway.DefaultEventGateway
- 
- DefaultEventGateway.Builder - Class in org.axonframework.eventhandling.gateway
- 
- DefaultEventMessageConverter - Class in org.axonframework.spring.messaging
- 
An  EventMessageConverter that will convert an Axon event message into a Spring message by:
 
 Copying axon event payload into Spring message payload
 Copying axon event metadata into Spring message headers
 Adding axon event message specific attributes - that are not part of axon metadata - to the Spring message Headers. 
- DefaultEventMessageConverter() - Constructor for class org.axonframework.spring.messaging.DefaultEventMessageConverter
-  
- defaultHandlerDefinition(Class<?>) - Method in class org.axonframework.config.DefaultConfigurer
- 
Provides the default HandlerDefinition. 
- defaultHandlerInterceptors - Variable in class org.axonframework.config.EventProcessingModule
-  
- DefaultHandlers<Case,Handler> - Class in org.axonframework.axonserver.connector
- 
- DefaultHandlers() - Constructor for class org.axonframework.axonserver.connector.DefaultHandlers
- 
Deprecated. 
- defaultHeaders(EventMessage<?>, SerializedObject<?>) - Static method in class org.axonframework.messaging.Headers
- 
Generate defaults headers to recognise an event message. 
- DefaultIdentifierFactory - Class in org.axonframework.common
- 
Default IdentifierFactory implementation that uses generates random java.util.UUIDbased identifiers.
 
- DefaultIdentifierFactory() - Constructor for class org.axonframework.common.DefaultIdentifierFactory
-  
- DefaultInstructionAckSource<T> - Class in org.axonframework.axonserver.connector
- 
- DefaultInstructionAckSource(Function<InstructionAck, T>) - Constructor for class org.axonframework.axonserver.connector.DefaultInstructionAckSource
- 
- DefaultInterceptorChain<T extends Message<?>> - Class in org.axonframework.messaging
- 
Mechanism that takes care of interceptor and handler execution. 
- DefaultInterceptorChain(UnitOfWork<? extends T>, Iterable<? extends MessageHandlerInterceptor<? super T>>, MessageHandler<? super T>) - Constructor for class org.axonframework.messaging.DefaultInterceptorChain
- 
Initialize the default interceptor chain to dispatch the given message, through thechain, to thehandler.
 
- defaultParameterResolverFactory(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
Provides the default ParameterResolverFactory. 
- DefaultParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
Factory for the default parameter resolvers. 
- DefaultParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.DefaultParameterResolverFactory
-  
- defaultQueryBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
Provides the default QueryBus implementations. 
- defaultQueryBus() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- defaultQueryExecutorServiceBuilder() - Static method in interface org.axonframework.axonserver.connector.util.ExecutorServiceBuilder
- 
Create a default ExecutorServiceBuilder used to create a  ThreadPoolExecutor for processing incoming
 queries. 
- defaultQueryGateway(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- DefaultQueryGateway - Class in org.axonframework.queryhandling
- 
Implementation of the QueryGateway interface that allows the registration of dispatchInterceptors. 
- DefaultQueryGateway(DefaultQueryGateway.Builder) - Constructor for class org.axonframework.queryhandling.DefaultQueryGateway
- 
- DefaultQueryGateway.Builder - Class in org.axonframework.queryhandling
- 
- defaultQueryPriorityCalculator() - Static method in interface org.axonframework.axonserver.connector.query.QueryPriorityCalculator
- 
- defaultQueryUpdateEmitter(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
Provides the default QueryUpdateEmitter implementation. 
- defaultQueryUpdateEmitter() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- defaultQueue() - Static method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
- 
- defaultResourceInjector(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- defaultScopeAwareProvider(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- defaultSerializer(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
Provides the default Serializer implementation. 
- defaultSerializer() - Static method in class org.axonframework.serialization.json.JacksonSerializer
- 
- defaultSerializer() - Static method in class org.axonframework.serialization.xml.XStreamSerializer
- 
- defaultSnapshotter(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- defaultSpanFactory(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- defaultStrategy() - Static method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
- 
- DefaultSubscriptionQueryResult<I,U> - Class in org.axonframework.queryhandling
- 
- DefaultSubscriptionQueryResult(Mono<I>, Flux<U>, Registration) - Constructor for class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
- 
Initializes the result with mono and flux used for result retrieval. 
- defaultTyping() - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
- 
Configures the underlying ObjectMapperto include type information when serializing Java objects into
 JSON.
 
- DefaultUnitOfWork<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
- 
Implementation of the UnitOfWork that processes a single message. 
- DefaultUnitOfWork(T) - Constructor for class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
- 
Initializes a Unit of Work (without starting it). 
- defaultUpcasterChain(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
- 
- delegate(SpanFactory) - Method in class org.axonframework.tracing.NestingSpanFactory.Builder
- 
Defines the delegate  SpanFactory to use, which actually provides the spans. 
- delegates() - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
-  
- delegateSagaStore(SagaStore<T>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
- 
Sets the  SagaStore instance providing access to (persisted) entries. 
- deleteSaga(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
- 
Remove the given saga as well as all known association values pointing to it from the repository. 
- deleteSaga(Class<? extends T>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
-  
- deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
-  
- deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
-  
- deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
-  
- deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. 
- deleteSaga(Class<? extends T>, String, Set<AssociationValue>) - Method in interface org.axonframework.modelling.saga.repository.SagaStore
- 
Deletes a Saga with given sagaTypeandsagaIdentifierand all its associations.
 
- deleteSnapshots(DeleteSnapshotsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- deleteSnapshots(Connection, String, long) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- deleteSnapshots(Connection, EventSchema, String, long) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- deleteSnapshots(String, long) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
- 
Deletes all snapshots from the underlying storage with given aggregateIdentifier.
 
- deleteSnapshots(String, long) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. Deletes all snapshots from the underlying storage with given aggregateIdentifier.
 
- DeleteSnapshotsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
- 
- deleteToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- deleteToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- deleteToken(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Creates a new  PreparedStatement to release the current claim this node has on a token belonging to a
 processor with given  processorName and  segment. 
- deleteToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- deleteToken(String, int) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- deleteToken(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Deletes the token for the processor with given processorNameandsegment.
 
- DenyAll - Enum in org.axonframework.commandhandling.distributed.commandfilter
- 
- DenyCommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
- 
- DenyCommandNameFilter(Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
- 
- DenyCommandNameFilter(String) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
- 
- describe(StreamingEventProcessor) - Static method in class org.axonframework.axonserver.connector.processor.StreamingEventProcessorInfoMessage
- 
Create an EventProcessorInfobased on the giveneventProcessor.
 
- describe(List<?>, Description) - Static method in class org.axonframework.test.saga.DescriptionUtils
- 
Describe the contents of the given listin the givendescription.
 
- describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ExactSequenceMatcher
-  
- describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListMatcher
- 
Describes the type of collection expected. 
- describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListWithAllOfMatcher
-  
- describeCollectionType(Description) - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
-  
- describeCollectionType(Description) - Method in class org.axonframework.test.matchers.SequenceMatcher
-  
- describeCurrentScope() - Static method in class org.axonframework.messaging.Scope
- 
Provide a description of the current  Scope. 
- describeScope() - Method in class org.axonframework.messaging.Scope
- 
Provide a description of this  Scope. 
- describeScope() - Method in class org.axonframework.modelling.command.AggregateLifecycle
-  
- describeScope() - Method in class org.axonframework.modelling.saga.SagaLifecycle
-  
- describeTo(StringBuilder) - Method in class org.axonframework.commandhandling.GenericCommandMessage
-  
- describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-  
- describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericEventMessage
-  
- describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
-  
- describeTo(StringBuilder) - Method in class org.axonframework.eventhandling.GenericTrackedEventMessage
-  
- describeTo(StringBuilder) - Method in class org.axonframework.messaging.GenericResultMessage
-  
- describeTo(StringBuilder) - Method in class org.axonframework.messaging.MessageDecorator
- 
Describe the message specific properties to the given stringBuilder.
 
- describeTo(StringBuilder) - Method in class org.axonframework.queryhandling.GenericQueryMessage
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.DeepEqualsMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.EmptyCollectionMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.EqualsMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.ExactClassMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.ListMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.MapEntryMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.NullOrVoidMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.PayloadMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.PayloadsMatcher
-  
- describeTo(Description) - Method in class org.axonframework.test.matchers.PredicateMatcher
-  
- describeType() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-  
- describeType() - Method in class org.axonframework.commandhandling.GenericCommandResultMessage
-  
- describeType() - Method in class org.axonframework.deadline.GenericDeadlineMessage
-  
- describeType() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-  
- describeType() - Method in class org.axonframework.eventhandling.GenericEventMessage
-  
- describeType() - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
-  
- describeType() - Method in class org.axonframework.eventhandling.GenericTrackedEventMessage
-  
- describeType() - Method in class org.axonframework.eventhandling.replay.GenericResetContext
-  
- describeType() - Method in class org.axonframework.messaging.GenericResultMessage
-  
- describeType() - Method in class org.axonframework.messaging.MessageDecorator
- 
- describeType() - Method in class org.axonframework.queryhandling.GenericQueryMessage
-  
- describeType() - Method in class org.axonframework.queryhandling.GenericStreamingQueryMessage
-  
- describeType() - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
-  
- describing(Throwable) - Static method in class org.axonframework.messaging.RemoteExceptionDescription
- 
Provide a description as a  List of  Strings of all the causes in the given  exception. 
- DescriptionUtils - Class in org.axonframework.test.saga
- 
Utility class for creating a description. 
- deserialize(Command) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
- 
- deserialize(CommandResponse) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
- 
- deserialize(SerializedObject<S>) - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
-  
- deserialize(SubscriptionQuery) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
- deserialize(QueryResponse) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
- deserialize(QueryUpdate) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-  
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.JavaSerializer
- 
Deprecated. 
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-  
- deserialize(JsonParser, DeserializationContext) - Method in class org.axonframework.serialization.json.MetaDataDeserializer
-  
- deserialize(SerializedObject<S>) - Method in interface org.axonframework.serialization.Serializer
- 
Deserializes the first object read from the given bytes.
 
- DeserializedResult<I,U> - Class in org.axonframework.axonserver.connector.query.subscription
- 
- DeserializedResult(SubscriptionQueryResult<QueryResponse, QueryUpdate>, SubscriptionMessageSerializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
- 
Deprecated. Instantiate a  DeserializedResult wrapping the  delegate which will be serialized by the given
  serializer. 
- deserializeRequest(QueryRequest) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
- 
- deserializeResponse(QueryResponse, ResponseType<R>) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
- 
- deserializeResponse(QueryResponse) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
- 
- deserializeWithType(JsonParser, DeserializationContext, TypeDeserializer) - Method in class org.axonframework.serialization.json.MetaDataDeserializer
-  
- destroy() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-  
- details() - Method in exception org.axonframework.axonserver.connector.AxonServerException
-  
- details() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
- 
Return a  List of  Strings, each describing a single "cause". 
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictResolver
- 
Resolve conflicts between unseen changes made to the aggregate and new changes that are about to be made. 
- detectConflicts(Predicate<List<DomainEventMessage<?>>>) - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictResolver
- 
Resolve conflicts between changes to be applied to the aggregate and unseen changes made to the aggregate. 
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ContextAwareConflictExceptionSupplier<T>) - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictResolver
- 
Resolve conflicts between unseen changes made to the aggregate and new changes that are about to be made. 
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ContextAwareConflictExceptionSupplier<T>) - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictResolver
-  
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
-  
- detectConflicts(Predicate<List<DomainEventMessage<?>>>) - Method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
-  
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ContextAwareConflictExceptionSupplier<T>) - Method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
-  
- determineMessageName(Message<?>) - Static method in class org.axonframework.tracing.SpanUtils
- 
Creates a human-readable name for a message's payload. 
- determinePriority(CommandMessage<?>) - Method in interface org.axonframework.axonserver.connector.command.CommandPriorityCalculator
- 
Determines the priority of the given command.
 
- determinePriority(QueryMessage<?, ?>) - Method in interface org.axonframework.axonserver.connector.query.QueryPriorityCalculator
- 
Determines the priority of the given query.
 
- diagnostics() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
-  
- diagnostics() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. 
- diagnostics() - Method in interface org.axonframework.messaging.deadletter.DeadLetter
- 
The diagnostic  MetaData concerning this letter. 
- diagnostics() - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
-  
- Digester - Class in org.axonframework.common.digest
- 
Utility class for generating hashes for values using several algorithms. 
- digestHex() - Method in class org.axonframework.common.digest.Digester
- 
Returns the hex representation of the digest of all data that has been provided so far. 
- DirectEventJobDataBinder() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
- 
- DirectEventJobDataBinder(Serializer) - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
- 
- DirectEventProcessingStrategy - Enum in org.axonframework.eventhandling
- 
Event processing strategy that directly initiates event processing. 
- DirectExecutor - Class in org.axonframework.common
- 
Simple executor implementation that runs a given Runnable immediately in the calling thread. 
- DirectExecutor() - Constructor for class org.axonframework.common.DirectExecutor
-  
- DirectlyAccessedProperty<T> - Class in org.axonframework.common.property
- 
Property implementation that accesses public field to obtain a value of a property for a given instance. 
- DirectlyAccessedProperty(Field, String) - Constructor for class org.axonframework.common.property.DirectlyAccessedProperty
-  
- DirectPropertyAccessStrategy - Class in org.axonframework.common.property
- 
Implementation of PropertyAccessStrategy that scans class hierarchy to get public field named "property" 
- DirectPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.DirectPropertyAccessStrategy
-  
- disableAxonTypeSecurity() - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
- 
Configures the underlying XStreaminstance to not include Axon's classes by default.
 
- disableAxonTypeSecurity() - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
-  
- disableSequenceNumberGeneration() - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
- 
Disables sequence number generation within this  Repository implementation. 
- disableSequenceNumberGeneration() - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. Disables sequence number generation within this  Repository implementation. 
- DisallowReplay - Annotation Type in org.axonframework.eventhandling
- 
Annotation marking a Handler (or class) as not being able to handle replays 
- disconnect(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Disconnects any active connection for the given context, forcing a new connection to be established when
 one is requested.
 
- disconnect() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Disconnects any active connections, forcing a new connection to be established when one is requested. 
- disconnect() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
- 
Disconnect the command bus for receiving commands from Axon Server, by unsubscribing all registered command
 handlers. 
- disconnect() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
- 
Disconnect the query bus from Axon Server, by unsubscribing all known query handlers. 
- disconnect() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
Disconnect the command bus for receiving new commands, by unsubscribing all registered command handlers. 
- dispatch(CommandMessage<C>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-  
- dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-  
- dispatch(CommandMessage<C>) - Method in interface org.axonframework.commandhandling.CommandBus
- 
Dispatch the given commandto the CommandHandler subscribed to the givencommand's name.
 
- dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in interface org.axonframework.commandhandling.CommandBus
- 
Dispatch the given commandto the CommandHandler subscribed to the givencommand's name.
 
- dispatch(CommandMessage<C>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-  
- dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
Dispatch the given commandto the CommandHandler subscribed to the givencommand's name.
 
- dispatch(CommandMessage<C>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-  
- dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-  
- dispatch(CommandMessage<C>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-  
- dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-  
- dispatch(CommandMessage<C>) - Method in class org.axonframework.test.utils.RecordingCommandBus
-  
- dispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.test.utils.RecordingCommandBus
-  
- DispatchInterceptors<M extends Message<?>> - Class in org.axonframework.axonserver.connector
- 
- DispatchInterceptors() - Constructor for class org.axonframework.axonserver.connector.DispatchInterceptors
-  
- dispatchInterceptors(MessageDispatchInterceptor<? super CommandMessage<?>>...) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
- 
- dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
- 
- dispatchInterceptors(MessageDispatchInterceptor<? super CommandMessage<?>>...) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
- 
- dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
- 
- dispatchInterceptors(MessageDispatchInterceptor<? super CommandMessage<?>>...) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
-  
- dispatchInterceptors(List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
-  
- dispatchInterceptors() - Method in class org.axonframework.deadline.AbstractDeadlineManager
- 
Provides a list of registered dispatch interceptors. 
- dispatchInterceptors(List<MessageDispatchInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- dispatchInterceptors(MessageDispatchInterceptor<? super EventMessage<?>>...) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
- 
- dispatchInterceptors(List<MessageDispatchInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
- 
- dispatchInterceptors(MessageDispatchInterceptor<? super EventMessage<?>>...) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
-  
- dispatchInterceptors(List<MessageDispatchInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
-  
- dispatchInterceptors(MessageDispatchInterceptor<? super QueryMessage<?, ?>>...) - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
- 
- dispatchInterceptors(List<MessageDispatchInterceptor<? super QueryMessage<?, ?>>>) - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
- 
- DispatchMessage - Class in org.axonframework.commandhandling.distributed
- 
Base class for dispatch messages which may be used in the  CommandBusConnector upon dispatching a command
 to other nodes. 
- DispatchMessage() - Constructor for class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Default constructor required for de-/serialization of extending classes. 
- DispatchMessage(CommandMessage<?>, Serializer, boolean) - Constructor for class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Initialized a DispatchMessage for the given commandMessage, which uses the givenserializerto deserialize its contents.
 
- DisposableResult<I,U> - Class in org.axonframework.axonserver.connector.query.subscription
- 
- DisposableResult(SubscriptionQueryResult<I, U>, Registration) - Constructor for class org.axonframework.axonserver.connector.query.subscription.DisposableResult
- 
Deprecated. 
- DisruptorCommandBus - Class in org.axonframework.disruptor.commandhandling
- 
Asynchronous CommandBus implementation with very high performance characteristics. 
- DisruptorCommandBus(DisruptorCommandBus.Builder) - Constructor for class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
- DisruptorCommandBus.Builder - Class in org.axonframework.disruptor.commandhandling
- 
- DisruptorUnitOfWork<T extends Message<?>> - Class in org.axonframework.disruptor.commandhandling
- 
- DisruptorUnitOfWork() - Constructor for class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-  
- distinct(List<E>) - Static method in class org.axonframework.common.ListUtils
- 
Returns a new list containing unique elements from the given list.
 
- Distributed<MessageBus> - Interface in org.axonframework.messaging
- 
A contract towards being a distributed message bus implementation. 
- DistributedCommandBus - Class in org.axonframework.commandhandling.distributed
- 
Implementation of a  CommandBus that is aware of multiple instances of a CommandBus working together to spread
 load. 
- DistributedCommandBus(DistributedCommandBus.Builder) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
- DistributedCommandBus.Builder - Class in org.axonframework.commandhandling.distributed
- 
- DistributedCommandBusProperties - Class in org.axonframework.springboot
- 
Defines the properties for the Distributed Command Bus, when automatically configured in the Application Context. 
- DistributedCommandBusProperties() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties
-  
- DistributedCommandBusProperties.JGroupsProperties - Class in org.axonframework.springboot
- 
The JGroups specific configuration for the Distributed Command Bus. 
- DistributedCommandBusProperties.JGroupsProperties.Gossip - Class in org.axonframework.springboot
-  
- DistributedCommandBusProperties.SpringCloudProperties - Class in org.axonframework.springboot
-  
- doApply(P, MetaData) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-  
- doApply(T, MetaData) - Method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Apply a  DomainEventMessage with given payload and metadata (metadata from
 interceptors will be combined with the provided metadata). 
- doApply(P, MetaData) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- doApply(T, MetaData) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-  
- doAssociateWith(AssociationValue) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
- 
Registers a AssociationValue with the given saga. 
- doAssociateWith(AssociationValue) - Method in class org.axonframework.modelling.saga.SagaLifecycle
- 
SagaLifecycle instance method to register the given  associationValue. 
- doCreateAggregate(String, DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
- 
Create an uninitialized Aggregate instance with the given aggregateIdentifier.
 
- doCreateAggregate(String, DomainEventMessage) - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
- 
Create an uninitialized Aggregate instance with the given aggregateIdentifier.
 
- doCreateInstance(String, Supplier<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
-  
- doCreateInstance(String, Supplier<T>) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
- 
Creates a new Saga instance. 
- doCreateNew(Callable<T>) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Creates a new aggregate instance using the given factoryMethod.
 
- doCreateNew(Class<T>, Callable<T>) - Method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Creates a new aggregate instance. 
- doCreateNew(Class<R>, Callable<R>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- doCreateNew(Callable<T>) - Method in class org.axonframework.modelling.command.LockingRepository
-  
- doCreateNew(Class<T>, Callable<T>) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-  
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-  
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository
-  
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository
- 
Deprecated. 
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.modelling.command.LockingRepository
- 
Creates a new aggregate instance using the given factoryMethod.
 
- doDelete(A) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Removes the aggregate from the repository. 
- doDelete(LockAwareAggregate<T, A>) - Method in class org.axonframework.modelling.command.LockingRepository
- 
- doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-  
- doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-  
- doDeleteWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository
-  
- doDeleteWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository
- 
Deprecated. 
- doDeleteWithLock(A) - Method in class org.axonframework.modelling.command.LockingRepository
- 
Perform the actual deleting of the aggregate. 
- doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Deserialize the given serializedObject.
 
- doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serialization.xml.XStreamSerializer
-  
- doDispatch(CommandMessage<C>, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
- 
Performs the actual dispatching logic. 
- doEnd() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
- 
Marks the saga as ended. 
- doEnd() - Method in class org.axonframework.modelling.saga.SagaLifecycle
- 
- doHealthCheck(Health.Builder) - Method in class org.axonframework.actuator.axonserver.AxonServerHealthIndicator
-  
- doLoad(String, Long) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Loads and initialized the aggregate with the given aggregateIdentifier. 
- doLoad(String, Long) - Method in class org.axonframework.modelling.command.LockingRepository
- 
Perform the actual loading of an aggregate. 
- doLoad(String) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
-  
- doLoad(String) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
- 
Loads a known Saga instance by its unique identifier. 
- doLoadOrCreate(String, Callable<T>) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Loads an aggregate from the reporsitory. 
- doLoadOrCreate(String, Callable<T>) - Method in class org.axonframework.modelling.command.LockingRepository
-  
- doLoadSaga(String) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
- 
Loads the saga with given  sagaIdentifier from the underlying saga store and returns it as a  AnnotatedSaga. 
- doLoadWithLock(String, Long) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
- 
Perform the actual loading of an aggregate. 
- doLoadWithLock(String, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
- 
Perform the actual loading of an aggregate. 
- doLoadWithLock(String, Long) - Method in class org.axonframework.modelling.command.GenericJpaRepository
-  
- doLoadWithLock(String, Long) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository
- 
Deprecated. 
- doLoadWithLock(String, Long) - Method in class org.axonframework.modelling.command.LockingRepository
- 
Loads the aggregate with the given aggregateIdentifier. 
- Dom4JToByteArrayConverter - Class in org.axonframework.serialization.xml
- 
Converter that converts Dom4j Document instances to a byte array. 
- Dom4JToByteArrayConverter() - Constructor for class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
-  
- DomainEventData<T> - Interface in org.axonframework.eventhandling
- 
Interface describing the properties of serialized Domain Event Messages. 
- DomainEventEntry - Class in org.axonframework.eventsourcing.eventstore.jpa
- 
Default implementation of a tracked domain event entry. 
- DomainEventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.DomainEventEntry
- 
Construct a new default domain event entry from a published domain event message to enable storing the event or
 sending it to a remote location. 
- DomainEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.DomainEventEntry
- 
Default constructor required by JPA 
- domainEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
- 
Returns the name of the Jpa event entity. 
- domainEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. Returns the name of the Jpa event entity. 
- domainEventFields(Function<EventSchema, String>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Set a comma separated list of domain event column names to select from an event or snapshot entry. 
- domainEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get a comma separated list of domain event column names to select from an event or snapshot entry. 
- domainEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- DomainEventMessage<T> - Interface in org.axonframework.eventhandling
- 
Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain. 
- DomainEventSequenceAware - Interface in org.axonframework.eventhandling
- 
Contract describing a component which is aware of  DomainEventMessage their sequences and is capable of
 providing the last known sequence number for a given Aggregate identifier. 
- DomainEventStream - Interface in org.axonframework.eventsourcing.eventstore
- 
The DomainEventStream represents a stream of historical events published by an Aggregate. 
- domainEventTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Returns the name of the domain event table. 
- doMarkDeleted() - Method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Marks this aggregate as deleted. 
- doMarkDeleted() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- doMarkDeleted() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-  
- doNotEnqueue() - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- DoNotEnqueue<M extends Message<?>> - Class in org.axonframework.messaging.deadletter
- 
- DoNotEnqueue() - Constructor for class org.axonframework.messaging.deadletter.DoNotEnqueue
-  
- doRegisterListener(L) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
- 
Registers the given listener with the cache implementation 
- doRegisterListener(CacheEventListener) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- doRegisterListener(CacheEntryListenerConfiguration<Object, Object>) - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- doRemoveAssociation(AssociationValue) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
- 
Removes the given association from this Saga. 
- doRemoveAssociation(AssociationValue) - Method in class org.axonframework.modelling.saga.SagaLifecycle
- 
SagaLifecycle instance method to remove the given  associationValue. 
- doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
- 
Resolve the Routing Key for the given command.
 
- doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-  
- doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
-  
- doSave(A) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Performs the actual saving of the aggregate. 
- doSave(LockAwareAggregate<T, A>) - Method in class org.axonframework.modelling.command.LockingRepository
- 
- doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-  
- doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-  
- doSaveWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository
-  
- doSaveWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository
- 
Deprecated. 
- doSaveWithLock(A) - Method in class org.axonframework.modelling.command.LockingRepository
- 
Perform the actual saving of the aggregate. 
- doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Serialize the given objectto the givenexpectedFormat.
 
- doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serialization.xml.XStreamSerializer
-  
- doSleepFor(long) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Instructs the current Thread to sleep until the given deadline. 
- doUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
- 
Upcasts the given intermediateRepresentation.
 
- doUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
- 
Upcasts the given intermediateRepresentation.
 
- doUpcast(IntermediateEventRepresentation) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
-  
- doUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
- 
Upcasts the given intermediateRepresentation.
 
- doUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryUpcaster
- 
Upcasts the given intermediateRepresentation.
 
- DuplicateCommandHandlerResolution - Class in org.axonframework.commandhandling
- 
- duplicateCommandHandlerResolver(DuplicateCommandHandlerResolver) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
-  
- DuplicateCommandHandlerResolver - Interface in org.axonframework.commandhandling
- 
Functional interface towards resolving the occurrence of a duplicate command handler being subscribed. 
- duplicateCommandHandlerResolver(DuplicateCommandHandlerResolver) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
- 
- duplicateCommandHandlerResolver(DuplicateCommandHandlerResolver) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- duplicateCommandHandlerResolver() - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- DuplicateCommandHandlerSubscriptionException - Exception in org.axonframework.commandhandling
- 
Exception indicating a duplicate Command Handler was subscribed whilst this behavior is purposefully guarded against. 
- DuplicateCommandHandlerSubscriptionException(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Constructor for exception org.axonframework.commandhandling.DuplicateCommandHandlerSubscriptionException
- 
Initialize a duplicate command handler subscription exception using the given initialHandlerandduplicateHandlerto form a specific message.
 
- DuplicateCommandHandlerSubscriptionException(String) - Constructor for exception org.axonframework.commandhandling.DuplicateCommandHandlerSubscriptionException
- 
Initializes a duplicate command handler subscription exception using the given message.
 
- DuplicateQueryHandlerResolution - Class in org.axonframework.queryhandling.registration
- 
- DuplicateQueryHandlerResolver - Interface in org.axonframework.queryhandling.registration
- 
Functional interface towards resolving the occurrence of a duplicate query handler being subscribed. 
- duplicateQueryHandlerResolver(DuplicateQueryHandlerResolver) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
- 
Sets the duplicate query handler resolver. 
- DuplicateQueryHandlerSubscriptionException - Exception in org.axonframework.queryhandling.registration
- 
Exception indicating a duplicate Query Handler was subscribed whilst this behavior is purposefully guarded against. 
- DuplicateQueryHandlerSubscriptionException(String, Type, QuerySubscription<?>, QuerySubscription<?>) - Constructor for exception org.axonframework.queryhandling.registration.DuplicateQueryHandlerSubscriptionException
- 
Initialize a duplicate query handler subscription exception using the given initialHandlerandduplicateHandlerto form a specific message.
 
- DuplicateQueryHandlerSubscriptionException(String) - Constructor for exception org.axonframework.queryhandling.registration.DuplicateQueryHandlerSubscriptionException
- 
Initializes a duplicate query handler subscription exception using the given message.
 
- EhCacheAdapter - Class in org.axonframework.common.caching
- 
Cache implementation that delegates all calls to an EhCache instance. 
- EhCacheAdapter(Ehcache) - Constructor for class org.axonframework.common.caching.EhCacheAdapter
- 
Initialize the adapter to forward all call to the given ehCacheinstance
 
- EmbeddedEventStore - Class in org.axonframework.eventsourcing.eventstore
- 
- EmbeddedEventStore(EmbeddedEventStore.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
- 
- EmbeddedEventStore - Class in org.axonframework.eventsourcing.eventstore.legacyjpa
- 
- EmbeddedEventStore(EmbeddedEventStore.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore
- 
Deprecated. 
- EmbeddedEventStore.Builder - Class in org.axonframework.eventsourcing.eventstore
- 
- EmbeddedEventStore.Builder - Class in org.axonframework.eventsourcing.eventstore.legacyjpa
- 
Deprecated. 
- emit(Predicate<SubscriptionQueryMessage<?, ?, U>>, SubscriptionQueryUpdateMessage<U>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
- 
Emits incremental update (as return value of provided update function) to subscription queries matching given
 filter. 
- emit(Predicate<SubscriptionQueryMessage<?, ?, U>>, U) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
- 
Emits given incremental update to subscription queries matching given filter. 
- emit(Class<Q>, Predicate<? super Q>, SubscriptionQueryUpdateMessage<U>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
- 
Emits given incremental update to subscription queries matching given query type and filter. 
- emit(Class<Q>, Predicate<? super Q>, U) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
- 
Emits given incremental update to subscription queries matching given query type and filter. 
- emit(Predicate<SubscriptionQueryMessage<?, ?, U>>, SubscriptionQueryUpdateMessage<U>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
-  
- empty() - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
- 
Create an empty DomainEventStream. 
- EmptyCollectionMatcher<T> - Class in org.axonframework.test.matchers
- 
Matches any empty collection. 
- EmptyCollectionMatcher(String) - Constructor for class org.axonframework.test.matchers.EmptyCollectionMatcher
- 
Creates a matcher of a list of empty items. 
- emptyInstance() - Static method in class org.axonframework.messaging.MetaData
- 
Returns an empty MetaData instance. 
- emptyOrNull(String) - Static method in class org.axonframework.common.StringUtils
- 
Validate whether the given  Strings is  null or not empty (where empty is defined as
  ""). 
- emptyType() - Static method in interface org.axonframework.serialization.SerializedType
- 
Returns the type that represents an empty message, of undefined type. 
- emptyType() - Static method in class org.axonframework.serialization.SimpleSerializedType
- 
Returns the type that represents an empty message, of undefined type. 
- encrypt(Event) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- encryptBytes(int, byte[]) - Method in class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- end() - Method in class org.axonframework.lifecycle.ShutdownLatch.ActivityHandle
- 
Mark this activity as being finalized. 
- end() - Static method in class org.axonframework.modelling.saga.SagaLifecycle
- 
Marks the saga as ended. 
- end() - Method in class org.axonframework.tracing.NoOpSpanFactory.NoOpSpan
-  
- end() - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpan
-  
- end() - Method in interface org.axonframework.tracing.Span
- 
Ends the span. 
- endpoint() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
- 
Returns this Member's endpoint. 
- EndSaga - Annotation Type in org.axonframework.modelling.saga
- 
Indicates that the annotated  SagaEventHandler method indicates the end of a Saga instance's lifecycle. 
- EndSagaMessageHandlerDefinition - Class in org.axonframework.modelling.saga
- 
- EndSagaMessageHandlerDefinition() - Constructor for class org.axonframework.modelling.saga.EndSagaMessageHandlerDefinition
-  
- EndSagaMessageHandlerDefinition.EndSageMessageHandlingMember<T> - Class in org.axonframework.modelling.saga
- 
- EndSageMessageHandlingMember(MessageHandlingMember<T>) - Constructor for class org.axonframework.modelling.saga.EndSagaMessageHandlerDefinition.EndSageMessageHandlingMember
- 
Initializes the member using the given delegate.
 
- endScope() - Method in class org.axonframework.messaging.Scope
- 
- enqueue(Object, DeadLetter<? extends M>) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- enqueue(Object, DeadLetter<? extends M>) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- enqueue() - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- enqueue(Throwable) - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- enqueue(Throwable, Function<DeadLetter<? extends M>, MetaData>) - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- enqueue(Object, DeadLetter<? extends M>) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- enqueue(Object, DeadLetter<? extends M>) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Enqueues a  dead letter containing an implementation of  M to this queue. 
- enqueueCause() - Method in class org.axonframework.messaging.deadletter.DoNotEnqueue
-  
- enqueueCause() - Method in interface org.axonframework.messaging.deadletter.EnqueueDecision
- 
- enqueueCause() - Method in class org.axonframework.messaging.deadletter.Ignore
-  
- enqueueCause() - Method in class org.axonframework.messaging.deadletter.ShouldEnqueue
-  
- enqueuedAt() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
-  
- enqueuedAt() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. 
- enqueuedAt() - Method in interface org.axonframework.messaging.deadletter.DeadLetter
- 
- enqueuedAt() - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
-  
- EnqueueDecision<M extends Message<?>> - Interface in org.axonframework.messaging.deadletter
- 
A contract towards describing a decision among a  dead letter containing a message of type
  M. 
- enqueueIfPresent(Object, Supplier<DeadLetter<? extends M>>) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Enqueue the result of the given  letterBuilder only if there already are other
  dead letters with the same  sequenceIdentifier present in this queue. 
- enqueuePolicy(EnqueuePolicy<EventMessage<?>>) - Method in class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker.Builder
- 
- EnqueuePolicy<M extends Message<?>> - Interface in org.axonframework.messaging.deadletter
- 
- ensureAccessible(T) - Static method in class org.axonframework.common.ReflectionUtils
- 
Makes the given memberaccessible via reflection if it is not the case already.
 
- ensureConflictsResolved() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictResolver
- 
- ensureSagaResourcesInitialized() - Method in class org.axonframework.test.saga.SagaTestFixture
- 
Initializes the saga resources if it hasn't already done so. 
- entityClass() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
- 
Returns the class this model describes 
- EntityId - Annotation Type in org.axonframework.modelling.command
- 
Field or  Method annotation that marks the member containing the
 identifier of an Entity. 
- entityManager() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
- 
Provides an EntityManagerinstance for storing and fetching event data.
 
- entityManager() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. Provides an EntityManagerinstance for storing and fetching event data.
 
- EntityManagerProvider - Interface in org.axonframework.common.jpa
- 
Provides components with an EntityManager to access the persistence mechanism. 
- EntityManagerProvider - Interface in org.axonframework.common.legacyjpa
- 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
- 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore.Builder
- 
Deprecated. 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
- 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
- 
- entityManagerProvider(EntityManagerProvider) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore.Builder
- 
Deprecated. 
- entityManagerProvider() - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
-  
- entityManagerProvider() - Method in class org.axonframework.springboot.autoconfig.legacyjpa.JpaJavaxAutoConfiguration
- 
Deprecated. 
- EntityModel<T> - Interface in org.axonframework.modelling.command.inspection
- 
Interface of an entity model that describes the properties and capabilities of an entity of type T.
 
- EntryListenerAdapter() - Constructor for class org.axonframework.common.caching.Cache.EntryListenerAdapter
-  
- entrySet() - Method in class org.axonframework.messaging.MetaData
-  
- EqualFieldsMatcher<T> - Class in org.axonframework.test.matchers
- 
Matcher that will match an Object if all the fields on that Object contain values equal to the same field in the
 expected instance. 
- EqualFieldsMatcher(T) - Constructor for class org.axonframework.test.matchers.EqualFieldsMatcher
- 
Initializes an EqualFieldsMatcher that will match an object with equal properties as the given expectedobject.
 
- EqualFieldsMatcher(T, FieldFilter) - Constructor for class org.axonframework.test.matchers.EqualFieldsMatcher
- 
Initializes an EqualFieldsMatcher that will match an object with equal properties as the given expectedobject.
 
- EqualRevisionPredicate - Class in org.axonframework.eventsourcing.eventstore
- 
A predicate that matches against DomainEventDatainstances that have a revision 'equal' to the
 revision of the class is has serialized data for.
 
- EqualRevisionPredicate(RevisionResolver, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.EqualRevisionPredicate
- 
Initializes the Predicate with given resolverto resolve revision of the class represented by the
 serialized data.
 
- equals(Object) - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
-  
- equals(Object) - Method in class org.axonframework.axonserver.connector.PriorityCallable
-  
- equals(Object) - Method in class org.axonframework.axonserver.connector.PriorityRunnable
-  
- equals(Object) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.NegateCommandMessageFilter
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.OrCommandMessageFilter
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-  
- equals(Object) - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
-  
- equals(Object) - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
-  
- equals(Object) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
-  
- equals(Object) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. 
- equals(Object) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.MergedTrackingToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.ReplayToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrScheduleToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.Segment
-  
- equals(Object) - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
-  
- equals(Object) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
-  
- equals(Object) - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- equals(Object) - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
-  
- equals(Object) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
-  
- equals(Object) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-  
- equals(Object) - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
-  
- equals(Object) - Method in class org.axonframework.messaging.deadletter.ShouldEnqueue
-  
- equals(Object) - Method in exception org.axonframework.messaging.deadletter.ThrowableCause
-  
- equals(Object) - Method in class org.axonframework.messaging.MetaData
-  
- equals(Object) - Method in class org.axonframework.messaging.RemoteExceptionDescription
-  
- equals(Object) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- equals(Object) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
-  
- equals(Object) - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
-  
- equals(Object) - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
-  
- equals(Object) - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
-  
- equals(Object) - Method in class org.axonframework.modelling.saga.AssociationValue
-  
- equals(Object) - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
-  
- equals(Object) - Method in class org.axonframework.queryhandling.QuerySubscription
-  
- equals(Object) - Method in class org.axonframework.serialization.SerializedMetaData
-  
- equals(Object) - Method in class org.axonframework.serialization.SimpleSerializedObject
-  
- equals(Object) - Method in class org.axonframework.serialization.SimpleSerializedType
-  
- equals(Object) - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
-  
- equals(Object) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
-  
- equals(Object) - Method in class org.axonframework.test.server.AxonServerEEContainer
-  
- equals(Object) - Method in class org.axonframework.test.server.AxonServerSEContainer
-  
- EqualsMatcher<T> - Class in org.axonframework.test.matchers
- 
- EqualsMatcher(T) - Constructor for class org.axonframework.test.matchers.EqualsMatcher
-  
- equalTo(T) - Static method in class org.axonframework.test.matchers.EqualsMatcher
-  
- equalTo(T) - Static method in class org.axonframework.test.matchers.Matchers
- 
- equalTo(T, FieldFilter) - Static method in class org.axonframework.test.matchers.Matchers
- 
- error() - Method in class org.axonframework.eventhandling.ErrorContext
- 
Returns the error that was raised in the processor 
- error(Throwable) - Method in interface org.axonframework.queryhandling.SinkWrapper
- 
Wrapper around Sink error(Throwable). 
- errorCode() - Method in exception org.axonframework.axonserver.connector.AxonServerException
-  
- ErrorCode - Enum in org.axonframework.axonserver.connector
- 
Converts an Axon Server Error to the relevant Axon framework exception. 
- errorCode() - Method in enum org.axonframework.axonserver.connector.ErrorCode
-  
- errorCode() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
- 
- ErrorContext - Class in org.axonframework.eventhandling
- 
Describes the context of an error. 
- ErrorContext(String, Throwable, List<? extends EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.ErrorContext
- 
Instantiate an ErrorContext for the given eventProcessor, due to the givenerror, with the givenfailedEvents.
 
- errorHandler(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- errorHandler(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
- 
- ErrorHandler - Interface in org.axonframework.eventhandling
- 
Interface of the error handler that will be invoked if event processing fails. 
- errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
-  
- errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
-  
- errorHandler(ErrorHandler) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
-  
- errorHandler(QueryInvocationErrorHandler) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
- 
- errorHandlers - Variable in class org.axonframework.config.EventProcessingModule
-  
- EVENT_BUS_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
- 
The key used to locate the Event Bus in the scheduler context. 
- EVENT_JOB_DATA_BINDER_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
- 
- EVENT_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
- 
- EventBuffer - Class in org.axonframework.axonserver.connector.event.axon
- 
Client-side buffer of messages received from the server. 
- EventBuffer(EventStream, EventUpcaster, Serializer, boolean) - Constructor for class org.axonframework.axonserver.connector.event.axon.EventBuffer
- 
Initializes an Event Buffer, passing messages through given upcasterChainand deserializing events using
 givenserializer.
 
- eventBus() - Method in interface org.axonframework.config.Configuration
- 
Retrieves the Event Bus defined in this Configuration. 
- EventBus - Interface in org.axonframework.eventhandling
- 
Specification of the mechanism on which the Event Listeners can subscribe for events and event publishers can publish
 their events. 
- eventBus(EventBus) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
- 
Sets the  EventBus used to publish events. 
- eventBus(EventBus) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway.Builder
-  
- eventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
- 
Sets the  EventBus used to publish events on to, once the schedule has been met. 
- eventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler.Builder
- 
Sets the  EventBus used to publish events on once the schedule has been met. 
- eventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
- 
Sets the  EventBus used to publish events on once the schedule has been met. 
- eventBus(EventBus) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
- 
Sets the  EventBus to which events are published. 
- eventBus(EventBus) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. Sets the  EventBus to which events are published. 
- eventBus() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- eventBus(Configuration) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- eventCipher(EventCipher) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- EventCipher - Class in org.axonframework.axonserver.connector.event.util
- 
- EventCipher() - Constructor for class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- EventCipher(byte[]) - Constructor for class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- EventCipher(Function<Event, Integer>, List<byte[]>) - Constructor for class org.axonframework.axonserver.connector.event.util.EventCipher
- 
Deprecated. 
- EventConsumer<T> - Interface in org.axonframework.test.eventscheduler
- 
A consumer that allows implementations to throw exceptions. 
- EventCountSnapshotTriggerDefinition - Class in org.axonframework.eventsourcing
- 
Snapshotter trigger mechanism that counts the number of events to decide when to create a snapshot. 
- EventCountSnapshotTriggerDefinition(Snapshotter, int) - Constructor for class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
- 
Initialized the SnapshotTriggerDefinition to threshold snapshots using the given snapshotterwhenthresholdevents have been applied to an Aggregate instance
 
- EventData<T> - Interface in org.axonframework.eventhandling
- 
Interface describing the properties of serialized Event Messages. 
- eventFlowControl(int, int, int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- eventGateway() - Method in interface org.axonframework.config.Configuration
- 
Returns the Event Gateway defined in this Configuration. 
- EventGateway - Interface in org.axonframework.eventhandling.gateway
- 
Interface towards the Event Handling components of an application. 
- eventGateway(EventBus) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- eventHandled(EventMessage<?>) - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
-  
- eventHandled(EventMessage<?>) - Method in interface org.axonframework.eventsourcing.SnapshotTrigger
- 
Invoked when an event is handled by an aggregate. 
- EventHandler - Annotation Type in org.axonframework.eventhandling
- 
Annotation to be placed on methods that can handle events. 
- eventHandlerInvoker(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
- 
- eventHandlerInvoker() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
- 
Returns the invoker assigned to this processor. 
- EventHandlerInvoker - Interface in org.axonframework.eventhandling
- 
Interface for an event message handler that defers handling to one or more other handlers. 
- eventHandlerInvoker(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
-  
- eventHandlerInvoker(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
-  
- eventHandlerInvoker(EventHandlerInvoker) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
-  
- EventHandlerRegistrar - Class in org.axonframework.spring.config
- 
- EventHandlerRegistrar(AxonConfiguration, ModuleConfiguration, EventProcessingConfigurer) - Constructor for class org.axonframework.spring.config.EventHandlerRegistrar
- 
Deprecated. Initialize the registrar to register beans discovered with the given eventProcessing.
 
- eventHandlers(Object...) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
- 
- eventHandlers(List<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
- 
- eventHandlers() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
- 
- eventIdentifierColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the event identifier column. 
- eventIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the identifier of the event. 
- EventJobDataBinder - Interface in org.axonframework.eventhandling.scheduling.quartz
- 
Strategy towards reading/writing an Axon EventMessage from/to a Quartz JobDataMap.
 
- EventLoggingInterceptor - Class in org.axonframework.eventhandling.interceptors
- 
Message Dispatch Interceptor that logs published events to a SLF4J logger. 
- EventLoggingInterceptor() - Constructor for class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
- 
Initialize the LoggingInterceptor with the default logger name, which is the fully qualified class name of this
 logger. 
- EventLoggingInterceptor(String) - Constructor for class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
- 
Initialize the interceptor with the given loggerName.
 
- eventMatching(Predicate<? super T>) - Static method in class org.axonframework.eventsourcing.conflictresolution.Conflicts
- 
Returns a  Predicate for a  ConflictResolver that responds affirmative if any event in a list of
 unseen events matches the given  messageFilter. 
- EventMessage<T> - Interface in org.axonframework.eventhandling
- 
Represents a Message wrapping an Event, which is represented by its payload. 
- EventMessageConverter - Interface in org.axonframework.spring.messaging
- 
Interface describing a mechanism that converts Spring Messages from an Axon Event Messages and vice versa. 
- EventMessageDeadLetterJpaConverter - Class in org.axonframework.eventhandling.deadletter.jpa
- 
- EventMessageDeadLetterJpaConverter() - Constructor for class org.axonframework.eventhandling.deadletter.jpa.EventMessageDeadLetterJpaConverter
-  
- EventMessageDeadLetterJpaConverter - Class in org.axonframework.eventhandling.deadletter.legacyjpa
- 
- EventMessageDeadLetterJpaConverter() - Constructor for class org.axonframework.eventhandling.deadletter.legacyjpa.EventMessageDeadLetterJpaConverter
- 
Deprecated. 
- EventMessageHandler - Interface in org.axonframework.eventhandling
- 
Interface to be implemented by classes that can handle events. 
- EventMultiUpcaster - Class in org.axonframework.serialization.upcasting.event
- 
Abstract implementation of a  SingleEntryMultiUpcaster and an  EventUpcaster that eases the common
 process of upcasting one intermediate event representation to several other representations by applying a flat
 mapping function to the input stream of intermediate representations. 
- EventMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.EventMultiUpcaster
-  
- eventProcessing() - Method in interface org.axonframework.config.Configurer
- 
- eventProcessing(Consumer<EventProcessingConfigurer>) - Method in interface org.axonframework.config.Configurer
- 
Locates the  EventProcessingConfigurer registered as a module with this Configurer and provides it to the
 given consumer for configuration. 
- eventProcessing() - Method in class org.axonframework.config.DefaultConfigurer
-  
- EventProcessingAutoConfiguration - Class in org.axonframework.springboot.autoconfig
- 
- EventProcessingAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.EventProcessingAutoConfiguration
-  
- eventProcessingConfiguration - Variable in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
-  
- eventProcessingConfiguration() - Method in interface org.axonframework.config.Configuration
- 
- EventProcessingConfiguration - Interface in org.axonframework.config
- 
Defines a contract for accessor methods regarding event processing configuration. 
- eventProcessingConfiguration() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- EventProcessingConfigurer - Interface in org.axonframework.config
- 
Defines a contract for configuring event processing. 
- EventProcessingConfigurer.DeadLetteringInvokerConfiguration - Interface in org.axonframework.config
- 
- EventProcessingConfigurer.EventProcessorBuilder - Interface in org.axonframework.config
- 
Contract which defines how to build an event processor. 
- EventProcessingConfigurer.PooledStreamingProcessorConfiguration - Interface in org.axonframework.config
- 
- EventProcessingException - Exception in org.axonframework.eventhandling
- 
Exception thrown when an  EventProcessor failed to handle a batch of events. 
- EventProcessingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.EventProcessingException
- 
Initialize the exception with given messageandcause.
 
- EventProcessingModule - Class in org.axonframework.config
- 
Event processing module configuration. 
- EventProcessingModule() - Constructor for class org.axonframework.config.EventProcessingModule
-  
- eventProcessingModule() - Method in class org.axonframework.springboot.autoconfig.EventProcessingAutoConfiguration
-  
- EventProcessingStrategy - Interface in org.axonframework.eventhandling
- 
Interface describing a strategy for the processing of a batch of events. 
- eventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- eventProcessor(String, Class<T>) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
Returns the  EventProcessor with the given  name if present, matching the given  expectedType. 
- eventProcessor() - Method in interface org.axonframework.config.SagaConfiguration
- 
Gets the  EventProcessor responsible for delivering events to this Saga. 
- eventProcessor() - Method in class org.axonframework.eventhandling.ErrorContext
- 
Returns the name of the Event Processor where the error occurred. 
- EventProcessor - Interface in org.axonframework.eventhandling
- 
An Event Processor processes event messages from an event queue or event bus. 
- eventProcessorByProcessingGroup(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- eventProcessorByProcessingGroup(String, Class<T>) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
Returns an  EventProcessor by the given  processingGroup if present, matching the given  expectedType. 
- eventProcessorByProcessingGroup(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- EventProcessorControlService - Class in org.axonframework.axonserver.connector.processor
- 
Service that listens to  PlatformOutboundInstructions to control  EventProcessors when for example
 requested by Axon Server. 
- EventProcessorControlService(AxonServerConnectionManager, EventProcessingConfiguration, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.processor.EventProcessorControlService
- 
- EventProcessorControlService(AxonServerConnectionManager, EventProcessingConfiguration, String) - Constructor for class org.axonframework.axonserver.connector.processor.EventProcessorControlService
- 
- EventProcessorControlService.AxonProcessorInstructionHandler - Class in org.axonframework.axonserver.connector.processor
-  
- EventProcessorInfoConfiguration - Class in org.axonframework.axonserver.connector.event.axon
- 
Module Configuration implementation that defines the components needed to control and monitor the  EventProcessors with AxonServer. 
- EventProcessorInfoConfiguration() - Constructor for class org.axonframework.axonserver.connector.event.axon.EventProcessorInfoConfiguration
- 
- EventProcessorInfoConfiguration(Function<Configuration, EventProcessingConfiguration>, Function<Configuration, AxonServerConnectionManager>, Function<Configuration, AxonServerConfiguration>) - Constructor for class org.axonframework.axonserver.connector.event.axon.EventProcessorInfoConfiguration
- 
- EventProcessorInfoConfiguration(Function<Configuration, EventProcessorControlService>) - Constructor for class org.axonframework.axonserver.connector.event.axon.EventProcessorInfoConfiguration
- 
- EventProcessorLatencyMonitor - Class in org.axonframework.metrics
- 
- EventProcessorLatencyMonitor() - Constructor for class org.axonframework.metrics.EventProcessorLatencyMonitor
- 
- EventProcessorLatencyMonitor(Clock) - Constructor for class org.axonframework.metrics.EventProcessorLatencyMonitor
- 
- EventProcessorLatencyMonitor - Class in org.axonframework.micrometer
- 
- EventProcessorLatencyMonitor(EventProcessorLatencyMonitor.Builder) - Constructor for class org.axonframework.micrometer.EventProcessorLatencyMonitor
- 
- EventProcessorLatencyMonitor.Builder - Class in org.axonframework.micrometer
- 
- EventProcessorProperties - Class in org.axonframework.springboot
- 
Properties describing the settings for Event Processors. 
- EventProcessorProperties() - Constructor for class org.axonframework.springboot.EventProcessorProperties
-  
- EventProcessorProperties.Mode - Enum in org.axonframework.springboot
- 
- EventProcessorProperties.ProcessorSettings - Class in org.axonframework.springboot
-  
- eventProcessors() - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- eventProcessors - Variable in class org.axonframework.config.EventProcessingModule
-  
- eventProcessors() - Method in class org.axonframework.config.EventProcessingModule
-  
- EventProcessorTask - Class in org.axonframework.eventhandling.async
- 
Scheduler that keeps track of (Event processing) tasks that need to be executed sequentially. 
- EventProcessorTask(Executor, EventProcessorTask.ShutdownCallback) - Constructor for class org.axonframework.eventhandling.async.EventProcessorTask
- 
Initialize a scheduler using the given executor.
 
- EventProcessorTask.ShutdownCallback - Interface in org.axonframework.eventhandling.async
- 
Callback that allows the SequenceManager to receive a notification when this scheduler finishes processing
 events. 
- EventPublicationFailedException - Exception in org.axonframework.messaging
- 
Exception indication that an error occurred while publishing an event to an AMQP Broker 
- EventPublicationFailedException(String, Throwable) - Constructor for exception org.axonframework.messaging.EventPublicationFailedException
- 
Initialize the exception using given descriptive messageandcause
 
- EventPublisher - Class in org.axonframework.disruptor.commandhandling
- 
Component of the DisruptorCommandBus that stores and publishes events generated by the command's execution. 
- EventPublisher(Executor, TransactionManager, RollbackConfiguration, int) - Constructor for class org.axonframework.disruptor.commandhandling.EventPublisher
- 
Initializes the EventPublisher to publish Events to the given eventStoreandeventBusfor
 aggregate of givenaggregateType.
 
- eventScheduler() - Method in interface org.axonframework.config.Configuration
- 
- EventScheduler - Interface in org.axonframework.eventhandling.scheduling
- 
Interface towards a mechanism capable of scheduling the publication of events. 
- eventScheduler(Serializer, AxonServerConnectionManager) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- EventSchedulerValidator - Class in org.axonframework.test.eventscheduler
- 
Helper class for validating events scheduled in a given event scheduler. 
- EventSchedulerValidator(StubEventScheduler) - Constructor for class org.axonframework.test.eventscheduler.EventSchedulerValidator
- 
Initializes the validator to validate the state of the given eventScheduler.
 
- EventSchema - Class in org.axonframework.eventsourcing.eventstore.jdbc
- 
Schema of an event entry to be stored using Jdbc. 
- EventSchema() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Initializes the default Event Schema 
- EventSchema.Builder - Class in org.axonframework.eventsourcing.eventstore.jdbc
- 
Builder for an  EventSchema that gets initialized with default values. 
- eventSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
- 
- eventSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
- 
Sets the  Serializer used to serialize and deserialize the Event Message's payload and Meta Data with. 
- eventSerializer() - Method in interface org.axonframework.config.Configuration
- 
Returns the  Serializer defined in this Configuration to be used for serializing Event Message payload
 and their metadata. 
- eventSerializer(Serializer) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
Sets the  Serializer to (de)serialize the event payload,
 event metadata, and diagnostics of the  DeadLetter when storing it to the database. 
- eventSerializer(Serializer) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. Sets the  Serializer to (de)serialize the event payload, event metadata, and diagnostics of the
  DeadLetter when storing it to the database. 
- eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
- 
Sets the  Serializer used to serialize and deserialize the Event Message's payload and  MetaData with. 
- eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
-  
- eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-  
- eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-  
- eventSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. 
- eventSerializer() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- eventSerializer(Serializer, Serializer, RevisionResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- EventSourcedAggregate<T> - Class in org.axonframework.eventsourcing
- 
Implementation of an  Aggregate that is sourced from events that have
 been published by the aggregate. 
- EventSourcedAggregate(T, AggregateModel<T>, EventBus, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Initializes an Aggregate instance for the given aggregateRoot, based on the givenmodel, which
 publishes events to the giveneventBus.
 
- EventSourcedAggregate(T, AggregateModel<T>, EventBus, RepositoryProvider, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Initializes an Aggregate instance for the given aggregateRoot, based on the givenmodel, which
 publishes events to the giveneventBus.
 
- EventSourcedAggregate(AggregateModel<T>, EventBus, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Creates a new EventSourcedAggregate instance based on the given model, which publishes events to the
 giveneventBus.
 
- EventSourcedAggregate(AggregateModel<T>, EventBus, RepositoryProvider, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Creates a new EventSourcedAggregate instance based on the given model, which publishes events to the
 giveneventBus.
 
- EventSourcingHandler - Annotation Type in org.axonframework.eventsourcing
- 
Annotation that marks a method in an Aggregate (either the root, or an entity) as a handler for Events generated by
 that aggregate. 
- EventSourcingRepository<T> - Class in org.axonframework.eventsourcing
- 
Abstract repository implementation that allows easy implementation of an Event Sourcing mechanism. 
- EventSourcingRepository(EventSourcingRepository.Builder<T>) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
- 
- EventSourcingRepository.Builder<T> - Class in org.axonframework.eventsourcing
- 
- EventStorageEngine - Interface in org.axonframework.eventsourcing.eventstore
- 
Provides a mechanism to append as well as retrieve events from an underlying storage like a database. 
- eventStorageEngine(Serializer, PersistenceExceptionResolver, Serializer, Configuration, ConnectionProvider, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
-  
- eventStorageEngine(Serializer, PersistenceExceptionResolver, Serializer, Configuration, EntityManagerProvider, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.JpaEventStoreAutoConfiguration
-  
- eventStorageEngine(Serializer, PersistenceExceptionResolver, Serializer, Configuration, EntityManagerProvider, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.legacyjpa.JpaJavaxEventStoreAutoConfiguration
- 
Deprecated. 
- eventStore() - Method in interface org.axonframework.config.Configuration
- 
Returns the Event Store in this Configuration, if it is defined. 
- eventStore(EventStore) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
- 
- eventStore(EventStore) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
-  
- eventStore - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- eventStore(EventStore) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
- 
Sets the  EventStore that holds the event stream this repository needs to event source an Aggregate. 
- EventStore - Interface in org.axonframework.eventsourcing.eventstore
- 
Provides a mechanism to open streams from events in the the underlying event storage. 
- eventStore(EventStore) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
-  
- eventStore(EventStorageEngine, Configuration) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- eventStore(AxonServerConfiguration, Configuration, AxonServerConnectionManager, Serializer, Serializer) - Method in class org.axonframework.springboot.autoconfig.AxonServerBusAutoConfiguration
-  
- EventStoreClientException - Exception in org.axonframework.axonserver.connector.event.util
- 
- EventStoreClientException(String, String) - Constructor for exception org.axonframework.axonserver.connector.event.util.EventStoreClientException
- 
Deprecated. 
- EventStoreClientException(String, String, Throwable) - Constructor for exception org.axonframework.axonserver.connector.event.util.EventStoreClientException
- 
Deprecated. 
- EventStoreException - Exception in org.axonframework.eventsourcing.eventstore
- 
Indicates that the given events stream could not be stored or read due to an underlying exception. 
- EventStoreException(String) - Constructor for exception org.axonframework.eventsourcing.eventstore.EventStoreException
- 
Initialize the exception with the given message.
 
- EventStoreException(String, Throwable) - Constructor for exception org.axonframework.eventsourcing.eventstore.EventStoreException
- 
Initialize the exception with the given messageandcause
 
- eventStreamFilter - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- eventStreamFilter(Predicate<? super DomainEventMessage<?>>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
- 
Sets the  Predicate used to filter events when reading from the EventStore. 
- EventStreamUtils - Class in org.axonframework.eventsourcing
- 
Utility class for dealing with event streams. 
- eventTable(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the domain events table. 
- EventTableFactory - Interface in org.axonframework.eventsourcing.eventstore.jdbc
- 
Interface describing a factory for JDBC to create the Domain and Snapshot Event tables. 
- EventTrackerStatus - Interface in org.axonframework.eventhandling
- 
- EventTrackerStatusChangeListener - Interface in org.axonframework.eventhandling
- 
- EventTypeUpcaster - Class in org.axonframework.serialization.upcasting.event
- 
- EventTypeUpcaster(String, String, String, String) - Constructor for class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
- 
Instantiate an  EventTypeUpcaster using the given expected and upcasted payload types and revisions. 
- EventTypeUpcaster.Builder - Class in org.axonframework.serialization.upcasting.event
- 
- EventUpcaster - Interface in org.axonframework.serialization.upcasting.event
- 
Interface that is used for upcasters of event data. 
- EventUpcasterChain - Class in org.axonframework.serialization.upcasting.event
- 
- EventUpcasterChain(EventUpcaster...) - Constructor for class org.axonframework.serialization.upcasting.event.EventUpcasterChain
- 
Initializes an upcaster chain from one or more upcasters. 
- EventUpcasterChain(List<? extends EventUpcaster>) - Constructor for class org.axonframework.serialization.upcasting.event.EventUpcasterChain
- 
Initializes an upcaster chain from the given list of upcasters. 
- eventUpcastersConfigurer(List<EventUpcaster>) - Method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- EventUtils - Class in org.axonframework.eventhandling
- 
Utility class for dealing with events. 
- EventValidator - Class in org.axonframework.test.saga
- 
Helper class for validating events published on a given EventBus. 
- EventValidator(EventBus, FieldFilter) - Constructor for class org.axonframework.test.saga.EventValidator
- 
Initializes the event validator to monitor the given eventBus.
 
- evict(DeadLetter<? extends M>) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- evict(DeadLetter<? extends M>) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- evict() - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- evict(DeadLetter<? extends M>) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- evict(DeadLetter<? extends M>) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Evict the given letterfrom this queue.
 
- ExactClassMatcher<T> - Class in org.axonframework.test.matchers
- 
Matcher testing for exact classes. 
- ExactClassMatcher(Class<T>) - Constructor for class org.axonframework.test.matchers.ExactClassMatcher
- 
Construct a  ExactClassMatcher that will match an  actual value with the given  expectedClass. 
- exactClassOf(Class<T>) - Static method in class org.axonframework.test.matchers.ExactClassMatcher
- 
Construct a  ExactClassMatcher that will match an  actual value with the given  expectedClass. 
- exactClassOf(Class<T>) - Static method in class org.axonframework.test.matchers.Matchers
- 
Returns a Matcher that matches with exact class type defined by the given expected.
 
- ExactSequenceMatcher<T> - Class in org.axonframework.test.matchers
- 
A matcher that will match if all the given matchersagainst the event in a list at their respective
 index.
 
- ExactSequenceMatcher(Matcher<? super T>...) - Constructor for class org.axonframework.test.matchers.ExactSequenceMatcher
- 
Construct a matcher that will return true if all the given matchersmatch against the event with
 the same index in a given List if Events.
 
- exactSequenceOf(Matcher<T>...) - Static method in class org.axonframework.test.matchers.Matchers
- 
Matches a List of Events if each of the given matchersmatches against the event at the respective
 index in the list.
 
- exceedsThreshold() - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
- 
This method is used to determine if a new snapshot should be created 
- EXCEPTION_RESULT_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the exception result type the handler can handle. 
- exceptionDetails() - Method in interface org.axonframework.messaging.ResultMessage
- 
If the this message contains an exception result, returns the details provided in the exception, if available. 
- ExceptionHandler - Annotation Type in org.axonframework.messaging.interceptors
- 
Annotation marking a Handler as an interceptor for other handlers that is only interested in handling
 exception results. 
- exceptionResult() - Method in interface org.axonframework.messaging.ResultMessage
- 
Returns the exception result. 
- exceptionRevision - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- ExceptionSerializer - Class in org.axonframework.axonserver.connector.util
- 
Utility class used to serializer  Throwables into  ErrorMessages. 
- exceptionType - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- ExceptionUtils - Class in org.axonframework.common
- 
Exception utility methods. 
- execute(Runnable) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- execute(Runnable) - Method in class org.axonframework.common.DirectExecutor
- 
Executes the given commandimmediately in the current thread.
 
- execute(String) - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager
- 
This function should only be called via Jobrunr when a deadline was triggered. 
- execute(JobExecutionContext) - Method in class org.axonframework.deadline.quartz.DeadlineJob
-  
- execute(JobExecutionContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
-  
- execute(Runnable) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Execute the given taskin the context of this Unit of Work.
 
- execute(Runnable, RollbackConfiguration) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Execute the given taskin the context of this Unit of Work.
 
- execute(Consumer<T>) - Method in interface org.axonframework.modelling.command.Aggregate
- 
Execute a method on the underlying aggregate or one of its instances. 
- execute(Runnable) - Method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Executes the given task. 
- execute(Consumer<T>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- execute(Consumer<AR>) - Method in class org.axonframework.modelling.command.LockAwareAggregate
-  
- execute(Consumer<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-  
- execute(Consumer<T>) - Method in interface org.axonframework.modelling.saga.Saga
- 
Execute the given invocationagainst the root object of this Saga instance.
 
- execute(Runnable) - Method in class org.axonframework.modelling.saga.SagaLifecycle
- 
SagaLifecycle instance method to execute given  task in the context of this SagaLifeCycle. 
- executeBatch(Connection, JdbcUtils.SqlFunction, Consumer<SQLException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
- 
Execute the a batch update or insert statement produced by the given sqlFunction.
 
- executeInTransaction(Runnable) - Method in interface org.axonframework.common.transaction.TransactionManager
- 
- executeQuery(Connection, JdbcUtils.SqlFunction, JdbcUtils.SqlResultConverter<R>, Function<SQLException, RuntimeException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
- 
Execute the query given by the sqlFunction.
 
- executeQuery(Connection, JdbcUtils.SqlFunction, JdbcUtils.SqlResultConverter<R>, Function<SQLException, RuntimeException>, boolean) - Static method in class org.axonframework.common.jdbc.JdbcUtils
- 
Execute the query given by the sqlFunction.
 
- executeUntilTrue(BooleanSupplier, long, long) - Static method in class org.axonframework.common.ProcessUtils
- 
Executes an action, with potential retry in case the result is false. 
- executeUpdate(Connection, JdbcUtils.SqlFunction, Function<SQLException, RuntimeException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
- 
Execute the update statement produced by the given updateFunction.
 
- executeUpdates(Connection, Consumer<SQLException>, JdbcUtils.SqlFunction...) - Static method in class org.axonframework.common.jdbc.JdbcUtils
- 
Execute the update statements produced by the given sqlFunctions.
 
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
- 
Execute the given taskin the context of this Unit of Work.
 
- executeWithResult(Callable<V>) - Method in class org.axonframework.messaging.Scope
- 
Scope instance method to execute given  task of type  Callable in the context of this
 Scope. 
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
- 
Execute the given taskin the context of this Unit of Work.
 
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-  
- executeWithResult(Callable<R>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Execute the given taskin the context of this Unit of Work.
 
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Execute the given taskin the context of this Unit of Work.
 
- executeWithRetry(Runnable, Predicate<RuntimeException>, long, TimeUnit, long) - Static method in class org.axonframework.common.ProcessUtils
- 
Executes an action, with potential retry in case of an exception. 
- ExecutionException - Exception in org.axonframework.messaging
- 
Exception thrown to indicate that execution of a task has failed. 
- ExecutionException(String, Throwable) - Constructor for exception org.axonframework.messaging.ExecutionException
- 
Initialize an ExecutionException with the given messageandcause.
 
- ExecutionResult - Class in org.axonframework.messaging.unitofwork
- 
Class of objects that contain the result of an executed task. 
- ExecutionResult(ResultMessage<?>) - Constructor for class org.axonframework.messaging.unitofwork.ExecutionResult
- 
- executor(Executor) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
- 
Sets the  Executor which processes the Command dispatching threads. 
- executor(Executor) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- executor(Executor) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
- 
Sets the  Executor which handles the actual snapshot creation process. 
- executor(Executor) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
-  
- executor(Executor) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
-  
- executorServiceBuilder(ExecutorServiceBuilder) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
- executorServiceBuilder(ExecutorServiceBuilder) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
- ExecutorServiceBuilder - Interface in org.axonframework.axonserver.connector.util
- 
- expectActiveSagas(int) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Expect the given number of Sagas to be active (i.e. 
- expectActiveSagas(int) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectAssociationWith(String, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that at least one of the active sagas is associated with the given associationKeyandassociationValue.
 
- expectAssociationWith(String, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectDeadlinesMet(Object...) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
- expectDeadlinesMet(Object...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectDeadlinesMet(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
- expectDeadlinesMet(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
- expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
- expectDeadlinesMetMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectDispatchedCommands(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that the given commands have been dispatched in exactly the order given. 
- expectDispatchedCommands(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectDispatchedCommandsMatching(Matcher<? extends List<? super CommandMessage<?>>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that the sagas dispatched commands as defined by the given matcher.
 
- expectDispatchedCommandsMatching(Matcher<? extends List<? super CommandMessage<?>>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectedResponseType - Variable in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- expectedSourceType() - Method in class org.axonframework.serialization.ChainedConverter
-  
- expectedSourceType() - Method in interface org.axonframework.serialization.ContentTypeConverter
- 
The expected type of input data. 
- expectedSourceType() - Method in class org.axonframework.serialization.converters.BlobToInputStreamConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.converters.ByteArrayToStringConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.converters.StringToByteArrayConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.json.JsonNodeToObjectNodeConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.json.ObjectNodeToJsonNodeConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.xml.InputStreamToDom4jConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.xml.InputStreamToXomConverter
-  
- expectedSourceType() - Method in class org.axonframework.serialization.xml.XomToStringConverter
-  
- expectedVersion() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
- 
The expected version, as indicated when loading the aggregate 
- expectedVersion() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
-  
- expectEvents(Object...) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the given set of events to have been published. 
- expectEvents(EventMessage<?>...) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the given set of events to have been published. 
- expectEvents(Object...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectEvents(EventMessage<?>...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the published events to match the given matcher.
 
- expectEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectException(Class<? extends Throwable>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the given expectedExceptionto occur during command handler execution.
 
- expectException(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect an exception to occur during command handler execution that matches with the given matcher.
 
- expectException(Class<? extends Throwable>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectException(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectExceptionDetails(Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the given exceptionDetailsto occur during command handler execution.
 
- expectExceptionDetails(Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the given exceptionDetailstype to occur during command handler execution.
 
- expectExceptionDetails(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect exception details to occur during command handler execution that matches with the given matcher.
 
- expectExceptionDetails(Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectExceptionDetails(Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectExceptionDetails(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectExceptionMessage(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect an exception message to occur during command handler execution that matches with the given matcher.
 
- expectExceptionMessage(String) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the given exceptionMessageto occur during command handler execution.
 
- expectExceptionMessage(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectExceptionMessage(String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectMarkedDeleted() - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that the Aggregate has been marked for deletion. 
- expectMarkedDeleted() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoAssociationWith(String, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that at none of the active sagas is associated with the given associationKeyandassociationValue.
 
- expectNoAssociationWith(String, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoDispatchedCommands() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that the sagas did not dispatch any commands. 
- expectNoDispatchedCommands() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoEvents() - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect no events to have been published from the command. 
- expectNoScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline equal to the given deadlinehas been scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline equal to the given deadlinehas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadline(Instant, Instant, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline equal to the given deadlinehas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadline(Instant, Instant, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline equal to the given deadlinehas been scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline equal to the given deadlinehas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadline(Instant, Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline equal to the given deadlinehas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadline(Instant, Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline matching the given matcheris scheduled.
 
- expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline matching the given matchershould be scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline matching the given matcherhas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadlineMatching(Instant, Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline matching the given matcherhas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineMatching(Instant, Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline matching the given matcheris scheduled.
 
- expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline matching the given matchershould be scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline matching the given matcherhas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadlineMatching(Instant, Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline matching the given matcherhas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadlineMatching(Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineMatching(Instant, Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline of the given deadlineTypehas been scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline with the given deadlineTypehas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadlineOfType(Instant, Instant, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline with the given deadlineTypehas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineOfType(Instant, Instant, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline of the given deadlineTypehas been scheduled at the givendurationToScheduledTime.
 
- expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline with the given deadlineTypehas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadlineOfType(Instant, Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline with the given deadlineTypehas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineOfType(Instant, Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlines() - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadlines are scheduled. 
- expectNoScheduledDeadlines() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlines() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadlines are scheduled. 
- expectNoScheduledDeadlines() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline with the given deadlineNamehas been scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline with the given deadlineNamehas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadlineWithName(Instant, Instant, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that no deadline with the given deadlineNamehas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineWithName(Instant, Instant, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectNoScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline with the given deadlineNamehas been scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline with the given deadlineNamehas been scheduled at the givenscheduledTime.
 
- expectNoScheduledDeadlineWithName(Instant, Instant, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no deadline with the given deadlineNamehas been scheduled between thetoandfromtimes, wheretoandfromare inclusive.
 
- expectNoScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledDeadlineWithName(Instant, Instant, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledEvent(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no event equal to the given eventhas been scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledEvent(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no event equal to the given eventhas been scheduled at the givenscheduledTime.
 
- expectNoScheduledEvent(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledEvent(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no event matching the given matcherhas been scheduled to be published after the
 givendurationToScheduledTime.
 
- expectNoScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no event matching the given matcherhas been scheduled at the givenscheduledTime.
 
- expectNoScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledEventOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no event of the given eventTypehas been scheduled after the givendurationToScheduledTime.
 
- expectNoScheduledEventOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that no event with the given eventTypehas been scheduled at the givenscheduledTime.
 
- expectNoScheduledEventOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledEventOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNoScheduledEvents() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Assert that no events are scheduled for publication. 
- expectNoScheduledEvents() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectNotMarkedDeleted() - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that the Aggregate has NOT been marked for deletion. 
- expectNotMarkedDeleted() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectPublishedEvents(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Assert that the saga published events on the EventBus in the exact sequence of the given expectedevents.
 
- expectPublishedEvents(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectPublishedEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Assert that the saga published events on the EventBus as defined by the given matcher.
 
- expectPublishedEventsMatching(Matcher<? extends List<? super EventMessage<?>>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectReply - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-  
- expectResultMessage(CommandResultMessage<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the command handler to return the given expectedResultMessageafter execution.
 
- expectResultMessage(CommandResultMessage<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectResultMessageMatching(Matcher<? super CommandResultMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the command handler to return a value that matches the given matcherafter execution.
 
- expectResultMessageMatching(Matcher<? super CommandResultMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectResultMessagePayload(Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the command handler to return the given expectedPayloadafter execution.
 
- expectResultMessagePayload(Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectResultMessagePayloadMatching(Matcher<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect the command handler to return a payload that matches the given matcherafter execution.
 
- expectResultMessagePayloadMatching(Matcher<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline equal to the given deadlinehas been scheduled after the givenduration.
 
- expectScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline equal to the given deadlinehas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadline(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline equal to the given deadlinehas been scheduled after the givenduration.
 
- expectScheduledDeadline(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline equal to the given deadlinehas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadline(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledDeadline(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline scheduled after given durationmatches the givenmatcher.
 
- expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline matching the given matcherhas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline scheduled after given durationmatches the givenmatcher.
 
- expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline matching the given matcherhas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadlineMatching(Duration, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledDeadlineMatching(Instant, Matcher<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline of the given deadlineTypehas been scheduled after the givenduration.
 
- expectScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline of the given deadlineTypehas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadlineOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline of the given deadlineTypehas been scheduled after the givenduration.
 
- expectScheduledDeadlineOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline of the given deadlineTypehas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadlineOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledDeadlineOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline with the given deadlineNamehas been scheduled after the givenduration.
 
- expectScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that a deadline with the given deadlineNamehas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectScheduledDeadlineWithName(Duration, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline with the given deadlineNamehas been scheduled after the givenduration.
 
- expectScheduledDeadlineWithName(Instant, String) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that a deadline with the given deadlineNamehas been scheduled at the givenscheduledTime.
 
- expectScheduledDeadlineWithName(Duration, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledDeadlineWithName(Instant, String) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledEvent(Duration, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that an event equal to the given eventhas been scheduled for publication after the givenduration.
 
- expectScheduledEvent(Instant, Object) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that an event equal to the given eventhas been scheduled for publication at the givenscheduledTime.
 
- expectScheduledEvent(Duration, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledEvent(Instant, Object) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that an event matching the given matcherhas been scheduled to be published after the givenduration.
 
- expectScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that an event matching the given matcherhas been scheduled to be published at the givenscheduledTime.
 
- expectScheduledEventMatching(Duration, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledEventMatching(Instant, Matcher<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledEventOfType(Duration, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that an event of the given eventTypehas been scheduled for publication after the givenduration.
 
- expectScheduledEventOfType(Instant, Class<?>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that an event of the given eventTypehas been scheduled for publication at the givenscheduledTime.
 
- expectScheduledEventOfType(Duration, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectScheduledEventOfType(Instant, Class<?>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectState(Consumer<T>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Provides access the the state of the Aggregate as it was stored in the repository, allowing for validation of the
 state of the aggregate, as it was left in the repository. 
- expectState(Consumer<T>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectSuccessfulHandlerExecution() - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Expect a successful execution of the given command handler, regardless of the actual return value. 
- expectSuccessfulHandlerExecution() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectSuccessfulHandlerExecution() - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Expect a successful execution of the given event handler. 
- expectSuccessfulHandlerExecution() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectTriggeredDeadlines(Object...) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that given expecteddeadlines have been triggered.
 
- expectTriggeredDeadlines(Object...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectTriggeredDeadlines(Object...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that given expecteddeadlines have been triggered.
 
- expectTriggeredDeadlines(Object...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectTriggeredDeadlinesMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that deadlines matching the given matcherhave been triggered for this aggregate.
 
- expectTriggeredDeadlinesMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectTriggeredDeadlinesMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that deadlines matching the given matcherhave been triggered for this aggregate.
 
- expectTriggeredDeadlinesMatching(Matcher<? extends List<? super DeadlineMessage<?>>>) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectTriggeredDeadlinesOfType(Class<?>...) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that the given expectedDeadlineTypeshave been triggered.
 
- expectTriggeredDeadlinesOfType(Class<?>...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectTriggeredDeadlinesOfType(Class<?>...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that the given expectedDeadlineTypeshave been triggered.
 
- expectTriggeredDeadlinesOfType(Class<?>...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- expectTriggeredDeadlinesWithName(String...) - Method in interface org.axonframework.test.aggregate.ResultValidator
- 
Asserts that the given expectedDeadlineNameshave been triggered.
 
- expectTriggeredDeadlinesWithName(String...) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-  
- expectTriggeredDeadlinesWithName(String...) - Method in interface org.axonframework.test.saga.FixtureExecutionResult
- 
Asserts that the given expectedDeadlineNameshave been triggered.
 
- expectTriggeredDeadlinesWithName(String...) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-  
- explicitFlush(boolean) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
Sets the explicitFlushfield specifying whether to explicitly callEntityManager.flush()after inserting the Events published in this Unit of Work.
 
- explicitFlush(boolean) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. Sets the explicitFlushfield specifying whether to explicitly callEntityManager.flush()after inserting the Events published in this Unit of Work.
 
- explicitlyUnequal(Object, Object) - Static method in class org.axonframework.common.ReflectionUtils
- 
Indicates whether the two given objects are  not the same, override an equals method that indicates
 they are  not equal, or implements  Comparable which indicates the two are not equal. 
- ExponentialBackOffIntervalRetryScheduler - Class in org.axonframework.commandhandling.gateway
- 
A RetryScheduler that uses a backoff strategy, retrying commands at increasing intervals when they fail because of
 an exception that is not explicitly non-transient. 
- ExponentialBackOffIntervalRetryScheduler(ExponentialBackOffIntervalRetryScheduler.Builder) - Constructor for class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler
- 
- ExponentialBackOffIntervalRetryScheduler.Builder - Class in org.axonframework.commandhandling.gateway
- 
- extendClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- extendClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- extendClaim(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Extends the claim on the current token held by the this node for the given processorNameandsegment.
 
- extendedGapCheckEnabled(boolean) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
Indicates whether an extra query should be performed to verify for gaps in the globalSequencelarger
 than the configured batch size.
 
- EXTERNAL_CONNECTIONS - Static variable in class org.axonframework.lifecycle.Phase
- 
Phase to start or shutdown all external connections. 
- extract(ResultSet, int, Class<T>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
- 
Returns the object read from the resultSet, which object can benull, at the given column (base 1).
 
- extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
- 
Extracts the AssociationValues from the given eventas relevant for a Saga of givensagaType.
 
- extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager
-  
- extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
- 
Extracts the Child Entity contained in the given  declaringEntity as an  EntityModel. 
- extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-  
- extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
-  
- extractChildEntityModel(EntityModel<T>, Map<String, Object>, Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
-  
- extractCommandHandlerRoutingKeys(Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
- 
Retrieves the routing keys of every command handler on the given childEntityModelto be able to correctly
 route commands to Entities.
 
- GapAwareTrackingToken - Class in org.axonframework.eventhandling
- 
Implementation of a  TrackingToken that uses the global insertion sequence number of the event to determine
 tracking order and additionally stores a set of possible gaps that have been detected while tracking the event
 store. 
- GapAwareTrackingToken(long, Collection<Long>) - Constructor for class org.axonframework.eventhandling.GapAwareTrackingToken
- 
This constructor is mean't to be used for deserialization. 
- GapAwareTrackingToken - Class in org.axonframework.eventsourcing.eventstore
- 
- GapAwareTrackingToken(long, Collection<Long>) - Constructor for class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
- 
Deprecated. 
- GapAwareTrackingTokenConverter - Class in org.axonframework.serialization
- 
Dedicated  CollectionConverter implementation to de-/serializer the  GapAwareTrackingToken and
  org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken. 
- GapAwareTrackingTokenConverter(Mapper) - Constructor for class org.axonframework.serialization.GapAwareTrackingTokenConverter
- 
- gapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken. 
- gapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken. 
- gapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken. 
- gapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out. 
- gapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out. 
- gapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out. 
- generateIdentifier() - Method in class org.axonframework.common.DefaultIdentifierFactory
- 
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events. 
- generateIdentifier() - Method in class org.axonframework.common.IdentifierFactory
- 
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events. 
- GenericAggregateFactory<T> - Class in org.axonframework.eventsourcing
- 
Aggregate factory that uses a convention to create instances of aggregates. 
- GenericAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
- 
Initialize the AggregateFactory for creating instances of the given aggregateType.
 
- GenericAggregateFactory(AggregateModel<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
- 
Initialize the AggregateFactory for creating instances of the given aggregateModel.
 
- GenericCommandMessage<T> - Class in org.axonframework.commandhandling
- 
Implementation of the CommandMessage that takes all properties as constructor parameters. 
- GenericCommandMessage(T) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
- 
Create a CommandMessage with the given commandas payload and empty metaData
 
- GenericCommandMessage(T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
- 
Create a CommandMessage with the given commandas payload.
 
- GenericCommandMessage(Message<T>, String) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
- 
Create a CommandMessage from the given delegatemessage containing payload, metadata and message
 identifier, and the givencommandName.
 
- GenericCommandResultMessage<R> - Class in org.axonframework.commandhandling
- 
- GenericCommandResultMessage(R) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
- 
Creates a Command Result Message with the given commandResultas the payload.
 
- GenericCommandResultMessage(Throwable) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
- 
Creates a Command Result Message with the given exception.
 
- GenericCommandResultMessage(R, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
- 
Creates a Command Result Message with the given commandResultas the payload andmetaDataas the
 meta data.
 
- GenericCommandResultMessage(Throwable, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
- 
Creates a Command Result Message with the given exceptionandmetaData.
 
- GenericCommandResultMessage(Message<R>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
- 
Creates a new Command Result Message with given delegatemessage.
 
- GenericCommandResultMessage(Message<R>, Throwable) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
- 
Creates a Command Result Message with given delegatemessage andexception.
 
- GenericDeadLetter<M extends Message<?>> - Class in org.axonframework.messaging.deadletter
- 
Generic implementation of the  dead letter allowing any type of  Message to be dead
 lettered. 
- GenericDeadLetter(Object, M) - Constructor for class org.axonframework.messaging.deadletter.GenericDeadLetter
- 
- GenericDeadLetter(Object, M, Throwable) - Constructor for class org.axonframework.messaging.deadletter.GenericDeadLetter
- 
- GenericDeadLetter(Object, M, Cause, Instant, Instant, MetaData) - Constructor for class org.axonframework.messaging.deadletter.GenericDeadLetter
- 
- GenericDeadlineMessage<T> - Class in org.axonframework.deadline
- 
- GenericDeadlineMessage(String) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
- 
Instantiate a GenericDeadlineMessage with the given  deadlineName, a  null payload and en empty
  MetaData. 
- GenericDeadlineMessage(String, T) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
- 
Instantiate a GenericDeadlineMessage with the given  deadlineName, a  payload of type  T and
 en empty  MetaData. 
- GenericDeadlineMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
- 
Instantiate a GenericDeadlineMessage with the given deadlineName, apayloadof typeTand
 the givenmetaData.
 
- GenericDeadlineMessage(String, String, T, Map<String, ?>, Instant) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
- 
Constructor to reconstructs a DeadlineMessage using existing data. 
- GenericDeadlineMessage(String, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
- 
Constructor to reconstruct a DeadlineMessage using existing data. 
- GenericDomainEventEntry<T> - Class in org.axonframework.eventhandling
- 
Generic implementation of a serialized domain event entry. 
- GenericDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventhandling.GenericDomainEventEntry
- 
Reconstruct an event entry from a stored object. 
- GenericDomainEventMessage<T> - Class in org.axonframework.eventhandling
- 
- GenericDomainEventMessage(String, String, long, T) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
- 
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier,
 with givensequenceNumberandpayload.
 
- GenericDomainEventMessage(String, String, long, T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
- 
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier,
 with givensequenceNumberandpayloadandmetaData.
 
- GenericDomainEventMessage(String, String, long, T, Map<String, ?>, String, Instant) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
- 
Initialize a DomainEventMessage originating from an Aggregate using existing data. 
- GenericDomainEventMessage(String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
- 
Initialize a DomainEventMessage originating from an Aggregate using existing data. 
- GenericDomainEventMessage(String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
- 
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier,
 with givensequenceNumberandpayload,metaDataandtimestamp.
 
- GenericEventMessage<T> - Class in org.axonframework.domain
- 
- GenericEventMessage() - Constructor for class org.axonframework.domain.GenericEventMessage
- 
Deprecated. 
- GenericEventMessage<T> - Class in org.axonframework.eventhandling
- 
Generic implementation of the EventMessage interface. 
- GenericEventMessage(T) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
- 
Creates a GenericEventMessage with given payload, and an empty MetaData.
 
- GenericEventMessage(T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
- 
Creates a GenericEventMessage with given payloadand givenmetaData.
 
- GenericEventMessage(String, T, Map<String, ?>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
- 
Constructor to reconstruct an EventMessage using existing data. 
- GenericEventMessage(Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
- 
Constructor to reconstruct an EventMessage using existing data. 
- GenericEventMessage(Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
- 
- GenericJpaRepository<T> - Class in org.axonframework.modelling.command
- 
Generic repository implementation that stores JPA annotated aggregates. 
- GenericJpaRepository(GenericJpaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.command.GenericJpaRepository
- 
- GenericJpaRepository<T> - Class in org.axonframework.modelling.command.legacyjpa
- 
- GenericJpaRepository(GenericJpaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository
- 
Deprecated. 
- GenericJpaRepository.Builder<T> - Class in org.axonframework.modelling.command
- 
- GenericJpaRepository.Builder<T> - Class in org.axonframework.modelling.command.legacyjpa
- 
Deprecated. 
- GenericMessage<T> - Class in org.axonframework.domain
- 
- GenericMessage() - Constructor for class org.axonframework.domain.GenericMessage
- 
Deprecated. 
- GenericMessage<T> - Class in org.axonframework.messaging
- 
Generic implementation of a  Message that contains the payload and metadata as unserialized values. 
- GenericMessage(T) - Constructor for class org.axonframework.messaging.GenericMessage
- 
Constructs a Message for the given payloadusing the correlation data of the current Unit of Work, if
 present.
 
- GenericMessage(T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
- 
Constructs a Message for the given payloadandmeta data.
 
- GenericMessage(Class<T>, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
- 
Constructs a Message for the given payloadandmeta data.
 
- GenericMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
- 
Constructor to reconstruct a Message using existing data. 
- GenericMessage(String, Class<T>, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
- 
Constructor to reconstruct a Message using existing data. 
- GenericQueryMessage<T,R> - Class in org.axonframework.queryhandling
- 
Generic implementation of the QueryMessage. 
- GenericQueryMessage(T, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
- 
Initializes the message with the given payloadand expectedresponseType.
 
- GenericQueryMessage(T, String, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
- 
Initializes the message with the given payload,queryNameand expectedresponseType.
 
- GenericQueryMessage(Message<T>, String, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
- 
Initialize the Query Message, using given delegateas the carrier of payload and metadata and givenqueryNameand expecting the givenresponseType.
 
- GenericQueryResponseMessage<R> - Class in org.axonframework.queryhandling
- 
QueryResponseMessage implementation that takes all properties as constructor parameters. 
- GenericQueryResponseMessage(R) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Initialize the response message with given result.
 
- GenericQueryResponseMessage(Class<R>, R) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Initialize a response message with given resultanddeclaredResultType.
 
- GenericQueryResponseMessage(Class<R>, Throwable) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Initialize the response message with given declaredResultTypeandexception.
 
- GenericQueryResponseMessage(R, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Initialize the response message with given resultandmetaData.
 
- GenericQueryResponseMessage(Class<R>, R, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Initialize the response message with a specific declaredResultType, the givenresultas payload
 andmetaData.
 
- GenericQueryResponseMessage(Class<R>, Throwable, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Initialize the response message with given declaredResultType,exceptionandmetaData.
 
- GenericQueryResponseMessage(Message<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Copy-constructor that takes the payload, meta data and message identifier of the given delegatefor this
 message.
 
- GenericQueryResponseMessage(Message<R>, Throwable) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
- 
Copy-constructor that takes the payload, meta data and message identifier of the given delegatefor this
 message and givenexceptionas a cause for the failure.
 
- GenericResetContext<T> - Class in org.axonframework.eventhandling.replay
- 
- GenericResetContext(T) - Constructor for class org.axonframework.eventhandling.replay.GenericResetContext
- 
- GenericResetContext(T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.replay.GenericResetContext
- 
- GenericResetContext(Message<T>) - Constructor for class org.axonframework.eventhandling.replay.GenericResetContext
-  
- GenericResultMessage<R> - Class in org.axonframework.messaging
- 
- GenericResultMessage(R) - Constructor for class org.axonframework.messaging.GenericResultMessage
- 
Creates a ResultMessage with the given resultas the payload.
 
- GenericResultMessage(Throwable) - Constructor for class org.axonframework.messaging.GenericResultMessage
- 
Creates a ResultMessage with the given exception.
 
- GenericResultMessage(R, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericResultMessage
- 
Creates a ResultMessage with the given resultas the payload andmetaDataas the meta data.
 
- GenericResultMessage(Throwable, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericResultMessage
- 
Creates a ResultMessage with the given exceptionandmetaData.
 
- GenericResultMessage(Message<R>) - Constructor for class org.axonframework.messaging.GenericResultMessage
- 
Creates a new ResultMessage with given delegatemessage.
 
- GenericResultMessage(Message<R>, Throwable) - Constructor for class org.axonframework.messaging.GenericResultMessage
- 
Creates a ResultMessage with given delegatemessage andexception.
 
- GenericSagaSqlSchema - Class in org.axonframework.modelling.saga.repository.jdbc
- 
Generic SagaSqlSchema implementation, for use in most databases. 
- GenericSagaSqlSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
- 
Initialize a GenericSagaSqlSchema using default settings. 
- GenericSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
- 
Initialize a GenericSagaSqlSchema. 
- genericSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
- genericSerializer(Serializer) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
Sets the  Serializer to (de)serialize the tracking token of the event in
 the  DeadLetter when storing it to the database. 
- genericSerializer(Serializer) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. Sets the  Serializer to (de)serialize the tracking token of the event in the  DeadLetter when
 storing it to the database. 
- GenericStreamingQueryMessage<Q,R> - Class in org.axonframework.queryhandling
- 
- GenericStreamingQueryMessage(Q, Class<R>) - Constructor for class org.axonframework.queryhandling.GenericStreamingQueryMessage
- 
Initializes the message with the given payloadand expectedresponseType.
 
- GenericStreamingQueryMessage(Q, String, Class<R>) - Constructor for class org.axonframework.queryhandling.GenericStreamingQueryMessage
- 
Initializes the message with the given payload,queryNameand expectedresponseType.
 
- GenericStreamingQueryMessage(Q, ResponseType<Publisher<R>>) - Constructor for class org.axonframework.queryhandling.GenericStreamingQueryMessage
- 
Initializes the message with the given payloadand expectedresponseType.
 
- GenericStreamingQueryMessage(Q, String, ResponseType<Publisher<R>>) - Constructor for class org.axonframework.queryhandling.GenericStreamingQueryMessage
- 
Initializes the message with the given payload,queryNameand expectedresponseType.
 
- GenericStreamingQueryMessage(Message<Q>, String, Class<R>) - Constructor for class org.axonframework.queryhandling.GenericStreamingQueryMessage
- 
Initializes the message with the given delegate,queryNameand expectedresponseType.
 
- GenericStreamingQueryMessage(Message<Q>, String, ResponseType<Publisher<R>>) - Constructor for class org.axonframework.queryhandling.GenericStreamingQueryMessage
- 
Initialize the Query Message, using given delegateas the carrier of payload and metadata and givenqueryNameand expecting the givenresponseType.
 
- GenericSubscriptionQueryMessage<Q,I,U> - Class in org.axonframework.queryhandling
- 
- GenericSubscriptionQueryMessage(Q, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
- 
Initializes the message with the given payload, expectedresponseTypeand expectedupdateResponseType.
 
- GenericSubscriptionQueryMessage(Q, String, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
- 
Initializes the message with the given payload,queryName, expectedresponseTypeand
 expectedupdateResponseType.
 
- GenericSubscriptionQueryMessage(Message<Q>, String, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
- 
Initializes the message, using given delegateas the carrier of payload and metadata and givenqueryName, expectedresponseTypeand expectedupdateResponseType.
 
- GenericSubscriptionQueryUpdateMessage<U> - Class in org.axonframework.queryhandling
- 
- GenericSubscriptionQueryUpdateMessage(U) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
- 
- GenericSubscriptionQueryUpdateMessage(Class<U>, U) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
- 
- GenericSubscriptionQueryUpdateMessage(Class<U>, U, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
- 
- GenericSubscriptionQueryUpdateMessage(Class<U>, Throwable, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
- 
Initialize the subscription query update message with given declaredType,exceptionandmetaData.
 
- GenericSubscriptionQueryUpdateMessage(Message<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
- 
Initializes a new decorator with given delegatemessage.
 
- GenericTokenEntry<T> - Class in org.axonframework.eventhandling.tokenstore
- 
Generic implementation of a token entry. 
- GenericTokenEntry(TrackingToken, Serializer, Class<T>, String, int) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
- 
Initializes a new token entry for given token,processandsegment.
 
- GenericTokenEntry(T, String, String, String, String, int, Class<T>) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
- 
Initializes a token entry from existing data. 
- GenericTokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
- 
Jdbc token entry table factory compatible with most databases. 
- GenericTokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
-  
- GenericTrackedDomainEventMessage<T> - Class in org.axonframework.eventhandling
- 
- GenericTrackedDomainEventMessage(TrackingToken, DomainEventMessage<T>) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
- 
Initialize a DomainEventMessage originating from an aggregate. 
- GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
- 
Initialize a DomainEventMessage originating from an Aggregate using existing data. 
- GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
- 
Initialize a DomainEventMessage originating from an aggregate. 
- GenericTrackedEventMessage<T> - Class in org.axonframework.eventhandling
- 
- GenericTrackedEventMessage(TrackingToken, EventMessage<T>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
- 
Creates a GenericTrackedEventMessage with given trackingTokenand delegate event message.
 
- GenericTrackedEventMessage(TrackingToken, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
- 
Creates a GenericTrackedEventMessage with given trackingTokenand delegate event message.
 
- GenericTrackedEventMessage(TrackingToken, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
- 
- GenericUpcasterChain<T> - Class in org.axonframework.serialization.upcasting
- 
Implementation of an  Upcaster that is formed of a chain of other upcasters which are combined to upcast a
 stream of intermediate objects. 
- GenericUpcasterChain(Upcaster<T>...) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
- 
Initializes an upcaster chain from one or more upcasters. 
- GenericUpcasterChain(List<? extends Upcaster<T>>) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
- 
Initializes an upcaster chain from the given list of upcasters. 
- get(String, Case) - Method in class org.axonframework.axonserver.connector.DefaultHandlers
- 
Deprecated. 
- get(String) - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
- 
Retrieve the column information referring to the given name.
 
- get(String, Case) - Method in interface org.axonframework.axonserver.connector.Handlers
- 
Gets all handlers that match given contextandrequestCase.
 
- get() - Method in class org.axonframework.axonserver.connector.util.GrpcMetaData
-  
- get(K) - Method in interface org.axonframework.common.caching.Cache
- 
Returns an item from the cache, or nullif no item was stored under that key
 
- get(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- get(K) - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- get(K) - Method in class org.axonframework.common.caching.NoCache
-  
- get(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
-  
- get() - Method in class org.axonframework.config.Component
- 
Retrieves the object contained in this component, triggering the builder function if the component hasn't been
 built yet. 
- get(String) - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
- 
Retrieves the value of the configuration element for the given key.
 
- get(String) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
-  
- get(String) - Method in interface org.axonframework.messaging.HandlerAttributes
- 
Retrieve the attribute for the given attributeKey.
 
- get(Object) - Method in class org.axonframework.messaging.MetaData
-  
- get(String) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
-  
- get() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
- 
Gets the UnitOfWork bound to the current thread. 
- get() - Method in class org.axonframework.serialization.CachingSupplier
-  
- get(Message<?>, String) - Method in class org.axonframework.tracing.opentelemetry.MetadataContextGetter
-  
- get() - Method in class org.axonframework.util.MavenArtifactVersionResolver
- 
Returns the specified jar version. 
- getActualVersion() - Method in exception org.axonframework.modelling.command.ConflictingAggregateVersionException
- 
Returns the actual version of the aggregate, as loaded by the repository. 
- getAdapterInterfaces() - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. Returns the interface that the adapter implements to connect the annotated method to the actual interface
 definition. 
- getAdapterInterfaces() - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
- 
Deprecated. 
- getAdapterInterfaces() - Method in class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
- 
Deprecated. 
- getAdditionalEntries() - Method in class org.axonframework.test.matchers.MapEntryMatcher
-  
- getAggregateFactory(Class<?>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
- 
Returns the AggregateFactory registered for the given aggregateType, ornullif no such
 AggregateFactory is known.
 
- getAggregateFactory() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
- 
Returns the factory used by this repository. 
- getAggregateFactory(Class<?>) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
-  
- getAggregateIdentifier() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-  
- getAggregateIdentifier() - Method in exception org.axonframework.disruptor.commandhandling.AggregateStateCorruptedException
- 
Returns the identifier of the blacklisted aggregate. 
- getAggregateIdentifier() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Returns the identifier of the aggregate to recover. 
- getAggregateIdentifier() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
-  
- getAggregateIdentifier() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getAggregateIdentifier() - Method in interface org.axonframework.eventhandling.DomainEventData
- 
Returns the Identifier of the Aggregate to which the Event was applied. 
- getAggregateIdentifier() - Method in interface org.axonframework.eventhandling.DomainEventMessage
- 
Returns the identifier of the Aggregate that generated this DomainEvent. 
- getAggregateIdentifier() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-  
- getAggregateIdentifier() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-  
- getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-  
- getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.AggregateNotFoundException
- 
Returns the identifier of the aggregate that could not be found. 
- getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.AggregateRolledBackException
- 
Returns the identifier of the compromised aggregate. 
- getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.ConflictingAggregateVersionException
- 
Returns the identifier of the aggregate which version is not as expected. 
- getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getAggregateIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the Identifier of the Aggregate to which the Event owning the object to upcast, was applied. 
- getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getAggregateRoot() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Get the annotated aggregate instance. 
- getAggregateType() - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-  
- getAggregateType() - Method in interface org.axonframework.eventsourcing.AggregateFactory
- 
Returns the type of aggregate this factory creates. 
- getAggregateType() - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Returns the aggregate type stored by this repository. 
- getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getAggregateType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the Type of the Aggregate to which the Event owning the object to upcast, was applied. 
- getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getAggregateType() - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-  
- getAll() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
-  
- getAll() - Method in interface org.axonframework.messaging.HandlerAttributes
- 
- getAll() - Method in class org.axonframework.messaging.SimpleHandlerAttributes
-  
- getAllHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Gets all handlers per type for inspected entity. 
- getAllInspectedTypes() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Returns a  Set of all types which have been inspected for handlers. 
- getAllInterceptors() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Returns a Map of all registered interceptor methods per inspected type. 
- getAppliedEventPayloads() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
- 
Returns the payloads of the Events applied while this lifecycle instance was active. 
- getAppliedEvents() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
- 
Returns the list of applied Events for this lifecycle instance. 
- getAssociationValue() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
- 
Returns the association value contained in this entry. 
- getAssociationValue(EventMessage<?>) - Method in class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
- 
The AssociationValue to find the saga instance with, or nullif no AssociationValue can be found on the
 giveneventMessage.
 
- getAssociationValues() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-  
- getAssociationValues() - Method in interface org.axonframework.modelling.saga.Saga
- 
Returns a view on the Association Values for this saga instance. 
- getAssociationValues() - Method in class org.axonframework.modelling.saga.SagaLifecycle
- 
- getAttributeProviders() - Method in class org.axonframework.springboot.TracingProperties
- 
- getAutoConfiguration() - Method in class org.axonframework.springboot.MetricsProperties
- 
Retrieves the AutoConfiguration settings for Metrics 
- getAxonServerAddress() - Method in class org.axonframework.test.server.AxonServerEEContainer
- 
Returns the Axon Server's address container in a host:port format. 
- getAxonServerAddress() - Method in class org.axonframework.test.server.AxonServerSEContainer
- 
Returns the Axon Server's address container in a host:port format. 
- getBatchSize() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-  
- getBatchSize() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Returns the maximum size of a processing batch. 
- getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.spring.config.annotation.SpringContextHandlerDefinitionBuilder
- 
Deprecated. Create, if necessary, a bean definition for a HandlerDefinition and returns the reference to bean for use in
 other Bean Definitions. 
- getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.spring.config.annotation.SpringContextParameterResolverFactoryBuilder
- 
Deprecated. Create, if necessary, a bean definition for a ParameterResolverFactory and returns the reference to bean for use
 in other Bean Definitions. 
- getBindAddr() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Returns the Address to bind the JGroups client to. 
- getBindPort() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Returns the port to listen to JGroups connections (default 7800). 
- getCallback() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Returns the CommandCallback instance for the executed command. 
- getCauseMessage() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Gets the message of the original exception. 
- getCauseType() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Gets the class of the original exception. 
- getCertFile() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getChannel() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Deprecated. 
- getChannel(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Deprecated. 
- getChannelIdentifier() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
- 
Returns the identifier of the channel over which the command message was sent. 
- getCharset() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Returns the character set used to convert character to bytes and vice versa. 
- getClientId() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getClusterName() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Returns the Cluster Name of the JGroups Cluster to connect with (defaults to "Axon"). 
- getCode() - Method in exception org.axonframework.axonserver.connector.event.util.EventStoreClientException
- 
Deprecated. Returns the error codeof this exception.
 
- getColumns() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
- 
The list of columns returned by the query. 
- getCommandBus() - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
- 
Returns the CommandBus used by this gateway. 
- getCommandBus() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- getCommandBus() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Returns the command bus used by this fixture. 
- getCommandBus() - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Returns the command bus used by this fixture. 
- getCommandBus() - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- getCommandExecutionErrorCode(Throwable) - Static method in enum org.axonframework.axonserver.connector.ErrorCode
- 
Returns an Command Execution ErrorCode variation based on the transiency of the given  Throwable
- getCommandFilter() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
- 
Returns this member's filter describing the commands it supports 
- getCommandFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Returns the identifier of the command carried by this instance. 
- getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the identifier of the command for which this message is a reply. 
- getCommandLoadFactor() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getCommandMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Returns the CommandMessage wrapped in this Message. 
- getCommandName() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-  
- getCommandName() - Method in interface org.axonframework.commandhandling.CommandMessage
- 
Returns the name of the command to execute. 
- getCommandName() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Returns the command name of the command carried by this instance. 
- getCommandName() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-  
- getCommandResultMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
- getCommandThreads() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getCommitTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getComponent(Class<T>) - Method in interface org.axonframework.config.Configuration
- 
Returns the Component declared under the given componentType, typically the interface the component
 implements.
 
- getComponent(Class<T>, Supplier<T>) - Method in interface org.axonframework.config.Configuration
- 
Returns the Component declared under the given componentType, typically the interface the component
 implements, reverting to the givendefaultImplif no such component is defined.
 
- getComponent(Class<T>, Supplier<T>) - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- getComponentName() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getComponents() - Method in class org.axonframework.config.DefaultConfigurer
- 
Returns a map of all registered components in this configuration. 
- getConfig() - Method in class org.axonframework.config.DefaultConfigurer
- 
Returns the current Configuration object being built by this Configurer, without initializing it. 
- getConfig() - Method in class org.axonframework.eventhandling.tokenstore.ConfigToken
- 
Returns the properties contained in this token as a Map. 
- getConfigurationFile() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Returns the path to the configuration file to use to configure the Groups instance. 
- getConfigurationPhase() - Method in class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
-  
- getConflictResolver() - Static method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
- 
Returns the ConflictResolver instance that can be used to resolve conflicts of an Aggregate that has been
 previously loaded in this Unit of Work. 
- getConnection() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Retrieves the AxonServerConnectionused for the default context of this application.
 
- getConnection(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Retrieves the AxonServerConnectionused for the givencontextof this application.
 
- getConnection() - Method in interface org.axonframework.common.jdbc.ConnectionProvider
- 
Returns a connection, ready for use. 
- getConnection() - Method in class org.axonframework.common.jdbc.DataSourceConnectionProvider
-  
- getConnection() - Method in class org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper
-  
- getConnection() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
- getConnection() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- getConnection() - Method in class org.axonframework.spring.jdbc.SpringDataSourceConnectionProvider
-  
- getConnectionEndpoint(Class<T>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-  
- getConnectionEndpoint(Class<T>) - Method in interface org.axonframework.commandhandling.distributed.Member
- 
Get the endpoint of this Member given a protocol.
 
- getConnectionEndpoint(Class<T>) - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-  
- getConnectTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getContentType() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
-  
- getContentType() - Method in class org.axonframework.serialization.SerializedMetaData
-  
- getContentType() - Method in interface org.axonframework.serialization.SerializedObject
- 
Returns the type of this representation's data. 
- getContentType() - Method in class org.axonframework.serialization.SimpleSerializedObject
-  
- getContentType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getContentType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the type of this representation's  data. 
- getContentType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getContext() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getConverter() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
-  
- getConverter() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Returns the Converter used by this serialized. 
- getConverter() - Method in class org.axonframework.serialization.JavaSerializer
- 
Deprecated. 
- getConverter() - Method in class org.axonframework.serialization.json.JacksonSerializer
-  
- getConverter() - Method in interface org.axonframework.serialization.Serializer
- 
Returns the  Converter used by this Serializer to convert between serialized representations. 
- getCorrelationData() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- getCorrelationData() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Get the correlation data contained in the  message being processed by the Unit of Work. 
- getCounter() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Retrieve the counter used to differentiate two deadlines scheduled at the same time. 
- getCreationPolicy() - Method in class org.axonframework.modelling.saga.SagaInitializationPolicy
- 
Returns the creation policy 
- getCreationPolicy() - Method in class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
- 
Returns the creation policy of the inspected method. 
- getCurrentDateTime() - Method in class org.axonframework.test.deadline.StubDeadlineManager
- 
- getCurrentDateTime() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
- 
Returns the "Current Date Time" as used by the scheduler. 
- getCurrentPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Return the estimated relative current token position this Segment represents. 
- getCurrentPosition() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- getCurrentPosition() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- getCurrentScope() - Static method in class org.axonframework.messaging.Scope
- 
Retrieve the current  Scope. 
- getCurrentToken() - Method in class org.axonframework.eventhandling.ReplayToken
- 
Gets the current token. 
- getData() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
-  
- getData() - Method in class org.axonframework.serialization.SerializedMetaData
-  
- getData() - Method in interface org.axonframework.serialization.SerializedObject
- 
The actual data of the serialized object. 
- getData() - Method in class org.axonframework.serialization.SimpleSerializedObject
-  
- getData() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getData(Class<D>) - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getData() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Get the data of this representation. 
- getData(Class<D>) - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Get the data of this representation. 
- getData() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getData(Class<D>) - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getDeadLetterId() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
The unique ID of this dead letter in the database. 
- getDeadlineName() - Method in interface org.axonframework.deadline.DeadlineMessage
- 
Retrieve a  String representing the name of this DeadlineMessage. 
- getDeadlineName() - Method in class org.axonframework.deadline.GenericDeadlineMessage
-  
- getDeadlineName() - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
Returns the  String with the name of the deadline. 
- getDeadlineName() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Retrieve a  String denoting the name of the deadline; can be used together with the  scheduleId to
 cancel the deadline. 
- getDeadlineScope() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Retrieve a description of the  Scope in which the deadline is scheduled. 
- getDeadlinesMet() - Method in class org.axonframework.test.deadline.StubDeadlineManager
- 
- getDefaultContext() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Returns the name of the default context of this application. 
- getDefaultCorrelationKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
- 
Returns the default metadata key for the correlation id of a message. 
- getDefaultFlowControlConfiguration() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getDefaultTraceKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
- 
Returns the default metadata key for the trace id of a message. 
- getDelegate() - Method in class org.axonframework.messaging.MessageDecorator
- 
Returns the wrapped message delegate. 
- getDelegates() - Method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
- 
Returns the delegates of this instance, in the order they are evaluated to resolve parameters. 
- getDelegates() - Method in class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
- 
Returns the delegates of this instance, in the order they are evaluated to resolve parameters. 
- getDelegates() - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
- 
Returns the delegates of this instance, in the order they are evaluated to resolve parameters. 
- getDescriptions() - Method in class org.axonframework.messaging.RemoteExceptionDescription
- 
Returns the  List of  Strings describing the causes of the exception on the remote end. 
- getDeserializedScopeDescriptor(Serializer) - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
- getDetails() - Method in exception org.axonframework.messaging.HandlerExecutionException
- 
Returns an Optional containing application-specific details of the exception, if any were provided. 
- getDiagnostics() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Returns the serialized diagnostics. 
- getDispatchedCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
- 
Returns a list with all commands that have been dispatched by this command bus. 
- getDomainEventData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Extracts the next domain event entry from the given resultSet.
 
- getEligibleMembers(String) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
- 
- getEnqueuedAt() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
The time the message was enqueued. 
- getEntityManager() - Method in interface org.axonframework.common.jpa.EntityManagerProvider
- 
Returns the EntityManager instance to use. 
- getEntityManager() - Method in class org.axonframework.common.jpa.SimpleEntityManagerProvider
-  
- getEntityManager() - Method in interface org.axonframework.common.legacyjpa.EntityManagerProvider
- 
Deprecated. Returns the EntityManager instance to use. 
- getEntityManager() - Method in class org.axonframework.common.legacyjpa.SimpleEntityManagerProvider
- 
Deprecated. 
- getEntityManager() - Method in class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
-  
- getEntityManager() - Method in class org.axonframework.springboot.util.legacyjpa.ContainerManagedEntityManagerProvider
- 
Deprecated. 
- getError() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Returns the exception that caused processing to fail, if present. 
- getError() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- getError() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
- 
Returns the error code as reported by the server. 
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.command.AxonServerNonTransientRemoteCommandHandlingException
- 
Returns the error code as reported by the server. 
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
- 
Returns the error code as reported by the server. 
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.query.AxonServerNonTransientRemoteQueryHandlingException
- 
Returns the error code as reported by the server. 
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
- 
Return a  String defining the error code. 
- getEvent() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
- 
The Event scheduled for publication. 
- getEvent() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
-  
- getEventAvailabilityTimeout() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-  
- getEventBus() - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
- 
Returns the EventBus used by this EventGateway. 
- getEventBus() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- getEventBus() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Returns the event bus used by this fixture. 
- getEventBus() - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Returns the event bus used by this fixture. 
- getEventBus() - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- getEventCipher() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getEventFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getEventIdentifier() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-  
- getEventIdentifier() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-  
- getEventIdentifier() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getEventIdentifier() - Method in interface org.axonframework.eventhandling.EventData
- 
Returns the identifier of the serialized event. 
- getEventIdentifier() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-  
- getEvents() - Method in class org.axonframework.springboot.SerializerProperties
- 
The type of serializer to use to serialize the payload and meta data of Event Messages. 
- getEventSerializer() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
- 
Get the serializer used by this storage engine when storing and retrieving events. 
- getEventStore() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
- 
Returns the event store this snapshotter uses to load domain events and store snapshot events. 
- getEventStore() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- getEventStore() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Returns the event store used by this fixture. 
- getEventTrackerStatusChangeListener() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
- 
- getExactSuperType(Type, Class<?>) - Static method in class org.axonframework.common.TypeReflectionUtils
- 
Finds the most specific supertype of type whose erasure is searchClass. 
- getException() - Method in class org.axonframework.test.saga.RecordingListenerInvocationErrorHandler
- 
Return the last encountered Exception after the startRecording method has been invoked, or an empty Optional of
 no Exception occurred. 
- getExceptionDescriptions() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
- 
Returns a  List of  Strings describing the remote exception. 
- getExceptionDescriptions() - Method in exception org.axonframework.messaging.RemoteHandlingException
- 
Returns a  List of  Strings describing the remote exception. 
- getExceptionDescriptions() - Method in exception org.axonframework.messaging.RemoteNonTransientHandlingException
- 
Returns a  List of  Strings describing the remote exception. 
- getExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
- 
Get the execution result in case the result is an exception. 
- getExceptionRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the exception revision of the serialized reply message. 
- getExceptionType() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the exception type of the serialized reply message. 
- getExecutionResult() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-  
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-  
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-  
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
- 
Get the result of processing the  Message. 
- getExecutionResult() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Get the result of the task that was executed by this Unit of Work. 
- getExecutionResults() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
- 
- getExecutor() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
- 
Returns the executor that executes snapshot taking tasks. 
- getExpectedResponseType() - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- getExpectedResponseType() - Method in interface org.axonframework.messaging.responsetypes.ResponseType
- 
Gets actual response type or generic placeholder. 
- getExpectedVersion() - Method in exception org.axonframework.modelling.command.ConflictingAggregateVersionException
- 
Returns the version expected by the component loading the aggregate. 
- getFailedField() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
- 
Returns the field that failed comparison, if any. 
- getFailedFieldActualValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
- 
Returns the actual value of a failed field comparison, if any. 
- getFailedFieldExpectedValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
- 
Returns the expected value of a failed field comparison, if any. 
- getFallbackUrl() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
- 
Returns the URL relative to the host's root to retrieve Instance Meta Data from. 
- getFieldValue(Field, Object) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the value of the given fieldin the givenobject.
 
- getFor(String) - Method in interface org.axonframework.axonserver.connector.command.CommandLoadFactorProvider
- 
Returns the load factor value for the specific command 
- getFromCode(String) - Static method in enum org.axonframework.axonserver.connector.ErrorCode
-  
- getGaps() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
- 
- getGeneral() - Method in class org.axonframework.springboot.SerializerProperties
- 
The type of serializer to use to serialize any type of object, for which no more specific serializer is
 configured. 
- getGlobalIndex() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
- 
Get the global sequence number of the event 
- getGossip() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
- getGroupIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
- 
Returns the Quartz group identifier. 
- getGrpcPort() - Method in class org.axonframework.test.server.AxonServerEEContainer
- 
Returns the mapped GRPC port used by this Axon Server container. 
- getGrpcPort() - Method in class org.axonframework.test.server.AxonServerSEContainer
- 
Returns the mapped GRPC port used by this Axon Server container. 
- getHandlerEnhancerDefinition() - Method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
- 
Returns handler enhancer definition used to wrap handlers. 
- getHandlerInterceptors() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-  
- getHandlerInterceptors() - Method in interface org.axonframework.eventhandling.EventProcessor
- 
- getHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
- getHandlers(Class<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Returns a list of detected members of given typethat are capable of handling certain messages.
 
- getHeartbeat() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getHosts() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
- 
- getId() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
- 
The ID of the entity in the database. 
- getId() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. The ID of the entity in the database. 
- getId() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
- 
The unique identifier of this entry. 
- getIdentifier() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-  
- getIdentifier() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-  
- getIdentifier() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-  
- getIdentifier() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- getIdentifier() - Method in class org.axonframework.domain.GenericMessage
- 
Deprecated. Get the message's identifier. 
- getIdentifier() - Method in interface org.axonframework.eventhandling.EventMessage
- 
Returns the identifier of this event. 
- getIdentifier() - Method in class org.axonframework.messaging.AbstractMessage
-  
- getIdentifier() - Method in interface org.axonframework.messaging.Message
- 
Returns the identifier of this message. 
- getIdentifier() - Method in class org.axonframework.messaging.MessageDecorator
-  
- getIdentifier() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- getIdentifier() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
- 
The identifier of the Aggregate targeted with this scope 
- getIdentifier(T) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
- 
Get the identifier of the given targetentity.
 
- getIdentifier() - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
- 
Returns the string representation of the identifier of the targeted Aggregate. 
- getIdentifier() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
- 
The identifier of the Saga targeted with this scope 
- getIdentifiers() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
- 
Returns the identifiers that uniquely identify this result entry. 
- getIdentifierValue() - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
- 
Returns the object representation of the identifier of the targeted Aggregate. 
- getIndex() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
- 
The index of the dead letter within its sequence identified by the sequenceIdentifier.
 
- getIndex() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. The index of the dead letter within its sequence identified by the sequenceIdentifier.
 
- getIndex() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
- 
Get the highest global sequence of events seen up until the point of this tracking token. 
- getInitialAssociationValue() - Method in class org.axonframework.modelling.saga.SagaInitializationPolicy
- 
Returns the initial association value for a newly created saga. 
- getInitialNrOfPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-  
- getInitialNrOfPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getInitialSegmentCount() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Returns the number of initial segments that should be created, if no segments are already present. 
- getInitialSegmentsCount() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-  
- getInitialTrackingToken() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-  
- getInstance() - Static method in class org.axonframework.common.annotation.PriorityAnnotationComparator
- 
Returns the instance of the comparator. 
- getInstance() - Static method in class org.axonframework.common.IdentifierFactory
- 
Returns an instance of the IdentifierFactory discovered on the classpath. 
- getInstance() - Static method in class org.axonframework.common.IdentifierValidator
- 
Returns the singleton instance of the IdentifierValidator. 
- getInstance() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
- 
- getInstance() - Static method in class org.axonframework.modelling.saga.SagaLifecycle
- 
- getInternalTrackingToken() - Method in class org.axonframework.eventhandling.TrackerStatus
- 
- getInterval() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
-  
- getInvocationInterceptorChain() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Returns the InterceptorChain for the invocation process registered with this entry, or nullif none is
 available.
 
- getInvokerId() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Returns the Identifier of the invoker that is chosen to handle this entry. 
- getIsLive() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-  
- getIsLive() - Method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Indicates whether this Aggregate instance is 'live'. 
- getIsLive() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- getIsLive() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-  
- getJgroups() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Returns the JGroups configuration to use (if JGroups is on the classpath). 
- getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrScheduleToken
- 
Returns the JobRunr job identifier. 
- getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
- 
Returns the Quartz job identifier. 
- getKeepAliveTime() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getKeepAliveTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getKey() - Method in class org.axonframework.modelling.saga.AssociationValue
- 
Returns the key of this association value. 
- getLastSeparator() - Method in class org.axonframework.test.matchers.ListMatcher
- 
The separator to use between the two last events. 
- getLastSeparator() - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
-  
- getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
-  
- getLastSequenceNumber() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
- 
Get the highest known sequence number in the upstream event entry stream. 
- getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.FilteringDomainEventStream
-  
- getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
-  
- getLastTouched() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
The time the messages was last touched, meaning having been queued or having been tried to process. 
- getListenerInvocationErrorHandler() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
- 
- getLoadFactor() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
Returns the current load factor of this node. 
- getLoadFactor() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Returns the load factor for this instance of the Distributed Command Bus (default 100). 
- getMask() - Method in class org.axonframework.eventhandling.Segment
- 
Getter for the segment mask. 
- getMatchers() - Method in class org.axonframework.test.matchers.ListMatcher
- 
Returns a read-only list of Matchers, in the order they were provided in the constructor. 
- getMatchOutcome(ConditionContext, AnnotatedTypeMetadata) - Method in class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
-  
- getMaxGrpcBufferedMessages() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getMaxMessageSize() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getMaxThreadCount() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-  
- getMeasurements() - Method in class org.axonframework.micrometer.reservoir.SlidingTimeWindowReservoir
- 
Retrieve the measurements 
- getMember(String, CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
- 
Returns the member instance to which the given messageshould be routed.
 
- getMemberGenericString(Member) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the generic string of the given member.
 
- getMemberGenericType(Member) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the generic type of value of the given  member, either by returning the generic type of  Field or generic return type of a  Method. 
- getMembers() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
- 
Returns the set of members registered with this consistent hash instance. 
- getMemberValue(Member, Object) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the value of the given  member in the given  object, either by returning  Field
 value or invoking the method. 
- getMemberValueType(Member) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the type of value of the given  member, either by returning the type of  Field or type of
 the return value of a  Method. 
- getMessage() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
- 
Returns the command message that was sent. 
- getMessage() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-  
- getMessage() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
- getMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-  
- getMessage() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-  
- getMessage() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
- 
Get the Message that is being processed in this context. 
- getMessage() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Get the message that is being processed by the Unit of Work. 
- getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getMessageIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the identifier of the message wrapping the object to upcast. 
- getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getMessages() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
- 
Get the batch of messages that is being processed (or has been processed) by this unit of work. 
- getMessages() - Method in class org.axonframework.springboot.SerializerProperties
- 
The type of serializer to use to serialize the payload and meta data of Messages. 
- getMessageSource() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
- 
Returns the message source from which this processor receives its events 
- getMessageSource() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
- getMessageType() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getMessageType() - Method in enum org.axonframework.spring.config.MessageHandlerConfigurer.Type
- 
Returns the supported  Message implementation. 
- getMetaData() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-  
- getMetaData() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
- 
Returns the serialized data of the MetaData of the serialized Event. 
- getMetaData() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-  
- getMetaData() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-  
- getMetaData() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- getMetaData() - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
Returns the  String containing the metadata about the deadline. 
- getMetaData() - Method in class org.axonframework.domain.GenericMessage
- 
Deprecated. Get the message's metadata. 
- getMetaData() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-  
- getMetaData() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getMetaData() - Method in interface org.axonframework.eventhandling.EventData
- 
Returns the serialized data of the MetaData of the serialized Event. 
- getMetaData() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-  
- getMetaData() - Method in class org.axonframework.messaging.GenericMessage
-  
- getMetaData() - Method in interface org.axonframework.messaging.Message
- 
Returns the meta data for this message. 
- getMetaData() - Method in class org.axonframework.messaging.MessageDecorator
-  
- getMetaData() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- getMetaData() - Method in class org.axonframework.serialization.SerializedMessage
-  
- getMetaData() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getMetaData() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the meta data of the message wrapping the object being upcast. 
- getMetaData() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getMetrics() - Method in class org.axonframework.metrics.CapacityMonitor
-  
- getMetrics() - Method in class org.axonframework.metrics.EventProcessorLatencyMonitor
-  
- getMetrics() - Method in class org.axonframework.metrics.MessageCountingMonitor
-  
- getMetrics() - Method in class org.axonframework.metrics.MessageTimerMonitor
-  
- getMetrics() - Method in class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
-  
- getMicrometer() - Method in class org.axonframework.springboot.MetricsProperties
- 
Retrieves the Micrometer specific settings for Metrics 
- getMissingEntries() - Method in class org.axonframework.test.matchers.MapEntryMatcher
-  
- getMode() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Returns the type of processor to configure. 
- getModules() - Method in interface org.axonframework.config.Configuration
- 
Returns all modules that have been registered with this Configuration. 
- getModules() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- getName() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-  
- getName() - Method in interface org.axonframework.eventhandling.EventProcessor
- 
Returns the name of this event processor. 
- getName() - Method in interface org.axonframework.serialization.SerializedType
- 
Returns the name of the serialized type. 
- getName() - Method in class org.axonframework.serialization.SimpleSerializedType
-  
- getNestedTimeLimit() - Method in class org.axonframework.springboot.TracingProperties
- 
The time limit set on nested handlers inside dispatching trace. 
- getNewPermitsThreshold() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-  
- getNewPermitsThreshold() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getNonEmptyOrDefault(T, T) - Static method in class org.axonframework.common.ObjectUtils
- 
Returns the given instance, if not nullor of zero length, or otherwise the givendefaultValue.
 
- getNonTransientFailures() - Method in class org.axonframework.commandhandling.gateway.NonTransientExceptionClassesPredicate
- 
Fetches a configured list of non-transient failures. 
- getNrOfNewPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-  
- getNrOfNewPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
- 
De-serializes the object and returns the result. 
- getObject() - Method in class org.axonframework.spring.config.annotation.HandlerDefinitionFactoryBean
-  
- getObject() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. 
- getObject() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. 
- getObject() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-  
- getObject() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
- 
Deprecated. 
- getObject() - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
- 
Deprecated. 
- getObject() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
- 
Deprecated. 
- getObject() - Method in class org.axonframework.spring.config.SpringAxonConfiguration
-  
- getObject() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
- 
Deprecated. 
- getObject() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-  
- getObject() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-  
- getObject() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-  
- getObject() - Method in class org.axonframework.spring.modelling.SpringRepositoryFactoryBean
- 
Deprecated. 
- getObjectMapper() - Method in class org.axonframework.serialization.json.JacksonSerializer
- 
Returns the ObjectMapper used by this serializer, allowing for configuration of the serialization settings. 
- getObjectType() - Method in class org.axonframework.spring.config.annotation.HandlerDefinitionFactoryBean
-  
- getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. 
- getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. 
- getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-  
- getObjectType() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
- 
Deprecated. 
- getObjectType() - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
- 
Deprecated. 
- getObjectType() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
- 
Deprecated. 
- getObjectType() - Method in class org.axonframework.spring.config.SpringAxonConfiguration
-  
- getObjectType() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
- 
Deprecated. 
- getObjectType() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-  
- getObjectType() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-  
- getObjectType() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-  
- getObjectType() - Method in class org.axonframework.spring.modelling.SpringRepositoryFactoryBean
- 
Deprecated. 
- getOrComputeResource(String, Function<? super String, R>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Returns the resource attached under given name.
 
- getOrDefault(String, Case, Collection<Handler>) - Method in interface org.axonframework.axonserver.connector.Handlers
- 
- getOrDefault(T, Supplier<T>) - Static method in class org.axonframework.common.ObjectUtils
- 
Returns the given instance, if not null, or otherwise the value provided bydefaultProvider.
 
- getOrDefault(T, T) - Static method in class org.axonframework.common.ObjectUtils
- 
Returns the given instance, if not null, or otherwise the givendefaultValue.
 
- getOrDefault(I, Function<I, T>, T) - Static method in class org.axonframework.common.ObjectUtils
- 
Returns the result of the given valueProviderby ingesting the giveninstance, if theinstanceis notnull.
 
- getOrDefaultResource(String, R) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Returns the resource attached under given name.
 
- getOriginServer() - Method in exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
- 
Returns the name of the server that reported the error. 
- getOverflowStrategy() - Method in class org.axonframework.queryhandling.SubscriptionQueryBackpressure
- 
Deprecated. Gets the overflow strategy. 
- getOwner() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Returns the identifier of the process (JVM) having a claim on this token, or nullif the token isn't
 claimed.
 
- getOwner() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
- 
Returns the identifier of the process (JVM) having a claim on this token, or nullif the token isn't
 claimed.
 
- getPayload() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-  
- getPayload() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-  
- getPayload() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-  
- getPayload() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-  
- getPayload() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- getPayload() - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
Returns the serialized  String of the payload. 
- getPayload() - Method in class org.axonframework.domain.GenericMessage
- 
Deprecated. Get the payload of this message. 
- getPayload() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-  
- getPayload() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getPayload() - Method in interface org.axonframework.eventhandling.EventData
- 
Returns the serialized data of the Event Message's payload. 
- getPayload() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-  
- getPayload() - Method in class org.axonframework.messaging.GenericMessage
-  
- getPayload() - Method in class org.axonframework.messaging.GenericResultMessage
-  
- getPayload() - Method in interface org.axonframework.messaging.Message
- 
Returns the payload of this message. 
- getPayload() - Method in class org.axonframework.messaging.MessageDecorator
-  
- getPayload() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- getPayload() - Method in class org.axonframework.serialization.SerializedMessage
-  
- getPayloadClass() - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
Returns the  String with the class of the payload. 
- getPayloadRevision() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Returns the payload revision of the serialized payload of the command carried by this instance. 
- getPayloadRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the payload revision of the serialized reply message. 
- getPayloadRevision() - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
Returns the  String with the revision of the payload. 
- getPayloadType() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-  
- getPayloadType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-  
- getPayloadType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-  
- getPayloadType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- getPayloadType() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Returns the payload type of the serialized payload of the command carried by this instance. 
- getPayloadType() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the payload type of the serialized reply message. 
- getPayloadType() - Method in class org.axonframework.domain.GenericMessage
- 
Deprecated. Get the type of payload of this message. 
- getPayloadType() - Method in class org.axonframework.messaging.GenericMessage
-  
- getPayloadType() - Method in interface org.axonframework.messaging.Message
- 
Returns the type of the payload. 
- getPayloadType() - Method in class org.axonframework.messaging.MessageDecorator
-  
- getPayloadType() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- getPayloadType() - Method in class org.axonframework.serialization.SerializedMessage
-  
- getPhase() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- getPhase() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. 
- getPhase() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- getPriority() - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-  
- getPriority() - Method in class org.axonframework.common.property.DirectPropertyAccessStrategy
-  
- getPriority() - Method in class org.axonframework.common.property.PropertyAccessStrategy
- 
The priority of this strategy. 
- getPriority() - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-  
- getProcessingGroup() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
The processing group this dead letter belongs to. 
- getProcessingStarted() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Timestamp indicating when the processing of this dead letter has started. 
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Returns the name of the process to which this token belongs. 
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-  
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
-  
- getProcessors() - Method in class org.axonframework.springboot.EventProcessorProperties
- 
Returns the settings for each of the configured processors, by name. 
- getProcessorsNotificationInitialDelay() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getProcessorsNotificationRate() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getProperty(Class<? extends T>, String) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
- 
Iterates over all known PropertyAccessStrategy implementations to create a  Property instance for the
 given parameters. 
- getPublisherId() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Returns the Identifier of the publisher that is chosen to handle this entry. 
- getPublisherInterceptorChain() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Returns the InterceptorChain for the publication process registered with this entry, or nullif none is
 available.
 
- getQueryExecutionErrorCode(Throwable) - Static method in enum org.axonframework.axonserver.connector.ErrorCode
- 
Returns an Query Execution ErrorCode variation based on the transiency of the given  Throwable
- getQueryFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getQueryHandler() - Method in class org.axonframework.queryhandling.QuerySubscription
- 
- getQueryName() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-  
- getQueryName() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- getQueryName() - Method in interface org.axonframework.queryhandling.annotation.QueryHandlingMember
- 
Returns the name of the query the handler can handle 
- getQueryName() - Method in class org.axonframework.queryhandling.GenericQueryMessage
-  
- getQueryName() - Method in interface org.axonframework.queryhandling.QueryMessage
- 
Returns the name identifying the query to be executed. 
- getQueryResultEntry() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
- 
Returns the wrapped entry as returned by the AxonServer Java Connector. 
- getQueryThreads() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getReader(Class<?>) - Method in class org.axonframework.serialization.json.JacksonSerializer
- 
Provides the ObjectReader, with which objects are read from the JSON form. 
- getRegistration() - Method in class org.axonframework.queryhandling.UpdateHandlerRegistration
- 
Gets the registration. 
- getRegistry() - Method in class org.axonframework.metrics.GlobalMetricRegistry
- 
Returns the global MetricRegistryto which components are registered.
 
- getRegistry() - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Returns the global MeterRegistryto which components are registered.
 
- getRemainingOfDeadline(long) - Static method in class org.axonframework.common.ObjectUtils
- 
- getRepository(Class<?>) - Static method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
- 
Returns the Repository instance for Aggregate with given typeIdentifierused by the CommandHandlerInvoker
 that is running on the current thread.
 
- getRepository() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- getRepository() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Returns the repository used by this fixture. 
- getRequestStream() - Method in class org.axonframework.axonserver.connector.util.UpstreamAwareStreamObserver
- 
Returns the request stream observer which allows interaction with the client stream. 
- getResetPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Return the relative position at which a reset was triggered for this Segment. 
- getResetPosition() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- getResetPosition() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- getResolver() - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-  
- getResolver() - Method in class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory
-  
- getResolver() - Method in class org.axonframework.eventhandling.TimestampParameterResolverFactory
-  
- getResolver() - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-  
- getResolver() - Method in class org.axonframework.messaging.annotation.AggregateTypeParameterResolverFactory
-  
- getResolver() - Method in class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
-  
- getResolver() - Method in class org.axonframework.messaging.annotation.SourceIdParameterResolverFactory
-  
- getResource(String) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Returns the resource attached under given name, ornullif no such resource is
 available.
 
- getResponseType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-  
- getResponseType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- getResponseType() - Method in class org.axonframework.queryhandling.GenericQueryMessage
-  
- getResponseType() - Method in interface org.axonframework.queryhandling.QueryMessage
- 
The type of response expected by the sender of the query 
- getResponseType() - Method in class org.axonframework.queryhandling.QuerySubscription
- 
Retrieve the response type of this subscription as a  Type. 
- getResponseType() - Method in interface org.axonframework.queryhandling.StreamingQueryMessage
-  
- getResult() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
- 
Waits if necessary for the command handling to complete, and then returns its result. 
- getResult(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
- 
Waits if necessary for at most the given time for the command handling to complete, and then retrieves its
 result, if available. 
- getResult() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Returns the result of the command's execution, or nullif the command is not yet executed or resulted in
 an exception.
 
- getResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
- 
Return the execution result message. 
- getResultType() - Method in interface org.axonframework.queryhandling.annotation.QueryHandlingMember
- 
Returns the return type declared by the handler 
- getRevision() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. Returns the revision of the serialized saga 
- getRevision() - Method in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
- 
Returns the revision of the serialized saga 
- getRevision() - Method in interface org.axonframework.serialization.SerializedType
- 
Returns the revision identifier of the serialized object. 
- getRevision() - Method in class org.axonframework.serialization.SimpleSerializedType
-  
- getRevisionResolver() - Method in class org.axonframework.serialization.json.JacksonSerializer
- 
Returns the revision resolver used by this serializer. 
- getRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
-  
- getRoutingKey(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.RoutingStrategy
- 
Generates a routing key for the given command.
 
- getRoutingKey(CommandMessage<?>) - Method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
-  
- getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
- 
Returns the Saga Initialization Policy for a Saga of the given sagaTypeandevent.
 
- getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager
-  
- getSagaId() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. Returns the identifier of the saga contained in this entry 
- getSagaId() - Method in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
- 
Returns the identifier of the saga contained in this entry 
- getSagaIdentifier() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-  
- getSagaIdentifier() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
- 
Returns the Saga Identifier contained in this entry. 
- getSagaIdentifier() - Method in interface org.axonframework.modelling.saga.Saga
- 
Returns the unique identifier of this saga. 
- getSagaIdentifier() - Method in class org.axonframework.modelling.saga.SagaLifecycle
- 
Retrieve a  String denoting the identifier of this Saga. 
- getSagaType() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
- 
Returns the class of Saga managed by this SagaManager 
- getSagaType() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. Returns the type identifier of the serialized saga 
- getSagaType() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
- 
Returns the type (fully qualified class name) of the Saga this association value belongs to 
- getSagaType() - Method in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
- 
Returns the type identifier of the serialized saga 
- getScheduledDeadlines() - Method in class org.axonframework.test.deadline.StubDeadlineManager
- 
Return all scheduled deadlines which have not been met (yet). 
- getScheduledItems() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
- 
Returns a view of all the scheduled Events at the time this method is called. 
- getScheduleId() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Retrieve a  String identifier representing the scheduled deadline; can be used together with the
  deadlineName to cancel the deadline. 
- getScheduleTime() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Retrieve the time as an  Instant at which the deadline is scheduled. 
- getScheduleTime() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
- 
The time the event was scheduled for publication. 
- getScheduleTime() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
-  
- getScopeDescriptor() - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
Returns the serialized  String which tells what the scope is of the deadline. 
- getScopeDescriptorClass() - Method in class org.axonframework.deadline.jobrunr.DeadlineDetails
- 
Returns the  String with the class of the scope descriptor. 
- getSegment() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
The segment for which this status is valid. 
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Returns the segment index of the process to which this token belongs. 
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-  
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
-  
- getSegment() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- getSegment() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- getSegmentId() - Method in class org.axonframework.eventhandling.Segment
- 
Getter for the segment identifier. 
- getSequenceIdentifier() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
The sequence identifier of this dead letter. 
- getSequenceIdentifier() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
- 
- getSequenceIdentifier() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. 
- getSequenceIdentifier() - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
- 
- getSequenceIdentifierFor(EventMessage<?>) - Method in class org.axonframework.eventhandling.async.FullConcurrencyPolicy
-  
- getSequenceIdentifierFor(EventMessage) - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy
-  
- getSequenceIdentifierFor(T) - Method in interface org.axonframework.eventhandling.async.SequencingPolicy
- 
Returns the sequence identifier for the given event.
 
- getSequenceIdentifierFor(EventMessage) - Method in class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-  
- getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.SequentialPolicy
-  
- getSequenceIndex() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
- getSequenceNumber() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-  
- getSequenceNumber() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
-  
- getSequenceNumber() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getSequenceNumber() - Method in interface org.axonframework.eventhandling.DomainEventData
- 
Returns the sequence number of the event in the aggregate. 
- getSequenceNumber() - Method in interface org.axonframework.eventhandling.DomainEventMessage
- 
Returns the sequence number that allows DomainEvents originating from the same Aggregate to be placed in the
 order of generation. 
- getSequenceNumber() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-  
- getSequenceNumber() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-  
- getSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-  
- getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getSequenceNumber() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the sequence number of the event in the aggregate, or an empty Optional if the message wrapping the
 object being upcast does not contain a sequence number. 
- getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getSequencingPolicy() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
- 
- getSequencingPolicy() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Returns the name of the bean that defines the  SequencingPolicy
 for this processor. 
- getSerializedException() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the serialized exception of the serialized reply message. 
- getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Returns the serialized metadata of the command carried by this instance. 
- getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the serialized meta data of the serialized reply message. 
- getSerializedObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
- 
Returns the serialized object to deserialize upon request 
- getSerializedPayload() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Returns the serialized payload of the command carried by this instance. 
- getSerializedPayload() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Returns the serialized payload of the serialized reply message. 
- getSerializedSaga() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. Returns the serialized form of the Saga. 
- getSerializedSaga() - Method in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
- 
Returns the serialized form of the Saga. 
- getSerializedToken() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Returns the serialized token. 
- getSerializedToken() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
- 
Returns the serialized token. 
- getSerializer() - Method in class org.axonframework.serialization.LazyDeserializingObject
- 
Returns the serializer to deserialize this object 
- getServer() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
- 
Returns the name of the server that reported the error. 
- getServer() - Method in exception org.axonframework.axonserver.connector.command.AxonServerNonTransientRemoteCommandHandlingException
- 
Returns the name of the server that reported the error. 
- getServer() - Method in exception org.axonframework.axonserver.connector.query.AxonServerNonTransientRemoteQueryHandlingException
- 
Returns the name of the server that reported the error. 
- getServer() - Method in exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
- 
Return a  String defining the location where the error originated. 
- getServers() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getSnapshotData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Extracts the next snapshot entry from the given resultSet.
 
- getSnapshotPrefetch() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getSnapshotSerializer() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
- 
Get the serializer used by this storage engine when storing and retrieving snapshots. 
- getSnapshotTrigger() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
The trigger instance that monitors this aggregate to trigger a snapshot 
- getSortValues() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
- 
Returns the list of values to use to compare the order of this entry to other entries. 
- getSource() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Returns the name of the bean that should be used as source for Event Messages. 
- getSpringCloud() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Returns the Spring Cloud configuration to use (if Spring Cloud is on the classpath). 
- getState() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Get the state of the event processor. 
- getSubscriptions() - Method in class org.axonframework.queryhandling.SimpleQueryBus
- 
Returns the subscriptions for this query bus. 
- getSubscriptions() - Method in class org.axonframework.test.utils.RecordingCommandBus
- 
Returns a Map will all Command Names and their Command Handler that have been subscribed to this command bus. 
- getSuppressDownloadMessage() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getTags() - Method in class org.axonframework.config.TagsConfiguration
- 
Gets tags. 
- getTags() - Method in class org.axonframework.springboot.TagsConfigurationProperties
- 
Gets tags. 
- getTargetType() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-  
- getTargetType() - Method in interface org.axonframework.messaging.MessageHandler
- 
Returns the instance type that this handler delegates to. 
- getterName(String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
- 
Returns the name of the method that is used to access the property. 
- getterName(String) - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-  
- getterName(String) - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-  
- getThreadCount() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
- getThreadFactory(String) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
- 
Provides the ThreadFactory to use to construct Threads for the processor with given processorName
 
- getTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
-  
- getTimestamp() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-  
- getTimestamp() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-  
- getTimeStamp() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getTimestamp() - Method in interface org.axonframework.eventhandling.EventData
- 
Returns the timestamp at which the event was first created. 
- getTimestamp() - Method in interface org.axonframework.eventhandling.EventMessage
- 
Returns the timestamp of this event. 
- getTimestamp() - Method in class org.axonframework.eventhandling.GenericEventMessage
-  
- getTimestamp() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-  
- getTimestamp() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
- 
Deprecated. Get the timestamp of the last event tracked by this token. 
- getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getTimestamp() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the timestamp at which the event was first created. 
- getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getToken() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- getToken(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Returns the token, deserializing it with given serializer
 
- getToken(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
- 
Returns the token, deserializing it with given serializer
 
- getTokenAtReset(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Return the relative position at which a reset was triggered for this Segment. 
- getTokenAtReset() - Method in class org.axonframework.eventhandling.ReplayToken
- 
Gets the token representing the position at which the reset was triggered. 
- getTokenClaimInterval() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
- 
Returns the time, in milliseconds, the processor should wait after a failed attempt to claim any segments for
 processing. 
- getTokenClaimInterval() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
- getTokenClaimIntervalTimeUnit() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Returns the time unit used to define tokens claim interval. 
- getTokenForStream(String) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
- 
Return the tracking token for an individual stream 
- getTokenId() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
- 
Returns the identifier of the scheduled task. 
- getTokenStoreIdentifier() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- getTokenStoreIdentifier() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
- getTokenStoreIdentifier() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- getTokenType() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Returns the  SerializedType of the serialized token, or  null if no token is stored by this entry. 
- getTokenType() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
- 
Returns the  SerializedType of the serialized token, or  null if no token is stored by this entry. 
- getTrackedEventData(ResultSet, GapAwareTrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Extracts the next tracked event entry from the given resultSet.
 
- getTrackedEvents() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
- 
Deprecated. Gets tracked events. 
- getTrackingToken() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getTrackingToken() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
The tracking token of the last event that has been seen by this Segment. 
- getTrackingToken() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- getTrackingToken() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getTrackingToken() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the tracking token of the event, or an empty Optional if the message wrapping the object being upcast
 does not contain a tracking token. 
- getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getTrackingTokens() - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
- 
Returns the map containing the constituent tokens. 
- getTriggeredDeadlines() - Method in class org.axonframework.test.deadline.StubDeadlineManager
- 
Return all triggered deadlines. 
- getType() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-  
- getType() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
-  
- getType() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
-  
- getType() - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEventEntry
- 
- getType() - Method in interface org.axonframework.eventhandling.DomainEventData
- 
Returns the type identifier of the aggregate. 
- getType() - Method in interface org.axonframework.eventhandling.DomainEventMessage
- 
Returns the type of the Aggregate that generated this DomainEvent. 
- getType() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-  
- getType() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-  
- getType() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-  
- getType() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
- 
Returns the type of Aggregate, as String, targeted by this scope 
- getType() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
- 
The type of Saga described by this scope 
- getType() - Method in class org.axonframework.serialization.LazyDeserializingObject
- 
Returns the class of the serialized object. 
- getType() - Method in class org.axonframework.serialization.SerializedMetaData
-  
- getType() - Method in interface org.axonframework.serialization.SerializedObject
- 
Returns the description of the type of object contained in the data. 
- getType() - Method in class org.axonframework.serialization.SimpleSerializedObject
-  
- getType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-  
- getType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
- 
Returns the type and version of the data contained in this representation. 
- getType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-  
- getUpcasters() - Method in class org.axonframework.serialization.upcasting.GenericUpcasterChain
- 
Returns the list of  upcasters that makes up this chain. 
- getUpdateResponseType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-  
- getUpdateResponseType() - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
-  
- getUpdateResponseType() - Method in interface org.axonframework.queryhandling.SubscriptionQueryMessage
- 
Returns the type of incremental responses. 
- getUpdates() - Method in class org.axonframework.queryhandling.UpdateHandlerRegistration
- 
Gets the updates. 
- getValue(T) - Method in class org.axonframework.common.property.DirectlyAccessedProperty
-  
- getValue(T) - Method in class org.axonframework.common.property.MethodAccessedProperty
-  
- getValue(T) - Method in interface org.axonframework.common.property.Property
- 
Returns the value of the property on given target.
 
- getValue() - Method in class org.axonframework.modelling.saga.AssociationValue
- 
Returns the value of this association. 
- getValues() - Method in class org.axonframework.domain.MetaData
- 
Deprecated. Get this metadata's mappings. 
- getVersion() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Gets the version of the aggregate. 
- getVersion(T) - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
- 
Get the current version number of the given aggregate.
 
- getVersion() - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
- 
Returns the version of the targeted Aggregate, or nullif the version is irrelevant.
 
- getViolatingMethod() - Method in exception org.axonframework.messaging.annotation.UnsupportedHandlerException
- 
A reference to the method that violated the event handler rules. 
- getViolations() - Method in exception org.axonframework.messaging.interceptors.JSR303ViolationException
- 
Returns the violations that were detected when this exception was thrown. 
- getViolations() - Method in exception org.axonframework.messaging.interceptors.legacyvalidation.JSR303ViolationException
- 
Deprecated. Returns the violations that were detected when this exception was thrown. 
- getWorkerTerminationTimeout() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
- 
- getWrappedAggregate() - Method in class org.axonframework.modelling.command.LockAwareAggregate
- 
Get the delegate aggregate wrapped by this instance. 
- getWriter() - Method in class org.axonframework.serialization.json.JacksonSerializer
- 
Provides the ObjectWriter, with which objects are serialized to JSON form. 
- getXStream() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Returns a reference to the underlying XStreaminstance, that does the actual
 serialization.
 
- given(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- given(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- given(Object...) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Configures the given domainEventsas the "given" events.
 
- given(List<?>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Configures the given domainEventsas the "given" events.
 
- givenAggregate(String) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Use this method to indicate that an aggregate with given identifier published certain events. 
- givenAggregate(String) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- GivenAggregateEventPublisher - Interface in org.axonframework.test.saga
- 
Interface to an object that publishes events on behalf of an aggregate. 
- givenAPublished(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Indicates that the given applicationEventhas been published in the past.
 
- givenAPublished(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- givenCommands(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- givenCommands(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- givenCommands(Object...) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Configures the given commandsas to execute against the aggregate under test to initiate the given-phase.
 
- givenCommands(List<?>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Configures the given commandsas to execute against the aggregate under test to initiate the given-phase.
 
- givenCurrentTime(Instant) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- givenCurrentTime(Instant) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start of
 the given state. 
- givenCurrentTime(Instant) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start of
 the given state. 
- givenCurrentTime(Instant) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- givenNoPriorActivity() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- givenNoPriorActivity() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Indicates that no relevant activities like commands or events have occurred in the past. 
- givenNoPriorActivity() - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Indicates that no relevant activity has occurred in the past. 
- givenNoPriorActivity() - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- givenState(Supplier<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- givenState(Supplier<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Sets the aggregate instance as supplied by given aggregateStateas the initial state for a test case.
 
- globalIndexColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the global index column. 
- globalIndexColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the global index of the event. 
- GlobalMetricRegistry - Class in org.axonframework.metrics
- 
Registry for application metrics with convenient ways to register Axon components. 
- GlobalMetricRegistry() - Constructor for class org.axonframework.metrics.GlobalMetricRegistry
- 
- GlobalMetricRegistry(MetricRegistry) - Constructor for class org.axonframework.metrics.GlobalMetricRegistry
- 
- GlobalMetricRegistry - Class in org.axonframework.micrometer
- 
Registry for application metrics with convenient ways to register Axon components. 
- GlobalMetricRegistry() - Constructor for class org.axonframework.micrometer.GlobalMetricRegistry
- 
- GlobalMetricRegistry(MeterRegistry) - Constructor for class org.axonframework.micrometer.GlobalMetricRegistry
- 
- globalMetricRegistry(MetricRegistry) - Static method in class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
-  
- globalMetricRegistry(MeterRegistry) - Static method in class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
-  
- GlobalSequenceTrackingToken - Class in org.axonframework.eventhandling
- 
Tracking token based on the global sequence number of an event. 
- GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventhandling.GlobalSequenceTrackingToken
- 
- GlobalSequenceTrackingToken - Class in org.axonframework.eventsourcing.eventstore
- 
- GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
- 
Deprecated. 
- Gossip() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
-  
- GrpcBackedCommandMessage<C> - Class in org.axonframework.axonserver.connector.command
- 
Wrapper that allows clients to access a gRPC  Command as a  CommandMessage. 
- GrpcBackedCommandMessage(Command, Serializer) - Constructor for class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
- 
- GrpcBackedDomainEventData - Class in org.axonframework.axonserver.connector.event.axon
- 
DomainEventData implementation that retrieves its raw data from a protobuf Eventmessage.
 
- GrpcBackedDomainEventData(Event) - Constructor for class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
- 
Initialize using the given eventas the source of raw data.
 
- GrpcBackedQueryMessage<Q,R> - Class in org.axonframework.axonserver.connector.query
- 
Wrapper that allows clients to access a gRPC  QueryRequest as a  QueryMessage. 
- GrpcBackedQueryMessage(QueryRequest, Serializer, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
- 
- GrpcBackedResponseMessage<R> - Class in org.axonframework.axonserver.connector.query
- 
- GrpcBackedResponseMessage(QueryResponse, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
- 
- GrpcBackedSubscriptionQueryMessage<Q,I,U> - Class in org.axonframework.axonserver.connector.query.subscription
- 
- GrpcBackedSubscriptionQueryMessage(SubscriptionQuery, Serializer, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
- 
- GrpcBufferingInterceptor - Class in org.axonframework.axonserver.connector.util
- 
- GrpcBufferingInterceptor(int) - Constructor for class org.axonframework.axonserver.connector.util.GrpcBufferingInterceptor
- 
Deprecated. Initialize the interceptor to ask for additionalBufferamount of messages from the server.
 
- GrpcExceptionParser - Class in org.axonframework.axonserver.connector.event.util
- 
- GrpcExceptionParser() - Constructor for class org.axonframework.axonserver.connector.event.util.GrpcExceptionParser
-  
- GrpcHeartbeatSource - Class in org.axonframework.axonserver.connector.heartbeat.source
- 
- GrpcHeartbeatSource(AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.heartbeat.source.GrpcHeartbeatSource
- 
Deprecated. 
- GrpcMetaData - Class in org.axonframework.axonserver.connector.util
- 
Implementation that provides access to a  Map of gRPC  MetaDataValues in the form of  MetaData. 
- GrpcMetaData(Map<String, MetaDataValue>, Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetaData
- 
Instantiate a wrapper around the given  metaDataValues providing access to them as a  MetaData
 object. 
- GrpcMetaDataAwareSerializer - Class in org.axonframework.axonserver.connector.event.axon
- 
Wrapper around standard Axon Framework serializer that can deserialize Metadata from AxonServer events. 
- GrpcMetaDataAwareSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
- 
- GrpcMetaDataConverter - Class in org.axonframework.axonserver.connector.util
- 
Utility class for converting gRPC MetaData entries into a Java Map and vice versa. 
- GrpcMetaDataConverter(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
- 
Initialize the converter, using the given serializerto serialize Objects.
 
- GrpcMetadataSerializer - Class in org.axonframework.axonserver.connector.util
- 
Mapping that translates a  MetaData into a map of GRPC  MetaDataValue. 
- GrpcMetadataSerializer(GrpcMetaDataConverter) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetadataSerializer
- 
- GrpcObjectSerializer<O> - Class in org.axonframework.axonserver.connector.util
- 
Mapping that translates an object into a GRPC SerializedObject.
 
- GrpcObjectSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcObjectSerializer
- 
Constructs a  GrpcObjectSerializer using the given  serializer to serialize the payload and type of
 given objects with. 
- GrpcObjectSerializer.Serializer<A> - Interface in org.axonframework.axonserver.connector.util
- 
Contract towards serializing an object of type A.
 
- GrpcPayloadSerializer - Class in org.axonframework.axonserver.connector.util
- 
Mapping that translates a  Message into a GRPC  SerializedObject. 
- GrpcPayloadSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcPayloadSerializer
- 
- GrpcSerializedObject - Class in org.axonframework.axonserver.connector.util
- 
Wrapper that allows clients to access a gRPC  SerializedObject message as a  SerializedObject. 
- GrpcSerializedObject(SerializedObject) - Constructor for class org.axonframework.axonserver.connector.util.GrpcSerializedObject
- 
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
- 
Returns the sql to register the auto incrementing global sequence column. 
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
-  
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
-  
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-  
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
-  
- identifier() - Method in interface org.axonframework.modelling.command.Aggregate
- 
Get the unique identifier of this aggregate 
- identifier() - Method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Retrieve a  Object denoting the identifier of this Aggregate. 
- identifier() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- identifier() - Method in class org.axonframework.modelling.command.LockAwareAggregate
-  
- identifier() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-  
- identifierAsString() - Method in interface org.axonframework.modelling.command.Aggregate
- 
Get the unique identifier of this aggregate, represented as a String. 
- identifierConverter(Function<String, ?>) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
- 
Sets the  Function which converts a  String based identifier to the Identifier object used in
 the Entity. 
- identifierConverter(Function<String, ?>) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. Sets the  Function which converts a  String based identifier to the Identifier object used in
 the Entity. 
- IdentifierFactory - Class in org.axonframework.common
- 
Abstract Factory class that provides access to an IdentifierFactory implementation. 
- IdentifierFactory() - Constructor for class org.axonframework.common.IdentifierFactory
-  
- IdentifierMissingException - Exception in org.axonframework.modelling.command
- 
Exception indicating that a required identifier is missing in the processed message. 
- IdentifierMissingException(String) - Constructor for exception org.axonframework.modelling.command.IdentifierMissingException
- 
Constructs an exception based on the given message.
 
- IdentifierValidator - Class in org.axonframework.common
- 
Validates the structure of an object passed as Aggregate Identifier. 
- identity() - Static method in interface org.axonframework.axonserver.connector.ManagedChannelCustomizer
- 
- ifShuttingDown(String) - Method in class org.axonframework.lifecycle.ShutdownLatch
- 
- ifShuttingDown(Supplier<RuntimeException>) - Method in class org.axonframework.lifecycle.ShutdownLatch
- 
- ifStarted(Consumer<UnitOfWork<?>>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
- 
If a UnitOfWork is started, invokes the given consumerwith the active Unit of Work.
 
- ignore() - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- Ignore<M extends Message<?>> - Class in org.axonframework.messaging.deadletter
- 
- Ignore() - Constructor for class org.axonframework.messaging.deadletter.Ignore
-  
- IgnoreField - Class in org.axonframework.test.matchers
- 
FieldFilter implementation that rejects a given Field 
- IgnoreField(Field) - Constructor for class org.axonframework.test.matchers.IgnoreField
- 
Initialize an instance that ignores the given field
 
- IgnoreField(Class<?>, String) - Constructor for class org.axonframework.test.matchers.IgnoreField
- 
Initialize an instance that ignores the a field with given fieldName, which is declared on the
 givenclazz.
 
- ignoringResultParameters(Supplier<T>) - Static method in class org.axonframework.messaging.annotation.ResultParameterResolverFactory
- 
Performs the given actionignoring any parameters expecting a result type.
 
- IllegalPayloadAccessException - Exception in org.axonframework.messaging
- 
Indicates situations when access to the Payload of a Message is not allowed. 
- IllegalPayloadAccessException(String) - Constructor for exception org.axonframework.messaging.IllegalPayloadAccessException
- 
Creates the exception with given message.
 
- IllegalPayloadAccessException(String, Throwable) - Constructor for exception org.axonframework.messaging.IllegalPayloadAccessException
- 
Creates the exception with given messageandcause.
 
- ImportSelector() - Constructor for class org.axonframework.spring.config.SpringAxonAutoConfigurer.ImportSelector
- 
Deprecated. 
- INBOUND_COMMAND_CONNECTOR - Static variable in class org.axonframework.lifecycle.Phase
- 
Phase to start or shutdown inbound command connectors. 
- INBOUND_EVENT_CONNECTORS - Static variable in class org.axonframework.lifecycle.Phase
- 
Phase to start or shutdown inbound event connectors. 
- INBOUND_QUERY_CONNECTOR - Static variable in class org.axonframework.lifecycle.Phase
- 
Phase to start or shutdown inbound query connectors. 
- InboundEventMessageChannelAdapter - Class in org.axonframework.spring.messaging
- 
Adapter class that publishes Events from a Spring Messaging Message Channel on the Event Bus. 
- InboundEventMessageChannelAdapter() - Constructor for class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
- 
Initialize the adapter to publish all incoming events to the subscribed processors. 
- InboundEventMessageChannelAdapter(EventBus) - Constructor for class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
- 
Initialize an InboundEventMessageChannelAdapter instance that sends all incoming Event Messages to the given
 eventBus.
 
- InboundEventMessageChannelAdapter(List<Consumer<List<? extends EventMessage<?>>>>, EventMessageConverter) - Constructor for class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
- 
Initialize the adapter to publish all incoming events to the subscribed processors. 
- IncompatibleAggregateException - Exception in org.axonframework.eventsourcing
- 
- IncompatibleAggregateException(String, Exception) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
- 
Initialize the exception with given messageandcause.
 
- IncompatibleAggregateException(String) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
- 
Initialize the exception with given message.
 
- infoSupplier(EventProcessor) - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
-  
- InfraConfiguration - Class in org.axonframework.springboot.autoconfig
- 
Infrastructure autoconfiguration class for Axon Framework application. 
- InfraConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- INITIAL_LOAD_FACTOR - Static variable in class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
The initial load factor of this node when it is registered with the  CommandRouter. 
- InitialEventRepresentation - Class in org.axonframework.serialization.upcasting.event
- 
- InitialEventRepresentation(EventData<?>, Serializer) - Constructor for class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
- 
- initializationFinished() - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
-  
- initializationFinished() - Method in interface org.axonframework.eventsourcing.SnapshotTrigger
- 
Invoked when the initialization of the aggregate based on passed events is completed. 
- initialize(Configuration) - Method in class org.axonframework.axonserver.connector.event.axon.EventProcessorInfoConfiguration
-  
- initialize(Configuration) - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatConfiguration
- 
Deprecated. Initializes the  GrpcHeartbeatSource component, needed to send heartbeats to AxonServer, any time the
 client will receive an heartbeat from the server. 
- initialize(Configuration) - Method in class org.axonframework.config.AggregateConfigurer
-  
- initialize(Configuration) - Method in class org.axonframework.config.EventProcessingModule
-  
- initialize(Configuration) - Method in interface org.axonframework.config.ModuleConfiguration
- 
Initialize the module configuration using the given global config.
 
- initialize(Configuration) - Method in class org.axonframework.config.SagaConfigurer
- 
- initialize(ConflictResolver) - Static method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
- 
Initialize conflict resolution in the context of the current Unit of Work dealing with a command on an event
 sourced aggregate. 
- initialize(T, AggregateModel<T>, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Initializes an EventSourcedAggregate instance for the given aggregateRoot, based on the giveninspector, which publishes events to the giveneventBus.
 
- initialize(T, AggregateModel<T>, EventBus, RepositoryProvider, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Initializes an EventSourcedAggregate instance for the given aggregateRoot, based on the giveninspector, which publishes events to the giveneventBus.
 
- initialize(Callable<T>, AggregateModel<T>, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Initializes an EventSourcedAggregate instance using the given aggregateFactory, based on the giveninspector, which publishes events to the giveneventBusand stores events in the giveneventStore.
 
- initialize(Callable<T>, AggregateModel<T>, EventBus, RepositoryProvider, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Initializes an EventSourcedAggregate instance using the given aggregateFactory, based on the giveninspector, which publishes events to the giveneventBusand stores events in the giveneventStore.
 
- initialize() - Method in class org.axonframework.lifecycle.ShutdownLatch
- 
- initialize(InterceptorChain) - Static method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
- 
- initialize(Member, EntityModel) - Method in interface org.axonframework.modelling.command.ForwardingMode
- 
- initialize(Member, EntityModel) - Method in class org.axonframework.modelling.command.ForwardMatchingInstances
-  
- initialize(Callable<T>, AggregateModel<T>, EventBus) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Initialize an aggregate created by the given aggregateFactorywhich is described in the givenaggregateModel.
 
- initialize(Callable<T>, AggregateModel<T>, EventBus, RepositoryProvider) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Initialize an aggregate created by the given aggregateFactorywhich is described in the givenaggregateModel.
 
- initialize(Callable<T>, AggregateModel<T>, EventBus, boolean) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Initialize an aggregate created by the given aggregateFactorywhich is described in the givenaggregateModel.
 
- initialize(Callable<T>, AggregateModel<T>, EventBus, RepositoryProvider, boolean) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Initialize an aggregate created by the given aggregateFactorywhich is described in the givenaggregateModel.
 
- initialize(T, AggregateModel<T>, EventBus) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Initialize an aggregate with the given aggregateRootwhich is described in the givenaggregateModel.
 
- initialize(T, AggregateModel<T>, EventBus, RepositoryProvider) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Initialize an aggregate with the given aggregateRootwhich is described in the givenaggregateModel.
 
- initializeAdapterFor(Object, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. Create an AnnotationEventListenerAdapter instance of the given bean.
 
- initializeAdapterFor(Object, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
- 
Deprecated. 
- initializeAdapterFor(Object, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
- 
Deprecated. 
- initializeAt(TemporalAccessor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
- 
Resets the initial "current time" of this manager. 
- initializeAt(TemporalAccessor) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
- 
Resets the initial "current time" of this SubEventScheduler. 
- initializeSegment(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- initializeSegment(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- initializeSegment(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- initializeSegment(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- initializeSegment(TrackingToken, String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Initializes a segment with given segmentfor the processor with givenprocessorNameto contain
 the giventoken.
 
- initializeState(DomainEventStream) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Initialize the state of this Event Sourced Aggregate with the events from the given eventStream.
 
- initializeTokenSegments(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- initializeTokenSegments(String, int, TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- initializeTokenSegments(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- initializeTokenSegments(String, int, TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- initializeTokenSegments(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- initializeTokenSegments(String, int, TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- initializeTokenSegments(String, int) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- initializeTokenSegments(String, int, TrackingToken) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- initializeTokenSegments(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Initializes the given segmentCountnumber of segments for the givenprocessorNameto track its
 tokens.
 
- initializeTokenSegments(String, int, TrackingToken) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Initializes the given segmentCountnumber of segments for the givenprocessorNameto track its
 tokens.
 
- initialResult() - Method in class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
-  
- initialResult() - Method in class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
- 
Deprecated. 
- initialResult() - Method in class org.axonframework.axonserver.connector.query.subscription.DisposableResult
- 
Deprecated. 
- initialResult() - Method in class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
-  
- initialResult() - Method in interface org.axonframework.queryhandling.SubscriptionQueryResult
- 
Subscribing to this mono will trigger invocation of query handler. 
- initialSegmentCount(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
- 
Sets the initial segment count used to create segments on start up. 
- initialToken(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
- 
- initiateShutdown() - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
- 
- initiateShutdown() - Method in class org.axonframework.lifecycle.ShutdownLatch
- 
Initiate the shutdown of this latch. 
- initSequence() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Enable sequences on this Aggregate, causing it to emit DomainEventMessages, starting at sequence 0. 
- initSequence(long) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Enable sequences on this Aggregate, causing it to emit DomainEventMessages based on the given lastKnownSequenceNumber.
 
- injectorAnnotationNames() - Method in class org.axonframework.modelling.saga.AbstractResourceInjector
- 
Provides an array with fully qualified class names of the annotation that indicate an injection point for a
 resource. 
- injectResources(Object) - Method in class org.axonframework.modelling.saga.AbstractResourceInjector
-  
- injectResources(Object) - Method in enum org.axonframework.modelling.saga.repository.NoResourceInjector
-  
- injectResources(Object) - Method in interface org.axonframework.modelling.saga.ResourceInjector
- 
Inject required resources into the given saga.
 
- injectResources(Object) - Method in class org.axonframework.spring.saga.SpringResourceInjector
-  
- InMemoryEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore.inmemory
- 
Thread-safe event storage engine that stores events and snapshots in memory. 
- InMemoryEventStorageEngine() - Constructor for class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
- 
Initializes an InMemoryEventStorageEngine. 
- InMemoryEventStorageEngine(long) - Constructor for class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
- 
Initializes an InMemoryEventStorageEngine using given offsetto initialize the tokens with.
 
- InMemorySagaStore - Class in org.axonframework.modelling.saga.repository.inmemory
- 
SagaRepository implementation that stores all Saga instances in memory. 
- InMemorySagaStore() - Constructor for class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
-  
- InMemorySequencedDeadLetterQueue<M extends Message<?>> - Class in org.axonframework.messaging.deadletter
- 
- InMemorySequencedDeadLetterQueue(InMemorySequencedDeadLetterQueue.Builder<M>) - Constructor for class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
- 
- InMemorySequencedDeadLetterQueue.Builder<M extends Message<?>> - Class in org.axonframework.messaging.deadletter
- 
- InMemoryTokenStore - Class in org.axonframework.eventhandling.tokenstore.inmemory
- 
Implementation of a  TokenStore that stores tracking tokens in memory. 
- InMemoryTokenStore() - Constructor for class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- InputStreamToByteArrayConverter - Class in org.axonframework.serialization.converters
- 
Converter that converts an InputStream to a byte array. 
- InputStreamToByteArrayConverter() - Constructor for class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
-  
- InputStreamToDom4jConverter - Class in org.axonframework.serialization.xml
- 
Converter that converts an input stream to a Dom4J document. 
- InputStreamToDom4jConverter() - Constructor for class org.axonframework.serialization.xml.InputStreamToDom4jConverter
-  
- InputStreamToXomConverter - Class in org.axonframework.serialization.xml
- 
Converter that converts an input stream to a XOM document. 
- InputStreamToXomConverter() - Constructor for class org.axonframework.serialization.xml.InputStreamToXomConverter
-  
- insertSaga(Class<? extends T>, String, T, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
-  
- insertSaga(Class<?>, String, Object, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
-  
- insertSaga(Class<?>, String, Object, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
-  
- insertSaga(Class<?>, String, Object, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
-  
- insertSaga(Class<?>, String, Object, Set<AssociationValue>) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. 
- insertSaga(Class<? extends T>, String, T, Set<AssociationValue>) - Method in interface org.axonframework.modelling.saga.repository.SagaStore
- 
Adds a new Saga and its initial association values to the store. 
- insertTokenEntry(Connection, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Inserts a new token entry via the given updatable resultSet.
 
- inspect(Class<? extends C>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Inspect another handler type and register the result to the inspector registry of this inspector. 
- inspectAggregate(Class<T>) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
- 
Shorthand to create a factory instance and inspect the model for the given aggregateType.
 
- inspectAggregate(Class<T>, Set<Class<? extends T>>) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
- 
Shorthand to create a factory instance and inspect the model for the given aggregateTypeand itssubtypes.
 
- inspectAggregate(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
- 
Shorthand to create a factory instance and inspect the model for the given aggregateType, using givenparameterResolverFactoryto resolve parameter values for annotated handlers.
 
- inspectAggregate(Class<T>, ParameterResolverFactory, HandlerDefinition) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
- 
Shorthand to create a factory instance and inspect the model for the given aggregateType, using givenparameterResolverFactoryto resolve parameter values for annotated handlers andhandlerDefinitionto create concrete handlers.
 
- inspectAggregate(Class<T>, ParameterResolverFactory, HandlerDefinition, Set<Class<? extends T>>) - Static method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
- 
Shorthand to create a factory instance and inspect the model for the given aggregateTypeand itssubytpes, using givenparameterResolverFactoryto resolve parameter values for annotated handlers andhandlerDefinitionto create concrete handlers.
 
- inspectType(Class<? extends T>) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
- inspectType(Class<? extends T>, ParameterResolverFactory) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Create an inspector for given handlerTypethat uses givenparameterResolverFactoryto resolve
 method parameters.
 
- inspectType(Class<? extends T>, ParameterResolverFactory, HandlerDefinition) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Create an inspector for given handlerTypethat uses givenparameterResolverFactoryto resolve
 method parameters and givenhandlerDefinitionto create handlers.
 
- inspectType(Class<? extends T>, ParameterResolverFactory, HandlerDefinition, Set<Class<? extends T>>) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
- 
Create an inspector for given handlerTypeand itsdeclaredSubtypesthat uses givenparameterResolverFactoryto resolve method parameters and givenhandlerDefinitionto create handlers.
 
- INSTANCE - Static variable in class org.axonframework.commandhandling.callbacks.LoggingCallback
- 
The singleton instance for this callback 
- INSTANCE - Static variable in class org.axonframework.commandhandling.callbacks.NoOpCallback
- 
A statically available instance of the NoOpCallback. 
- instance() - Static method in class org.axonframework.commandhandling.FailingDuplicateCommandHandlerResolver
- 
Returns a DuplicateCommandHandlerResolver that throws an exception when a duplicate registration is detected 
- instance() - Static method in class org.axonframework.commandhandling.LoggingDuplicateCommandHandlerResolver
- 
Returns an instance that logs duplicate registrations. 
- INSTANCE - Static variable in class org.axonframework.common.caching.NoCache
- 
Creates a singleton reference the NoCache implementation. 
- INSTANCE - Static variable in class org.axonframework.common.DirectExecutor
- 
Returns a singleton instance of the DirectExecutor. 
- INSTANCE - Static variable in class org.axonframework.common.lock.NoOpLock
-  
- instance() - Static method in enum org.axonframework.common.transaction.NoTransactionManager
- 
Returns the singleton instance of this TransactionManager 
- instance() - Static method in class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
- 
Return a singleton instance of the this Sequencing Policy. 
- instance() - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
- 
- INSTANCE - Static variable in class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
- 
Creates a singleton reference the the GenericTokenTableFactory implementation. 
- INSTANCE - Static variable in class org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory
- 
Creates a singleton reference the the Oracle11TokenTableFactory implementation. 
- INSTANCE - Static variable in class org.axonframework.eventhandling.tokenstore.jdbc.PostgresTokenTableFactory
- 
Creates a singleton reference the the PostgresTokenTableFactory implementation. 
- INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
- 
Singleton HsqlEventTableFactory instance 
- INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
- 
Singleton MySqlEventTableFactory instance 
- INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
- 
Singleton PostgresEventTableFactory instance 
- instance() - Static method in class org.axonframework.messaging.annotation.HandlerComparator
- 
Returns the singleton comparator managed by the HandlerComparator class. 
- INSTANCE - Static variable in class org.axonframework.messaging.NoScopeDescriptor
- 
- instance() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
- 
Returns the instance of {@link NoOpMessageMonitor}.
 
- instance() - Static method in class org.axonframework.queryhandling.registration.FailingDuplicateQueryHandlerResolver
- 
- instance() - Static method in class org.axonframework.queryhandling.registration.LoggingDuplicateQueryHandlerResolver
- 
Returns an instance that logs duplicate registrations. 
- instance() - Static method in class org.axonframework.test.matchers.AllFieldsFilter
- 
Returns the (singleton) instance of the AllFieldsFilter 
- instance() - Static method in class org.axonframework.test.matchers.NonStaticFieldsFilter
-  
- instance() - Static method in class org.axonframework.test.matchers.NonTransientFieldsFilter
- 
Returns the (singleton) instance of the AllFieldsFilter 
- INSTANCE - Static variable in class org.axonframework.tracing.LoggingSpanFactory
- 
- INSTANCE - Static variable in class org.axonframework.tracing.NoOpSpanFactory
- 
Singleton instance of the  NoOpSpanFactory, which is used for configuration when there is no specific
 implementation configured. 
- INSTANCE - Static variable in class org.axonframework.tracing.opentelemetry.MetadataContextGetter
- 
- INSTANCE - Static variable in class org.axonframework.tracing.opentelemetry.MetadataContextSetter
- 
- instanceOf(Class<R>) - Static method in class org.axonframework.messaging.responsetypes.ResponseTypes
- 
Specify the desire to retrieve a single instance of type Rwhen performing a query.
 
- InstanceResponseType<R> - Class in org.axonframework.messaging.responsetypes
- 
A  ResponseType implementation that will match with query handlers which return a single instance of the
 expected response type. 
- InstanceResponseType(Class<R>) - Constructor for class org.axonframework.messaging.responsetypes.InstanceResponseType
- 
Instantiate a  InstanceResponseType with the given  expectedResponseType as the type to be matched
 against and to which the query response should be converted to. 
- INSTRUCTION_COMPONENTS - Static variable in class org.axonframework.lifecycle.Phase
- 
Phase to start or shutdown components which send/receive/handle instructions for/to other connectors. 
- InstructionAckSource<T> - Interface in org.axonframework.axonserver.connector
- 
Responsible for sending instruction acknowledgements. 
- instructionAckSource(InstructionAckSource<QueryProviderOutbound>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
- InstructionResultPublisher - Interface in org.axonframework.axonserver.connector
- 
- intercept(T) - Method in class org.axonframework.axonserver.connector.DispatchInterceptors
-  
- intercept(CommandMessage<C>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
- 
Invokes all the dispatch interceptors. 
- intercept(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
- 
Invokes all the dispatch interceptors. 
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.axonframework.axonserver.connector.util.ContextAddingInterceptor
- 
Deprecated. 
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.axonframework.axonserver.connector.util.GrpcBufferingInterceptor
- 
Deprecated. 
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class org.axonframework.axonserver.connector.util.TokenAddingInterceptor
- 
Deprecated. 
- InterceptorChain - Interface in org.axonframework.messaging
- 
The interceptor chain manages the flow of a message through a chain of interceptors and ultimately to the message
 handler. 
- InterceptorChainParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
Parameter resolver factory that adds support for resolving current  InterceptorChain. 
- InterceptorChainParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
-  
- interceptorsFor(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- interceptorsFor(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- IntermediateEventRepresentation - Interface in org.axonframework.serialization.upcasting.event
- 
Interface describing the intermediate representation of an event during upcasting. 
- intersect(Collection<? extends T>, Collection<? extends T>, Supplier<C>) - Static method in class org.axonframework.common.CollectionUtils
- 
Returns a collection containing the elements that are in both given collections collection1andcollection2, using the givencollectionBuilderto create an instance for the new collection.
 
- IntervalRetryScheduler - Class in org.axonframework.commandhandling.gateway
- 
RetryScheduler implementation that retries commands at regular intervals when they fail because of an exception that
 is not explicitly non-transient. 
- IntervalRetryScheduler(IntervalRetryScheduler.Builder) - Constructor for class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
- 
- IntervalRetryScheduler.Builder - Class in org.axonframework.commandhandling.gateway
- 
- invoke(Object, Method, Object[]) - Method in interface org.axonframework.commandhandling.gateway.CommandGatewayFactory.InvocationHandler
- 
Handle the invocation of the given invokedMethod, invoked on givenproxywith givenargs.
 
- invoke(Function<T, R>) - Method in interface org.axonframework.modelling.command.Aggregate
- 
Invoke a method on the underlying aggregate root or one of its instances. 
- invoke(Function<T, R>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- invoke(Function<AR, R>) - Method in class org.axonframework.modelling.command.LockAwareAggregate
-  
- invoke(Function<T, R>) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-  
- invoke(Function<T, R>) - Method in interface org.axonframework.modelling.saga.Saga
- 
Execute the given invocationagainst the root object of this Saga instance.
 
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- invokeAndGetMethodValue(Method, Object) - Static method in class org.axonframework.common.ReflectionUtils
- 
Invokes and returns the return value of the given methodin the givenobject.
 
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- invokeHandlers(EventMessage<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-  
- invokeInitHandlers() - Method in class org.axonframework.config.DefaultConfigurer
- 
Calls all registered init handlers. 
- invokerInterceptors(List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- invokerThreadCount(int) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
Sets the number of Threads that should be used to invoke the Command Handlers. 
- invokeShutdownHandlers() - Method in class org.axonframework.config.DefaultConfigurer
- 
Invokes all registered shutdown handlers. 
- invokeStartHandlers() - Method in class org.axonframework.config.DefaultConfigurer
- 
Invokes all registered start handlers. 
- IOUtils - Class in org.axonframework.common.io
- 
Utility methods for IO operations. 
- isAccessible(AccessibleObject) - Static method in class org.axonframework.common.ReflectionUtils
- 
Indicates whether the given memberis accessible.
 
- isActive() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Indicates whether this UnitOfWork is started. 
- isActive() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-  
- isActive() - Method in interface org.axonframework.modelling.saga.Saga
- 
Indicates whether or not this saga is active. 
- isAfter(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
- 
Check if this Phase comes after given other phase.
 
- isAggregateIdentifier() - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- isAnnotatedWith(Class<? extends Annotation>, Class<? extends Annotation>, Set<Class<? extends Annotation>>, Set<Class<? extends Annotation>>) - Static method in class org.axonframework.common.annotation.AnnotationUtils
- 
Validate whether the given  target annotation  Class is meta-annotated with the given  subject. 
- isAnnotationPresent(AnnotatedElement, Class<? extends Annotation>) - Static method in class org.axonframework.common.annotation.AnnotationUtils
- 
Indicates whether an annotation of given annotationTypeis present on the givenelement,
 considering that the givenannotationTypemay be present as a meta annotation on any other annotation on
 that element.
 
- isAnnotationPresent(AnnotatedElement, String) - Static method in class org.axonframework.common.annotation.AnnotationUtils
- 
Indicates whether an annotation with given annotationTypeis present on the givenelement,
 considering that the givenannotationTypemay be present as a meta annotation on any other annotation on
 that element.
 
- isArray(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isArrayOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isAssignableFrom(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isAutoStart() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-  
- isAutoStart() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
- 
- isAutoStartup() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- isAutoStartup() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. 
- isAutoStartup() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- isBefore(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
- 
Check if this Phase comes before given other phase.
 
- isCaughtUp() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Whether the Segment of this status has caught up with the head of the event stream. 
- isCaughtUp() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- isCaughtUp() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- isCauseOf(Throwable) - Static method in exception org.axonframework.common.AxonNonTransientException
- 
Indicates whether the given throwableis a AxonNonTransientException exception or indicates to be
 caused by one.
 
- isCommandHandler(Class<?>) - Static method in class org.axonframework.util.HandlerTypeResolver
- 
- isConnected(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Returns trueif a gRPC channel for the specific context is opened between client and AxonServer.
 
- isCurrent() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
- isDeleted() - Method in interface org.axonframework.modelling.command.Aggregate
- 
Check if this aggregate has been deleted. 
- isDeleted() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- isDeleted() - Method in class org.axonframework.modelling.command.LockAwareAggregate
-  
- isDeserialized() - Method in class org.axonframework.serialization.LazyDeserializingObject
- 
Indicates whether this object has already been deserialized. 
- isDifferent(EventTrackerStatus) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
- isDifferent(EventTrackerStatus, boolean) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
- isDimensional() - Method in class org.axonframework.springboot.MetricsProperties.Micrometer
- 
Indicates whether the Micrometer Tags/Dimensions will be used 
- isDisableEventBlacklisting() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- isDuplicateKeyCode(SQLException, List<Integer>) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-  
- isDuplicateKeyCode(SQLException, List<Integer>) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.SQLErrorCodesResolver
- 
Deprecated. 
- isDuplicateKeyViolation(Exception) - Method in interface org.axonframework.common.jdbc.PersistenceExceptionResolver
- 
Indicates whether the given exceptionrepresents a duplicate key violation.
 
- isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcSQLErrorCodesResolver
-  
- isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-  
- isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
-  
- isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.SQLErrorCodesResolver
- 
Deprecated. 
- isEmpty() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
-  
- isEmpty() - Method in interface org.axonframework.messaging.HandlerAttributes
- 
Validate whether zero attributes are present in this object. 
- isEmpty() - Method in class org.axonframework.messaging.MetaData
-  
- isEmpty() - Method in class org.axonframework.messaging.SimpleHandlerAttributes
-  
- isEmpty() - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
- 
Indicates whether any elements are contained within this map. 
- isEmptyType(SerializedType) - Static method in interface org.axonframework.serialization.SerializedType
- 
Check whether the serializedTypeequalsSerializedType#emptyType#getName()and returns a
 correspondingtrueorfalsewhether this is the case or not.
 
- isEnabled() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
-  
- isEnabled() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- isEnabled() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Indicates whether the (auto-configuration) of the Distributed Command Bus is enabled. 
- isEnabled() - Method in class org.axonframework.springboot.MetricsProperties.AutoConfiguration
- 
Indicates whether the auto-configuration of Metrics is enabled 
- isError() - Method in interface org.axonframework.eventhandling.EventProcessor
- 
Indicates whether the processor has been shut down due to an error. 
- isError() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- isError() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-  
- isError() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- isErrorState() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Indicates whether this status represents an error. 
- isErrorState() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- isErrorState() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- isEventHandler(Class<?>) - Static method in class org.axonframework.util.HandlerTypeResolver
- 
- isExceptional() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-  
- isExceptional() - Method in class org.axonframework.messaging.GenericResultMessage
-  
- isExceptional() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- isExceptional() - Method in interface org.axonframework.messaging.ResultMessage
- 
Indicates whether the ResultMessage represents unsuccessful execution. 
- isExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
- 
Check if the result of the execution yielded an exception. 
- isExpectedPayloadType(String) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
- 
Check whether the given payloadTypematches the outcome ofexpectedPayloadType.
 
- isExpectedRevision(String) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
- 
Check whether the given revisionmatches the outcome ofexpectedRevision.
 
- isExpectReply() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
- 
Indicates whether the sender of this message requests a reply. 
- isExplicitlyNonTransient(Throwable) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
- 
Indicates whether the given failureis clearly non-transient.
 
- isExplicitlyNonTransient(Throwable) - Static method in class org.axonframework.common.ExceptionUtils
- 
Indicates whether the given failureis clearly non-transient.
 
- isFactoryHandler() - Method in interface org.axonframework.commandhandling.CommandMessageHandlingMember
- 
Check if this message handler creates a new instance of the entity of type Tto handle this command.
 
- isFactoryHandler() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-  
- isFallbackToHttpGet() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
- 
Indicates whether to fall back to HTTP GET when retrieving Instance Meta Data from the Discovery Server
 fails. 
- isFalse(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
- 
Asserts that the given expressionis false.
 
- isFieldTypeSupported(Field) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
- 
- isFirstMessage(Message<?>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
- 
Checks if the given messageis the first of the batch being processed in this unit of work.
 
- isFirstMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
- 
Checks if the message being processed now is the first of the batch being processed in this unit of work. 
- isForceReadFromLeader() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- isFull(Object) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- isFull(Object) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- isFull(Object) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- isFull(Object) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Validates whether this queue is full for the given sequenceIdentifier.
 
- isGenericArrayOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isGenericArrayType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isGenericAssignableFrom(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isHeld() - Method in interface org.axonframework.common.lock.Lock
- 
Indicates whether the lock is still owned true, or whether it has been releasedfalse.
 
- isHeld() - Method in class org.axonframework.common.lock.NoOpLock
-  
- isInitialized() - Method in class org.axonframework.config.Component
- 
Checks if the component is already initialized. 
- isIterableOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isLastMessage(Message<?>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
- 
Checks if the given messageis the last of the batch being processed in this unit of work.
 
- isLastMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
- 
Checks if the message being processed now is the last of the batch being processed in this unit of work. 
- isLive() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Indicates whether this Aggregate instance is 'live'. 
- isLockHeld() - Method in class org.axonframework.modelling.command.LockAwareAggregate
- 
Check if the aggregate currently holds a lock. 
- isLowerSegmentAdvanced() - Method in class org.axonframework.eventhandling.MergedTrackingToken
- 
- isMarkedDeleted() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
- 
Indicates whether an Aggregate has invoked "markDeleted" while this lifecycle was active. 
- isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
- 
Check whether the given  Member is of a type supported by this definition. 
- isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-  
- isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
-  
- isMemberTypeSupported(Member) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
-  
- isMergeableWith(Segment) - Method in class org.axonframework.eventhandling.Segment
- 
Indicates whether this segment can be merged with the given othersegment.
 
- isMergeInProgress(TrackingToken) - Static method in class org.axonframework.eventhandling.MergedTrackingToken
- 
Indicates whether the given trackingTokenrepresents a token that is part of a merge.
 
- isMerging() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Indicates whether this Segment is still merging two (or more) Segments. 
- isMerging() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- isMerging() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- isMessageId() - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- isMessageName() - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- isMessageType() - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- isMetadata() - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- isMetaDataDeserialized() - Method in class org.axonframework.serialization.SerializedMessage
- 
Indicates whether the metaData of this message has already been deserialized. 
- isNestedHandlers() - Method in class org.axonframework.springboot.TracingProperties
- 
Getting value for nesting handlers in dispatching traces. 
- isNonFinalPublicMember(Member) - Static method in class org.axonframework.common.ReflectionUtils
- 
Checks whether the given memberis public and non-final.
 
- isNonTransientFailure(Throwable) - Method in class org.axonframework.commandhandling.gateway.NonTransientExceptionClassesPredicate
- 
Checks if the provided failureis considered non-transient.
 
- isParameterizedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isParameterizedTypeOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isPayloadDeserialized() - Method in class org.axonframework.serialization.SerializedMessage
- 
Indicates whether the payload of this message has already been deserialized. 
- isPayloadType() - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- isPersistent() - Method in class org.axonframework.messaging.RemoteExceptionDescription
- 
Returns whether the exception is considered persistent or not. 
- isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. Indicates whether an object of the given targetClassshould be post processed.
 
- isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
- 
Deprecated. 
- isPostProcessingCandidate(Class<?>) - Method in class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
- 
Deprecated. 
- isPublisherOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isQualifierMatch(String, ConfigurableListableBeanFactory, String) - Static method in class org.axonframework.spring.SpringUtils
- 
Match if the given qualifiercan be found on theBeanDefinitionof the givenbeanName.
 
- isQueryHandler(Class<?>) - Static method in class org.axonframework.util.HandlerTypeResolver
- 
- isRecoverEntry() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Indicates whether this entry is a recovery entry. 
- isReplay() - Method in enum org.axonframework.eventhandling.ReplayStatus
- 
Indicates whether this status represents a replay. 
- isReplay(Message<?>) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Indicates whether the given message is "redelivered", as a result of a previous reset. 
- isReplay(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Indicates whether the given trackingTokenrepresents a position that is part of a replay.
 
- isReplaying() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Indicates whether this Segment is still replaying previously processed Events. 
- isReplaying() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
- isReplaying() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- isReplaying() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- isReverseCallbackOrder() - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
- 
Check whether registered handlers for this phase should be invoked in the order of registration (first
 registered handler is invoked first) or in the reverse order of registration (last registered handler is
 invoked first). 
- isRolledBack() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- isRolledBack() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Check if the Unit of Work has been rolled back. 
- isRoot() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Check that returns trueif this Unit of Work has not got a parent.
 
- isRunning() - Method in interface org.axonframework.eventhandling.EventProcessor
- 
Indicates whether this processor is currently running (i.e. 
- isRunning() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- isRunning() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-  
- isRunning() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- isRunning() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- isRunning() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. 
- isRunning() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- isRunning() - Method in class org.axonframework.spring.config.SpringAxonConfiguration
-  
- isSerializedMetaData(SerializedObject<?>) - Static method in class org.axonframework.serialization.SerializedMetaData
- 
Indicates whether the given  serializedObject represents a serialized form of a MetaData object,
 such as the ones created by this class (see  SerializedMetaData(Object, Class). 
- isShowEventSourcingHandlers() - Method in class org.axonframework.springboot.TracingProperties
- 
Getting value for showing event sourcing handlers in traces. 
- isShutdown() - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- isShuttingDown() - Method in class org.axonframework.lifecycle.ShutdownLatch
- 
- isSingleton() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. 
- isSingleton() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. 
- isSingleton() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-  
- isSingleton() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
- 
Deprecated. 
- isSingleton() - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
- 
Deprecated. 
- isSingleton() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
- 
Deprecated. 
- isSingleton() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
- 
Deprecated. 
- isSingleton() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-  
- isSingleton() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-  
- isSingleton() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-  
- isSnapshot() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-  
- isSslEnabled() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- isStarted() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
- 
Indicates whether a unit of work has already been started. 
- isStarted() - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
- 
Check if a Unit of Work in this phase has been started, i.e. 
- isStreamOfExpectedType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isSubscribed(MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
- 
Indicates whether the given commandHandleris subscribed to this command bus.
 
- isSubscribed(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
- 
Indicates whether the given commandHandleris subscribed to commands of the givencommandTypeon this command bus.
 
- isSuppressHandlerErrors() - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
- 
Indicates whether the handlers triggered for this phase should have their exceptions suppressed. 
- isTerminated() - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- isTransient(Field) - Static method in class org.axonframework.common.ReflectionUtils
- 
Indicates whether the given field has the "transient" modifier 
- isTrue(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
- 
Asserts that the given expressionis true.
 
- isType(Class<?>) - Method in interface org.axonframework.config.ModuleConfiguration
- 
Checks whether this Module Configuration is of the given type.
 
- isTypeVariable(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isUpperSegmentAdvanced() - Method in class org.axonframework.eventhandling.MergedTrackingToken
- 
- isValid() - Method in class org.axonframework.axonserver.connector.heartbeat.connection.checker.ActiveGrpcChannelChecker
- 
Deprecated. Returns true if the connection is still alive, false otherwise. 
- isValid() - Method in class org.axonframework.axonserver.connector.heartbeat.connection.checker.HeartbeatConnectionChecker
- 
Deprecated. Returns true if the connection is still alive, false otherwise. 
- isValid() - Method in interface org.axonframework.axonserver.connector.heartbeat.ConnectionSanityChecker
- 
Deprecated. Returns true if the connection is still alive, false otherwise. 
- isValidIdentifier(Class<?>) - Method in class org.axonframework.common.IdentifierValidator
- 
Indicates whether or not the given identifierTypeis safe to use as aggregate identifier
 
- isWildcardType(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- isWildcardTypeWithMatchingUpperBound(Type) - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- ITERABLE_MATCH - Static variable in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
- 
Indicates that the response matches with the  Type while returning an iterable result. 
- iterator() - Method in class org.axonframework.common.jpa.PagingJpaQueryIterable
-  
- iterator() - Method in class org.axonframework.common.legacyjpa.PagingJpaQueryIterable
- 
Deprecated. 
- iterator() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-  
- IteratorBackedDomainEventStream - Class in org.axonframework.eventsourcing.eventstore
- 
DomainEventStream implementation that gets its messages from an Iterator. 
- IteratorBackedDomainEventStream(Iterator<? extends DomainEventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
- 
Initialize the stream which provides access to message from the given iterator
 
- main(String[]) - Static method in class org.axonframework.reactorlesstest.ReactorlessStartup
-  
- makeCurrent() - Method in class org.axonframework.tracing.NoOpSpanFactory.NoOpSpan
-  
- makeCurrent() - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpan
-  
- makeCurrent() - Method in interface org.axonframework.tracing.Span
- 
Sets the Span as the current for the current thread. 
- managedAggregates(UnitOfWork<?>) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Returns the map of aggregates currently managed by this repository under the given unit of work. 
- ManagedChannelCustomizer - Interface in org.axonframework.axonserver.connector
- 
Customizer to add more customizations to a managed channel to Axon Server. 
- managedChannelCustomizer() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- manager() - Method in interface org.axonframework.config.SagaConfiguration
- 
Retrieve the Saga Manager in this Configuration. 
- map(Function<UnitOfWork<?>, T>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
- 
If a Unit of Work is started, execute the given functionon it.
 
- MapEntryMatcher - Class in org.axonframework.test.matchers
- 
Matcher that will match an Object if that object is a  Map of which all
 keys-values pairs are equal to pairs of the expected instance. 
- MapEntryMatcher(Map<String, Object>) - Constructor for class org.axonframework.test.matchers.MapEntryMatcher
-  
- markConsumed(Integer) - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
- 
Deprecated. Notifies the stream observer that [@code consumed} messages are processed by the client. 
- markDeleted() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Marks this aggregate as deleted, instructing a repository to remove that aggregate at an appropriate time. 
- markError(Throwable) - Method in class org.axonframework.eventhandling.TrackerStatus
- 
Return a new  TrackerStatus based on this status, setting the given  error as the  errorState. 
- markTouched() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
-  
- markTouched() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. 
- markTouched() - Method in interface org.axonframework.messaging.deadletter.DeadLetter
- 
- markTouched() - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
-  
- marshal(Object, HierarchicalStreamWriter, MarshallingContext) - Method in class org.axonframework.serialization.GapAwareTrackingTokenConverter
-  
- MATCH - Static variable in interface org.axonframework.messaging.responsetypes.ResponseType
- 
Indicates that the response matches with the  Type while returning a single result. 
- MatchAllFieldFilter - Class in org.axonframework.test.matchers
- 
FieldFilter that delegates to an arbitrary number of other filters. 
- MatchAllFieldFilter(Collection<FieldFilter>) - Constructor for class org.axonframework.test.matchers.MatchAllFieldFilter
- 
Initializes a filter that accepts any field that is accepted by all given filters
 
- MatcherExecutionException - Exception in org.axonframework.test.matchers
- 
Exception indicating that an error occurred that prevented successful execution of a matcher. 
- MatcherExecutionException(String) - Constructor for exception org.axonframework.test.matchers.MatcherExecutionException
- 
Construct the exception with the given message.
 
- MatcherExecutionException(String, Throwable) - Constructor for exception org.axonframework.test.matchers.MatcherExecutionException
- 
Construct the exception with the given messageandcause.
 
- Matchers - Class in org.axonframework.test.matchers
- 
Utility class containing static methods to obtain instances of (List) Matchers. 
- matches(Message) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-  
- matches(CommandMessage<?>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
-  
- matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
-  
- matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-  
- matches(CommandMessage<?>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
-  
- matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
-  
- matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.NegateCommandMessageFilter
-  
- matches(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.OrCommandMessageFilter
-  
- matches(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.CommandMessageFilter
- 
Indicates whether the given commandMessagematches this filter.
 
- matches(Message<?>) - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-  
- matches(int) - Method in class org.axonframework.eventhandling.Segment
- 
Returns truewhen the mask applied to the given value, matches the segment id.
 
- matches(Object) - Method in class org.axonframework.eventhandling.Segment
- 
Indicates whether the given valuematches this segment.
 
- matches(Message) - Method in class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
-  
- matches(Message<?>) - Method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
-  
- matches(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
-  
- matches(Message<?>) - Method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
-  
- matches(Message<?>) - Method in interface org.axonframework.messaging.annotation.ParameterResolver
- 
Indicates whether this resolver is capable of providing a value for the given message.
 
- matches(Message) - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
-  
- matches(Type) - Method in class org.axonframework.messaging.responsetypes.InstanceResponseType
- 
Match the query handler its response  Type with this implementation its responseType
  R. 
- matches(Type) - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
- 
Match the query handler its response  Type with this implementation its responseType
  R. 
- matches(Type) - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
- 
Match the query handler its response  Type with this implementation its responseType  R. 
- matches(Type) - Method in class org.axonframework.messaging.responsetypes.PublisherResponseType
- 
Match the query handler its response  Type with this implementation its responseType
  R. 
- matches(Type) - Method in interface org.axonframework.messaging.responsetypes.ResponseType
- 
Match the query handler its response  Type with the  ResponseType implementation
 its expected response type  R. 
- matches(ConditionContext, AnnotatedTypeMetadata) - Method in class org.axonframework.spring.config.NoBeanOfType.NoBeanOfTypeDefined
- 
Deprecated. 
- matches(Object) - Method in class org.axonframework.test.matchers.DeepEqualsMatcher
-  
- matches(Object) - Method in class org.axonframework.test.matchers.EmptyCollectionMatcher
-  
- matches(Object) - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
-  
- matches(Object) - Method in class org.axonframework.test.matchers.ListMatcher
-  
- matches(Predicate<T>) - Static method in class org.axonframework.test.matchers.Matchers
- 
Returns a Matcher that matches with values defined by the given predicate.
 
- matches(Object) - Method in class org.axonframework.test.matchers.NullOrVoidMatcher
-  
- matches(Object) - Method in class org.axonframework.test.matchers.PayloadMatcher
-  
- matches(Object) - Method in class org.axonframework.test.matchers.PayloadsMatcher
-  
- matchesList(List<T>) - Method in class org.axonframework.test.matchers.ExactSequenceMatcher
-  
- matchesList(List<T>) - Method in class org.axonframework.test.matchers.ListMatcher
- 
Evaluates the matcher for argument item.
 
- matchesList(List<T>) - Method in class org.axonframework.test.matchers.ListWithAllOfMatcher
-  
- matchesList(List<T>) - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
-  
- matchesList(List<T>) - Method in class org.axonframework.test.matchers.SequenceMatcher
-  
- matchesSafely(T) - Method in class org.axonframework.test.matchers.EqualsMatcher
-  
- matchesSafely(T) - Method in class org.axonframework.test.matchers.ExactClassMatcher
-  
- matchesSafely(Map<String, Object>) - Method in class org.axonframework.test.matchers.MapEntryMatcher
-  
- matchesSafely(T) - Method in class org.axonframework.test.matchers.PredicateMatcher
-  
- matchesSegment(Segment, String) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
- 
Checks whether the given sagaIdmatches with the givensegment.
 
- matchPositions(EventTrackerStatus) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Match the position fields of thisandthat.
 
- matchRank(Type) - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
- 
Match the query handler its response  Type with this implementation its responseType  R. 
- matchRank(Type) - Method in class org.axonframework.messaging.responsetypes.PublisherResponseType
-  
- matchRank(Type) - Method in interface org.axonframework.messaging.responsetypes.ResponseType
- 
Defines the match and its priority. 
- matchRemainder(Iterator<Matcher<? super T>>) - Method in class org.axonframework.test.matchers.ListMatcher
- 
Matches all the remaining Matchers in the given matcherIteratoragainstnull.
 
- matchStates(EventTrackerStatus) - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Match the boolean state fields of thisandthat.
 
- MavenArtifactRevisionResolver - Class in org.axonframework.serialization
- 
RevisionResolver that uses Maven meta data to retrieve the application version. 
- MavenArtifactRevisionResolver(String, String) - Constructor for class org.axonframework.serialization.MavenArtifactRevisionResolver
- 
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given
 groupIdandartifactId.
 
- MavenArtifactRevisionResolver(String, String, ClassLoader) - Constructor for class org.axonframework.serialization.MavenArtifactRevisionResolver
- 
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given
 groupIdandartifactId.
 
- MavenArtifactVersionResolver - Class in org.axonframework.util
- 
Artifact version resolver that uses Maven meta data to retrieve the jar version. 
- MavenArtifactVersionResolver(String, String, ClassLoader) - Constructor for class org.axonframework.util.MavenArtifactVersionResolver
- 
Creates an instance to look for the version in the Meta Data of the artifact with given
 groupIdandartifactId.
 
- maxCapacity() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
- 
Specifies the maximum amount of segments this  EventProcessor can process at the same time. 
- maxCapacity() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Specifies the maximum amount of segments this  EventProcessor can process at the same time. 
- maxCapacity() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- maxClaimedSegments(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
- 
- maxGapOffset(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
Sets the maxGapOffsetspecifying the maximum distance in sequence numbers between a missing event
 and
 the event with the highest known index.
 
- maxGapOffset(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
Sets the maxGapOffsetspecifying the maximum distance in sequence numbers between a missing event and
 the event with the highest known index.
 
- maxGapOffset(int) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. Sets the maxGapOffsetspecifying the maximum distance in sequence numbers between a missing event and
 the event with the highest known index.
 
- maxMessageSize(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- maxRetryCount(int) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
- 
Sets the maximum number of retries allowed for a single command. 
- maxSequences(int) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
- maxSequences(int) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. 
- maxSequences(int) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue.Builder
- 
- maxSequenceSize(int) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
- maxSequenceSize(int) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. 
- maxSequenceSize(int) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue.Builder
- 
- mayClaim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Check if given ownermay claim this token.
 
- mayClaim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
- 
Check if given ownermay claim this token.
 
- md5Hex(String) - Static method in class org.axonframework.common.digest.Digester
- 
Utility method that creates a hex string of the MD5 hash of the given input
 
- Member - Interface in org.axonframework.commandhandling.distributed
- 
Member of a cluster of connected command endpoints. 
- MemberAccessibilityCallback - Class in org.axonframework.common
- 
PrivilegedAction that makes the given method accessible for reflection. 
- MemberAccessibilityCallback(AccessibleObject) - Constructor for class org.axonframework.common.MemberAccessibilityCallback
- 
Initialize the callback to make the given methodaccessible for reflection.
 
- merge(T, T, Supplier<T>) - Static method in class org.axonframework.common.CollectionUtils
- 
Merge two collections into a new collection instance. 
- mergeableSegmentId() - Method in class org.axonframework.eventhandling.Segment
- 
Returns the  segmentId of the segment this one can be merged with 
- mergeCompletedPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
- 
Return the estimated relative token position this Segment will have after a merge operation is complete. 
- mergeCompletedPosition() - Method in class org.axonframework.eventhandling.TrackerStatus
-  
- mergeCompletedPosition() - Method in class org.axonframework.eventhandling.WrappedTrackerStatus
-  
- merged(TrackingToken, TrackingToken) - Static method in class org.axonframework.eventhandling.MergedTrackingToken
- 
Create a merged token using the given lowerSegmentTokenandupperSegmentToken.
 
- MergedTrackingToken - Class in org.axonframework.eventhandling
- 
Special Wrapped Token implementation that keeps track of two separate tokens, of which the streams have been merged
 into a single one. 
- MergedTrackingToken(TrackingToken, TrackingToken) - Constructor for class org.axonframework.eventhandling.MergedTrackingToken
- 
Initialize a Merged Token, with the lowerSegmentTokenrepresenting the progress of the segment with the
 lower segmentId, andupperSegmentTokenrepresenting the progress of the segment with the higher
 segmentId.
 
- MergedTrackingToken(TrackingToken, TrackingToken, boolean, boolean) - Constructor for class org.axonframework.eventhandling.MergedTrackingToken
- 
Initialize a Merged Token, with the  lowerSegmentToken representing the progress of the segment with the
 lower segmentId, and  upperSegmentToken representing the progress of the segment with the higher
 segmentId, additionally indicating if either of these segments were advanced by the latest call to  MergedTrackingToken.advancedTo(TrackingToken)
- mergedWith(Segment) - Method in class org.axonframework.eventhandling.Segment
- 
Calculates the Segment that represents the merger of this segment with the given othersegment.
 
- mergedWith(HandlerAttributes) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerAttributes
-  
- mergedWith(HandlerAttributes) - Method in interface org.axonframework.messaging.HandlerAttributes
- 
Returns a  HandlerAttributes, merging the attributes in  this instance with the given  attributes. 
- mergedWith(Map<String, ?>) - Method in class org.axonframework.messaging.MetaData
- 
Returns a MetaData instance containing values of this, combined with the givenadditionalEntries.
 
- mergedWith(HandlerAttributes) - Method in class org.axonframework.messaging.SimpleHandlerAttributes
-  
- mergePosition(TrackingToken) - Static method in class org.axonframework.eventhandling.MergedTrackingToken
- 
Return the estimated relative token position this Segment will have after a merge operation is complete. 
- mergeSegment(int) - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService.AxonProcessorInstructionHandler
-  
- mergeSegment(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- mergeSegment(int) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Instruct the processor to merge the segment with given segmentIdback with the segment that it was
 originally split from.
 
- mergeSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- message() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaDeadLetter
-  
- message() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaDeadLetter
- 
Deprecated. 
- message() - Method in interface org.axonframework.messaging.deadletter.Cause
- 
A message describing a cause for dead lettering. 
- message() - Method in interface org.axonframework.messaging.deadletter.DeadLetter
- 
The  Message of type  M contained in this letter. 
- message() - Method in class org.axonframework.messaging.deadletter.GenericDeadLetter
-  
- message() - Method in exception org.axonframework.messaging.deadletter.ThrowableCause
-  
- Message<T> - Interface in org.axonframework.messaging
- 
Representation of a Message, containing a Payload and MetaData. 
- MESSAGE_ID - Static variable in class org.axonframework.messaging.Headers
- 
Key pointing to a message identifier. 
- MESSAGE_METADATA - Static variable in class org.axonframework.messaging.Headers
- 
Key pointing to the  MetaData of a message. 
- MESSAGE_REVISION - Static variable in class org.axonframework.messaging.Headers
- 
Key pointing to the revision of a message. 
- MESSAGE_TIMESTAMP - Static variable in class org.axonframework.messaging.Headers
- 
Key pointing to the timestamp of a message. 
- MESSAGE_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the  Message type being handled by the handler. 
- MESSAGE_TYPE - Static variable in class org.axonframework.messaging.Headers
- 
Key pointing to the payload type of a message. 
- MessageCountingMonitor - Class in org.axonframework.metrics
- 
Counts the number of ingested, successful, failed and processed messages 
- MessageCountingMonitor() - Constructor for class org.axonframework.metrics.MessageCountingMonitor
-  
- MessageCountingMonitor - Class in org.axonframework.micrometer
- 
Counts the number of ingested, successful, failed and processed messages 
- MessageDecorator<T> - Class in org.axonframework.messaging
- 
Abstract implementation of a  Message that delegates to an existing message. 
- MessageDecorator(Message<T>) - Constructor for class org.axonframework.messaging.MessageDecorator
- 
Initializes a new decorator with given delegatemessage.
 
- MessageDispatchInterceptor<T extends Message<?>> - Interface in org.axonframework.messaging
- 
Interceptor that allows messages to be intercepted and modified before they are dispatched. 
- MessageDispatchInterceptorSupport<T extends Message<?>> - Interface in org.axonframework.messaging
- 
Interface marking components capable of registering Dispatch Interceptors. 
- MessageHandler - Annotation Type in org.axonframework.messaging.annotation
- 
Annotation indicating that a member method should be able to respond to  Messages. 
- MessageHandler<T extends Message<?>> - Interface in org.axonframework.messaging
- 
Interface for a component that processes Messages. 
- messageHandlerBeans(Class<? extends Message<?>>, ConfigurableListableBeanFactory) - Static method in class org.axonframework.spring.config.MessageHandlerLookup
- 
Returns a list of beans found in the given registerthat contain a handler for the givenmessageType.
 
- messageHandlerBeans(Class<? extends Message<?>>, ConfigurableListableBeanFactory, boolean) - Static method in class org.axonframework.spring.config.MessageHandlerLookup
- 
Returns a list of beans found in the given registerthat contain a handler for the givenmessageType.
 
- MessageHandlerConfigurer - Class in org.axonframework.spring.config
- 
An implementation of a  ConfigurerModule that will register a list of beans as handlers for a specific type of
 message. 
- MessageHandlerConfigurer(MessageHandlerConfigurer.Type, List<String>) - Constructor for class org.axonframework.spring.config.MessageHandlerConfigurer
- 
Registers the beans identified in given  beanRefs as the given  type of handler with the Axon
  Configuration. 
- MessageHandlerConfigurer.Type - Enum in org.axonframework.spring.config
- 
Enumeration defining the auto configurable message handler types. 
- MessageHandlerInterceptor - Annotation Type in org.axonframework.messaging.interceptors
- 
Annotation marking an handler method as an interceptor handler. 
- MessageHandlerInterceptor<T extends Message<?>> - Interface in org.axonframework.messaging
- 
Workflow interface that allows for customized message handler invocation chains. 
- MessageHandlerInterceptorDefinition - Class in org.axonframework.messaging.annotation
- 
- MessageHandlerInterceptorDefinition() - Constructor for class org.axonframework.messaging.annotation.MessageHandlerInterceptorDefinition
-  
- MessageHandlerInterceptorMemberChain<T> - Interface in org.axonframework.messaging.annotation
- 
Interface to interact with a MessageHandlingMember instance through a chain of interceptors, which were used to build
 up this chain. 
- MessageHandlerInterceptorSupport<T extends Message<?>> - Interface in org.axonframework.messaging
- 
Interface marking components capable of registering Handler Interceptors. 
- MessageHandlerInvocationException - Exception in org.axonframework.messaging.annotation
- 
MessageHandlerInvocationException is a runtime exception that wraps an exception thrown by an invoked message
 handler. 
- MessageHandlerInvocationException(String, Throwable) - Constructor for exception org.axonframework.messaging.annotation.MessageHandlerInvocationException
- 
Initialize the MessageHandlerInvocationException using given messageandcause.
 
- MessageHandlerLookup - Class in org.axonframework.spring.config
- 
A  BeanDefinitionRegistryPostProcessor implementation that detects beans with Axon Message handlers and
 registers an  MessageHandlerConfigurer to have these handlers registered in the Axon
  Configuration. 
- MessageHandlerLookup() - Constructor for class org.axonframework.spring.config.MessageHandlerLookup
-  
- messageHandlerLookup() - Static method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- MessageHandlerRegistrar - Class in org.axonframework.config
- 
- MessageHandlerRegistrar(Supplier<Configuration>, Function<Configuration, Object>, BiFunction<Configuration, Object, Registration>) - Constructor for class org.axonframework.config.MessageHandlerRegistrar
- 
- MessageHandlingMember<T> - Interface in org.axonframework.messaging.annotation
- 
Interface describing a handler for specific messages targeting entities of a specific type. 
- MessageIdentifier - Annotation Type in org.axonframework.messaging.annotation
- 
Annotation indication that a parameter on a Message Handler method should be injected with the identifier of a
 Message. 
- MessageIdentifierParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a  String type that
 are annotated with the  MessageIdentifier annotation and assigns the identifier of the Message. 
- MessageIdentifierParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
- 
- messageIdSpanAttributesProvider() - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
-  
- MessageIdSpanAttributesProvider - Class in org.axonframework.tracing.attributes
- 
Adds the message identifier to the Span. 
- MessageIdSpanAttributesProvider() - Constructor for class org.axonframework.tracing.attributes.MessageIdSpanAttributesProvider
-  
- MessageInterceptingMember<T> - Interface in org.axonframework.messaging.annotation
- 
Marker interface for  MessageHandlingMember instances that need to be treated as interceptors, rather
 than regular members. 
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
-  
- messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
-  
- messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
- 
Sets the  MessageMonitor for generic types implementing  CommandMessage, which is used to
 monitor incoming messages and their execution result. 
- messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
- 
- messageMonitor(Class<?>, String) - Method in interface org.axonframework.config.Configuration
- 
Returns the message monitor configured for a component of given componentTypeandcomponentName.
 
- messageMonitor(Class<?>, String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
Returns the  MessageMonitor set to the given  componentType and  componentName registered
 within this configuration. 
- messageMonitor(Class<?>, String) - Method in class org.axonframework.config.EventProcessingModule
-  
- messageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus.Builder
- 
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
- 
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
-  
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.SimpleEventBus.Builder
-  
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
-  
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
-  
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
-  
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
-  
- messageMonitor(MessageMonitor<? super EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore.Builder
- 
Deprecated. 
- MessageMonitor<T extends Message<?>> - Interface in org.axonframework.monitoring
- 
Specifies a mechanism to monitor message processing. 
- messageMonitor(MessageMonitor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
- 
- messageMonitor(Class<?>, String) - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- MessageMonitor.MonitorCallback - Interface in org.axonframework.monitoring
- 
An interface to let the message processor inform the message monitor of the result
 of processing the message 
- messageMonitorFactories - Variable in class org.axonframework.config.EventProcessingModule
-  
- MessageMonitorFactory - Interface in org.axonframework.config
- 
Interface describing a factory for a Message Monitor. 
- messageNameSpanAttributesProvider() - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
-  
- MessageNameSpanAttributesProvider - Class in org.axonframework.tracing.attributes
- 
- MessageNameSpanAttributesProvider() - Constructor for class org.axonframework.tracing.attributes.MessageNameSpanAttributesProvider
-  
- MessageOriginProvider - Class in org.axonframework.messaging.correlation
- 
CorrelationDataProvider that provides the  identifier of a  Message to
 other messages that are created as result of processing the first message. 
- MessageOriginProvider() - Constructor for class org.axonframework.messaging.correlation.MessageOriginProvider
- 
- MessageOriginProvider(String, String) - Constructor for class org.axonframework.messaging.correlation.MessageOriginProvider
- 
- messageOriginProvider() - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- MessageProcessingContext<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
- 
Maintains the context around the processing of a single Message. 
- MessageProcessingContext(T) - Constructor for class org.axonframework.messaging.unitofwork.MessageProcessingContext
- 
Creates a new processing context for the given message.
 
- messageSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
Sets the message  Serializer used to de-/serialize incoming and outgoing queries and query responses. 
- messageSerializer() - Method in interface org.axonframework.config.Configuration
- 
Returns the  Serializer defined in this Configuration to be used for serializing Message payloads and
 metadata. 
- messageSerializer() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- messageSerializer(Serializer, RevisionResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- messageSource(StreamableMessageSource<TrackedEventMessage<?>>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
- 
- messageSource(SubscribableMessageSource<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
- 
- messageSource(StreamableMessageSource<TrackedEventMessage<?>>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
- 
- MessageTimerMonitor - Class in org.axonframework.metrics
- 
A  MessageMonitor which creates  Timer instances for the overall, success, failure and ignored time an
 ingested  Message takes. 
- MessageTimerMonitor(MessageTimerMonitor.Builder) - Constructor for class org.axonframework.metrics.MessageTimerMonitor
- 
- MessageTimerMonitor() - Constructor for class org.axonframework.metrics.MessageTimerMonitor
- 
- MessageTimerMonitor(Clock) - Constructor for class org.axonframework.metrics.MessageTimerMonitor
- 
- MessageTimerMonitor - Class in org.axonframework.micrometer
- 
A  MessageMonitor which introduces a  Timer for the overall timer of all  Messages being
 ingested, as well as a success, failure and ignored  Timer. 
- MessageTimerMonitor(MessageTimerMonitor.Builder) - Constructor for class org.axonframework.micrometer.MessageTimerMonitor
- 
- MessageTimerMonitor.Builder - Class in org.axonframework.metrics
- 
- MessageTimerMonitor.Builder - Class in org.axonframework.micrometer
- 
- messageTypeSpanAttributesProvider() - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
-  
- MessageTypeSpanAttributesProvider - Class in org.axonframework.tracing.attributes
- 
Adds the message type (simple class name) to the Span. 
- MessageTypeSpanAttributesProvider() - Constructor for class org.axonframework.tracing.attributes.MessageTypeSpanAttributesProvider
-  
- messageWithPayload(Matcher<?>) - Static method in class org.axonframework.test.matchers.Matchers
- 
Matches a single Message if the given payloadMatchermatches that message's payload.
 
- META_DATA_TAGGER_FUNCTION - Static variable in class org.axonframework.micrometer.TagsUtil
- 
The function for creating the Micrometer Tags based on the message metadata.
 
- MetaData - Class in org.axonframework.domain
- 
- MetaData() - Constructor for class org.axonframework.domain.MetaData
- 
Deprecated. 
- MetaData - Class in org.axonframework.messaging
- 
Represents MetaData that is passed along with a payload in a Message. 
- MetaData(Map<String, ?>) - Constructor for class org.axonframework.messaging.MetaData
- 
Initializes a MetaData instance with the given itemsas content.
 
- MetaDataAssociationResolver - Class in org.axonframework.modelling.saga
- 
Used to derive the value of an association property by looking it up the event message's  MetaData. 
- MetaDataAssociationResolver() - Constructor for class org.axonframework.modelling.saga.MetaDataAssociationResolver
-  
- metaDataColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the event metadata column. 
- metaDataColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the serialized metadata of the event. 
- MetaDataCommandTargetResolver - Class in org.axonframework.modelling.command
- 
CommandTargetResolver implementation that uses MetaData entries to extract the identifier and optionally the version
 of the aggregate that the command targets. 
- MetaDataCommandTargetResolver(String) - Constructor for class org.axonframework.modelling.command.MetaDataCommandTargetResolver
- 
Initializes the MetaDataCommandTargetResolver to use the given identifierKeyas the MetaData key to the
 aggregate identifier, and anull(ignored) version.
 
- MetaDataCommandTargetResolver(String, String) - Constructor for class org.axonframework.modelling.command.MetaDataCommandTargetResolver
- 
Initializes the MetaDataCommandTargetResolver to use the given identifierKeyas the MetaData key to the
 aggregate identifier, and the givenversionKeyas key to the (optional) version entry.
 
- MetadataContextGetter - Class in org.axonframework.tracing.opentelemetry
- 
This  TextMapGetter implementation is able to extract the parent OpenTelemetry span context from a
  Message. 
- MetadataContextSetter - Class in org.axonframework.tracing.opentelemetry
- 
This  TextMapSetter implementation is able to insert the current OpenTelemetry span context into a
  Message. 
- MetaDataDeserializer - Class in org.axonframework.serialization.json
- 
JsonDeserializer implementation that deserializes MetaData instances. 
- MetaDataDeserializer() - Constructor for class org.axonframework.serialization.json.MetaDataDeserializer
-  
- metaDataKey(String) - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.Builder
- 
Sets the  metaDataKey searched for by this routing strategy on a  CommandMessage's  MetaData to base the routing key on. 
- MetaDataRoutingStrategy - Class in org.axonframework.commandhandling.distributed
- 
RoutingStrategy implementation that uses the value in the  MetaData of a  CommandMessage assigned to a given key. 
- MetaDataRoutingStrategy(MetaDataRoutingStrategy.Builder) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
- 
- MetaDataRoutingStrategy(String) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
- 
- MetaDataRoutingStrategy(String, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
- 
- MetaDataRoutingStrategy.Builder - Class in org.axonframework.commandhandling.distributed
- 
- metadataSpanAttributesProvider() - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
-  
- MetadataSpanAttributesProvider - Class in org.axonframework.tracing.attributes
- 
Adds the metadata of the message to the span as attributes. 
- MetadataSpanAttributesProvider() - Constructor for class org.axonframework.tracing.attributes.MetadataSpanAttributesProvider
-  
- MetaDataValue - Annotation Type in org.axonframework.messaging.annotation
- 
Annotation that indicates the parameter needs to be resolved to the value of the Message MetaData stored under the
 given key.
 
- meterNamePrefix(String) - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
- 
Sets the name used to prefix the names of the  Gauge instances created by this
  MessageMonitor. 
- meterNamePrefix(String) - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
- 
Sets the name used to prefix the names of the  Timer instances created by this  MessageMonitor. 
- meterRegistry(MeterRegistry) - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
- 
Specifies the MeterRegistryused to registered theGaugeinstances to.
 
- meterRegistry(MeterRegistry) - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
- 
Specifies the MeterRegistryused to registered theTimerinstances to.
 
- meterRegistry() - Static method in class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
-  
- MethodAccessedProperty<T> - Class in org.axonframework.common.property
- 
Property implementation that invokes a method to obtain a value of a property for a given instance. 
- MethodAccessedProperty(Method, String) - Constructor for class org.axonframework.common.property.MethodAccessedProperty
- 
Initialize a reader that uses given accessorMethodto access a property with givenpropertyName.
 
- MethodCommandHandlerDefinition - Class in org.axonframework.commandhandling
- 
- MethodCommandHandlerDefinition() - Constructor for class org.axonframework.commandhandling.MethodCommandHandlerDefinition
-  
- MethodCommandHandlerInterceptorDefinition - Class in org.axonframework.modelling.command.inspection
- 
- MethodCommandHandlerInterceptorDefinition() - Constructor for class org.axonframework.modelling.command.inspection.MethodCommandHandlerInterceptorDefinition
-  
- MethodCreationPolicyDefinition - Class in org.axonframework.modelling.command.inspection
- 
- MethodCreationPolicyDefinition() - Constructor for class org.axonframework.modelling.command.inspection.MethodCreationPolicyDefinition
-  
- methodOf(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
- 
Utility function which returns a  Method matching the given  methodName and
  parameterTypes in the  clazz. 
- MethodQueryMessageHandlerDefinition - Class in org.axonframework.queryhandling.annotation
- 
- MethodQueryMessageHandlerDefinition() - Constructor for class org.axonframework.queryhandling.annotation.MethodQueryMessageHandlerDefinition
-  
- methodsOf(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns an  Iterable of all the methods declared on the given class and its super classes. 
- methodsOf(Class<?>, boolean) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns an  Iterable of all the methods declared on the given class. 
- metricRegistry() - Static method in class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
-  
- MetricsAutoConfiguration - Class in org.axonframework.springboot.autoconfig
- 
Auto configuration to set up Metrics for the infrastructure components. 
- MetricsAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
-  
- MetricsConfigurerModule - Class in org.axonframework.metrics
- 
- MetricsConfigurerModule(GlobalMetricRegistry) - Constructor for class org.axonframework.metrics.MetricsConfigurerModule
-  
- MetricsConfigurerModule - Class in org.axonframework.micrometer
- 
- MetricsConfigurerModule(GlobalMetricRegistry) - Constructor for class org.axonframework.micrometer.MetricsConfigurerModule
-  
- MetricsConfigurerModule(GlobalMetricRegistry, boolean) - Constructor for class org.axonframework.micrometer.MetricsConfigurerModule
-  
- metricsConfigurerModule(GlobalMetricRegistry) - Static method in class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
-  
- metricsConfigurerModule(GlobalMetricRegistry, MetricsProperties) - Static method in class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
-  
- MetricsProperties - Class in org.axonframework.springboot
- 
Properties describing the settings for Metrics. 
- MetricsProperties() - Constructor for class org.axonframework.springboot.MetricsProperties
-  
- MetricsProperties.AutoConfiguration - Class in org.axonframework.springboot
- 
Auto configuration specific properties around Metrics. 
- MetricsProperties.Micrometer - Class in org.axonframework.springboot
-  
- Micrometer() - Constructor for class org.axonframework.springboot.MetricsProperties.Micrometer
-  
- MicrometerMetricsAutoConfiguration - Class in org.axonframework.springboot.autoconfig
- 
Auto configuration to set up Micrometer Metrics for the infrastructure components. 
- MicrometerMetricsAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
-  
- modelFactory() - Method in interface org.axonframework.modelling.saga.metamodel.SagaModel
- 
Returns the factory that created this model. 
- modelOf(Class<? extends C>) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
- 
Get the EntityModel of an entity of type childEntityTypein case it is the child of the modeled entity.
 
- modelOf(Class<T>) - Method in class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
-  
- modelOf(Class<T>) - Method in interface org.axonframework.modelling.saga.metamodel.SagaMetaModelFactory
- 
Create a saga meta model for the given sagaType.
 
- ModuleConfiguration - Interface in org.axonframework.config
- 
Interface describing a module for the Axon Configuration API. 
- MongoTrackingToken - Class in org.axonframework.mongo.eventsourcing.eventstore
- 
- MongoTrackingToken() - Constructor for class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
- 
Deprecated. 
- MonitorAwareCallback<C,R> - Class in org.axonframework.commandhandling
- 
Wrapper for a callback that notifies a Message Monitor of the message execution result. 
- MonitorAwareCallback(CommandCallback<C, R>, MessageMonitor.MonitorCallback) - Constructor for class org.axonframework.commandhandling.MonitorAwareCallback
- 
Initialize a callback wrapped around the delegatewhich will notify a Message Monitor for the givenmessageMonitorCallback.
 
- MultiCorrelationDataProvider<T extends Message> - Class in org.axonframework.messaging.correlation
- 
CorrelationDataProvider that combines the data of multiple other correlation providers. 
- MultiCorrelationDataProvider(List<? extends CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.correlation.MultiCorrelationDataProvider
- 
Initialize the correlation data provider, delegating to given correlationDataProviders.
 
- MultiEventHandlerInvoker - Class in org.axonframework.eventhandling
- 
- MultiEventHandlerInvoker(EventHandlerInvoker...) - Constructor for class org.axonframework.eventhandling.MultiEventHandlerInvoker
- 
Initializes multi invoker with different invokers. 
- MultiEventHandlerInvoker(List<EventHandlerInvoker>) - Constructor for class org.axonframework.eventhandling.MultiEventHandlerInvoker
- 
Initializes multi invoker with different invokers. 
- MultiHandlerDefinition - Class in org.axonframework.messaging.annotation
- 
HandlerDefinition instance that delegates to multiple other instances, in the order provided. 
- MultiHandlerDefinition(HandlerDefinition...) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerDefinition
- 
Initializes an instance that delegates to the given delegates, in the order provided.
 
- MultiHandlerDefinition(List<HandlerDefinition>) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerDefinition
- 
Initializes an instance that delegates to the given delegates, in the order provided.
 
- MultiHandlerDefinition(List<HandlerDefinition>, HandlerEnhancerDefinition) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerDefinition
- 
Initializes an instance that delegates to the given delegates, in the order provided.
 
- MultiHandlerEnhancerDefinition - Class in org.axonframework.messaging.annotation
- 
HandlerEnhancerDefinition instance that delegates to multiple other instances, in the order provided. 
- MultiHandlerEnhancerDefinition(HandlerEnhancerDefinition...) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
- 
Initializes an instance that delegates to the given delegates, in the order provided.
 
- MultiHandlerEnhancerDefinition(Collection<HandlerEnhancerDefinition>) - Constructor for class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
- 
Initializes an instance that delegates to the given delegates, in the order provided.
 
- MultiMessageMonitor<T extends Message<?>> - Class in org.axonframework.monitoring
- 
Delegates messages and callbacks to the given list of message monitors 
- MultiMessageMonitor(MessageMonitor<? super T>...) - Constructor for class org.axonframework.monitoring.MultiMessageMonitor
- 
Initialize a message monitor with the given messageMonitors 
- MultiMessageMonitor(List<MessageMonitor<? super T>>) - Constructor for class org.axonframework.monitoring.MultiMessageMonitor
- 
Initialize a message monitor with the given list of messageMonitors 
- MultiParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
ParameterResolverFactory instance that delegates to multiple other instances, in the order provided. 
- MultiParameterResolverFactory(ParameterResolverFactory...) - Constructor for class org.axonframework.messaging.annotation.MultiParameterResolverFactory
- 
Initializes an instance that delegates to the given delegates, in the order provided.
 
- MultiParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.messaging.annotation.MultiParameterResolverFactory
- 
Initializes an instance that delegates to the given delegates, in the order provided.
 
- multipleInstancesOf(Class<R>) - Static method in class org.axonframework.messaging.responsetypes.ResponseTypes
- 
Specify the desire to retrieve a collection of instances of type Rwhen performing a query.
 
- MultipleInstancesResponseType<R> - Class in org.axonframework.messaging.responsetypes
- 
A  ResponseType implementation that will match with query handlers which return a multiple instances of the
 expected response type. 
- MultipleInstancesResponseType(Class<R>) - Constructor for class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
- 
Instantiate a  MultipleInstancesResponseType with the given  expectedCollectionGenericType as the
 type to be matched against and which the convert function will use as the generic for the  List
 return value. 
- MultiSourceTrackingToken - Class in org.axonframework.eventhandling
- 
A  TrackingToken implementation combining several  TrackingTokens into one. 
- MultiSourceTrackingToken(Map<String, TrackingToken>) - Constructor for class org.axonframework.eventhandling.MultiSourceTrackingToken
- 
- MultiSpanFactory - Class in org.axonframework.tracing
- 
Implementation of a  SpanFactory that delegates calls to multiple other factories. 
- MultiSpanFactory(List<SpanFactory>) - Constructor for class org.axonframework.tracing.MultiSpanFactory
- 
Creates the  MultiSpanFactory with the delegate factory implementations that it should use. 
- MultiStreamableMessageSource - Class in org.axonframework.eventhandling
- 
Implementation which allows for tracking processors to process messages from an arbitrary number of sources. 
- MultiStreamableMessageSource(MultiStreamableMessageSource.Builder) - Constructor for class org.axonframework.eventhandling.MultiStreamableMessageSource
- 
- MultiStreamableMessageSource - Class in org.axonframework.eventsourcing
- 
- MultiStreamableMessageSource(MultiStreamableMessageSource.Builder) - Constructor for class org.axonframework.eventsourcing.MultiStreamableMessageSource
- 
- MultiStreamableMessageSource.Builder - Class in org.axonframework.eventhandling
- 
- MultiStreamableMessageSource.Builder - Class in org.axonframework.eventsourcing
- 
- MySqlEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
- 
Jdbc event entry table factory for MySql databases. 
- MySqlEventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
-  
- packageOfObject(Object) - Static method in class org.axonframework.config.EventProcessingModule
- 
Gets the package name from the class of the given object. 
- PagingIterator() - Constructor for class org.axonframework.common.jpa.PagingJpaQueryIterable.PagingIterator
-  
- PagingIterator() - Constructor for class org.axonframework.common.legacyjpa.PagingJpaQueryIterable.PagingIterator
- 
Deprecated. 
- PagingJpaQueryIterable<T,R> - Class in org.axonframework.common.jpa
- 
Enables iterating through a JPA query using paging while lazily mapping the results when necessary. 
- PagingJpaQueryIterable(int, TransactionManager, Supplier<TypedQuery<T>>, Function<T, R>) - Constructor for class org.axonframework.common.jpa.PagingJpaQueryIterable
- 
Constructs a new  Iterable using the provided  querySupplier to construct queries when a new page
 needs to be fetched. 
- PagingJpaQueryIterable<T,R> - Class in org.axonframework.common.legacyjpa
- 
- PagingJpaQueryIterable(int, TransactionManager, Supplier<TypedQuery<T>>, Function<T, R>) - Constructor for class org.axonframework.common.legacyjpa.PagingJpaQueryIterable
- 
Deprecated. Constructs a new  Iterable using the provided  querySupplier to construct queries when a new page
 needs to be fetched. 
- PagingJpaQueryIterable.PagingIterator - Class in org.axonframework.common.jpa
- 
The  Iterator that loops through the provided query's pages until it runs out of items. 
- PagingJpaQueryIterable.PagingIterator - Class in org.axonframework.common.legacyjpa
- 
Deprecated. The  Iterator that loops through the provided query's pages until it runs out of items. 
- ParameterResolver<T> - Interface in org.axonframework.messaging.annotation
- 
Interface for a mechanism that resolves handler method parameter values from a given  Message. 
- parameterResolverFactory() - Method in interface org.axonframework.config.Configuration
- 
Returns the Parameter Resolver Factory defined in this Configuration 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
- 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
- 
Sets the  ParameterResolverFactory used to resolve parameter values for annotated handlers in the
 snapshot aggregate this snapshotter creates. 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- ParameterResolverFactory - Interface in org.axonframework.messaging.annotation
- 
Interface for objects capable of creating Parameter Resolver instances for annotated handler methods. 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
- 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
- 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
-  
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
-  
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
- 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
- 
- parameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
-  
- parameterResolverFactory(List<ParameterResolverFactory>) - Method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- parametersMatch(Message<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
- 
Checks if the parameter resolvers of this member are compatible with the given message.
 
- parent() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-  
- parent() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- parent() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Returns an optional for the parent of this Unit of Work. 
- parse(Throwable) - Static method in class org.axonframework.axonserver.connector.event.util.GrpcExceptionParser
- 
- parseInstant(CharSequence) - Static method in class org.axonframework.common.DateTimeUtils
- 
Parse the given  timestamp into an  Instant. 
- pause() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
- 
- pauseProcessor() - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService.AxonProcessorInstructionHandler
-  
- PAYLOAD_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the payload type contained in the  Message. 
- PAYLOAD_TYPE_TAG - Static variable in class org.axonframework.micrometer.TagsUtil
- 
The micrometer Tagkey that represents the Axon message payload type
 
- PAYLOAD_TYPE_TAGGER_FUNCTION - Static variable in class org.axonframework.micrometer.TagsUtil
- 
The function for creating the Micrometer Tags based on the message payload type.
 
- PayloadAssociationResolver - Class in org.axonframework.modelling.saga
- 
Used to derive the value of an association property by looking it up the event message's payload. 
- PayloadAssociationResolver() - Constructor for class org.axonframework.modelling.saga.PayloadAssociationResolver
-  
- payloadColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the event payload column. 
- payloadColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the serialized payload of the event. 
- PayloadMatcher<T extends Message> - Class in org.axonframework.test.matchers
- 
Matcher that matches any message (e.g. 
- PayloadMatcher(Matcher<?>) - Constructor for class org.axonframework.test.matchers.PayloadMatcher
- 
Constructs an instance with the given payloadMatcher.
 
- payloadMatching(Predicate<Object>) - Static method in class org.axonframework.eventsourcing.conflictresolution.Conflicts
- 
Returns a  Predicate for a  ConflictResolver that responds affirmative if the payload of any event
 in a list of unseen events matches the given  messageFilter. 
- payloadMatching(Class<T>, Predicate<? super T>) - Static method in class org.axonframework.eventsourcing.conflictresolution.Conflicts
- 
Returns a  Predicate for a  ConflictResolver that responds affirmative if the payload of any event
 in a list of unseen events is of given  payloadType and matches the given  messageFilter. 
- PayloadParameterResolver - Class in org.axonframework.messaging.annotation
- 
Implementation of a  ParameterResolver that resolves the Message payload as parameter in a handler method. 
- PayloadParameterResolver(Class<?>) - Constructor for class org.axonframework.messaging.annotation.PayloadParameterResolver
- 
- payloadRevision - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-  
- payloadRevision - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- payloadRevisionColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the event payload revision column. 
- payloadRevisionColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the revision number of the serialized payload. 
- PayloadsMatcher - Class in org.axonframework.test.matchers
- 
Matches a list of Messages if the list of their payloads matches the given matcher.. 
- PayloadsMatcher(Matcher<? extends Iterable<?>>) - Constructor for class org.axonframework.test.matchers.PayloadsMatcher
- 
Constructs an instance that uses the given matcherto match the payloads.
 
- payloadsMatching(Matcher<? extends List<?>>) - Static method in class org.axonframework.test.matchers.Matchers
- 
Matches a list of Messages if a list containing their respective payloads matches the given
 matcher.
 
- payloadType - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-  
- payloadType - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
- 
Returns the sql to describe the type of payload column. 
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
-  
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
-  
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-  
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
-  
- payloadType() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-  
- payloadType() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
- 
Returns the payload type of messages that can be processed by this handler. 
- payloadType() - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-  
- payloadType() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-  
- payloadTypeColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the event payload type column. 
- payloadTypeColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the event payload type. 
- PayloadTypeMessageMonitorWrapper<T extends MessageMonitor<Message<?>> & com.codahale.metrics.MetricSet> - Class in org.axonframework.metrics
- 
A  MessageMonitor implementation which creates a new MessageMonitor for every  Message payload type
 ingested by it. 
- PayloadTypeMessageMonitorWrapper(Supplier<T>) - Constructor for class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
- 
Create a PayloadTypeMessageMonitorWrapper which builds monitors through a given monitorSupplierfor
 every message payload type encountered.
 
- PayloadTypeMessageMonitorWrapper(Supplier<T>, Function<Class<?>, String>) - Constructor for class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
- 
Create a PayloadTypeMessageMonitorWrapper which builds monitors through a given monitorSupplierfor
 every message payload type encountered and sets the monitor name as specified by themonitorNameBuilder.
 
- PayloadTypeMessageMonitorWrapper<T extends MessageMonitor<Message<?>>> - Class in org.axonframework.micrometer
- 
- PayloadTypeMessageMonitorWrapper(Function<String, T>) - Constructor for class org.axonframework.micrometer.PayloadTypeMessageMonitorWrapper
- 
Deprecated. Create a PayloadTypeMessageMonitorWrapper which builds monitors through a given monitorSupplierfor
 every message payload type encountered.
 
- PayloadTypeMessageMonitorWrapper(Function<String, T>, Function<Class<?>, String>) - Constructor for class org.axonframework.micrometer.PayloadTypeMessageMonitorWrapper
- 
Deprecated. Create a PayloadTypeMessageMonitorWrapper which builds monitors through a given monitorSupplierfor
 every message payload type encountered and sets the monitor name as specified by themonitorNameBuilder.
 
- payloadTypeOf(Class<T>) - Static method in class org.axonframework.eventsourcing.conflictresolution.Conflicts
- 
Returns a  Predicate for a  ConflictResolver that responds affirmative if the payload type of any
 event in a list of unseen events is assignable to given  payloadType. 
- payloadTypeSpanAttributesProvider() - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
-  
- PayloadTypeSpanAttributesProvider - Class in org.axonframework.tracing.attributes
- 
- PayloadTypeSpanAttributesProvider() - Constructor for class org.axonframework.tracing.attributes.PayloadTypeSpanAttributesProvider
-  
- peek() - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
-  
- peek() - Method in interface org.axonframework.common.stream.BlockingStream
- 
Checks whether or not the next message in the stream is immediately available. 
- peek() - Method in class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
-  
- peek() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
- 
Returns the next events in the stream, if available, without moving the pointer forward. 
- peek() - Method in class org.axonframework.eventsourcing.eventstore.FilteringDomainEventStream
-  
- peek() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
-  
- performReset() - Method in class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker
-  
- performReset(R) - Method in class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker
-  
- performReset() - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
- 
Performs any activities that are required to reset the state managed by handlers assigned to this invoker. 
- performReset(R) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
- 
Performs any activities that are required to reset the state managed by handlers assigned to this invoker. 
- performReset() - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
-  
- performReset(R) - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
-  
- performReset() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-  
- performReset(R) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-  
- performReset() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-  
- performReset(Object) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-  
- PersistenceExceptionResolver - Interface in org.axonframework.common.jdbc
- 
The PersistenceExceptionResolver is used to find out if an exception is caused by  duplicate keys. 
- persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
- 
- persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
-  
- persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-  
- persistenceExceptionResolver(PersistenceExceptionResolver) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. 
- persistenceExceptionResolver(DataSource) - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
-  
- persistenceExceptionResolver(DataSource) - Method in class org.axonframework.springboot.autoconfig.legacyjpa.JpaJavaxAutoConfiguration
- 
Deprecated. 
- PessimisticLockFactory - Class in org.axonframework.common.lock
- 
Implementation of a  LockFactory that uses a pessimistic locking strategy. 
- PessimisticLockFactory(PessimisticLockFactory.Builder) - Constructor for class org.axonframework.common.lock.PessimisticLockFactory
- 
Creates an instance of the lock factory using the given buildercontaining the configuration properties
 to use.
 
- PessimisticLockFactory.Builder - Class in org.axonframework.common.lock
- 
- phase() - Method in interface org.axonframework.config.ModuleConfiguration
- 
- Phase - Class in org.axonframework.lifecycle
- 
- phase() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- phase() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Returns the current phase of the Unit of Work. 
- PK() - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
- 
Constructor for JPA 
- PK(String, int) - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
- 
Constructs a primary key for a TokenEntry 
- PK() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
- 
Constructor for JPA. 
- platformConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
- 
- platformConnectionManager(AxonServerConfiguration, TagsConfigurationProperties, ManagedChannelCustomizer) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- pooledStreamingEventProcessor(String, EventHandlerInvoker, Configuration, StreamableMessageSource<TrackedEventMessage<?>>, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in class org.axonframework.config.EventProcessingModule
- 
- PooledStreamingEventProcessor - Class in org.axonframework.eventhandling.pooled
- 
- PooledStreamingEventProcessor(PooledStreamingEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
- 
- PooledStreamingEventProcessor.Builder - Class in org.axonframework.eventhandling.pooled
- 
- position() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
-  
- position() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
-  
- position() - Method in class org.axonframework.eventhandling.MergedTrackingToken
-  
- position() - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
- 
Returns the sum of all positions of the constituent tracking tokens. 
- position() - Method in class org.axonframework.eventhandling.ReplayToken
-  
- position() - Method in interface org.axonframework.eventhandling.TrackingToken
- 
Return the estimated relative position this token represents. 
- postDelete(A) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Perform action that needs to be done directly after deleting an aggregate and committing the aggregate's
 uncommitted events. 
- PostgresEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
- 
Jdbc table factory for Postgresql databases. 
- PostgresSagaSqlSchema - Class in org.axonframework.modelling.saga.repository.jdbc
- 
SQL schema supporting PostgreSQL databases. 
- PostgresSagaSqlSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
- 
Initialize a PostgresSagaSqlSchema using the default schema configuration. 
- PostgresSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
- 
Initialize a PostgresSagaSqlSchema using the given sagaSchema.
 
- PostgresTokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
- 
Jdbc token entry table factory for Postgres databases. 
- PostgresTokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.PostgresTokenTableFactory
-  
- postProcessAfterInitialization(Object, String) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. 
- postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.MessageHandlerLookup
-  
- postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.SpringAggregateLookup
-  
- postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.SpringSagaLookup
-  
- postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.axonframework.spring.config.MessageHandlerLookup
-  
- postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.axonframework.spring.config.SpringAggregateLookup
-  
- postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.axonframework.spring.config.SpringSagaLookup
-  
- postProcessBeforeInitialization(Object, String) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. 
- postProcessInstance(T) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
- 
Perform any processing that must be done on an aggregate instance that was reconstructed from a Snapshot Event. 
- postSave(A) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Perform action that needs to be done directly after updating an aggregate and committing the aggregate's
 uncommitted events. 
- predicate(Predicate<T>) - Static method in class org.axonframework.test.matchers.Matchers
- 
Returns a Matcher that matches with values defined by the given predicate.
 
- PredicateMatcher<T> - Class in org.axonframework.test.matchers
- 
Matcher implementation that delegates the matching to a Predicate. 
- PredicateMatcher(Predicate<T>) - Constructor for class org.axonframework.test.matchers.PredicateMatcher
- 
Initializes the matcher using given predicateto test values to match against.
 
- prepareCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
- 
Process given eventswhile the Unit of Work root is preparing for commit.
 
- prepareCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-  
- prepareForCommit(A) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Register handlers with the current Unit of Work that save or delete the given aggregatewhen
 the Unit of Work is committed.
 
- prepareForCommit(LockAwareAggregate<T, A>) - Method in class org.axonframework.modelling.command.LockingRepository
-  
- prepareMessageHandlerRegistrars() - Method in class org.axonframework.config.DefaultConfigurer
- 
- prepareModules() - Method in class org.axonframework.config.DefaultConfigurer
- 
Prepare the registered modules for initialization. 
- prepareReset() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-  
- prepareReset(R) - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-  
- prepareReset() - Method in interface org.axonframework.eventhandling.EventMessageHandler
- 
Performs any activities that are required to reset the state managed by handlers assigned to this handler. 
- prepareReset(R) - Method in interface org.axonframework.eventhandling.EventMessageHandler
- 
Performs any activities that are required to reset the state managed by handlers assigned to this handler. 
- prepareReset() - Method in interface org.axonframework.modelling.saga.Saga
-  
- prepareReset(Object) - Method in interface org.axonframework.modelling.saga.Saga
-  
- prepareTrigger(Class<?>) - Method in class org.axonframework.eventsourcing.AggregateLoadTimeSnapshotTriggerDefinition
-  
- prepareTrigger(Class<?>) - Method in class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
-  
- prepareTrigger(Class<?>) - Method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
-  
- prepareTrigger(Class<?>) - Method in interface org.axonframework.eventsourcing.SnapshotTriggerDefinition
- 
Prepares a new trigger for an aggregate with the given aggregateIdentifierandaggregateType.
 
- priority() - Method in class org.axonframework.axonserver.connector.PriorityCallable
-  
- priority() - Method in class org.axonframework.axonserver.connector.PriorityRunnable
-  
- priority() - Method in interface org.axonframework.axonserver.connector.PriorityTask
- 
Returns the priority of this task. 
- priority(List<ProcessingInstruction>) - Static method in class org.axonframework.axonserver.connector.util.ProcessingInstructionHelper
- 
Retrieve the priority as a longfrom the givenprocessingInstructions, by searching for theProcessingInstructionwho's key equals theProcessingKey.PRIORITY.
 
- Priority - Annotation Type in org.axonframework.common
- 
Indicates the relative priority of the annotated component. 
- priority() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
- 
Returns a number representing the priority of this handler over other handlers capable of processing the same
 message. 
- priority() - Method in interface org.axonframework.messaging.annotation.MessageInterceptingMember
-  
- priority() - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-  
- priority() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-  
- PriorityAnnotationComparator<T> - Class in org.axonframework.common.annotation
- 
Comparator that compares objects based on the value on an  @Priority
 annotation. 
- priorityCalculator(CommandPriorityCalculator) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
Sets the  CommandPriorityCalculator used to deduce the priority of an incoming command among other
 commands, to give precedence over high(er) valued queries for example. 
- priorityCalculator(QueryPriorityCalculator) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
Sets the  QueryPriorityCalculator used to deduce the priority of an incoming query among other
 queries, to give precedence over high(er) valued queries for example. 
- PriorityCallable<T> - Class in org.axonframework.axonserver.connector
- 
- PriorityCallable(Callable<T>, long, long) - Constructor for class org.axonframework.axonserver.connector.PriorityCallable
- 
Construct a priority task. 
- PriorityExecutorService - Class in org.axonframework.axonserver.connector.util
- 
- PriorityRunnable - Class in org.axonframework.axonserver.connector
- 
- PriorityRunnable(Runnable, long, long) - Constructor for class org.axonframework.axonserver.connector.PriorityRunnable
- 
Construct a priority task. 
- PriorityTask - Interface in org.axonframework.axonserver.connector
- 
- PriorityTaskSchedulers - Interface in org.axonframework.axonserver.connector.util
- 
Responsible for creating  Scheduler implementations relevant to the Axon Server connector. 
- proceed() - Method in class org.axonframework.messaging.DefaultInterceptorChain
-  
- proceed() - Method in interface org.axonframework.messaging.InterceptorChain
- 
Signals the Interceptor Chain to continue processing the message. 
- process(Predicate<DeadLetter<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker
-  
- process(Predicate<DeadLetter<? extends M>>, Function<DeadLetter<? extends M>, EnqueueDecision<M>>) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- process(Function<DeadLetter<? extends M>, EnqueueDecision<M>>) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- process(Predicate<DeadLetter<? extends M>>, Function<DeadLetter<? extends M>, EnqueueDecision<M>>) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- process(Function<DeadLetter<? extends M>, EnqueueDecision<M>>) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- process(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
- 
Process the given messages. 
- process(Predicate<DeadLetter<? extends M>>, Function<DeadLetter<? extends M>, EnqueueDecision<M>>) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- process(Predicate<DeadLetter<? extends M>>) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterProcessor
- 
Process a sequence of  dead letters matching the given  sequenceFilter. 
- process(Predicate<DeadLetter<? extends M>>, Function<DeadLetter<? extends M>, EnqueueDecision<M>>) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Process a sequence of enqueued  dead letters through the given  processingTask matching
 the  sequenceFilter. 
- process(Function<DeadLetter<? extends M>, EnqueueDecision<M>>) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Process a sequence of enqueued  dead letters with the given  processingTask. 
- processAny() - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterProcessor
- 
Process any sequence of  dead letters belonging to this component. 
- processDispatchInterceptors(DeadlineMessage<T>) - Method in class org.axonframework.deadline.AbstractDeadlineManager
- 
- ProcessingGroup - Annotation Type in org.axonframework.config
- 
Hint for the Configuration API that the annotated Event Handler object should be assigned to an Event Processor with
 the specified name. 
- processingGroup() - Method in interface org.axonframework.config.SagaConfiguration
- 
Gets the Processing Group this Saga is assigned to. 
- processingGroup(String) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
Sets the processing group, which is used for storing and quering which event processor the deadlettered item
 belonged to. 
- processingGroup(String) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. Sets the processing group, which is used for storing and quering which event processor the deadlettered item
 belonged to. 
- ProcessingInstructionHelper - Class in org.axonframework.axonserver.connector.util
- 
Utility class contain helper methods to extract information from ProcessingInstructions.
 
- processingLoop(Segment) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Fetch and process event batches continuously for as long as the processor is not shutting down. 
- processingSegments(TrackingToken, Segment) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Indicates whether the eventMessageidentified with giventokenshould be processed as part of the
 givensegment.
 
- processingStatus() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- processingStatus() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Returns the status for each of the segments processed by this processor as  EventTrackerStatus instances. 
- processingStatus() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- processingStrategy(EventProcessingStrategy) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
- 
- processInterceptors(CommandMessage<C>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
- 
Invokes all the dispatch interceptors and returns the CommandMessage instance that should be dispatched. 
- processInterceptors(EventMessage<E>) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
- 
Invokes all the dispatch interceptors and returns the EventMessage instance that should be dispatched. 
- processInUnitOfWork(List<? extends EventMessage<?>>, UnitOfWork<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
- 
Process a batch of events. 
- processInUnitOfWork(List<? extends EventMessage<?>>, UnitOfWork<? extends EventMessage<?>>, Collection<Segment>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
- 
Process a batch of events. 
- PROCESSOR_NAME_TAG - Static variable in class org.axonframework.micrometer.TagsUtil
- 
The micrometer Tagkey that represents the Axon event processor name
 
- processorInfoConfiguration(EventProcessingConfiguration, AxonServerConnectionManager, AxonServerConfiguration) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- processorNameColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
- 
Returns the name of the column containing the name of the processor to which the token belongs. 
- ProcessorSettings() - Constructor for class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-  
- ProcessRetriesExhaustedException - Exception in org.axonframework.common
- 
Exception indicating that an action was retried a maximum times, without a good result. 
- ProcessRetriesExhaustedException(String) - Constructor for exception org.axonframework.common.ProcessRetriesExhaustedException
- 
Initializes the exception using the given message.
 
- ProcessRetriesExhaustedException(String, Throwable) - Constructor for exception org.axonframework.common.ProcessRetriesExhaustedException
- 
Initializes the exception using the given messageandcause.
 
- ProcessUtils - Class in org.axonframework.common
- 
Processing utilities. 
- producerType(ProducerType) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
Sets the ProducerTypeto use by theDisruptor.
 
- projectReactorOnClassPath() - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-  
- projectReactorOnClasspath() - Static method in class org.axonframework.util.ClasspathResolver
- 
Return trueif Project Reactor is on classpath,falseotherwise.
 
- propagateContext(M) - Method in class org.axonframework.tracing.LoggingSpanFactory
-  
- propagateContext(M) - Method in class org.axonframework.tracing.MultiSpanFactory
-  
- propagateContext(M) - Method in class org.axonframework.tracing.NestingSpanFactory
-  
- propagateContext(M) - Method in class org.axonframework.tracing.NoOpSpanFactory
-  
- propagateContext(M) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
-  
- propagateContext(M) - Method in interface org.axonframework.tracing.SpanFactory
- 
Propagates the currently active trace and span to the message. 
- PropagatingErrorHandler - Enum in org.axonframework.eventhandling
- 
Singleton ErrorHandler implementation that does not do anything. 
- Property<T> - Interface in org.axonframework.common.property
- 
Interface describing a mechanism that can read a predefined property from a given instance. 
- PropertyAccessException - Exception in org.axonframework.common.property
- 
Exception indicating that a predefined property is not accessible. 
- PropertyAccessException(String, Throwable) - Constructor for exception org.axonframework.common.property.PropertyAccessException
- 
Initializes the PropertyAccessException with given messageandcause.
 
- PropertyAccessStrategy - Class in org.axonframework.common.property
- 
Abstract Strategy that provides access to all PropertyAccessStrategy implementations. 
- PropertyAccessStrategy() - Constructor for class org.axonframework.common.property.PropertyAccessStrategy
-  
- propertyExtractor(Function<T, K>) - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy.Builder
- 
Defines the property extractor, a function which is applied to the event message payload to extract the
 sequence identifier. 
- propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-  
- propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.DirectPropertyAccessStrategy
-  
- propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.PropertyAccessStrategy
- 
Returns a Property instance for the given property, defined in giventargetClass, ornullif no such property is found on the class.
 
- propertyName(String) - Method in class org.axonframework.eventhandling.async.PropertySequencingPolicy.Builder
- 
Defines the name of the property to be extracted as sequence identifier. 
- PropertySequencingPolicy<T,K> - Class in org.axonframework.eventhandling.async
- 
A  SequencingPolicy implementation that extracts the sequence identifier from the event message payload based
 on a given property or property extractor. 
- PropertySequencingPolicy(PropertySequencingPolicy.Builder) - Constructor for class org.axonframework.eventhandling.async.PropertySequencingPolicy
- 
- PropertySequencingPolicy.Builder<T,K> - Class in org.axonframework.eventhandling.async
- 
- provideForMessage(Message<?>) - Method in class org.axonframework.tracing.attributes.AggregateIdentifierSpanAttributesProvider
-  
- provideForMessage(Message<?>) - Method in class org.axonframework.tracing.attributes.MessageIdSpanAttributesProvider
-  
- provideForMessage(Message<?>) - Method in class org.axonframework.tracing.attributes.MessageNameSpanAttributesProvider
-  
- provideForMessage(Message<?>) - Method in class org.axonframework.tracing.attributes.MessageTypeSpanAttributesProvider
-  
- provideForMessage(Message<?>) - Method in class org.axonframework.tracing.attributes.MetadataSpanAttributesProvider
-  
- provideForMessage(Message<?>) - Method in class org.axonframework.tracing.attributes.PayloadTypeSpanAttributesProvider
-  
- provideForMessage(Message<?>) - Method in interface org.axonframework.tracing.SpanAttributesProvider
- 
Provides a map of attributes to add to the  Span based on the  Message provided. 
- provideScopeAwareStream(ScopeDescriptor) - Method in class org.axonframework.config.ConfigurationScopeAwareProvider
-  
- provideScopeAwareStream(ScopeDescriptor) - Method in interface org.axonframework.messaging.ScopeAwareProvider
- 
- psepConfigs - Variable in class org.axonframework.config.EventProcessingModule
-  
- publish(M) - Method in interface org.axonframework.axonserver.connector.Publisher
- 
Deprecated. Publishes the given message
 
- publish(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-  
- publish(EventMessage<?>...) - Method in interface org.axonframework.eventhandling.EventBus
- 
Publish a collection of events on this bus (one, or multiple). 
- publish(List<? extends EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventBus
- 
Publish a collection of events on this bus (one, or multiple). 
- publish(Object) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
- 
Publishes (dispatches) an event. 
- publish(List<?>) - Method in class org.axonframework.eventhandling.gateway.DefaultEventGateway
-  
- publish(Object...) - Method in interface org.axonframework.eventhandling.gateway.EventGateway
- 
Publish a collection of events on this bus (one, or multiple). 
- publish(List<?>) - Method in interface org.axonframework.eventhandling.gateway.EventGateway
- 
Publish a collection of events on this bus (one, or multiple). 
- publish(String, String) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
- 
This function should only be called via Jobrunr when a scheduled event was triggered. 
- publish(String, String, String) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
- 
This function should only be called via Jobrunr when a scheduled event was triggered. 
- publish(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-  
- publish(EventMessage<?>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Publish an event to the aggregate root and its entities first and external event handlers (using the given event
 bus) later. 
- publish(EventMessage<?>, P) - Method in class org.axonframework.modelling.command.inspection.AnnotatedChildEntity
-  
- publish(EventMessage<?>, T) - Method in interface org.axonframework.modelling.command.inspection.ChildEntity
- 
Publish the given msgto the appropriate handlers on the givendeclaringInstance.
 
- publish(EventMessage<?>, T) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
- 
Publish given event messageon the giventargetentity.
 
- published(Object...) - Method in interface org.axonframework.test.saga.GivenAggregateEventPublisher
- 
Register the given eventsas being published somewhere in the past.
 
- Publisher<M> - Interface in org.axonframework.axonserver.connector
- 
- PUBLISHER_MATCH - Static variable in class org.axonframework.messaging.responsetypes.PublisherResponseType
- 
Indicates that the response matches with the  Type while returning a publisher result. 
- publisherInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- publisherOf(Class<R>) - Static method in class org.axonframework.messaging.responsetypes.ResponseTypes
- 
Specify the desire to retrieve a Publisher (reactive stream) of instances of type Rwhen performing a
 query.
 
- PublisherResponseType<R> - Class in org.axonframework.messaging.responsetypes
- 
A  ResponseType implementation that will match with query
 handlers that return a  Publisher stream of the expected response type. 
- PublisherResponseType(Class<?>) - Constructor for class org.axonframework.messaging.responsetypes.PublisherResponseType
- 
Instantiate a  PublisherResponseType with the given
  expectedResponseType as the type to be matched against and to which the query response should be
 converted to. 
- publisherThreadCount(int) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
Sets the number of Threads that should be used to store and publish the generated Events. 
- publishes(Object) - Method in interface org.axonframework.test.saga.WhenAggregateEventPublisher
- 
Register the given eventto be published on behalf of an aggregate.
 
- publishes(Object, Map<String, ?>) - Method in interface org.axonframework.test.saga.WhenAggregateEventPublisher
- 
Register the given eventto be published on behalf of an aggregate, with given additionalmetaData.
 
- publishFailureFor(String, Throwable) - Method in interface org.axonframework.axonserver.connector.InstructionResultPublisher
- 
Deprecated. Notifies to Axon Server a failure during the execution of the specified instruction. 
- publishFailureFor(String, String) - Method in interface org.axonframework.axonserver.connector.InstructionResultPublisher
- 
Deprecated. Notifies to Axon Server a failure during the execution of the specified instruction. 
- publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-  
- publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Publish an event to external event handlers using the given event bus. 
- publishSuccessFor(String) - Method in interface org.axonframework.axonserver.connector.InstructionResultPublisher
- 
Deprecated. Notifies to Axon Server a successful execution of the specified instruction. 
- publishWithRevision(String, String, String) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
- 
This function should only be called via Jobrunr when a scheduled event was triggered. 
- publishWithRevision(String, String, String, String) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
- 
This function should only be called via Jobrunr when a scheduled event was triggered. 
- pulse() - Method in interface org.axonframework.axonserver.connector.heartbeat.HeartbeatSource
- 
Deprecated. Send an heartbeat to AxonServer 
- pulse() - Method in class org.axonframework.axonserver.connector.heartbeat.source.GrpcHeartbeatSource
- 
Deprecated. Send an heartbeat to AxonServer 
- put(Object, Object) - Method in interface org.axonframework.common.caching.Cache
- 
Stores the given valuein the cache, under givenkey.
 
- put(Object, Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- put(Object, Object) - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- put(Object, Object) - Method in class org.axonframework.common.caching.NoCache
-  
- put(Object, Object) - Method in class org.axonframework.common.caching.WeakReferenceCache
-  
- put(String, Object) - Method in class org.axonframework.messaging.MetaData
- 
This operation is not supported. 
- putAll(Map<? extends String, ?>) - Method in class org.axonframework.messaging.MetaData
- 
This operation is not supported. 
- putIfAbsent(Object, Object) - Method in interface org.axonframework.common.caching.Cache
- 
Stores the given valuein the cache, under givenkey, if no element is yet available under that
 key.
 
- putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.NoCache
-  
- putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.WeakReferenceCache
-  
- ReactorlessStartup - Class in org.axonframework.reactorlesstest
- 
Dummy spring boot app just to wire up Axon beans without Project Reactor on the classpath. 
- ReactorlessStartup() - Constructor for class org.axonframework.reactorlesstest.ReactorlessStartup
-  
- readAssociationValues(ResultSet) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- readAssociationValues(ResultSet) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
- readData(Class<T>) - Method in class org.axonframework.serialization.UnknownSerializedType
- 
Returns the data contained in the serialized object in the given desiredFormat, if supported.
 
- readEventData(String, long) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
- 
Returns a  Stream of serialized event data entries for an aggregate with given  identifier. 
- readEventData(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
- 
Returns a global  Stream containing all serialized event data entries in the event storage that have a
  TrackingToken greater than the given  trackingToken. 
- readEventData(String, long) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
-  
- readEventData(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine
- 
Returns a global  Stream containing all serialized event data entries in the event storage that have a
  TrackingToken greater than the given  trackingToken. 
- readEventData(Connection, String, long, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- readEventData(Connection, TrackingToken, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Creates a statement to read tracked event entries stored since given tracking token. 
- readEventDataForAggregate(ReadEventDataForAggregateStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- readEventDataForAggregate(Connection, EventSchema, String, long, int) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- ReadEventDataForAggregateStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
- 
- readEventDataWithGaps(ReadEventDataWithGapsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- readEventDataWithGaps(Connection, long, int, List<Long>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- readEventDataWithGaps(Connection, EventSchema, long, int, List<Long>) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- ReadEventDataWithGapsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
- 
- readEventDataWithoutGaps(ReadEventDataWithoutGapsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- readEventDataWithoutGaps(Connection, long, int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- readEventDataWithoutGaps(Connection, EventSchema, long, int) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- ReadEventDataWithoutGapsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
- 
- readEvents(String) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
-  
- readEvents(String) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
- 
Reads the events for the given aggregateIdentifier from the eventStore. 
- readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-  
- readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-  
- readEvents(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
- 
Open an event stream containing all domain events belonging to the given aggregateIdentifier.
 
- readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-  
- readEvents(TrackingToken, boolean) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
- 
Open an event stream containing all events stored since given tracking token. 
- readEvents(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
- 
Get a  DomainEventStream containing all events published by the aggregate with given  aggregateIdentifier. 
- readEvents(String, long) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
- 
Get a  DomainEventStream containing all events published by the aggregate with given  aggregateIdentifier starting with the first event having a sequence number that is equal or larger than the
 given  firstSequenceNumber. 
- readEvents(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
- 
Open an event stream containing all domain events belonging to the given aggregateIdentifier.
 
- readEvents(String, long) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
- 
Open an event stream containing all domain events belonging to the given aggregateIdentifier.
 
- readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
- 
Open an event stream containing all events stored since given tracking token. 
- readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-  
- readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-  
- readEvents(String, long) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-  
- readEvents(TrackingToken, boolean) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-  
- readEvents(String) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-  
- readEvents(String, long) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-  
- readPayload(ResultSet, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Reads a serialized object from the given resultSetat givencolumnIndex.
 
- readResolve() - Method in class org.axonframework.messaging.MetaData
- 
Java Serialization specification method that will ensure that deserialization will maintain a single instance of
 empty MetaData. 
- readSerializedData(ResultSet, String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Returns the serialized token data from the given resultSetat givencolumnName.
 
- readSerializedSaga(ResultSet) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- readSerializedSaga(ResultSet) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
- readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-  
- readSnapshot(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
- 
Try to load a snapshot event of the aggregate with given aggregateIdentifier.
 
- readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-  
- readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-  
- readSnapshot(String) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-  
- readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
- 
Returns a stream of serialized event entries for given aggregateIdentifierif the backing database
 contains a snapshot of the aggregate.
 
- readSnapshotData(ReadSnapshotDataStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- readSnapshotData(Connection, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-  
- readSnapshotData(Connection, EventSchema, String) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
- 
- readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-  
- readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. 
- ReadSnapshotDataStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
- 
Contract which defines how to build a PreparedStatement for use on {@link JdbcEventStorageEngine#readSnapshotData(String) 
- readTimeStamp(ResultSet, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Reads a timestamp from the given resultSetat givencolumnIndex.
 
- readToken(ResultSet) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- readToken(ResultSet) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Reads a token from the given resultSet.
 
- readTokenEntry(ResultSet) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
- reconfigure(Class<?>, SnapshotTrigger) - Method in class org.axonframework.eventsourcing.AggregateLoadTimeSnapshotTriggerDefinition
-  
- reconfigure(Class<?>, SnapshotTrigger) - Method in class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
-  
- reconfigure(Class<?>, SnapshotTrigger) - Method in interface org.axonframework.eventsourcing.SnapshotTriggerDefinition
- 
Reconfigure the necessary infrastructure components in the given trigger instance, which may have been
 lost in the (de)serialization process.
 
- reconstruct(T, AggregateModel<T>, long, boolean, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Reconstructs an EventSourcedAggregate instance with given aggregateRoot.
 
- reconstruct(T, AggregateModel<T>, long, boolean, EventBus, RepositoryProvider, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
- 
Reconstructs an EventSourcedAggregate instance with given aggregateRoot.
 
- recordException(Throwable) - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
- 
Record the given exceptionas a result of this validator.
 
- recordException(Throwable) - Method in class org.axonframework.tracing.NoOpSpanFactory.NoOpSpan
-  
- recordException(Throwable) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpan
-  
- recordException(Throwable) - Method in interface org.axonframework.tracing.Span
- 
Records an exception to the span. 
- RecordingCommandBus - Class in org.axonframework.test.utils
- 
CommandBus implementation that does not perform any actions on subscriptions or dispatched commands, but records
 them instead. 
- RecordingCommandBus() - Constructor for class org.axonframework.test.utils.RecordingCommandBus
-  
- RecordingListenerInvocationErrorHandler - Class in org.axonframework.test.saga
- 
- RecordingListenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Constructor for class org.axonframework.test.saga.RecordingListenerInvocationErrorHandler
- 
- recreateAggregate(AggregateModel<T>, EventStore, SnapshotTriggerDefinition) - Method in class org.axonframework.eventsourcing.AggregateCacheEntry
-  
- recreateAggregate(AggregateModel<T>, EventStore, RepositoryProvider, SnapshotTriggerDefinition) - Method in class org.axonframework.eventsourcing.AggregateCacheEntry
-  
- recreateWithNewMessage(DeadlineMessage<?>) - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Creates a new instance of scheduled deadline info with new deadlineMessage.
 
- RECURSIVE - Static variable in class org.axonframework.common.ReflectionUtils
- 
Specifying a reflection operation should be performed recursive. 
- REFIRE_IMMEDIATELY_POLICY - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
- 
The key under which a  Predicate is stored within the  SchedulerContext. 
- refireImmediatelyPolicy(Predicate<Throwable>) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
- 
- ReflectionUtils - Class in org.axonframework.common
- 
Utility class for working with Java Reflection API. 
- register(BiPredicate<String, Case>, Handler) - Method in class org.axonframework.axonserver.connector.DefaultHandlers
- 
Deprecated. 
- register(Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
- 
Registers a handlerthat can handle instructions regardless of context or request case.
 
- register(String, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
- 
Registers a handlerthat can handle instructions for givencontextregardless of request case.
 
- register(Case, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
- 
Registers a handlerthat can handle instructions for givenrequestCaseregardless of context.
 
- register(String, Case, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
- 
Registers a handlerthat can handle instructions for givencontextandrequestCase.
 
- register(BiPredicate<String, Case>, Handler) - Method in interface org.axonframework.axonserver.connector.Handlers
- 
Registers a handlerthat can handle instructions matching givenhandlerSelectorpredicate.
 
- register(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
- 
Registers a PropertyAccessStrategy implementation at runtime. 
- registerActivity() - Method in class org.axonframework.lifecycle.ShutdownLatch
- 
Add an activity this latch should wait on before opening up. 
- registerAggregateFactory(AggregateFactory<?>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
- 
Registers the given aggregateFactorywith this snapshotter.
 
- registerAggregateFactory(AggregateFactory<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerAggregateFactory(AggregateFactory<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers the given aggregateFactorywith the fixture.
 
- registerAggregateIdentifier(String) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Registers the identifier of the aggregate that will process the next command. 
- registerAnnotatedCommandHandler(Object) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerAnnotatedCommandHandler(Object) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers an annotatedCommandHandlerwith this fixture.
 
- registerAnnotationCommandHandlerBeanPostProcessor(BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.AnnotationDrivenRegistrar
- 
Deprecated. 
- registerAnnotationQueryHandlerBeanPostProcessor(BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.AnnotationDrivenRegistrar
- 
Deprecated. 
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.AnnotationDrivenRegistrar
- 
Deprecated. 
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer
- 
Deprecated. 
- registerBeanDefinitions(AnnotationMetadata, BeanDefinitionRegistry) - Method in class org.axonframework.springboot.util.DefaultEntityRegistrar
-  
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
-  
- registerCacheEntryListener(Cache.EntryListener) - Method in interface org.axonframework.common.caching.Cache
- 
Registers the given cacheEntryListenerto listen for Cache changes.
 
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.NoCache
-  
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.WeakReferenceCache
-  
- registerCommandBus(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a  CommandBus. 
- registerCommandBus(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a  CommandBus. 
- registerCommandBus(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a  CommandBus using  Tags through the given  tagsBuilder. 
- registerCommandCallback(CommandCallback<C, R>, ResponseType<R>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
- 
Registers the callback, which is invoked for each sent command, unless Axon is able to detect that the
 result of the command does not match the type accepted by the callback.
 
- registerCommandDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerCommandDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
- registerCommandGateway(Class<T>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Creates a Command Gateway for the given gatewayInterfaceand registers that as a resource.
 
- registerCommandGateway(Class<T>, T) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Creates a Command Gateway for the given gatewayInterfaceand registers that as a resource.
 
- registerCommandGateway(Class<I>) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerCommandGateway(Class<I>, I) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerCommandHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
- 
Registers a command handler bean with this  Configurer. 
- registerCommandHandler(int, Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
- 
- registerCommandHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerCommandHandler(Class<?>, MessageHandler<CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerCommandHandler(String, MessageHandler<CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerCommandHandler(Class<?>, MessageHandler<CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers a commandHandlerto handle commands of the givencommandTypewith the
 command bus used by this fixture.
 
- registerCommandHandler(String, MessageHandler<CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers a commandHandlerto handle commands of the givencommandTypewith the
 command bus used by this fixture.
 
- registerCommandHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerCommandHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
- registerCommandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerCommandTargetResolver(CommandTargetResolver) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
- registerComponent(Class<C>, Function<Configuration, ? extends C>) - Method in interface org.axonframework.config.Configurer
- 
Registers a component which should be made available to other components or modules in this Configuration. 
- registerComponent(Class<C>, Function<Configuration, ? extends C>) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerComponent(Class<?>, String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
- 
Registers new metrics to the MetricRegistryto monitor a component of givencomponentType.
 
- registerComponent(Class<?>, String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a component of the given componentType.
 
- registerComponentWithDefaultTags(Class<?>, String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a component of the given componentType.
 
- registerConverter(ContentTypeConverter) - Method in class org.axonframework.serialization.ChainingConverter
- 
Registers the given converterwith this factory.
 
- registerConverter(Class<? extends ContentTypeConverter>) - Method in class org.axonframework.serialization.ChainingConverter
- 
Registers a convert of the given converterTypewith this factory, only if initialization of such a
 converter is possible.
 
- registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
- 
Registers any converters that are specific to the type of content written by this serializer. 
- registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.json.JacksonSerializer
- 
Registers converters with the given converterwhich depend on the actual contents of the serialized form
 to represent a JSON format.
 
- registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.xml.XStreamSerializer
-  
- registerCorrelationDataProvider(CorrelationDataProvider) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- registerCorrelationDataProvider(CorrelationDataProvider) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Register given correlationDataProviderwith this Unit of Work.
 
- registerDeadLetteringEventHandlerInvokerConfiguration(String, EventProcessingConfigurer.DeadLetteringInvokerConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDeadLetteringEventHandlerInvokerConfiguration(String, EventProcessingConfigurer.DeadLetteringInvokerConfiguration) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDeadLetterPolicy(String, Function<Configuration, EnqueuePolicy<EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDeadLetterPolicy(String, Function<Configuration, EnqueuePolicy<EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDeadLetterQueue(String, Function<Configuration, SequencedDeadLetterQueue<EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDeadLetterQueue(String, Function<Configuration, SequencedDeadLetterQueue<EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers a deadline dispatch interceptor which will always be invoked before a deadline is dispatched
 (scheduled) on the  DeadlineManager to perform a task specified in the
 interceptor. 
- registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Registers a deadline dispatch interceptor which will always be invoked before a deadline is dispatched
 (scheduled) on the  DeadlineManager to perform a task specified in the
 interceptor. 
- registerDeadlineDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers a deadline handler interceptor which will always be invoked before a deadline is handled to perform a
 task specified in the interceptor. 
- registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Registers a deadline handler interceptor which will always be invoked before a deadline is handled to perform a
 task specified in the interceptor. 
- registerDeadlineHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerDefaultDeadLetterPolicy(Function<Configuration, EnqueuePolicy<EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDefaultDeadLetterPolicy(Function<Configuration, EnqueuePolicy<EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- RegisterDefaultEntities - Annotation Type in org.axonframework.springboot.util
-  
- registerDefaultErrorHandler(Function<Configuration, ErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDefaultErrorHandler(Function<Configuration, ErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDefaultHandlerInterceptor(BiFunction<Configuration, String, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDefaultHandlerInterceptor(BiFunction<Configuration, String, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDefaultListenerInvocationErrorHandler(Function<Configuration, ListenerInvocationErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDefaultListenerInvocationErrorHandler(Function<Configuration, ListenerInvocationErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDefaultSequencingPolicy(Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDefaultSequencingPolicy(Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDefaultTransactionManager(Function<Configuration, TransactionManager>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerDefaultTransactionManager(Function<Configuration, TransactionManager>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super M>) - Method in class org.axonframework.axonserver.connector.DispatchInterceptors
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
Registers the given list of dispatch interceptors to the command bus. 
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
- 
- registerDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
- 
Registers the given dispatchInterceptorwhich is invoked for each Command dispatched through the Command
 Gateways created by this factory.
 
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
- 
Registers the given list of dispatch interceptors to the command bus. 
- registerDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.deadline.AbstractDeadlineManager
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
- 
Register the given DispatchInterceptor. 
- registerDispatchInterceptor(MessageDispatchInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
- 
Registers an event dispatch interceptor within an  EventGateway. 
- registerDispatchInterceptor(MessageDispatchInterceptor<? super T>) - Method in interface org.axonframework.messaging.MessageDispatchInterceptorSupport
- 
Register the given DispatchInterceptor. 
- registerDispatchInterceptor(MessageDispatchInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
- 
Registers an interceptor that intercepts Queries as they are sent. 
- registerDispatchInterceptor(MessageDispatchInterceptor<? super SubscriptionQueryUpdateMessage<?>>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-  
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
-  
- registerErrorHandler(String, Function<Configuration, ErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerErrorHandler(String, Function<Configuration, ErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerEventBus(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor an  EventBus. 
- registerEventBus(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor an  EventBus. 
- registerEventBus(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor an  EventBus using  Tags through the given  tagsBuilder. 
- registerEventHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
- 
Registers a  Function that builds an Event Handler instance. 
- registerEventHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
Registers a  Function that builds an Event Handler instance. 
- registerEventHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerEventHandlerInterceptor(MessageHandlerInterceptor<? super EventMessage<?>>) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
- registerEventHandlerInterceptor(MessageHandlerInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerEventProcessor(String, EventProcessingConfigurer.EventProcessorBuilder) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerEventProcessor(String, EventProcessingConfigurer.EventProcessorBuilder) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerEventProcessor(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
- 
- registerEventProcessor(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
- registerEventProcessor(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor an  EventProcessor using  Tags through the given
  tagsBuilder. 
- registerEventProcessorFactory(EventProcessingConfigurer.EventProcessorBuilder) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerEventProcessorFactory(EventProcessingConfigurer.EventProcessorBuilder) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerEventUpcaster(Function<Configuration, EventUpcaster>) - Method in interface org.axonframework.config.Configurer
- 
Registers an upcaster to be used to upcast Events to a newer version 
- registerEventUpcaster(Function<Configuration, EventUpcaster>) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerFieldFilter(FieldFilter) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerFieldFilter(FieldFilter) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers the given fieldFilter, which is used to define which Fields are used when comparing objects.
 
- registerFieldFilter(FieldFilter) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Registers the given fieldFilter, which is used to define which Fields are used when comparing objects.
 
- registerFieldFilter(FieldFilter) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerHandlerDefinition(BiFunction<Configuration, Class, HandlerDefinition>) - Method in interface org.axonframework.config.Configurer
- 
Registers the definition of a Handler class. 
- registerHandlerDefinition(BiFunction<Configuration, Class, HandlerDefinition>) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerHandlerDefinition(HandlerDefinition) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
- registerHandlerDefinition(HandlerDefinition) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
- registerHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerHandlerEnhancerDefinition(Function<Configuration, HandlerEnhancerDefinition>) - Method in interface org.axonframework.config.Configurer
- 
- registerHandlerEnhancerDefinition(Function<Configuration, HandlerEnhancerDefinition>) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
- registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
- registerHandlerEnhancerDefinition(HandlerEnhancerDefinition) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
- 
Registers the given interceptor to the command bus. 
- registerHandlerInterceptor(String, Function<Configuration, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerHandlerInterceptor(String, Function<Configuration, MessageHandlerInterceptor<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.deadline.AbstractDeadlineManager
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super T>) - Method in interface org.axonframework.messaging.MessageHandlerInterceptorSupport
- 
Register the given handlerInterceptor.
 
- registerHandlerInterceptor(MessageHandlerInterceptor<? super QueryMessage<?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
- 
Registers an interceptor that is used to intercept Queries before they are passed to their respective handlers. 
- registerHandlerInterceptor(MessageHandlerInterceptor<? super DeadlineMessage<?>>) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-  
- registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
-  
- registerIgnoredField(Class<?>, String) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerIgnoredField(Class<?>, String) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Indicates that a field with given fieldName, which is declared in givendeclaringClassis ignored when performing deep equality checks.
 
- registerIgnoredField(Class<?>, String) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Indicates that a field with given fieldName, which is declared in givendeclaringClassis ignored
 when performing deep equality checks.
 
- registerIgnoredField(Class<?>, String) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerInjectableResource(Object) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerInjectableResource(Object) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers a resource that is eligible for injection in handler method (e.g. 
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
- 
Deprecated. 
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-  
- registerLifecycleHandlers(Configuration, Object) - Static method in class org.axonframework.config.LifecycleHandlerInspector
- 
Register any lifecycle handlers found on given componentwith givenconfiguration.
 
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.config.MessageHandlerRegistrar
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.deadline.SimpleDeadlineManager
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-  
- registerLifecycleHandlers(Lifecycle.LifecycleRegistry) - Method in interface org.axonframework.lifecycle.Lifecycle
- 
Registers the activities to be executed in the various phases of an application's lifecycle. 
- registerListenerInvocationErrorHandler(String, Function<Configuration, ListenerInvocationErrorHandler>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerListenerInvocationErrorHandler(String, Function<Configuration, ListenerInvocationErrorHandler>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerListenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
- registerListenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerMessageHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
- 
Registers a message handler bean with this configuration. 
- registerMessageHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerMessageMonitor(String, Function<Configuration, MessageMonitor<Message<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerMessageMonitorFactory(String, MessageMonitorFactory) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerMessageMonitorFactory(String, MessageMonitorFactory) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerModule(ModuleConfiguration) - Method in interface org.axonframework.config.Configurer
- 
Registers an Axon module with this configuration. 
- registerModule(ModuleConfiguration) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerParameterResolverFactory(ParameterResolverFactory) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
- registerParameterResolverFactory(ParameterResolverFactory) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
- registerParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerPooledStreamingEventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerPooledStreamingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerPooledStreamingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerPooledStreamingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerPooledStreamingEventProcessorConfiguration(EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerPooledStreamingEventProcessorConfiguration(String, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerPooledStreamingEventProcessorConfiguration(String, EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerPooledStreamingEventProcessorConfiguration(EventProcessingConfigurer.PooledStreamingProcessorConfiguration) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerQueryBus(String) - Method in class org.axonframework.metrics.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a  QueryBus. 
- registerQueryBus(String) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a  QueryBus. 
- registerQueryBus(String, Function<Message<?>, Iterable<Tag>>) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
Registers new metrics to the registry to monitor a  QueryBus using  Tags through the given  tagsBuilder. 
- registerQueryHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
- 
Registers a query handler bean with this  Configurer. 
- registerQueryHandler(int, Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
- 
- registerQueryHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.DefaultConfigurer
-  
- registerRepository(Repository<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerRepository(Repository<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers an arbitrary repositorywith the fixture.
 
- registerRepositoryProvider(RepositoryProvider) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- registerRepositoryProvider(RepositoryProvider) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Registers repository provider with the fixture. 
- registerResource(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Registers the given resource.
 
- registerResource(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerResourceInjector(ResourceInjector) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
- registerResourceInjector(ResourceInjector) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerRollbackConfiguration(String, Function<Configuration, RollbackConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerRollbackConfiguration(String, Function<Configuration, RollbackConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerRoot(Callable<T>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
- 
Registers the aggregate root created by the given aggregateFactorywith this aggregate.
 
- registerSaga(Class<T>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
Registers a Saga with default configuration within this Configurer. 
- registerSaga(Class<T>, Consumer<SagaConfigurer<T>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
Registers a Saga, allowing specific configuration to use for this Saga type. 
- registerSaga(Class<T>, Consumer<SagaConfigurer<T>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerSagaStore(Function<Configuration, SagaStore>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerSagaStore(Function<Configuration, SagaStore>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerSequencingPolicy(String, Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
Registers the  SequencingPolicy created by the given  policyBuilder to the processing group with
 given  processingGroup. 
- registerSequencingPolicy(String, Function<Configuration, SequencingPolicy<? super EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerSpanAttributeProvider(SpanAttributesProvider) - Method in class org.axonframework.tracing.LoggingSpanFactory
-  
- registerSpanAttributeProvider(SpanAttributesProvider) - Method in class org.axonframework.tracing.MultiSpanFactory
-  
- registerSpanAttributeProvider(SpanAttributesProvider) - Method in class org.axonframework.tracing.NestingSpanFactory
-  
- registerSpanAttributeProvider(SpanAttributesProvider) - Method in class org.axonframework.tracing.NoOpSpanFactory
-  
- registerSpanAttributeProvider(SpanAttributesProvider) - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpanFactory
-  
- registerSpanAttributeProvider(SpanAttributesProvider) - Method in interface org.axonframework.tracing.SpanFactory
- 
- registerStartRecordingCallback(Runnable) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Registers a callback to be invoked when the fixture execution starts recording. 
- registerStartRecordingCallback(Runnable) - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
- 
Registers a callback to be invoked when the fixture execution starts recording. 
- registerStartRecordingCallback(Runnable) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- registerSubscribingEventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerSubscribingEventProcessor(String, Function<Configuration, SubscribableMessageSource<? extends EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerSubscribingEventProcessor(String, Function<Configuration, SubscribableMessageSource<? extends EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerTokenStore(String, Function<Configuration, TokenStore>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerTokenStore(Function<Configuration, TokenStore>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
Register a  Function that builds a  TokenStore to use as the default in case no explicit token
 store was configured for a processor. 
- registerTokenStore(String, Function<Configuration, TokenStore>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerTokenStore(Function<Configuration, TokenStore>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerTrackingEventProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerTrackingEventProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerTrackingEventProcessorConfiguration(String, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerTrackingEventProcessorConfiguration(Function<Configuration, TrackingEventProcessorConfiguration>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerTrackingEventProcessorConfiguration(String, Function<Configuration, TrackingEventProcessorConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerTrackingEventProcessorConfiguration(Function<Configuration, TrackingEventProcessorConfiguration>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerTransactionManager(String, Function<Configuration, TransactionManager>) - Method in interface org.axonframework.config.EventProcessingConfigurer
- 
- registerTransactionManager(String, Function<Configuration, TransactionManager>) - Method in class org.axonframework.config.EventProcessingModule
-  
- registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
- 
- registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, int) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
- 
Registers an Update Handler for given querywith givenupdateBufferSize.
 
- registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
- 
- registerUpdateHandler(SubscriptionQueryMessage<?, ?, ?>, int) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
-  
- registerWithConfigurer(Configurer) - Method in class org.axonframework.metrics.GlobalMetricRegistry
- 
- registerWithConfigurer(Configurer) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
- registerWithConfigurerWithDefaultTags(Configurer) - Method in class org.axonframework.micrometer.GlobalMetricRegistry
- 
- Registration - Interface in org.axonframework.common
- 
Interface that provides a mechanism to cancel a registration. 
- rejectAll() - Static method in interface org.axonframework.eventsourcing.snapshotting.SnapshotFilter
- 
- rejectDuplicates() - Static method in class org.axonframework.commandhandling.DuplicateCommandHandlerResolution
- 
- rejectDuplicates() - Static method in class org.axonframework.queryhandling.registration.DuplicateQueryHandlerResolution
- 
- release() - Method in interface org.axonframework.common.lock.Lock
- 
Releases this lock. 
- release() - Method in class org.axonframework.common.lock.NoOpLock
-  
- releaseClaim(String) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
- 
Release any claim of ownership currently active on this Token, if owned by the given owner.
 
- releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- releaseClaim(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Creates a new  PreparedStatement to release the current claim this node has on a token belonging to a
 processor with given  processorName and  segment. 
- releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- releaseClaim(String) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
- 
Release any claim of ownership currently active on this Token, if owned by the given owner.
 
- releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- releaseClaim(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Release a claim of the token for given processorNameandsegment.
 
- releaseSegment(int) - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService.AxonProcessorInstructionHandler
-  
- releaseSegment(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- releaseSegment(int, long, TimeUnit) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- releaseSegment(int) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Instructs the processor to release the segment with given segmentId.
 
- releaseSegment(int, long, TimeUnit) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Instructs the processor to release the segment with given segmentId.
 
- releaseSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Instructs the processor to release the segment with given segmentId.
 
- releaseSegment(int, long, TimeUnit) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- REMOTE_MEMBER - Static variable in class org.axonframework.commandhandling.distributed.SimpleMember
- 
Denotes that a  SimpleMember is a representation of a Remote Member. 
- RemoteExceptionDescription - Class in org.axonframework.messaging
- 
Description of an Exception received from a remote source. 
- RemoteExceptionDescription(List<String>) - Constructor for class org.axonframework.messaging.RemoteExceptionDescription
- 
Initialize a RemoteExceptionDescription with given descriptionsdescribing the exception chain on the
 remote end of communication
 
- RemoteExceptionDescription(List<String>, boolean) - Constructor for class org.axonframework.messaging.RemoteExceptionDescription
- 
Initialize a RemoteExceptionDescription with given descriptionsdescribing the exception
 chain on the remote end of communication.
 
- RemoteHandlingException - Exception in org.axonframework.messaging
- 
Exception indicating that an error has occurred while remotely handling a message. 
- RemoteHandlingException(RemoteExceptionDescription) - Constructor for exception org.axonframework.messaging.RemoteHandlingException
- 
Initializes the exception using the given exceptionDescriptiondescribing the remote cause-chain.
 
- RemoteHandlingException(RemoteExceptionDescription, boolean) - Constructor for exception org.axonframework.messaging.RemoteHandlingException
- 
Initializes the exception using the given exceptionDescriptionandwritableStackTrace.
 
- RemoteNonTransientHandlingException - Exception in org.axonframework.messaging
- 
Exception indicating that a non transient error has occurred while remotely handling a message. 
- RemoteNonTransientHandlingException(RemoteExceptionDescription) - Constructor for exception org.axonframework.messaging.RemoteNonTransientHandlingException
- 
Initializes the exception using the given exceptionDescriptiondescribing the remote cause-chain.
 
- remove(Object) - Method in interface org.axonframework.common.caching.Cache
- 
Removes the entry stored under given key.
 
- remove(Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- remove(Object) - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- remove(Object) - Method in class org.axonframework.common.caching.NoCache
-  
- remove(Object) - Method in class org.axonframework.common.caching.WeakReferenceCache
-  
- remove() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-  
- remove(Object) - Method in class org.axonframework.messaging.MetaData
- 
This operation is not supported. 
- remove(AssociationValue) - Method in interface org.axonframework.modelling.saga.AssociationValues
- 
Removes the given associationValue, if it is contained by this instance.
 
- remove(AssociationValue) - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-  
- remove(AssociationValue, String, String) - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
- 
Removes an association between the given associationValueandsagaIdentifier.
 
- removeAll() - Method in interface org.axonframework.common.caching.Cache
- 
Remove all stored entries in this cache. 
- removeAll() - Method in class org.axonframework.common.caching.EhCacheAdapter
-  
- removeAll() - Method in class org.axonframework.common.caching.JCacheAdapter
-  
- removeAll() - Method in class org.axonframework.common.caching.NoCache
-  
- removeAll() - Method in class org.axonframework.common.caching.WeakReferenceCache
-  
- removeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
- 
Removes the given associationValueof the saga with givensagaIdentifierandsagaType.
 
- removeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. Removes the given associationValueof the saga with givensagaIdentifierandsagaType.
 
- removeAssociationWith(String, String) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
- 
Removes the given association from the currently active Saga. 
- removeAssociationWith(String, Number) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
- 
Removes the given association from the currently active Saga. 
- removedAssociations() - Method in interface org.axonframework.modelling.saga.AssociationValues
- 
- removedAssociations() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-  
- RemovedTrackerStatus - Class in org.axonframework.eventhandling
- 
- RemovedTrackerStatus(EventTrackerStatus) - Constructor for class org.axonframework.eventhandling.RemovedTrackerStatus
- 
- ReplayAwareMessageHandlerWrapper - Class in org.axonframework.eventhandling.replay
- 
- ReplayAwareMessageHandlerWrapper() - Constructor for class org.axonframework.eventhandling.replay.ReplayAwareMessageHandlerWrapper
-  
- ReplayContext - Annotation Type in org.axonframework.eventhandling.replay
- 
Annotation indication that a parameter on a Message Handler method should be injected with the  resetContext
 present in a  ReplayToken. 
- replayContext(EventMessage<?>, Class<T>) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Extracts the context from a messageof the matchingcontextClass.
 
- replayContext(TrackingToken, Class<T>) - Static method in class org.axonframework.eventhandling.ReplayToken
- 
Extracts the context from a messageof the matchingcontextClass.
 
- ReplayContextParameterResolverFactory - Class in org.axonframework.eventhandling.replay
- 
- ReplayContextParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.replay.ReplayContextParameterResolverFactory
-  
- ReplayParameterResolverFactory - Class in org.axonframework.eventhandling.replay
- 
- ReplayParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.replay.ReplayParameterResolverFactory
-  
- ReplayStatus - Enum in org.axonframework.eventhandling
- 
Type that can be used as parameter of Event Handler methods that indicates whether a message is delivered as part of
 a replay, or in regular operations. 
- ReplayToken - Class in org.axonframework.eventhandling
- 
Token keeping track of the position before a reset was triggered. 
- ReplayToken(TrackingToken) - Constructor for class org.axonframework.eventhandling.ReplayToken
- 
- ReplayToken(TrackingToken, TrackingToken) - Constructor for class org.axonframework.eventhandling.ReplayToken
- 
- ReplyMessage - Class in org.axonframework.commandhandling.distributed
- 
Base class for reply messages which may be used in the  CommandBusConnector for replying on received
 commands from other nodes. 
- ReplyMessage() - Constructor for class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Default constructor required for de-/serialization of extending classes. 
- ReplyMessage(String, CommandResultMessage<?>, Serializer) - Constructor for class org.axonframework.commandhandling.distributed.ReplyMessage
- 
Initializes a ReplyMessage containing a reply to the command with given {commandIdentifier} and given
 commandResultMessage.
 
- reportDifferentMetaData(Class<?>, Map<String, Object>, Map<String, Object>) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to a difference in the metadata of a message 
- reportDifferentPayloads(Class<?>, Object, Object) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to a difference between the message payloads. 
- reportDifferentPayloads(Class<?>, Field, Object, Object) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to a difference in one of the fields of the message payload. 
- Reporter - Class in org.axonframework.test.aggregate
- 
The reporter generates extensive human readable reports of what the expected outcome of a test was, and what the
 actual results were. 
- Reporter() - Constructor for class org.axonframework.test.aggregate.Reporter
-  
- reportFailed(Matcher<? super T>) - Method in class org.axonframework.test.matchers.ListMatcher
- 
Report the given matcheras a failing matcher.
 
- reportFailure(Throwable) - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
- 
Notify the monitor that a failure occurred during processing of the message 
- reportFailure(Throwable) - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
-  
- reportIgnored(EventMessage<?>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
- 
Report the given eventMessageas ignored.
 
- reportIgnored() - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
- 
Notify the monitor that the message was ignored 
- reportIgnored() - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
-  
- reportIllegalState(LockAwareAggregate<T, EventSourcedAggregate<T>>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-  
- reportIllegalState(A) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Invoked when an the given aggregateinstance has been detected that has been part of a rolled back Unit
 of Work.
 
- reportIncorrectDeletedState(boolean) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to a difference in the expected state of the `isDeleted` marker on the Aggregate. 
- reportResult(CommandResultMessage<R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
- 
- reportSuccess() - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
- 
Notify the monitor that the message was handled successfully 
- reportSuccess() - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
-  
- reportUnexpectedException(Throwable, Description) - Method in class org.axonframework.test.aggregate.Reporter
- 
Reports an error due to an unexpected exception. 
- reportUnexpectedReturnValue(Object, Description) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to an unexpected return value, while an exception was expected. 
- reportWrongEvent(Collection<?>, Collection<?>, Throwable) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error in the ordering or count of events. 
- reportWrongEvent(Collection<?>, StringDescription, Throwable) - Method in class org.axonframework.test.aggregate.Reporter
- 
- reportWrongEvent(Collection<?>, Description, Description, Throwable) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error of events not matching expectations defined by Matchers.
 
- reportWrongException(Throwable, Description) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to an exception of an unexpected type. 
- reportWrongExceptionDetails(Object, Description) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to a difference in exception details. 
- reportWrongExceptionMessage(Throwable, Description) - Method in class org.axonframework.test.aggregate.Reporter
- 
Report an error due to a difference in exception message. 
- reportWrongResult(Object, Object) - Method in class org.axonframework.test.aggregate.Reporter
- 
Reports an error due to a wrong return value. 
- repository() - Method in interface org.axonframework.config.AggregateConfiguration
- 
Returns the repository defined to load instances of the Aggregate type defined in this configuration. 
- repository() - Method in class org.axonframework.config.AggregateConfigurer
-  
- repository(Class<A>) - Method in interface org.axonframework.config.Configuration
- 
Returns the  Repository configured for the given  aggregateType. 
- repository() - Method in interface org.axonframework.config.SagaConfiguration
- 
- repository(Repository<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
- 
Sets the  Repository used to add and load Aggregate instances of generic type  T upon handling
 commands for it. 
- Repository<T> - Interface in org.axonframework.modelling.command
- 
The  Repository provides an abstraction of the storage of aggregates. 
- repository(Class<T>) - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- repository(Class<T>, Configuration) - Static method in class org.axonframework.spring.config.BeanHelper
- 
Retrieves the  Repository for given  aggregateType from given  configuration. 
- RepositoryContentValidator<T> - Class in org.axonframework.test.saga
- 
Helper class for the validation of Saga Repository content. 
- RepositoryFactoryBean<T> - Class in org.axonframework.spring.config
- 
- RepositoryFactoryBean(AggregateConfiguration<T>) - Constructor for class org.axonframework.spring.config.RepositoryFactoryBean
- 
Deprecated. Initialize the Factory Bean using given aggregateConfigurationto locate the configured Repository
 instance.
 
- repositoryFor(Class<T>) - Method in interface org.axonframework.modelling.command.RepositoryProvider
- 
Provides a repository for given aggregate type. 
- repositoryProvider(RepositoryProvider) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
- 
Sets the  RepositoryProvider provided to the snapshot aggregates this snapshotter creates for correct
 instantiation. 
- repositoryProvider - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- repositoryProvider(RepositoryProvider) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
- 
- repositoryProvider(RepositoryProvider) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
- 
- repositoryProvider(RepositoryProvider) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. 
- RepositoryProvider - Interface in org.axonframework.modelling.command
- 
Provides a repository for given aggregate type. 
- repositoryProvider(RepositoryProvider) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
-  
- requestStreamFactory(Function<UpstreamAwareStreamObserver<QueryProviderInbound>, StreamObserver<QueryProviderOutbound>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
- requestTimeout(long, TimeUnit) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
- 
Sets the timeout in which a confirmation of the scheduling interaction is expected. 
- requeue(DeadLetter<? extends M>, UnaryOperator<DeadLetter<? extends M>>) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- requeue(DeadLetter<? extends M>, UnaryOperator<DeadLetter<? extends M>>) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- requeue(Throwable) - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- requeue(Throwable, Function<DeadLetter<? extends M>, MetaData>) - Static method in class org.axonframework.messaging.deadletter.Decisions
- 
- requeue(DeadLetter<? extends M>, UnaryOperator<DeadLetter<? extends M>>) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- requeue(DeadLetter<? extends M>, UnaryOperator<DeadLetter<? extends M>>) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Reenters the given letter, updating the contents with theletterUpdater.
 
- requiresExplicitSegmentInitialization() - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- requiresExplicitSegmentInitialization() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- requiresExplicitSegmentInitialization() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- requiresExplicitSegmentInitialization() - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- requiresExplicitSegmentInitialization() - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Indicates whether this TokenStore instance requires segments to be explicitly initialized, before any tokens
 can be claimed for that segment. 
- reschedule(ScheduleToken, Duration, Object) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
- 
Changes the trigger time for a scheduled event. 
- reschedule(ScheduleToken, Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
- 
Cancel a scheduled event and schedule another in its place. 
- reschedule(ScheduleToken, Instant, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
- 
Cancel a scheduled event and schedule another in its place. 
- rescheduleCommandsOnCorruptState(boolean) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
Set the indicator specifying whether commands that failed because they were executed against potentially
 corrupted aggregate state should be automatically rescheduled. 
- reservoirFactory(Supplier<Reservoir>) - Method in class org.axonframework.metrics.MessageTimerMonitor.Builder
- 
Sets factory method creating a  Reservoir to be used by the  Timer instances created by this
  MessageMonitor. 
- reset(CommandMessage<?>, MessageHandler<? super CommandMessage<?>>, int, int, BlacklistDetectingCallback<?, ?>, List<MessageHandlerInterceptor<? super CommandMessage<?>>>, List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Resets this entry, preparing it for use for another command. 
- reset(T) - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
- 
Resets the state of this Unit of Work, by setting its phase to NOT_STARTED, replacing the message of this
 Unit of Work with givenmessage, and clearing its collection of registered handlers.
 
- reset() - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
- 
This method is used to reset all the variables that are used to check if a threshold has been exceeded 
- reset(T) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
- 
Reset the processing context. 
- resetAsCallable(Callable<Object>, int, int, BlacklistDetectingCallback<Object, Object>) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Resets this entry, preparing it to run given callablefrom within theinvocationInterceptorChain.
 
- resetAsRecoverEntry(String) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Resets this entry, preparing it for use as a recovery entry. 
- ResetContext<T> - Interface in org.axonframework.eventhandling.replay
- 
Represents a Message initiating the reset of an Event Handling Component. 
- ResetHandler - Annotation Type in org.axonframework.eventhandling
- 
Annotation that can be placed on a method that is to be invoked when a reset is being prepared. 
- ResetNotSupportedException - Exception in org.axonframework.eventhandling
- 
Exception indicating that a reset is not supported by a component. 
- ResetNotSupportedException(String) - Constructor for exception org.axonframework.eventhandling.ResetNotSupportedException
- 
Initialize the exception with given message
 
- ResetNotSupportedException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.ResetNotSupportedException
- 
Initialize the exception with given messageandcause.
 
- resetTokens() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- resetTokens(R) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>, R) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- resetTokens(TrackingToken) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- resetTokens(TrackingToken, R) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- resetTokens() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Resets tokens to their initial state. 
- resetTokens(R) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Resets tokens to their initial state. 
- resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Reset tokens to the position as return by the given initialTrackingTokenSupplier.
 
- resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>, R) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Reset tokens to the position as return by the given initialTrackingTokenSupplier.
 
- resetTokens(TrackingToken) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Resets tokens to the given startPosition.
 
- resetTokens(TrackingToken, R) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Resets tokens to the given startPosition.
 
- resetTokens() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- resetTokens(R) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- resetTokens(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>, R) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- resetTokens(TrackingToken) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- resetTokens(TrackingToken, R) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- resolve(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.DuplicateCommandHandlerResolver
- 
Chooses what to do when a duplicate handler is registered, returning the handler that should be selected for
 command handling, or otherwise throwing an exception to reject registration altogether. 
- resolve(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.FailingDuplicateCommandHandlerResolver
-  
- resolve(String, MessageHandler<? super CommandMessage<?>>, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.LoggingDuplicateCommandHandlerResolver
-  
- resolve(String, EventMessage<?>, MessageHandlingMember<T>) - Method in interface org.axonframework.modelling.saga.AssociationResolver
- 
Resolves the associationPropertyName as a value. 
- resolve(String, EventMessage<?>, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.MetaDataAssociationResolver
- 
Finds the association property value by looking up the association property name in the event message's  MetaData. 
- resolve(String, EventMessage<?>, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.PayloadAssociationResolver
- 
Finds the association property value in the message's payload. 
- resolve(String, Type, List<QuerySubscription<?>>, QuerySubscription<?>) - Method in interface org.axonframework.queryhandling.registration.DuplicateQueryHandlerResolver
- 
Chooses what to do when a duplicate handler is registered, returning the handlers that should be selected for
 query handling, or otherwise throwing an exception to reject registration altogether. 
- resolve(String, Type, List<QuerySubscription<?>>, QuerySubscription<?>) - Method in class org.axonframework.queryhandling.registration.FailingDuplicateQueryHandlerResolver
-  
- resolve(String, Type, List<QuerySubscription<?>>, QuerySubscription<?>) - Method in class org.axonframework.queryhandling.registration.LoggingDuplicateQueryHandlerResolver
-  
- resolveAssociation(EventMessage<?>) - Method in interface org.axonframework.modelling.saga.metamodel.SagaModel
- 
Returns the  AssociationValue used to find sagas of type  T that can handle the given  eventMessage. 
- resolveClassName(SerializedType) - Method in class org.axonframework.serialization.json.JacksonSerializer
- 
Resolve the class name from the given serializedType.
 
- resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
- 
Resolve the target of an incoming  CommandMessage to the right Child Entity. 
- resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-  
- resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
-  
- resolveCommandTarget(CommandMessage<?>, T, Member, EntityModel<Object>) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
-  
- resolveContext(T) - Method in interface org.axonframework.axonserver.connector.TargetContextResolver
- 
Provides the context to which a message should be routed. 
- resolveDetails(Throwable) - Static method in exception org.axonframework.messaging.HandlerExecutionException
- 
Resolve details from the given throwable, taking into account that the details may be available in any of
 theHandlerExecutionExceptions is the "cause" chain.
 
- resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
- 
Resolve the targets of an incoming  EventMessage to the right Child Entities. 
- resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-  
- resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
-  
- resolveEventTargets(EventMessage, T, Member, ForwardingMode) - Method in class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
-  
- resolveGenericType(Field, int) - Static method in class org.axonframework.common.ReflectionUtils
- 
Resolve a generic type parameter from a field declaration 
- resolveMemberGenericType(Member, int) - Static method in class org.axonframework.common.ReflectionUtils
- 
Resolve a generic type parameter from a member declaration. 
- resolveParameterValue(Message) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-  
- resolveParameterValue(Message<?>) - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-  
- resolveParameterValue(Message) - Method in class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
-  
- resolveParameterValue(Message<?>) - Method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
-  
- resolveParameterValue(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
-  
- resolveParameterValue(Message<?>) - Method in class org.axonframework.messaging.annotation.InterceptorChainParameterResolverFactory
-  
- resolveParameterValue(Message<?>) - Method in interface org.axonframework.messaging.annotation.ParameterResolver
- 
Resolves the parameter value to use for the given message, ornullif no suitable
 parameter value can be resolved.
 
- resolveParameterValue(Message) - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
-  
- resolvePrimitiveWrapperType(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the boxed wrapper type for the given primitiveType.
 
- resolvePrimitiveWrapperTypeIfPrimitive(Type) - Static method in class org.axonframework.common.ReflectionUtils
- 
Returns the boxed wrapper type for the given typeif it is primitive.
 
- resolveReturnValue(CommandMessage<?>, Aggregate<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
- 
Resolves the value to return when the given commandhas created the givenaggregate.
 
- resolveTarget(CommandMessage<?>) - Method in class org.axonframework.modelling.command.AnnotationCommandTargetResolver
- 
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given commandshould be executed.
 
- resolveTarget(CommandMessage<?>) - Method in interface org.axonframework.modelling.command.CommandTargetResolver
- 
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given commandshould be executed.
 
- resolveTarget(CommandMessage<?>) - Method in class org.axonframework.modelling.command.MetaDataCommandTargetResolver
-  
- resourceInjector() - Method in interface org.axonframework.config.Configuration
- 
Returns the ResourceInjector used to provide resources to Saga instances. 
- resourceInjector(ResourceInjector) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
- 
Sets the  ResourceInjector used to initialize  Saga instances after a target instance is
 created or loaded from the store. 
- ResourceInjector - Interface in org.axonframework.modelling.saga
- 
Interface describing a mechanism to inject resources into Saga instances. 
- resourceInjector() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- resourceInjector() - Method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- resources() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- resources() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Returns a mutable map of resources registered with the Unit of Work. 
- responseMessagePayloadType() - Method in class org.axonframework.messaging.responsetypes.InstanceResponseType
-  
- responseMessagePayloadType() - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
-  
- responseMessagePayloadType() - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
-  
- responseMessagePayloadType() - Method in class org.axonframework.messaging.responsetypes.PublisherResponseType
-  
- responseMessagePayloadType() - Method in interface org.axonframework.messaging.responsetypes.ResponseType
- 
Returns a  Class representing the type of the payload to be contained in the response message. 
- ResponseType<R> - Interface in org.axonframework.messaging.responsetypes
- 
Specifies the expected response type required when performing a query through the  QueryBus/ QueryGateway. 
- ResponseTypes - Class in org.axonframework.messaging.responsetypes
- 
Utility class containing static methods to obtain instances of  ResponseType. 
- ResubscribableStreamObserver<V> - Class in org.axonframework.axonserver.connector.util
- 
- ResubscribableStreamObserver(StreamObserver<V>, Consumer<Throwable>) - Constructor for class org.axonframework.axonserver.connector.util.ResubscribableStreamObserver
- 
Deprecated. Creates the Re-subscribable Stream Observer. 
- RESULT_TYPE - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the result type the handler can handle. 
- ResultHandler - Annotation Type in org.axonframework.messaging.interceptors
- 
Meta-Annotation used to demarcate  MessageHandlerInterceptor annotated methods as interceptors that should
 only act on the result of a handler invocation. 
- ResultMessage<R> - Interface in org.axonframework.messaging
- 
Message that represents a result of handling some form of request message. 
- ResultParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
ParameterResolverFactory that provides support for Parameters where the result of Handler execution is expected to
 be injected. 
- ResultParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.ResultParameterResolverFactory
-  
- ResultValidator<T> - Interface in org.axonframework.test.aggregate
- 
Interface describing the operations available on the "validate result" (a.k.a. 
- ResultValidatorImpl<T> - Class in org.axonframework.test.aggregate
- 
Implementation of the ResultValidator. 
- ResultValidatorImpl(List<EventMessage<?>>, FieldFilter, Supplier<Aggregate<T>>, StubDeadlineManager) - Constructor for class org.axonframework.test.aggregate.ResultValidatorImpl
- 
Initialize the ResultValidatorImpl with the given storedEventsandpublishedEvents.
 
- resume() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
- 
- retrieveStorageIdentifier() - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- retrieveStorageIdentifier() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- retrieveStorageIdentifier() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- retrieveStorageIdentifier() - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- retrieveStorageIdentifier() - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Returns a unique identifier that uniquely identifies the storage location of the tokens in this store. 
- retryExecutor(ScheduledExecutorService) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
- 
- RetryingCallback<C,R> - Class in org.axonframework.commandhandling.gateway
- 
Callback implementation that will invoke a retry scheduler if a command results in a runtime exception. 
- RetryingCallback(CommandCallback<C, R>, RetryScheduler, CommandBus) - Constructor for class org.axonframework.commandhandling.gateway.RetryingCallback
- 
Initialize the RetryingCallback with the given delegate, representing the actual callback passed as
 a parameter to dispatch, the givencommandMessage,retrySchedulerandcommandBus.
 
- retryInterval(int) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler.Builder
- 
Sets the retry interval in milliseconds at which to schedule a retry. 
- retryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
- 
Sets the  RetryScheduler capable of performing retries of failed commands. 
- retryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
- 
Sets the  RetryScheduler which will decide whether to reschedule commands. 
- retryScheduler(RetryScheduler) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
-  
- RetryScheduler - Interface in org.axonframework.commandhandling.gateway
- 
Interface towards a mechanism that decides whether to schedule a command for execution when a previous attempts
 resulted in an exception. 
- revision(String) - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
- 
- revision - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. 
- revision - Variable in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
-  
- Revision - Annotation Type in org.axonframework.serialization
- 
Annotation that attaches revision information to a Serializable object. 
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.AnnotationRevisionResolver
-  
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.FixedValueRevisionResolver
-  
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.MavenArtifactRevisionResolver
-  
- revisionOf(Class<?>) - Method in interface org.axonframework.serialization.RevisionResolver
- 
Returns the revision for the given payloadType.
 
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.SerialVersionUIDRevisionResolver
-  
- revisionResolver(RevisionResolver) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
- 
Sets the  RevisionResolver used to resolve the revision from an object to be serialized. 
- revisionResolver(RevisionResolver) - Method in class org.axonframework.serialization.JavaSerializer.Builder
- 
Deprecated. Sets the  RevisionResolver used to resolve the revision from an object to be serialized. 
- revisionResolver(RevisionResolver) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
- 
Sets the  RevisionResolver used to resolve the revision from an object to be serialized. 
- RevisionResolver - Interface in org.axonframework.serialization
- 
Interface towards a mechanism that resolves the revision of a given payload type. 
- revisionResolver(RevisionResolver) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
-  
- revisionResolver() - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- RevisionSnapshotFilter - Class in org.axonframework.eventsourcing.snapshotting
- 
- RevisionSnapshotFilter(RevisionSnapshotFilter.Builder) - Constructor for class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter
- 
- RevisionSnapshotFilter(String) - Constructor for class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter
- 
- RevisionSnapshotFilter.Builder - Class in org.axonframework.eventsourcing.snapshotting
- 
- rollback() - Method in interface org.axonframework.common.transaction.Transaction
- 
Roll back this transaction. 
- rollback(Throwable) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- rollback() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
- rollback(Throwable) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
- rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
-  
- rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
- 
- rollbackConfiguration(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- rollbackConfiguration(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
- rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
- 
- rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
-  
- rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
- 
- rollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
- 
- RollbackConfiguration - Interface in org.axonframework.messaging.unitofwork
- 
The RollbackConfiguration defines if a Unit of Work should be rolled back when an exception is raised during the
 processing of a Message. 
- rollbackConfigurations - Variable in class org.axonframework.config.EventProcessingModule
-  
- RollbackConfigurationType - Enum in org.axonframework.messaging.unitofwork
- 
Enum containing common rollback configurations for the Unit of Work. 
- rollBackOn(Throwable) - Method in interface org.axonframework.messaging.unitofwork.RollbackConfiguration
- 
Decides whether the given throwableshould trigger a rollback.
 
- rollbackTransaction(TransactionStatus) - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
- 
Rolls back the transaction with given statusif the transaction is new and not completed.
 
- root() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Returns the root of this Unit of Work. 
- root() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
- 
Returns the (annotated) Saga instance. 
- ROOT_SEGMENT - Static variable in class org.axonframework.eventhandling.Segment
- 
Represents the Segment that matches against all input, but can be split to start processing elements in parallel. 
- rootType() - Method in interface org.axonframework.modelling.command.Aggregate
- 
Get the class type of the wrapped aggregate root that the Aggregate defers to for command handling. 
- rootType() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- rootType() - Method in class org.axonframework.modelling.command.LockAwareAggregate
-  
- routingKey() - Method in interface org.axonframework.commandhandling.CommandMessageHandlingMember
- 
Returns the property of the command that is to be used as routing key towards this command handler instance. 
- RoutingKey - Annotation Type in org.axonframework.commandhandling
- 
Field or method level annotation that marks a field or method providing the routing key that a command
 targets. 
- routingKey() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-  
- routingKey() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
- 
Get the name of the routing key property on commands and events that provides the identifier that should be used
 to target entities of this kind. 
- routingServers() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- routingStrategy(RoutingStrategy) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
Sets the  RoutingStrategy used to correctly configure connections between Axon clients and Axon
 Server. 
- RoutingStrategy - Interface in org.axonframework.commandhandling.distributed
- 
Interface describing a mechanism that generates a routing key for a given command. 
- routingStrategy() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- run() - Method in class org.axonframework.axonserver.connector.PriorityRunnable
-  
- run() - Method in class org.axonframework.common.MemberAccessibilityCallback
-  
- run() - Method in interface org.axonframework.config.LifecycleHandler
- 
- run() - Method in class org.axonframework.eventhandling.async.EventProcessorTask
-  
- run() - Method in interface org.axonframework.lifecycle.Lifecycle.LifecycleHandler
- 
Execute the lifecycle activity. 
- run(Runnable) - Method in interface org.axonframework.tracing.Span
- 
Runs a piece of code which will be traced. 
- runCallable(Callable<T>) - Method in interface org.axonframework.tracing.Span
- 
Runs a piece of code which will be traced. 
- runConsumer(Consumer<T>, T) - Method in interface org.axonframework.tracing.Span
- 
Runs a piece of code that returns a value and which will be traced. 
- runOnPrepareCommitOrNow(Runnable) - Method in class org.axonframework.deadline.AbstractDeadlineManager
- 
Run a given  deadlineCall immediately, or schedule it for the  UnitOfWork it's 'prepare commit'
 phase if a UnitOfWork is active. 
- runSupplier(Supplier<T>) - Method in interface org.axonframework.tracing.Span
- 
Runs a piece of code that returns a value and which will be traced. 
- saga() - Method in interface org.axonframework.modelling.saga.repository.SagaStore.Entry
- 
Returns the Saga instance in unserialized form. 
- Saga<T> - Interface in org.axonframework.modelling.saga
- 
Interface describing an implementation of a Saga. 
- Saga - Annotation Type in org.axonframework.spring.stereotype
- 
Annotation that informs Axon's auto configurer for Spring that a given Componentis a saga instance.
 
- SAGA_ASSOCIATION_PROPERTY - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the property in the handled  EventMessage to
 associate a saga instance with. 
- SAGA_ASSOCIATION_PROPERTY_KEY_NAME - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the saga event handler's association property key name used. 
- SAGA_ASSOCIATION_RESOLVER - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the type of association resolver used by a saga event handler. 
- sagaCache(Cache) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
- 
Sets the  sagaCache of type  Cache used to store Sagas with. 
- sagaConfiguration(Class<T>) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- SagaConfiguration<S> - Interface in org.axonframework.config
- 
Represents a set of components needed to configure a Saga. 
- sagaConfigurations() - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- sagaConfigurations() - Method in class org.axonframework.config.EventProcessingModule
-  
- SagaConfigurer<T> - Class in org.axonframework.config
- 
Provides mechanisms to configure the components used to manage and store Saga. 
- SagaConfigurer(Class<T>) - Constructor for class org.axonframework.config.SagaConfigurer
- 
Initializes a configurer for the given Saga Type. 
- SagaCreationException - Exception in org.axonframework.modelling.saga.repository
- 
Exception triggered when a new saga instance could not be instantiated. 
- SagaCreationException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.repository.SagaCreationException
- 
Initializes the exception using the given messageandcause.
 
- SagaCreationPolicy - Enum in org.axonframework.modelling.saga
- 
Enumeration containing the possible Creation Policies for Sagas. 
- SagaEntry<T> - Class in org.axonframework.modelling.saga.repository.jpa
- 
Java Persistence Entity allowing sagas to be stored in a relational database. 
- SagaEntry(T, String, Serializer) - Constructor for class org.axonframework.modelling.saga.repository.jpa.SagaEntry
- 
Constructs a new SagaEntry for the given saga.
 
- SagaEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.SagaEntry
- 
Constructor required by JPA. 
- sagaEntryEntityName() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
- 
Intended for clients to override. 
- sagaEntryEntityName() - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. Intended for clients to override. 
- sagaEntryTable() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
- 
Returns the name of the sagaEntry table 
- SagaEventHandler - Annotation Type in org.axonframework.modelling.saga
- 
Method-level annotation indicating that the annotated method is an event handler method for the saga instance. 
- sagaEventProcessor(Class<?>) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- SagaExecutionException - Exception in org.axonframework.modelling.saga
- 
Exception triggered by a saga while it is processing an event or processing a task. 
- SagaExecutionException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaExecutionException
- 
Initializes the exception using the given messageandcause.
 
- sagaFactory(Supplier<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
- 
Sets the  sagaFactory of type  Supplier responsible for creating new Saga instances. 
- sagaFactory(Supplier<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-  
- sagaId - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. 
- sagaId - Variable in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
-  
- SagaInitializationPolicy - Class in org.axonframework.modelling.saga
- 
Describes the conditions under which a Saga should be created, and which AssociationValue it should be initialized
 with. 
- SagaInitializationPolicy(SagaCreationPolicy, AssociationValue) - Constructor for class org.axonframework.modelling.saga.SagaInitializationPolicy
- 
Creates an instance using the given creationPolicyandinitialAssociationValue.
 
- SagaInstantiationException - Exception in org.axonframework.modelling.saga
- 
Exception triggered during initialization of a Saga. 
- SagaInstantiationException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaInstantiationException
- 
Initializes the exception using the given messageandcause.
 
- SagaLifecycle - Class in org.axonframework.modelling.saga
- 
Abstract base class of a component that models a saga's life cycle. 
- SagaLifecycle() - Constructor for class org.axonframework.modelling.saga.SagaLifecycle
-  
- SagaMetaModelFactory - Interface in org.axonframework.modelling.saga.metamodel
- 
Interface of a factory for a  SagaModel for any given saga type. 
- SagaMethodMessageHandlerDefinition - Class in org.axonframework.modelling.saga
- 
Utility class that inspects annotation on a Saga instance and returns the relevant configuration for its Event
 Handlers. 
- SagaMethodMessageHandlerDefinition() - Constructor for class org.axonframework.modelling.saga.SagaMethodMessageHandlerDefinition
- 
- SagaMethodMessageHandlingMember<T> - Class in org.axonframework.modelling.saga
- 
- SagaMethodMessageHandlingMember(MessageHandlingMember<T>, SagaCreationPolicy, String, String, AssociationResolver) - Constructor for class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
- 
Creates a SagaMethodMessageHandler. 
- sagaModel(SagaModel<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
- 
- SagaModel<T> - Interface in org.axonframework.modelling.saga.metamodel
- 
Interface of a model that describes a Saga of type T.
 
- sagaModel(SagaModel<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
- 
Sets the  SagaModel of generic type  T, describing the structure of the Saga this
  SagaRepository implementation will store. 
- sagaProcessingGroup(Class<?>) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
Gets the processing group for given sagaType.
 
- sagaProcessingGroup(Class<?>) - Method in class org.axonframework.config.EventProcessingModule
-  
- sagaRepository(SagaRepository<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
- 
Sets the  SagaRepository of generic type  T used to save and load Saga instances. 
- sagaRepository(SagaRepository<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-  
- SagaRepository<T> - Interface in org.axonframework.modelling.saga
- 
Interface towards the storage mechanism of Saga instances. 
- sagaSchema() - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
- 
Returns the  SagaSchema used to configure this sql saga schema. 
- SagaSchema - Class in org.axonframework.modelling.saga.repository.jdbc
- 
SagaSchema allows specification of custom storage locations for the saga repositories. 
- SagaSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
- 
Initialize SagaSchema with default values. 
- SagaSchema(String, String) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
- 
Initialize SagaSchema with custom locations for event entry tables. 
- SagaScopeDescriptor - Class in org.axonframework.eventhandling.saga
- 
- SagaScopeDescriptor(String, Object) - Constructor for class org.axonframework.eventhandling.saga.SagaScopeDescriptor
- 
Deprecated. Instantiate a SagaScopeDescriptor with the provided typeandidentifier.
 
- SagaScopeDescriptor - Class in org.axonframework.modelling.saga
- 
Describes the scope of a Saga by means of its type and identifier. 
- SagaScopeDescriptor(String, Object) - Constructor for class org.axonframework.modelling.saga.SagaScopeDescriptor
- 
Instantiate a SagaScopeDescriptor with the provided typeandidentifier.
 
- SagaSqlSchema - Interface in org.axonframework.modelling.saga.repository.jdbc
- 
Interface describing the SQL statements that the JdbcSagaRepository needs to execute against the underlying
 database. 
- SagaStorageException - Exception in org.axonframework.modelling.saga
- 
Exception indicating that an error has occurred while storing a Saga. 
- SagaStorageException(String) - Constructor for exception org.axonframework.modelling.saga.SagaStorageException
- 
Initialize a SagaStorageException with the given descriptive message.
 
- SagaStorageException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaStorageException
- 
Initialize a SagaStorageException with the given descriptive messageandcause.
 
- sagaStore() - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
Returns a  SagaStore registered within this configuration. 
- sagaStore() - Method in class org.axonframework.config.EventProcessingModule
-  
- sagaStore(SagaStore<? super T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
- 
Sets the  SagaStore used to save and load saga instances. 
- SagaStore<T> - Interface in org.axonframework.modelling.saga.repository
- 
Provides a mechanism to find, load update and delete sagas of type Tfrom an underlying storage like a
 database.
 
- sagaStore(Serializer, EntityManagerProvider) - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
-  
- sagaStore(Serializer, EntityManagerProvider) - Method in class org.axonframework.springboot.autoconfig.legacyjpa.JpaJavaxAutoConfiguration
- 
Deprecated. 
- SagaStore.Entry<T> - Interface in org.axonframework.modelling.saga.repository
- 
Interface describing a Saga entry fetched from a SagaStore. 
- sagaStoreNoSchema(ConnectionProvider, Serializer) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
-  
- sagaStoreWithSchema(ConnectionProvider, Serializer, SagaSqlSchema) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
-  
- SagaTestFixture<T> - Class in org.axonframework.test.saga
- 
Fixture for testing Annotated Sagas based on events and time passing. 
- SagaTestFixture(Class<T>) - Constructor for class org.axonframework.test.saga.SagaTestFixture
- 
Creates an instance of the AnnotatedSagaTestFixture to test sagas of the given sagaType.
 
- sagaType - Variable in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
-  
- sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
- 
Sets the  sagaType as a  Class managed by this instance. 
- sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-  
- sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
- 
- sagaType - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. 
- sagaType - Variable in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
-  
- sameInstanceSupplier(Supplier<T>) - Static method in class org.axonframework.common.ObjectUtils
- 
Wraps the given supplierto ensure that the same instance is returned on multiple consecutive
 invocations.
 
- scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-  
- scatterGather(String, Q, ResponseType<R>, long, TimeUnit) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
-  
- scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryBus
- 
Dispatch the given queryto all QueryHandlers subscribed to the givenquery's
 queryName/responseType.
 
- scatterGather(Q, ResponseType<R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus, expecting a response in the
 form of  responseType from several sources. 
- scatterGather(String, Q, ResponseType<R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus, expecting a response in the
 form of  responseType from several sources. 
- scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in class org.axonframework.queryhandling.SimpleQueryBus
-  
- schedule(Instant, Object) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
- 
Schedules an event to be published at a given moment. 
- schedule(Duration, Object) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
- 
Schedules an event to be published after a specified amount of time. 
- schedule(Instant, String) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Schedules a deadline at given triggerDateTimewith givendeadlineName.
 
- schedule(Instant, String, Object) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Schedules a deadline at given triggerDateTimewith givendeadlineName.
 
- schedule(Instant, String, Object, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Schedules a deadline at given triggerDateTimewith provided context.
 
- schedule(Duration, String) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Schedules a deadline after the given triggerDurationwith givendeadlineName.
 
- schedule(Duration, String, Object) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Schedules a deadline after the given triggerDuration.
 
- schedule(Duration, String, Object, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
- 
Schedules a deadline after the given triggerDurationwith provided context.
 
- schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager
-  
- schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-  
- schedule(Duration, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-  
- schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.SimpleDeadlineManager
-  
- schedule(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
- 
Schedules this task for execution when all pre-conditions have been met. 
- schedule(Instant, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
- 
Schedule the given eventfor publication at the giventriggerDateTime.
 
- schedule(Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
- 
Schedule the given eventfor publication after the giventriggerDuration.
 
- schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-  
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-  
- schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
-  
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
-  
- schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-  
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-  
- schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-  
- schedule(Duration, String, Object, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-  
- schedule(Instant, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-  
- schedule(Duration, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-  
- ScheduledDeadlineInfo - Class in org.axonframework.test.deadline
- 
Holds the data regarding deadline schedule. 
- ScheduledDeadlineInfo(Instant, String, String, int, DeadlineMessage<?>, ScopeDescriptor) - Constructor for class org.axonframework.test.deadline.ScheduledDeadlineInfo
- 
Instantiates a ScheduledDeadlineInfo. 
- scheduledExecutorService(ScheduledExecutorService) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
- 
- scheduledExecutorService(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
- 
- ScheduledItem - Interface in org.axonframework.test.eventscheduler
- 
Interface describing an event to be scheduled at a given date and time. 
- scheduleEvents(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.EventProcessorTask
- 
Schedules a batch of events for processing. 
- Scheduler - Interface in org.axonframework.axonserver.connector.util
- 
Schedules tasks to be executed in future. 
- scheduler(Scheduler) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
- 
Sets the Schedulerused for scheduling and triggering purposes of the deadlines.
 
- scheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
- 
Sets the Schedulerused for scheduling and triggering purposes of the deadlines.
 
- Scheduler.ScheduledTask - Interface in org.axonframework.axonserver.connector.util
-  
- scheduleRetry(Runnable, long) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
- 
Schedule the provided task to run after the given interval. 
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
- 
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in interface org.axonframework.commandhandling.gateway.RetryScheduler
- 
Inspect the given commandMessagethat failed with givenlastFailure.
 
- scheduleSnapshot(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-  
- scheduleSnapshot(Class<?>, String) - Method in interface org.axonframework.eventsourcing.Snapshotter
- 
Schedules snapshot taking for an aggregate with given aggregateIdentifier.
 
- ScheduleToken - Interface in org.axonframework.eventhandling.scheduling
- 
Token that identifies a single scheduled Event. 
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.axonframework.axonserver.connector.util.Scheduler
- 
Schedules a commandto be executed periodically afterinitialDelay.
 
- SchedulingException - Exception in org.axonframework.eventhandling.scheduling
- 
Exception indicating a problem in the Event Scheduling mechanism. 
- SchedulingException(String) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
- 
Initialize a SchedulingException with the given message.
 
- SchedulingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
- 
Initialize a SchedulingException with the given messageandcause.
 
- schema(TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
- 
Sets the  schema which describes a JDBC token entry for this  TokenStore. 
- schema(EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
Sets the  EventSchema describing the database schema of event entries. 
- schema() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
Returns the  EventSchema that defines the table and column names of event tables in the database. 
- Scope - Class in org.axonframework.messaging
- 
Describes functionality off processes which can be 'in scope', like an Aggregate or Saga. 
- Scope() - Constructor for class org.axonframework.messaging.Scope
-  
- SCOPE_AWARE_RESOLVER - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
- 
- ScopeAware - Interface in org.axonframework.messaging
- 
Interface describing components which are  Scope aware. 
- scopeAwareProvider() - Method in interface org.axonframework.config.Configuration
- 
- scopeAwareProvider(ScopeAwareProvider) - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager.Builder
- 
- scopeAwareProvider(ScopeAwareProvider) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
- 
- scopeAwareProvider(ScopeAwareProvider) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
- 
- ScopeAwareProvider - Interface in org.axonframework.messaging
- 
Contract towards a mechanism to provide a  Stream of components which are  ScopeAware. 
- scopeDescription() - Method in class org.axonframework.messaging.NoScopeDescriptor
-  
- scopeDescription() - Method in interface org.axonframework.messaging.ScopeDescriptor
- 
- scopeDescription() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
-  
- scopeDescription() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
-  
- ScopeDescriptor - Interface in org.axonframework.messaging
- 
Denotes the description of a  Scope. 
- ScopeDescriptorParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
- ScopeDescriptorParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.ScopeDescriptorParameterResolverFactory
-  
- Segment - Class in org.axonframework.eventhandling
- 
A representation of a segment and corresponding mask with various capabilities. 
- Segment(int, int) - Constructor for class org.axonframework.eventhandling.Segment
- 
Construct a new Segment instance with given segmentIdandmask
 
- segmentColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
- 
Returns the name of the column containing the segment of the processor to which the token belongs. 
- segmentCount() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
- 
Returns this member's segment count which relates to the relative load factor of the member. 
- select(Connection, String, int, boolean) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Returns a  PreparedStatement to select a token entry from the underlying storage, either for updating
 or just for reading. 
- selectForSegments(Connection, String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Returns a  PreparedStatement to select all segments ids for a given processorName from the underlying
 storage. 
- selectForUpdate(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
- selectImports(AnnotationMetadata) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer.ImportSelector
- 
Deprecated. 
- selectSegments(Connection, String, int, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Returns a  PreparedStatement for the count of segments that can be found after searching for the  splitSegmentId and  mergableSegmetnId. 
- selectTokenEntries(Connection, String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
- send(Member, CommandMessage<? extends C>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
- 
Sends the given commandto the node assigned to handle messages with the givenroutingKey.
 
- send(Member, CommandMessage<C>, CommandCallback<? super C, R>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
- 
Sends the given commandto the node assigned to handle messages with the givenroutingKey.
 
- send(C, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
- 
Sends the given command, and invokes thecallbackwhen the command is processed.
 
- send(C, CommandCallback<? super C, ? super R>) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
- 
Sends the given command, and have the result of the command's execution reported to the givencallback.
 
- send(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
- 
Sends the given  command and returns a  CompletableFuture immediately, without waiting for the
 command to execute. 
- send(Object, MetaData) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
- 
Sends the given  command with the given  metaData and returns a  CompletableFuture
 immediately, without waiting for the command to execute. 
- send(C, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-  
- send(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-  
- send(Message<?>, ScopeDescriptor) - Method in interface org.axonframework.messaging.ScopeAware
- 
Send a  Message to a  Scope which is described by the given  scopeDescription. 
- send(Message<?>, ScopeDescriptor) - Method in class org.axonframework.modelling.command.AbstractRepository
-  
- send(Message<?>, ScopeDescriptor) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-  
- sendAck(String, boolean, ErrorMessage, StreamObserver<T>) - Method in class org.axonframework.axonserver.connector.DefaultInstructionAckSource
-  
- sendAck(String, boolean, ErrorMessage, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
- 
Sends an acknowledgement. 
- sendAndForget(Object) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
- 
Dispatches a command without callback. 
- sendAndWait(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
- 
Sends the given commandand wait for it to execute.
 
- sendAndWait(Object, MetaData) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
- 
Sends the given commandwith the givenmetaDataand wait for it to execute.
 
- sendAndWait(Object, long, TimeUnit) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
- 
Sends the given commandand wait for it to execute.
 
- sendAndWait(Object, MetaData, long, TimeUnit) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
- 
Sends the given commandwith the givenmetaDataand wait for it to execute.
 
- sendAndWait(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
- 
Sends the given commandand waits for its execution to complete, or until the waiting thread is
 interrupted.
 
- sendAndWait(Object, long, TimeUnit) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
- 
Sends the given commandand waits for its execution to complete, or until the giventimeouthas expired, or the waiting thread is interrupted.
 
- sendInitialPermits() - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
- 
Deprecated. 
- sendSuccessfulAck(String, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
- 
Sends successful acknowledgement. 
- sendUnsuccessfulAck(String, ErrorMessage, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
- 
Sends unsuccessful acknowledgement. 
- sendUnsupportedInstruction(String, String, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
- 
Sends acknowledgement of unsupported instruction. 
- sequence() - Method in class org.axonframework.axonserver.connector.PriorityCallable
-  
- sequence() - Method in class org.axonframework.axonserver.connector.PriorityRunnable
-  
- sequence() - Method in interface org.axonframework.axonserver.connector.PriorityTask
- 
Returns the sequence of this task. 
- sequencedDeadLetterProcessor(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- sequencedDeadLetterProcessor(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- SequencedDeadLetterProcessor<M extends Message<?>> - Interface in org.axonframework.messaging.deadletter
- 
Contract describing a component that can process  dead letters that it has enqueued. 
- SequencedDeadLetterQueue<M extends Message<?>> - Interface in org.axonframework.messaging.deadletter
- 
Interface describing the required functionality for a dead letter queue. 
- SequenceEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
- 
EventStorageEngine implementation that combines the streams of two event storage engines. 
- SequenceEventStorageEngine(EventStorageEngine, EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
- 
- sequenceIdentifier(EventMessage<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-  
- SequenceMatcher<T> - Class in org.axonframework.test.matchers
- 
A matcher that will match if all the given matcherseach match against an item that the previous
 matcher matched against.
 
- SequenceMatcher(Matcher<? super T>...) - Constructor for class org.axonframework.test.matchers.SequenceMatcher
- 
Construct a matcher that will return true if all the given matchersmatch against an item
 positioned after the item that the previous matcher matched against.
 
- SequenceNumber - Annotation Type in org.axonframework.eventhandling
- 
Annotation indicating that a parameter on an Event Handler method should be injected with the SequenceNumber of
 a DomainEventMessage. 
- sequenceNumberColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the event identifier column. 
- sequenceNumberColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Get the name of the column containing the aggregate sequence number of the event. 
- SequenceNumberParameterResolver() - Constructor for class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
-  
- SequenceNumberParameterResolverFactory - Class in org.axonframework.eventhandling
- 
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a  Long type
 annotated with the  SequenceNumber annotation and assigns the sequenceNumber of the DomainEventMessage. 
- SequenceNumberParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory
- 
- SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver - Class in org.axonframework.eventhandling
- 
ParameterResolver that resolves SequenceNumber parameters 
- sequenceOf(Matcher<T>...) - Static method in class org.axonframework.test.matchers.Matchers
- 
Matches a list of Events if each of the matchersmatch against an Event that comes after the Event
 that the previous matcher matched against.
 
- sequenceSize(Object) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- sequenceSize(Object) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- sequenceSize(Object) - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- sequenceSize(Object) - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Returns the number of dead letters for the sequence matching the given sequenceIdentifiercontained in
 this queue.
 
- sequencingPolicies - Variable in class org.axonframework.config.EventProcessingModule
-  
- sequencingPolicy(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
- 
- sequencingPolicy(String) - Method in class org.axonframework.config.EventProcessingModule
-  
- SequencingPolicy<T> - Interface in org.axonframework.eventhandling.async
- 
Interface to a policy definition for concurrent processing, for example event handling. 
- sequencingPolicy(SequencingPolicy<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
- 
- sequencingPolicyMatchesSegment(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-  
- SequentialPerAggregatePolicy - Class in org.axonframework.eventhandling.async
- 
Concurrency policy that requires sequential processing of events raised by the same aggregate. 
- SequentialPerAggregatePolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-  
- SequentialPolicy - Class in org.axonframework.eventhandling.async
- 
SequencingPolicy that requires sequential handling of all events delivered to an event handler. 
- SequentialPolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPolicy
-  
- SerializationException - Exception in org.axonframework.serialization
- 
Indicates that an exception occurred while serializing or deserializing an object. 
- SerializationException(String) - Constructor for exception org.axonframework.serialization.SerializationException
- 
Initializes the exception using the given message.
 
- SerializationException(String, Throwable) - Constructor for exception org.axonframework.serialization.SerializationException
- 
Initializes the exception using the given messageandcause.
 
- serialize(CommandMessage<?>, String, int) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
- 
- serialize(CommandResultMessage<?>, String) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
- 
- serialize(Object, Class<T>) - Method in class org.axonframework.axonserver.connector.event.axon.GrpcMetaDataAwareSerializer
-  
- serialize(SubscriptionQueryUpdateMessage<?>) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
Serializes the given subscriptionQueryUpdateMessageinto aQueryUpdate.
 
- serialize(SubscriptionQueryMessage<?, ?, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
- serialize(String, Throwable) - Static method in class org.axonframework.axonserver.connector.util.ExceptionSerializer
- 
Serializes a given  Throwable into an  ErrorMessage. 
- serialize(A, Class<T>) - Method in interface org.axonframework.axonserver.connector.util.GrpcObjectSerializer.Serializer
- 
Serialize the given objectinto an object of theexpectedRepresentation.
 
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-  
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
- 
Deprecated. 
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-  
- serialize(Object, Class<T>) - Method in interface org.axonframework.serialization.Serializer
- 
Serialize the given objectinto a Serialized Object containing the givenexpectedRepresentation.
 
- SERIALIZED_DEADLINE_MESSAGE - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
- 
- SERIALIZED_DEADLINE_MESSAGE_CLASS_NAME - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
- 
- SERIALIZED_DEADLINE_SCOPE - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
- 
- SERIALIZED_DEADLINE_SCOPE_CLASS_NAME - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
- 
Key pointing to the class name of the deadline  ScopeDescriptor in the  JobDataMap
- SERIALIZED_MESSAGE_PAYLOAD - Static variable in class org.axonframework.messaging.Headers
- 
Key pointing to the serialized payload of a message. 
- serializedException - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- SerializedMessage<T> - Class in org.axonframework.serialization
- 
A message containing serialized payload data and metadata. 
- SerializedMessage(String, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serialization.SerializedMessage
- 
Initializes a  SerializedMessage with given  identifier from the given serialized payload and
 metadata. 
- SerializedMessage(String, LazyDeserializingObject<T>, LazyDeserializingObject<MetaData>) - Constructor for class org.axonframework.serialization.SerializedMessage
- 
Initializes a  SerializedMessage with given  identifier from the given lazily deserializing payload
 and metadata. 
- serializedMetaData - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-  
- serializedMetaData - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- SerializedMetaData<T> - Class in org.axonframework.serialization
- 
Represents the serialized form of a  MetaData instance. 
- SerializedMetaData(T, Class<T>) - Constructor for class org.axonframework.serialization.SerializedMetaData
- 
Construct an instance with given  bytes representing the serialized form of a  MetaData
 instance. 
- SerializedObject<T> - Interface in org.axonframework.serialization
- 
Interface describing the structure of a serialized object. 
- SerializedObjectHolder - Class in org.axonframework.serialization
- 
Holder that keeps references to serialized representations of a payload and meta data of a specific message. 
- SerializedObjectHolder(Message) - Constructor for class org.axonframework.serialization.SerializedObjectHolder
- 
Initialize the holder for the serialized representations of the payload and meta data of given
 message
 
- serializedObjectType() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
- 
Intended for clients to override. 
- serializedObjectType() - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. Intended for clients to override. 
- serializedPayload - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-  
- serializedPayload - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-  
- serializedSaga - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
- 
Deprecated. 
- serializedSaga - Variable in class org.axonframework.modelling.saga.repository.jpa.SagaEntry
-  
- SerializedSaga - Class in org.axonframework.modelling.saga.repository.jpa
- 
Specialization of the SerializedObject for Sagas represented as byte array. 
- SerializedSaga(byte[], String, String) - Constructor for class org.axonframework.modelling.saga.repository.jpa.SerializedSaga
- 
Initialize a SerializedSaga instance with given data, of giventypeandrevision.
 
- SerializedType - Interface in org.axonframework.serialization
- 
Describes the type of a serialized object. 
- serializedType() - Method in class org.axonframework.serialization.UnknownSerializedType
- 
Returns the type of the serialized object, for which no class could be resolved. 
- serializeExceptionResult(Serializer, Class<T>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- serializeExceptionResult(Serializer, Class<T>) - Method in interface org.axonframework.messaging.ResultMessage
- 
Serializes the exception result. 
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.messaging.GenericMessage
-  
- serializeMetaData(Serializer, Class<R>) - Method in interface org.axonframework.messaging.Message
- 
Serialize the meta data of this message to the expectedRepresentationusing givenserializer.
 
- serializeMetaData(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
-  
- serializeMetaData(Serializer, Class<R1>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
-  
- serializeMetaData(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
-  
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.messaging.GenericMessage
-  
- serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.GenericResultMessage
-  
- serializePayload(Serializer, Class<R>) - Method in interface org.axonframework.messaging.Message
- 
Serialize the payload of this message to the expectedRepresentationusing givenserializer.
 
- serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
-  
- serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-  
- serializePayload(Serializer, Class<S>) - Method in interface org.axonframework.messaging.ResultMessage
-  
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
-  
- serializePayload(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
-  
- serializeQuery(SubscriptionQueryMessage) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
Serializes the given subscriptionQueryMessageinto aQueryRequest.
 
- serializer(Serializer) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
Sets the  Serializer used to de-/serialize incoming and outgoing commands and command results. 
- serializer() - Method in interface org.axonframework.config.Configuration
- 
Returns the serializer defined in this Configuration 
- serializer(Serializer) - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager.Builder
- 
- serializer(Serializer) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
- 
- serializer(Serializer) - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
Sets the  Serializer to (de)serialize the event payload,
 event metadata, tracking token, and diagnostics of the  DeadLetter when storing it to the database. 
- serializer(Serializer) - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. Sets the  Serializer to deserialize the events, metadata and diagnostics of the  DeadLetter
 when storing it to a database. 
- serializer(Serializer) - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler.Builder
- 
- serializer(Serializer) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
- 
- serializer(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
- 
- serializer() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Returns the serializer used by the Token Store to serialize tokens. 
- serializer(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
- 
- serializer() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
- 
Returns the serializer used by the Token Store to serialize tokens. 
- serializer(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore.Builder
- 
Deprecated. 
- serializer() - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. Returns the serializer used by the Token Store to serialize tokens. 
- serializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
- 
Sets the  Serializer used to de-/serialize a Saga instance. 
- serializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
- 
Sets the  Serializer used to de-/serialize a Saga instance. 
- serializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore.Builder
- 
Deprecated. Sets the  Serializer used to de-/serialize a Saga instance. 
- Serializer - Interface in org.axonframework.serialization
- 
Interface describing a serialization mechanism. 
- serializer(RevisionResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- serializerConfigurer(Serializer, Serializer, Serializer) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- serializeRequest(QueryMessage<Q, R>, int, long, int) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
- 
- serializeRequest(QueryMessage<Q, R>, int, long, int, boolean) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
- 
- serializeResponse(QueryResponseMessage<?>, String) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
- 
- SerializerProperties - Class in org.axonframework.springboot
- 
A group of properties that allows easy configuration of the serializers used for different types of objects that
 Axon needs to serialize. 
- SerializerProperties() - Constructor for class org.axonframework.springboot.SerializerProperties
-  
- SerializerProperties.SerializerType - Enum in org.axonframework.springboot
- 
Enumerates different possible standard serializers, available in Axon. 
- serializeUpdateType(SubscriptionQueryMessage<?, ?, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
Serializes the given subscriptionQueryMessageinto aSerializedObject.
 
- SerialVersionUIDRevisionResolver - Class in org.axonframework.serialization
- 
RevisionResolver implementation that returns the (String representation of the) serialVersionUID of a class. 
- SerialVersionUIDRevisionResolver() - Constructor for class org.axonframework.serialization.SerialVersionUIDRevisionResolver
-  
- ServerConnectorConfigurerModule - Class in org.axonframework.axonserver.connector
- 
Configurer module which is auto-loadable by the  DefaultConfigurer that sets sensible
 default to use when the AxonServer connector is available on the classpath. 
- ServerConnectorConfigurerModule() - Constructor for class org.axonframework.axonserver.connector.ServerConnectorConfigurerModule
-  
- servers(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- ServiceRegistryException - Exception in org.axonframework.commandhandling.distributed
- 
Exception that is triggered when an error occurs that is related to the registration or deregistration of a member to
 the distributed command bus service registry. 
- ServiceRegistryException(String) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
- 
Initializes the exception using the given message.
 
- ServiceRegistryException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
- 
Initializes the exception using the given messageandcause.
 
- set(UnitOfWork<?>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
- 
Binds the given unitOfWorkto the current thread.
 
- set(Map<String, String>, String, String) - Method in class org.axonframework.tracing.opentelemetry.MetadataContextSetter
-  
- setAdditionalConverters(List<ContentTypeConverter>) - Method in class org.axonframework.serialization.ChainingConverter
- 
Setter for dependency injection frameworks that require property methods. 
- setAdditionalFactories(List<ParameterResolverFactory>) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
- 
Defines any additional parameter resolver factories that need to be used to resolve parameters. 
- setAdditionalHandlerEnhancers(List<HandlerEnhancerDefinition>) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. Defines any additional handler definitions that should be used. 
- setAdditionalHandlers(List<HandlerDefinition>) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. Defines any additional handler definitions that should be used. 
- setAdditionalHandlers(List<HandlerEnhancerDefinition>) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. Defines any additional handler enhancer definitions that should be used. 
- setAggregateFactory(String) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
- setAggregateIdentifier(boolean) - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
- 
Deprecated. 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
- 
Deprecated. 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.MessageHandlerConfigurer
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.SpringAxonConfiguration
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.SpringSagaConfigurer
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.messaging.ApplicationContextEventPublisher
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.saga.SpringResourceInjector
-  
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-  
- setAttributeProviders(TracingProperties.AttributeProviders) - Method in class org.axonframework.springboot.TracingProperties
- 
- setAutoConfiguration(MetricsProperties.AutoConfiguration) - Method in class org.axonframework.springboot.MetricsProperties
- 
Defines the AutoConfiguration settings for Metrics. 
- setAutoStart(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
- 
- setBatchSize(int) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Sets the maximum size of a processing batch. 
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.HandlerDefinitionFactoryBean
-  
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. 
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. 
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-  
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-  
- setBeanFactory(BeanFactory) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. 
- setBeanFactory(BeanFactory) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer
- 
Deprecated. 
- setBeanName(String) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-  
- setBindAddr(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Sets the Address to bind the JGroups to. 
- setBindPort(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Returns the port to listen to JGroups connections (default 7800). 
- setCache(String) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
Sets the bean name of the  Cache to use for this Aggregate. 
- setCallbackBehavior(CallbackBehavior) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback. 
- setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.utils.RecordingCommandBus
- 
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback. 
- setCause(Cause) - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Sets the cause of the error when the message was originally processed, or processed later and the cause was
 updated. 
- setCertFile(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setClientId(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setClusterName(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Sets the Cluster Name of the JGroups Cluster to connect with (defaults to "Axon"). 
- setCommandBus(CommandBus) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. Sets the command bus to use when subscribing command handlers. 
- setCommandFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setCommandHandlers(Collection<MessageHandler>) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. Sets the command handlers to subscribe to the bus. 
- setCommandLoadFactor(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setCommandTargetResolver(String) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
- setCommandThreads(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setCommandThreads(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setCommitTimeout(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setComponentName(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setConfiguration(Configuration) - Method in class org.axonframework.spring.modelling.SpringRepositoryFactoryBean
- 
Deprecated. 
- setConfigurationFile(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
Sets the path to the configuration file to use to configure the Groups instance. 
- setConfigurerModules(List<ConfigurerModule>) - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
- 
Deprecated. Registers the configurerModulesthat provide context-sensitive default settings for the Configurer.
 
- setConnectTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setContext(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setDiagnostics(MetaData, Serializer) - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Sets the diagnostics, taking in a  Serializer to serialize if to the correct format. 
- setDimensional(boolean) - Method in class org.axonframework.springboot.MetricsProperties.Micrometer
- 
Disables (if false, default) or enables (iftrue) the usage of Micrometer Tags/Dimensions
 
- setDisableEventBlacklisting(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
-  
- setEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setEnabled(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Enables (if true) or disables (iffalse, default) the auto-configuration of a Distributed
 Command Bus instance in the application context.
 
- setEnabled(boolean) - Method in class org.axonframework.springboot.MetricsProperties.AutoConfiguration
- 
Enables (if true, default) or disables (iffalse) the auto-configuration of Metrics within
 the application context.
 
- setEntityManager(EntityManager) - Method in class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
- 
Sets the container managed entityManager to use. 
- setEntityManager(EntityManager) - Method in class org.axonframework.springboot.util.legacyjpa.ContainerManagedEntityManagerProvider
- 
Deprecated. Sets the container managed entityManager to use. 
- setEventBus(EventBus) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
- 
Sets the eventBus that scheduled events should be published to. 
- setEventBus(EventBus) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
- 
Sets the event bus to which scheduled events need to be published. 
- setEventFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setEventHandlers(List<Object>) - Method in class org.axonframework.spring.config.EventHandlerRegistrar
- 
Deprecated. Registers the given beansas event handlers with the Event Handler Configuration.
 
- setEventJobDataBinder(EventJobDataBinder) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
- 
Sets the  EventJobDataBinder instance which reads / writes the event message to publish to the
  JobDataMap. 
- setEvents(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
- 
The type of serializer to use to serialize the payload and meta data of Event Messages. 
- setEventSecretKey(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- setEventStore(EventStore) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
- 
Sets the Event Store instance to write the snapshots to 
- setExclusiveLoad(boolean) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
- 
Sets whether loading of Sagas should occur exclusively by a single node, by requiring a row lock from the
 database. 
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-  
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
- 
Set the execution result of processing the current  Message. 
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-  
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-  
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
- 
Set the execution result of processing the current  Message. 
- setExecutor(Executor) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
- 
Sets the executor to process the creation (and storage) of each snapshot. 
- setExecutorService(ScheduledExecutorService) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
- 
Sets the ExecutorService implementation that monitors the triggers and provides the Threads to publish events. 
- setFallbackToHttpGet(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
- 
Whether to fall back to HTTP GET when retrieving Instance Meta Data from the Discovery Server fails. 
- setFallbackUrl(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
- 
Sets the URL relative to the host's root to retrieve Instance Meta Data from. 
- setFieldValue(Field, Object, T) - Static method in class org.axonframework.common.ReflectionUtils
- 
Set the fieldofobjectto a certainvalue.
 
- setFilterEventsByType(boolean) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
Indicates whether to enable "filter events by type" for this Aggregate. 
- setForceFlushOnSave(boolean) - Method in class org.axonframework.modelling.command.GenericJpaRepository
- 
Indicates whether the EntityManager's state should be flushed each time an aggregate is saved. 
- setForceFlushOnSave(boolean) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository
- 
Deprecated. Indicates whether the EntityManager's state should be flushed each time an aggregate is saved. 
- setForceReadFromLeader(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
- 
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken. 
- setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken. 
- setGapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
- 
- setGapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
- 
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out. 
- setGapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out. 
- setGeneral(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
- 
Sets the type of serializer to use to serialize any type of object, for which no more specific serializer is
 configured. 
- setGossip(DistributedCommandBusProperties.JGroupsProperties.Gossip) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
- 
- setGroupIdentifier(String) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
- 
Sets the group identifier to use when scheduling jobs with Quartz. 
- setGroupIdentifier(String) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
- 
Sets the group identifier to use when scheduling jobs with Quartz. 
- setHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. Sets the HandlerDefinition to create concrete handlers. 
- setHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
- 
Sets handler definition to be able to create concrete handlers. 
- setHeartbeat(AxonServerConfiguration.HeartbeatConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setHosts(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
- 
- setInitialNrOfPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-  
- setInitialNrOfPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setInitialSegmentCount(Integer) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Sets the number of initial segments that should be created, if no segments are already present. 
- setInterval(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
-  
- setJgroups(DistributedCommandBusProperties.JGroupsProperties) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Sets the JGroups configuration to use (if JGroups is on the classpath). 
- setKeepAliveTime(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setKeepAliveTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setLastTouched(Instant) - Method in class org.axonframework.eventhandling.deadletter.jpa.DeadLetterEntry
- 
Sets the time the message was last touched. 
- setListenerInvocationErrorHandler(ListenerInvocationErrorHandler) - Method in class org.axonframework.test.saga.RecordingListenerInvocationErrorHandler
- 
- setLoadFactor(int) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Sets the load factor for this instance of the Distributed Command Bus (default 100). 
- setLockFactory(String) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
Sets the bean name of the  LockFactory to use for this Aggregate. 
- setMaxGrpcBufferedMessages(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setMaxMessageSize(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setMessageId(boolean) - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- setMessageName(boolean) - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- setMessages(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
- 
The type of serializer to use to serialize the payload and meta data of Messages. 
- setMessageType(boolean) - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- setMetadata(boolean) - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- setMicrometer(MetricsProperties.Micrometer) - Method in class org.axonframework.springboot.MetricsProperties
- 
Defines the Micrometer settings for Metrics. 
- setMode(EventProcessorProperties.Mode) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Sets the type of processor that should be configured. 
- setNestedHandlers(boolean) - Method in class org.axonframework.springboot.TracingProperties
- 
Setting value for nesting handlers in dispatching traces. 
- setNestedTimeLimit(Duration) - Method in class org.axonframework.springboot.TracingProperties
- 
Sets the value for the time limit set on nested handlers inside dispatching trace. 
- setNewPermitsThreshold(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-  
- setNewPermitsThreshold(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setNrOfNewPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-  
- setNrOfNewPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setOnAvailableCallback(Runnable) - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
-  
- setOnAvailableCallback(Runnable) - Method in interface org.axonframework.common.stream.BlockingStream
- 
Set a callbackto be invoked once new messages are available on this stream.
 
- setOwnerColum(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
- setOwnerColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
Sets the name of the owner column. 
- setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
- 
Deprecated. Sets the ParameterResolverFactory to create the Parameter Resolvers with that provide the parameter values for
 the handler methods. 
- setPayloadType(boolean) - Method in class org.axonframework.springboot.TracingProperties.AttributeProviders
- 
- setPhase(UnitOfWork.Phase) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
- 
Overwrite the current phase with the given phase.
 
- setProcessorNameColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
Sets the name of the processor name column. 
- setProcessorsNotificationInitialDelay(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setProcessorsNotificationRate(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setQueryBus(QueryBus) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- setQueryFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setQueryHandlers(Collection<QueryHandlerAdapter>) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- setQueryThreads(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setReportIllegalStateChange(boolean) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-  
- setReportIllegalStateChange(boolean) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
- 
Sets whether or not the fixture should detect and report state changes that occur outside of Event Handler
 methods. 
- setRepository(String) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
Sets the bean name of the  Repository to configure for this Aggregate. 
- setRepositoryProvider(RepositoryProvider) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
- 
Sets repository provider in order to have possibility to spawn new aggregates from THE aggregate. 
- setResult(CommandResultMessage<?>) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
- 
Registers the result of the command's execution, if successful. 
- setRollbackCause(Throwable) - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-  
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
- 
Sets the cause for rolling back this Unit of Work. 
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-  
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-  
- setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus
- 
- setSagaStore(String) - Method in class org.axonframework.spring.config.SpringSagaConfigurer
- 
Sets the bean name of the  SagaStore to configure. 
- setScheduler(Scheduler) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
- 
Sets the backing Quartz Scheduler for this timer. 
- setSegmentColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
Sets the name of the processor segment column. 
- setSequencingPolicy(String) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
- setSerializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
- 
Sets the Serializer instance to serialize Sagas with. 
- setSerializer(Serializer) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
- 
- setServers(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setShowEventSourcingHandlers(boolean) - Method in class org.axonframework.springboot.TracingProperties
- 
Setting value for showing event sourcing handlers in traces. 
- setSnapshotFilter(String) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
Sets the bean name of the  SnapshotFilter to configure for this Aggregate. 
- setSnapshotPrefetch(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setSnapshotter(Snapshotter) - Method in class org.axonframework.eventsourcing.AbstractSnapshotTrigger
- 
Sets the snapshotter 
- setSnapshotTriggerDefinition(String) - Method in class org.axonframework.spring.config.SpringAggregateConfigurer
- 
- setSource(String) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Sets the name of the bean that should be used as source for Event Messages. 
- setSpringCloud(DistributedCommandBusProperties.SpringCloudProperties) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
- 
Sets the Spring Cloud configuration to use (if Spring Cloud is on the classpath). 
- setSslEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setSuppressDownloadMessage(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setTags(Map<String, String>) - Method in class org.axonframework.springboot.TagsConfigurationProperties
- 
Sets tags. 
- setThreadCount(int) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
- setTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.HeartbeatConfiguration
-  
- setTimestampColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
Sets the name of the timestamp column. 
- setToken(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-  
- setTokenClaimInterval(long) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Sets the time to wait after a failed attempt to claim any token, before making another attempt. 
- setTokenClaimIntervalTimeUnit(TimeUnit) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
- 
Sets the time unit used to defined tokens claim interval. 
- setTokenColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
Sets the name of the serialized token column. 
- setTokenTable(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
Sets the name of the token entry table. 
- setTokenTypeColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
- 
Sets the name of the token type column. 
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
- 
The TransactionDefinition to use by the transaction manager. 
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
- 
The TransactionDefinition to use by the transaction manager. 
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
- 
Optionally sets the transaction definition to use. 
- setTransactionManager(Object) - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
- 
Deprecated. Sets the actual transaction manager. 
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
- 
Sets the transaction manager that manages the transaction around the publication of an event. 
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
- 
Sets the transaction manager that manages the transaction around the publication of an event. 
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
- 
Sets the transaction manager to manager underlying transaction with. 
- setUseExplicitFlush(boolean) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
- 
Sets whether or not to do an explicit EntityManager.flush()after each data modifying operation on the
 backing storage.
 
- setUseExplicitFlush(boolean) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. Sets whether or not to do an explicit EntityManager.flush()after each data modifying operation on the
 backing storage.
 
- shouldEnqueue() - Method in class org.axonframework.messaging.deadletter.DoNotEnqueue
-  
- shouldEnqueue() - Method in interface org.axonframework.messaging.deadletter.EnqueueDecision
- 
The decision whether the  dead letter should be enqueued in a queue. 
- shouldEnqueue() - Method in class org.axonframework.messaging.deadletter.Ignore
-  
- ShouldEnqueue<M extends Message<?>> - Class in org.axonframework.messaging.deadletter
- 
- ShouldEnqueue() - Constructor for class org.axonframework.messaging.deadletter.ShouldEnqueue
- 
- ShouldEnqueue(Throwable) - Constructor for class org.axonframework.messaging.deadletter.ShouldEnqueue
- 
- ShouldEnqueue(Throwable, Function<DeadLetter<? extends M>, MetaData>) - Constructor for class org.axonframework.messaging.deadletter.ShouldEnqueue
- 
- shouldEnqueue() - Method in class org.axonframework.messaging.deadletter.ShouldEnqueue
-  
- shouldInvokeInterceptorChain() - Method in interface org.axonframework.modelling.command.inspection.CommandHandlerInterceptorHandlingMember
- 
Deprecated. Indicates whether interceptor chain (containing a command handler) should be invoked automatically or command
 handler interceptor will invoke it manually. 
- showEventSourcingHandlers(boolean) - Method in class org.axonframework.tracing.TracingHandlerEnhancerDefinition.Builder
- 
Configures whether event sourcing handlers should be traced. 
- shutdown() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
Stops the Connection Manager, closing any active connections and preventing new connections from being created. 
- shutdown() - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
- 
Deprecated. Stops the scheduled task and shutdown the monitor, that cannot be restarted again. 
- shutdown() - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- shutdown() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
- 
Shuts down the Executor used to asynchronously dispatch incoming commands. 
- shutdown() - Method in interface org.axonframework.config.Configuration
- 
Shuts down the components defined in this Configuration 
- shutdown() - Method in class org.axonframework.config.MessageHandlerRegistrar
- 
- shutdown() - Method in interface org.axonframework.config.ModuleConfiguration
- 
- shutdown() - Method in interface org.axonframework.deadline.DeadlineManager
- 
Shuts down this deadline manager. 
- shutdown() - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager
-  
- shutdown() - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-  
- shutdown() - Method in class org.axonframework.deadline.SimpleDeadlineManager
-  
- shutDown() - Method in interface org.axonframework.eventhandling.EventProcessor
- 
Stops processing events. 
- shutDown() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- shutdown() - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
- 
Shuts down this event scheduler. 
- shutdown() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-  
- shutdown() - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler
-  
- shutdown() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-  
- shutDown() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
- 
Shut down this processor. 
- shutDown() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Shuts down the processor. 
- shutDown() - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
- 
Method to invoke when the application shuts down. 
- shutDown() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore
- 
Deprecated. Method to invoke when the application shuts down. 
- shutdown() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- SHUTDOWN_PHASE - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the  Phase to invoke a shutdown handler in. 
- shutdownAsync() - Method in interface org.axonframework.eventhandling.EventProcessor
- 
Initiates a shutdown, providing a  CompletableFuture that completes when the shutdown process is
 finished. 
- shutdownAsync() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- shutdownAsync() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Initiates a shutdown, providing a  CompletableFuture that completes when the shutdown process is
 finished. 
- shutdownDispatching() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
- 
Shutdown the command bus asynchronously for dispatching commands to Axon Server. 
- shutdownDispatching() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
- 
- shutdownDispatching() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
- 
Shutdown the query bus asynchronously for dispatching queries to Axon Server. 
- shutdownDispatching() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
Shutdown the command bus asynchronously for dispatching commands to other instances. 
- ShutdownHandler - Annotation Type in org.axonframework.lifecycle
- 
Annotation indicating that a member method should be a part of the shutdown cycle of an Axon application. 
- ShutdownInProgressException - Exception in org.axonframework.lifecycle
- 
Exception indicating a process tried to register an activity whilst the application is shutting down. 
- ShutdownInProgressException() - Constructor for exception org.axonframework.lifecycle.ShutdownInProgressException
- 
Construct this exception with the default message "Cannot start the activity, shutdown in progress".
 
- ShutdownInProgressException(String) - Constructor for exception org.axonframework.lifecycle.ShutdownInProgressException
- 
Constructs this exception with given messageexplaining the cause.
 
- ShutdownLatch - Class in org.axonframework.lifecycle
- 
A latch implementation to be used in shutdown scenarios. 
- ShutdownLatch() - Constructor for class org.axonframework.lifecycle.ShutdownLatch
-  
- ShutdownLatch.ActivityHandle - Class in org.axonframework.lifecycle
- 
- shutdownNow() - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- shutdownNow() - Method in interface org.axonframework.axonserver.connector.util.Scheduler
- 
Cancels all scheduled tasks. 
- signature() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
- 
Returns the signature of the member. 
- silentlyAdd() - Static method in class org.axonframework.queryhandling.registration.DuplicateQueryHandlerResolution
- 
- silentOverride() - Static method in class org.axonframework.commandhandling.DuplicateCommandHandlerResolution
- 
- SimpleCommandBus - Class in org.axonframework.commandhandling
- 
Implementation of the CommandBus that dispatches commands to the handlers subscribed to that specific command's name. 
- SimpleCommandBus(SimpleCommandBus.Builder) - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
- 
- SimpleCommandBus.Builder - Class in org.axonframework.commandhandling
- 
- SimpleCorrelationDataProvider - Class in org.axonframework.messaging.correlation
- 
CorrelationDataProvider implementation defines correlation headers by the header names. 
- SimpleCorrelationDataProvider(String...) - Constructor for class org.axonframework.messaging.correlation.SimpleCorrelationDataProvider
- 
Initializes the CorrelationDataProvider to return the meta data of messages with given metaDataKeysas correlation data.
 
- SimpleDeadlineManager - Class in org.axonframework.deadline
- 
- SimpleDeadlineManager(SimpleDeadlineManager.Builder) - Constructor for class org.axonframework.deadline.SimpleDeadlineManager
- 
- SimpleDeadlineManager.Builder - Class in org.axonframework.deadline
- 
- SimpleEntityManagerProvider - Class in org.axonframework.common.jpa
- 
Simple implementation of the EntityManagerProvider that returns the EntityManager instance provided at construction
 time. 
- SimpleEntityManagerProvider(EntityManager) - Constructor for class org.axonframework.common.jpa.SimpleEntityManagerProvider
- 
Initializes an instance that always returns the given entityManager.
 
- SimpleEntityManagerProvider - Class in org.axonframework.common.legacyjpa
- 
- SimpleEntityManagerProvider(EntityManager) - Constructor for class org.axonframework.common.legacyjpa.SimpleEntityManagerProvider
- 
Deprecated. Initializes an instance that always returns the given entityManager.
 
- SimpleEventBus - Class in org.axonframework.eventhandling
- 
Implementation of the  EventBus that dispatches events in the thread the publishes them. 
- SimpleEventBus(SimpleEventBus.Builder) - Constructor for class org.axonframework.eventhandling.SimpleEventBus
- 
- SimpleEventBus.Builder - Class in org.axonframework.eventhandling
- 
- SimpleEventHandlerInvoker - Class in org.axonframework.eventhandling
- 
- SimpleEventHandlerInvoker(SimpleEventHandlerInvoker.Builder<?>) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
- 
- SimpleEventHandlerInvoker.Builder<B extends SimpleEventHandlerInvoker.Builder<?>> - Class in org.axonframework.eventhandling
- 
- SimpleEventScheduler - Class in org.axonframework.eventhandling.scheduling.java
- 
An  EventScheduler implementation that uses Java's ScheduledExecutorService as scheduling and triggering
 mechanism. 
- SimpleEventScheduler(SimpleEventScheduler.Builder) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
- 
- SimpleEventScheduler.Builder - Class in org.axonframework.eventhandling.scheduling.java
- 
- SimpleEventSchedulerFactoryBean - Class in org.axonframework.spring.eventhandling.scheduling.java
- 
Spring FactoryBean that creates a SimpleEventScheduler instance using resources found in the Spring Application
 Context. 
- SimpleEventSchedulerFactoryBean() - Constructor for class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-  
- SimpleHandlerAttributes - Class in org.axonframework.messaging
- 
Simple implementation of the  HandlerAttributes which is given the  attributes in the constructor. 
- SimpleHandlerAttributes(Map<String, Object>) - Constructor for class org.axonframework.messaging.SimpleHandlerAttributes
- 
- SimpleMember<E> - Class in org.axonframework.commandhandling.distributed
- 
An endpoint in the network for a command handling service. 
- SimpleMember(String, E, boolean, Consumer<SimpleMember<E>>) - Constructor for class org.axonframework.commandhandling.distributed.SimpleMember
- 
Create the service member 
- SimpleQueryBus - Class in org.axonframework.queryhandling
- 
Implementation of the QueryBus that dispatches queries to the handlers within the JVM. 
- SimpleQueryBus(SimpleQueryBus.Builder) - Constructor for class org.axonframework.queryhandling.SimpleQueryBus
- 
- SimpleQueryBus.Builder - Class in org.axonframework.queryhandling
- 
- SimpleQueryUpdateEmitter - Class in org.axonframework.queryhandling
- 
Implementation of  QueryUpdateEmitter that uses Project Reactor to implement Update Handlers. 
- SimpleQueryUpdateEmitter(SimpleQueryUpdateEmitter.Builder) - Constructor for class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
- 
- SimpleQueryUpdateEmitter.Builder - Class in org.axonframework.queryhandling
- 
- SimpleResourceInjector - Class in org.axonframework.modelling.saga
- 
A resource injector that checks for @Inject annotated fields and setter methods to inject resources. 
- SimpleResourceInjector(Object...) - Constructor for class org.axonframework.modelling.saga.SimpleResourceInjector
- 
Initializes the resource injector to inject to given resources.
 
- SimpleResourceInjector(Collection<?>) - Constructor for class org.axonframework.modelling.saga.SimpleResourceInjector
- 
Initializes the resource injector to inject to given resources.
 
- SimpleResourceParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
- SimpleResourceParameterResolverFactory(Iterable<?>) - Constructor for class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
- 
Initialize the ParameterResolverFactory to inject the given resourcein applicable parameters.
 
- SimpleScheduleToken - Class in org.axonframework.eventhandling.scheduling.java
- 
ScheduleToken for tasks event scheduled using the SimpleEventScheduler. 
- SimpleScheduleToken(String) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
- 
Creates a SimpleScheduleToken with the given tokenId.
 
- SimpleSerializedObject<T> - Class in org.axonframework.serialization
- 
SerializedObject implementation that takes all properties as constructor parameters. 
- SimpleSerializedObject(T, Class<T>, SerializedType) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
- 
Initializes a SimpleSerializedObject using given dataandserializedType.
 
- SimpleSerializedObject(T, Class<T>, String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
- 
Initializes a SimpleSerializedObject using given dataand a serialized type identified by giventypeandrevision.
 
- SimpleSerializedType - Class in org.axonframework.serialization
- 
SerializedType implementation that takes its properties as constructor parameters. 
- SimpleSerializedType(String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedType
- 
Initialize with given objectTypeandrevisionNumber
 
- simulateAutoIncrement(Connection, String, String) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
- 
Oracle11 does not have auto incremented values. 
- SingleEntryMultiUpcaster<T> - Class in org.axonframework.serialization.upcasting
- 
Abstract implementation of an  Upcaster that eases the common process of upcasting one intermediate
 representation to several other representations by applying a simple flat mapping function to the input stream of
 intermediate representations. 
- SingleEntryMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
-  
- SingleEntryUpcaster<T> - Class in org.axonframework.serialization.upcasting
- 
Abstract implementation of an  Upcaster that eases the common process of upcasting one intermediate
 representation to another representation by applying a simple mapping function to the input stream of intermediate
 representations. 
- SingleEntryUpcaster() - Constructor for class org.axonframework.serialization.upcasting.SingleEntryUpcaster
-  
- SingleEventUpcaster - Class in org.axonframework.serialization.upcasting.event
- 
Abstract implementation of an event  Upcaster that eases the common process of upcasting one intermediate
 event representation to another representation by applying a simple mapping function to the input stream of
 intermediate representations. 
- SingleEventUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.SingleEventUpcaster
-  
- SinkWrapper<T> - Interface in org.axonframework.queryhandling
- 
Abstraction interface to bridge old FluxSinkandSinks.ManyAPI with a common
 API.
 
- size() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue
-  
- size() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue
- 
Deprecated. 
- size() - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue
-  
- size() - Method in interface org.axonframework.messaging.deadletter.SequencedDeadLetterQueue
- 
Returns the number of dead letters contained in this queue. 
- size() - Method in class org.axonframework.messaging.MetaData
-  
- size() - Method in interface org.axonframework.modelling.saga.AssociationValues
- 
Returns the number of AssociationValue instances available in this container 
- size() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-  
- size() - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
- 
Returns an approximation of the size of this map. 
- size() - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
- 
Returns the number of Sagas currently contained in this repository. 
- skipMessagesWithPayloadTypeOf(TrackedEventMessage<?>) - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
- 
Report the stream that a specific message was ignored by the consumer. 
- skipMessagesWithPayloadTypeOf(M) - Method in interface org.axonframework.common.stream.BlockingStream
- 
Report the stream that a specific message was ignored by the consumer. 
- SlidingTimeWindowReservoir - Class in org.axonframework.micrometer.reservoir
- 
A reservoir of measurements constrained by a sliding window that stores only the measurements made
 in the last Nseconds (or other time unit).
 
- SlidingTimeWindowReservoir(long, TimeUnit, Clock) - Constructor for class org.axonframework.micrometer.reservoir.SlidingTimeWindowReservoir
- 
- SnapshotEventEntry - Class in org.axonframework.eventsourcing.eventstore.jpa
- 
Default implementation of an event entry containing a serialized snapshot of an aggregate. 
- SnapshotEventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
- 
Construct a new default snapshot event entry from an aggregate. 
- SnapshotEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
- 
Default constructor required by JPA 
- snapshotEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
- 
Returns the name of the Snapshot event entity. 
- snapshotEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. Returns the name of the Snapshot event entity. 
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
- 
- snapshotFilter(SnapshotFilter) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
- 
Sets the  SnapshotFilter used to filter snapshots when returning aggregate events. 
- snapshotFilter() - Method in interface org.axonframework.config.AggregateConfiguration
- 
- snapshotFilter() - Method in class org.axonframework.config.AggregateConfigurer
-  
- snapshotFilter() - Method in interface org.axonframework.config.Configuration
- 
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
- 
- snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
- 
Sets the snapshotFilterdeciding whether to take a snapshot into account.
 
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
- 
- snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
-  
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
- snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-  
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
- snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-  
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
- snapshotFilter(SnapshotFilter) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. 
- SnapshotFilter - Interface in org.axonframework.eventsourcing.snapshotting
- 
- snapshotPrefetch(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- snapshotSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
- 
Sets the  Serializer used to serialize and deserialize snapshots. 
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
- 
Sets the  Serializer used to serialize and deserialize snapshots. 
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
-  
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-  
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-  
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. 
- snapshotTable(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
- 
Sets the name of the snapshot events table. 
- snapshotTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
- 
Returns the name of the snapshot event table. 
- snapshotter() - Method in interface org.axonframework.config.Configuration
- 
- Snapshotter - Interface in org.axonframework.eventsourcing
- 
Interface describing instances that are capable of creating snapshot events for aggregates. 
- SnapshotTrigger - Interface in org.axonframework.eventsourcing
- 
Interface describing a mechanism that keeps track of an Aggregate's activity in order to trigger a snapshot. 
- snapshotTriggerDefinition - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- snapshotTriggerDefinition(SnapshotTriggerDefinition) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
- 
- SnapshotTriggerDefinition - Interface in org.axonframework.eventsourcing
- 
Interface describing the mechanism for triggering Snapshots. 
- source() - Method in exception org.axonframework.axonserver.connector.AxonServerException
-  
- source() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
- 
Return a  String defining the source where the error originated. 
- SourceId - Annotation Type in org.axonframework.messaging.annotation
- 
Annotation indication that a parameter on a Message Handler method should be
 injected with the aggregate identifier of a DomainEventMessage. 
- SourceIdParameterResolverFactory - Class in org.axonframework.messaging.annotation
- 
An extension of the AbstractAnnotatedParameterResolverFactory that accepts
 parameters of a  String type that are annotated with the  SourceId
 annotation and assigns the aggregate identifier of the DomainEventMessage. 
- SourceIdParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.SourceIdParameterResolverFactory
- 
- Span - Interface in org.axonframework.tracing
- 
Represents a part of the application logic that will be traced. 
- SPAN_FACTORY - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
- 
The key under which the  SpanFactory is stored within the  SchedulerContext. 
- SpanAttributesProvider - Interface in org.axonframework.tracing
- 
Represents a provider of attributes to a  Span, based on a  Message. 
- spanFactory(SpanFactory) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory() - Method in interface org.axonframework.config.Configuration
- 
- spanFactory(SpanFactory) - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.eventhandling.AbstractEventBus.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory - Variable in class org.axonframework.eventhandling.AbstractEventProcessor
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventhandling.SimpleEventBus.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore.Builder
- 
Deprecated. 
- spanFactory(SpanFactory) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory - Variable in class org.axonframework.modelling.command.AbstractRepository
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. 
- spanFactory(SpanFactory) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-  
- spanFactory(SpanFactory) - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter.Builder
- 
Sets the  SpanFactory implementation to use for providing tracing capabilities. 
- spanFactory(SpanFactory) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
-  
- spanFactory() - Method in class org.axonframework.springboot.autoconfig.AxonTracingAutoConfiguration
-  
- spanFactory(TracingProperties) - Method in class org.axonframework.springboot.autoconfig.OpenTelemetryAutoConfiguration
-  
- SpanFactory - Interface in org.axonframework.tracing
- 
The  SpanFactory is responsible for making  spans in a way the chosen tracing provider is
 compatible with. 
- spanFactory(SpanFactory) - Method in class org.axonframework.tracing.TracingHandlerEnhancerDefinition.Builder
- 
Configures the  SpanFactory the handler enhancer should use for tracing. 
- SpanScope - Interface in org.axonframework.tracing
- 
Represents the scope of a  Span. 
- SpanUtils - Class in org.axonframework.tracing
- 
Utilities for creating spans which are relevant for all implementations of tracing. 
- split() - Method in class org.axonframework.eventhandling.Segment
- 
- split() - Method in class org.axonframework.eventhandling.TrackerStatus
- 
Splits the current status object to reflect the status of their underlying segments being split. 
- split(Segment, TrackingToken) - Static method in class org.axonframework.eventhandling.TrackerStatus
- 
Split the given segmentandtrackingTokenin two.
 
- splitBalanced(Segment, int) - Static method in class org.axonframework.eventhandling.Segment
- 
Split a given  Segment n-times in round robin fashion. 
- splitSegment(int) - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService.AxonProcessorInstructionHandler
-  
- splitSegment(int) - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- splitSegment(int) - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
Instruct the processor to split the segment with given segmentIdinto two segments, allowing an
 additional process to start processing events from it.
 
- splitSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- splitSegmentId() - Method in class org.axonframework.eventhandling.Segment
- 
Returns the segmentId of the counterpart of this segment, if this segment were to be split. 
- SpringAggregateConfigurer<T> - Class in org.axonframework.spring.config
- 
- SpringAggregateConfigurer(Class<T>, Set<Class<? extends T>>) - Constructor for class org.axonframework.spring.config.SpringAggregateConfigurer
- 
- SpringAggregateLookup - Class in org.axonframework.spring.config
- 
A  BeanDefinitionRegistryPostProcessor implementation that scans for Aggregate types and registers a
  configurer for each Aggregate found. 
- SpringAggregateLookup() - Constructor for class org.axonframework.spring.config.SpringAggregateLookup
-  
- springAggregateLookup() - Static method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- SpringAggregateSnapshotter - Class in org.axonframework.spring.eventsourcing
- 
Snapshotter implementation that uses the AggregateRoot as state for the snapshot. 
- SpringAggregateSnapshotter(SpringAggregateSnapshotter.Builder) - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
- 
- SpringAggregateSnapshotter.Builder - Class in org.axonframework.spring.eventsourcing
- 
- SpringAggregateSnapshotterFactoryBean - Class in org.axonframework.spring.eventsourcing
- 
Implementation of the  AggregateSnapshotter that eases the configuration when
 used within a Spring Application Context. 
- SpringAggregateSnapshotterFactoryBean() - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-  
- SpringAxonAutoConfigurer - Class in org.axonframework.spring.config
- 
- SpringAxonAutoConfigurer() - Constructor for class org.axonframework.spring.config.SpringAxonAutoConfigurer
- 
Deprecated. 
- SpringAxonAutoConfigurer.ImportSelector - Class in org.axonframework.spring.config
- 
Deprecated. 
- SpringAxonConfiguration - Class in org.axonframework.spring.config
- 
- SpringAxonConfiguration(Configurer) - Constructor for class org.axonframework.spring.config.SpringAxonConfiguration
- 
- springAxonConfiguration(Configurer) - Method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- springAxonConfigurer(ConfigurableListableBeanFactory, List<ConfigurerModule>, List<ModuleConfiguration>) - Method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- SpringBeanDependencyResolverFactory - Class in org.axonframework.spring.config.annotation
- 
ParameterResolverFactory implementation that resolves parameters using Spring dependency resolution. 
- SpringBeanDependencyResolverFactory(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringBeanDependencyResolverFactory
- 
Default constructor requiring an application context, for use internally by Axon. 
- SpringBeanParameterResolverFactory - Class in org.axonframework.spring.config.annotation
- 
ParameterResolverFactory implementation that resolves parameters in the Spring Application Context. 
- SpringBeanParameterResolverFactory() - Constructor for class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
- 
Default constructor, which relies on Spring to inject the application context. 
- SpringBeanParameterResolverFactory(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
- 
Convenience constructor to use when an instance is not managed by Spring, but an application context is
 available. 
- SpringCloudProperties() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
-  
- SpringConfigurer - Class in org.axonframework.spring.config
- 
A  Configurer implementation that considers the Spring Application context as a
 source for components. 
- SpringConfigurer(ConfigurableListableBeanFactory) - Constructor for class org.axonframework.spring.config.SpringConfigurer
- 
Initialize this  Configurer using given  beanFactory to locate
 components. 
- SpringContextHandlerDefinitionBuilder - Class in org.axonframework.spring.config.annotation
- 
- SpringContextParameterResolverFactoryBuilder - Class in org.axonframework.spring.config.annotation
- 
- SpringDataSourceConnectionProvider - Class in org.axonframework.spring.jdbc
- 
ConnectionProvider implementation that is aware of Transaction Managers and provides the connection attached to an
 active transaction manager, instead of asking a Data Source directly. 
- SpringDataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.spring.jdbc.SpringDataSourceConnectionProvider
- 
Initialize the connection provider, using given dataSourceto obtain a connection, when required.
 
- SpringHandlerDefinitionBean - Class in org.axonframework.spring.config.annotation
- 
- SpringHandlerDefinitionBean() - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. Initializes definition bean with assumption that application context will be injected. 
- SpringHandlerDefinitionBean(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
- 
Deprecated. Initializes definition bean with given application context. 
- SpringHandlerEnhancerDefinitionBean - Class in org.axonframework.spring.config.annotation
- 
- SpringHandlerEnhancerDefinitionBean() - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. Initializes definition bean with assumption that application context will be injected. 
- SpringHandlerEnhancerDefinitionBean(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
- 
Deprecated. Initializes definition bean with given application context. 
- SpringParameterResolverFactoryBean - Class in org.axonframework.spring.config.annotation
- 
Spring factory bean that creates a ParameterResolverFactory instance that is capable of resolving parameter values as
 Spring Beans, in addition to the default behavior defined by Axon. 
- SpringParameterResolverFactoryBean() - Constructor for class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-  
- SpringPrototypeAggregateFactory<T> - Class in org.axonframework.spring.eventsourcing
- 
AggregateFactory implementation that uses Spring prototype beans to create new uninitialized instances of
 Aggregates. 
- SpringPrototypeAggregateFactory(String) - Constructor for class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
- 
Initializes the factory to create beans instances for the bean with given prototypeBeanName.
 
- SpringPrototypeAggregateFactory(String, Map<Class<? extends T>, String>) - Constructor for class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
- 
Initializes the factory to create beans instances for the bean with given prototypeBeanNameand itssubtypes.
 
- SpringRepositoryFactoryBean<T> - Class in org.axonframework.spring.modelling
- 
- SpringRepositoryFactoryBean(Class<T>) - Constructor for class org.axonframework.spring.modelling.SpringRepositoryFactoryBean
- 
Deprecated. 
- SpringResourceInjector - Class in org.axonframework.spring.saga
- 
ResourceInjector implementation that injects Saga instances with resources available from the Spring Application
 context the injector is registered in. 
- SpringResourceInjector() - Constructor for class org.axonframework.spring.saga.SpringResourceInjector
-  
- SpringSagaConfigurer - Class in org.axonframework.spring.config
- 
A  ConfigurerModule implementation that configures a Saga based on configuration found in the Application
 Context. 
- SpringSagaConfigurer(Class<?>) - Constructor for class org.axonframework.spring.config.SpringSagaConfigurer
- 
Initialize the Saga for given sagaType.
 
- SpringSagaLookup - Class in org.axonframework.spring.config
- 
A  BeanDefinitionRegistryPostProcessor implementation that scans for Saga types and registers a  configurer for each Saga found. 
- SpringSagaLookup() - Constructor for class org.axonframework.spring.config.SpringSagaLookup
-  
- springSagaLookup() - Static method in class org.axonframework.springboot.autoconfig.InfraConfiguration
-  
- SpringTransactionManager - Class in org.axonframework.spring.messaging.unitofwork
- 
TransactionManager implementation that uses a PlatformTransactionManageras
 underlying transaction manager.
 
- SpringTransactionManager(PlatformTransactionManager, TransactionDefinition) - Constructor for class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
-  
- SpringTransactionManager(PlatformTransactionManager) - Constructor for class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
- 
Initializes the SpringTransactionManager with the given transactionManagerand the default
 transaction definition.
 
- SpringUtils - Class in org.axonframework.spring
- 
Utility class for Spring specific helper functions. 
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.HsqlSagaSqlSchema
-  
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.Oracle11SagaSqlSchema
-  
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
-  
- sql_createTableAssocValueEntry(Connection) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that creates the table for storing Association Values for Sagas. 
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.Oracle11SagaSqlSchema
-  
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
-  
- sql_createTableSagaEntry(Connection) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that creates the table for storing Sagas. 
- sql_deleteAssociationEntries(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_deleteAssociationEntries(Connection, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that deletes all association entries for a Saga with given
 sagaIdentifier.
 
- sql_deleteSagaEntry(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_deleteSagaEntry(Connection, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that deletes a Saga with given sagaIdentifier.
 
- sql_findAssociations(Connection, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_findAssociations(Connection, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that finds the associations of a Saga of given sagaTypeand givensagaIdentifier.
 
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that finds identifiers of Sagas of given sagaTypeassociated with the
 given associationkeyandvalue.
 
- sql_loadSaga(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_loadSaga(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
-  
- sql_loadSaga(Connection, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that loads a single Saga, with given sagaId.
 
- sql_removeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_removeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that removes an association value for given sagaIdentifier, where the
 association is identified with givenkeyandvalue.
 
- sql_storeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_storeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that stores an association with given keyandvalue, for a
 Saga of giventypeandidentifier.
 
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that inserts a Saga entry, of given sagaTypeand with givensagaIdentifier.
 
- sql_updateSaga(Connection, String, byte[], String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-  
- sql_updateSaga(Connection, String, byte[], String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
- 
Creates a PreparedStatement that updates the serialized form of an existing Saga entry, of given
 sagaTypeand with givensagaIdentifier.
 
- SQLErrorCodesResolver - Class in org.axonframework.eventsourcing.eventstore.jpa
- 
SQLErrorCodesResolver is an implementation of PersistenceExceptionResolver used to resolve sql error codes to see if
 it is an duplicate key constraint violation. 
- SQLErrorCodesResolver(List<Integer>) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
- 
Initializes the SQLErrorCodesResolver using the given list of SQL Codes representing Key Constraint Violations. 
- SQLErrorCodesResolver(DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
- 
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource. 
- SQLErrorCodesResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
- 
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource. 
- SQLErrorCodesResolver(Properties, String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
- 
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource. 
- SQLErrorCodesResolver(Properties, DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
- 
Initialize the SQLErrorCodesResolver with the given propertiesand use thedataSourceto automatically retrieve the database product name.
 
- SQLErrorCodesResolver - Class in org.axonframework.eventsourcing.eventstore.legacyjpa
- 
- SQLErrorCodesResolver(List<Integer>) - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.SQLErrorCodesResolver
- 
Deprecated. Initializes the SQLErrorCodesResolver using the given list of SQL Codes representing Key Constraint Violations. 
- SQLErrorCodesResolver(DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.SQLErrorCodesResolver
- 
Deprecated. Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource. 
- SQLErrorCodesResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.SQLErrorCodesResolver
- 
Deprecated. Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource. 
- SQLErrorCodesResolver(Properties, String) - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.SQLErrorCodesResolver
- 
Deprecated. Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource. 
- SQLErrorCodesResolver(Properties, DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.legacyjpa.SQLErrorCodesResolver
- 
Deprecated. Initialize the SQLErrorCodesResolver with the given propertiesand use thedataSourceto automatically retrieve the database product name.
 
- sqlSchema(SagaSqlSchema) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
- 
- SQLStateResolver - Class in org.axonframework.eventsourcing.eventstore.jpa
- 
SQLStateResolver is an implementation of PersistenceExceptionResolver used to resolve sql state values to see if it
 violates a unique key constraint. 
- SQLStateResolver() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
- 
Constructor that uses the standard SQL state category for the check. 
- SQLStateResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
- 
Constructor that can be used to supply a specific SQL state code for the check. 
- ssl(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- stagedDomainEventMessages(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
- 
Returns a Stream of all DomainEventMessages that have been staged for publication by an Aggregate with given
 aggregateIdentifier.
 
- start() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
- 
- start() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
- 
- start() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler
- 
- start() - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
- 
Deprecated. Schedule a task that verifies that the connection is still alive and, if it is not, invoke a callback in order to
 react to the disconnection. 
- start() - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
- 
- start() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
- 
Start the Axon Server  QueryBus implementation. 
- start() - Method in interface org.axonframework.config.Configuration
- 
Starts this configuration. 
- start() - Method in interface org.axonframework.config.Configurer
- 
Builds the configuration and starts it immediately. 
- start() - Method in class org.axonframework.config.MessageHandlerRegistrar
- 
- start() - Method in interface org.axonframework.config.ModuleConfiguration
- 
- start() - Method in interface org.axonframework.eventhandling.EventProcessor
- 
Start processing events. 
- start() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- start() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
- 
Start this processor. 
- start() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Start this processor. 
- start() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-  
- start() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
- 
Starts the current unit of work. 
- start() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- start() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. 
- start() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- start() - Method in class org.axonframework.spring.config.SpringAxonConfiguration
-  
- start() - Method in class org.axonframework.tracing.NoOpSpanFactory.NoOpSpan
-  
- start() - Method in class org.axonframework.tracing.opentelemetry.OpenTelemetrySpan
-  
- start() - Method in interface org.axonframework.tracing.Span
- 
Starts the Span. 
- START_PHASE - Static variable in interface org.axonframework.messaging.HandlerAttributes
- 
Attribute key referencing the  Phase to invoke a start handler in. 
- startAndGet(T) - Static method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
- 
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork. 
- StartHandler - Annotation Type in org.axonframework.lifecycle
- 
Annotation indicating that a member method should be a part of the start cycle of an Axon application. 
- startProcessor() - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService.AxonProcessorInstructionHandler
-  
- startRecording() - Method in class org.axonframework.test.saga.CommandValidator
- 
Starts recording commands on the command bus. 
- startRecording() - Method in class org.axonframework.test.saga.EventValidator
- 
Starts recording event published by the event bus. 
- startRecording() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
- 
Tells this class to start monitoring activity in infrastructure classes. 
- startRecording() - Method in class org.axonframework.test.saga.RecordingListenerInvocationErrorHandler
- 
Start recording by clearing any current  Exception. 
- StartSaga - Annotation Type in org.axonframework.modelling.saga
- 
Indicates that the annotated  SagaEventHandler method can trigger the
 creation of a new Saga instance. 
- startScope() - Method in class org.axonframework.messaging.Scope
- 
- startSegmentWorkers() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
- 
Starts workers for a number of segments. 
- startTransaction() - Method in enum org.axonframework.common.transaction.NoTransactionManager
-  
- startTransaction() - Method in interface org.axonframework.common.transaction.TransactionManager
- 
Starts a transaction. 
- startTransaction() - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
-  
- state(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
- 
Asserts that the value of stateis true.
 
- stop() - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
- 
Shuts down the command bus. 
- stop() - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- stop(Runnable) - Method in class org.axonframework.spring.config.AxonConfiguration
- 
Deprecated. 
- stop(Runnable) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. 
- stop() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
- 
Deprecated. 
- stop(Runnable) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- stop() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
- 
Deprecated. 
- stop() - Method in class org.axonframework.spring.config.SpringAxonConfiguration
-  
- storageEngine(EventStorageEngine) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
-  
- storageEngine() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
-  
- storageEngine - Variable in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
-  
- storageEngine(EventStorageEngine) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
- 
- storageEngine() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
- 
- storageEngine(EventStorageEngine) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
-  
- storageEngine(EventStorageEngine) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore.Builder
- 
Deprecated. 
- store(String, CommandCallbackWrapper<E, C, R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
- 
Stores a callback 
- store() - Method in interface org.axonframework.config.SagaConfiguration
- 
Retrieve the  SagaStore in this Configuration. 
- storeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
- 
Stores the given associationValueof the saga with givensagaIdentifierandsagaType.
 
- storeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore
- 
Deprecated. Stores the given associationValueof the saga with givensagaIdentifierandsagaType.
 
- storeSaga(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
- 
Stores a newly created Saga instance. 
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-  
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
- 
Store the given snapshotof an Aggregate.
 
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-  
- storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
- 
Store an event that contains a snapshot of an aggregate. 
- storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
- 
Stores the given (temporary) snapshotevent.
 
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-  
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-  
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-  
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine
- 
Deprecated. 
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-  
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-  
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-  
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-  
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-  
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore
- 
Deprecated. 
- storeToken(TrackingToken, String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
- 
Stores the given tokenin the store.
 
- storeUpdate(Connection, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Returns a  PreparedStatement which updates the given  token for the given  processorName and
  segment combination. 
- storingTokensAfterProcessing() - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
- 
Set this processor to store Tracking Tokens only at the end of processing. 
- StreamableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
- 
Interface for a source of  messages that processors can track. 
- StreamingEventProcessor - Interface in org.axonframework.eventhandling
- 
- StreamingEventProcessorInfoMessage - Class in org.axonframework.axonserver.connector.processor
- 
- streamingQuery(StreamingQueryMessage<Q, R>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-  
- streamingQuery(String, Q, Class<R>) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
-  
- streamingQuery(StreamingQueryMessage<Q, R>) - Method in interface org.axonframework.queryhandling.QueryBus
- 
Builds a Publisherof responses to the givenquery.
 
- streamingQuery(Q, Class<R>) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus, expecting a response
 as  Publisher of  responseType. 
- streamingQuery(String, Q, Class<R>) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus, expecting a response
 as  Publisher of  responseType. 
- streamingQuery(StreamingQueryMessage<Q, R>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
-  
- StreamingQueryMessage<Q,R> - Interface in org.axonframework.queryhandling
- 
A special type of  QueryMessage used for initiating streaming queries. 
- StreamUtils - Class in org.axonframework.common.stream
- 
Utility class for working with Streams. 
- StringToByteArrayConverter - Class in org.axonframework.serialization.converters
- 
ContentTypeConverter that converts String into byte arrays. 
- StringToByteArrayConverter() - Constructor for class org.axonframework.serialization.converters.StringToByteArrayConverter
-  
- StringUtils - Class in org.axonframework.common
- 
Utility methods for when dealing with  Strings. 
- StubAggregateLifecycle - Class in org.axonframework.test.aggregate
- 
Stub implementation of an AggregateLifecycle that registers all applied events for verification later. 
- StubAggregateLifecycle() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycle
-  
- StubAggregateLifecycleExtension - Class in org.axonframework.test.aggregate
- 
Implementation of  StubAggregateLifecycle that can be used as an  RegisterExtension
 annotated method or field in a test class. 
- StubAggregateLifecycleExtension() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycleExtension
-  
- StubAggregateLifecycleRule - Class in org.axonframework.test.aggregate
- 
- StubAggregateLifecycleRule() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycleRule
- 
Deprecated. 
- StubDeadlineManager - Class in org.axonframework.test.deadline
- 
- StubDeadlineManager() - Constructor for class org.axonframework.test.deadline.StubDeadlineManager
- 
- StubDeadlineManager(TemporalAccessor) - Constructor for class org.axonframework.test.deadline.StubDeadlineManager
- 
Initializes the manager with provided currentDateTimeas current time.
 
- StubEventScheduler - Class in org.axonframework.test.eventscheduler
- 
EventScheduler implementation that uses it's own concept of "Current Time" for the purpose of testing. 
- StubEventScheduler() - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
- 
Creates an instance of the StubScheduler that uses the current date time as its conceptual "current time". 
- StubEventScheduler(TemporalAccessor) - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
- 
Creates an instance of the StubScheduler that uses the given currentDateTimeas its conceptual
 "current time".
 
- StubScheduleToken - Class in org.axonframework.test.eventscheduler
- 
ScheduleToken returned by the StubEventScheduler. 
- submit(Callable<T>) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- submit(Runnable, T) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- submit(Runnable) - Method in class org.axonframework.axonserver.connector.util.PriorityExecutorService
-  
- SubscribableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
- 
Interface for a source of  messages to which message processors can subscribe. 
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-  
- subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-  
- subscribe(CommandBus) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
- 
Subscribe this command handler to the given commandBus.
 
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.CommandBus
- 
Subscribe the given handlerto commands with the givencommandName.
 
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
- 
Subscribes a command message handler for commands with given commandName.
 
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
- 
Subscribe the given handlerto commands with the givencommandName.
 
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
- 
Subscribe the given handlerto commands with givencommandName.
 
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-  
- subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-  
- subscribe(Consumer<List<? extends M>>) - Method in interface org.axonframework.messaging.SubscribableMessageSource
- 
Subscribe the given messageProcessorto this message source.
 
- subscribe(CommandBus) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
- 
Subscribe this command handler to the given commandBus.
 
- subscribe(QueryBus) - Method in class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
-  
- subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in interface org.axonframework.queryhandling.QueryBus
- 
Subscribe the given handlerto queries with the givenqueryNameandresponseType.
 
- subscribe(QueryBus) - Method in interface org.axonframework.queryhandling.QueryHandlerAdapter
- 
- subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
-  
- subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
-  
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
-  
- subscribingEventProcessor(String, EventHandlerInvoker, SubscribableMessageSource<? extends EventMessage<?>>) - Method in class org.axonframework.config.EventProcessingModule
- 
- SubscribingEventProcessor - Class in org.axonframework.eventhandling
- 
- SubscribingEventProcessor(SubscribingEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
- 
- SubscribingEventProcessor.Builder - Class in org.axonframework.eventhandling
- 
- SubscriptionMessageSerializer - Class in org.axonframework.axonserver.connector.query.subscription
- 
- SubscriptionMessageSerializer(Serializer, Serializer, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
- 
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
- 
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, int) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-  
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
- 
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, int) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
-  
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>) - Method in interface org.axonframework.queryhandling.QueryBus
- 
Dispatch the given queryto a single QueryHandler subscribed to the givenquery's
 queryName/initialResponseType/updateResponseType.
 
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryBus
- 
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, int) - Method in interface org.axonframework.queryhandling.QueryBus
- 
Dispatch the given queryto a single QueryHandler subscribed to the givenquery's
 queryName/initialResponseType/updateResponseType.
 
- subscriptionQuery(Q, Class<I>, Class<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus and returns result containing initial response and
 incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
 the emitting side). 
- subscriptionQuery(String, Q, Class<I>, Class<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus and returns result containing initial response and
 incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
 the emitting side). 
- subscriptionQuery(Q, ResponseType<I>, ResponseType<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus and returns result containing initial response and
 incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
 the emitting side). 
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus and returns result containing initial response and
 incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
 the emitting side). 
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, int) - Method in interface org.axonframework.queryhandling.QueryGateway
- 
Sends given  query over the  QueryBus and returns result containing initial response and
 incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
 the emitting side). 
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.SimpleQueryBus
- 
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, int) - Method in class org.axonframework.queryhandling.SimpleQueryBus
-  
- SubscriptionQueryBackpressure - Class in org.axonframework.queryhandling
- 
- SubscriptionQueryBackpressure(FluxSink.OverflowStrategy) - Constructor for class org.axonframework.queryhandling.SubscriptionQueryBackpressure
- 
Deprecated. Initializes backpressure with reactor's overflow strategy. 
- SubscriptionQueryMessage<Q,I,U> - Interface in org.axonframework.queryhandling
- 
Message type that carries a Subscription Query: a request for information. 
- SubscriptionQueryResult<I,U> - Interface in org.axonframework.queryhandling
- 
Result of the subscription query. 
- SubscriptionQueryUpdateMessage<U> - Interface in org.axonframework.queryhandling
- 
Message which holds incremental update of an subscription query. 
- subset(String...) - Method in class org.axonframework.messaging.MetaData
- 
Returns a MetaData instance containing a subset of the keysin this instance.
 
- subtype(Class<? extends T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- subtype(Class<? extends T>) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
- 
- subtype(Class<? extends T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
-  
- subtype(Class<? extends T>) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. 
- subtype(Class<? extends T>) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
-  
- subtypes(Set<Class<? extends T>>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- subtypes - Variable in class org.axonframework.modelling.command.AbstractRepository.Builder
-  
- subtypes(Set<Class<? extends T>>) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
- 
- subtypes(Set<Class<? extends T>>) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
-  
- subtypes(Set<Class<? extends T>>) - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. 
- subtypes(Set<Class<? extends T>>) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
-  
- supplyException(String, long, long) - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictExceptionSupplier
- 
Creates an instance of an exception indicating a conflict in an aggregate with given aggregateIdentifier,
 the givenexpectedVersionandactualVersion.
 
- supplyException(ConflictDescription) - Method in interface org.axonframework.eventsourcing.conflictresolution.ContextAwareConflictExceptionSupplier
- 
Creates an instance of an exception indicating a conflict described by the given conflictDescription.
 
- supportedCommandNames() - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-  
- supportedCommandNames() - Method in interface org.axonframework.commandhandling.CommandMessageHandler
- 
Returns the set of command names this handler supports. 
- supportedCommandNames() - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
-  
- supportedPayloadType() - Method in interface org.axonframework.messaging.annotation.ParameterResolver
- 
Returns the class of the payload that is supported by this resolver. 
- supportedPayloadType() - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
-  
- supportsFormat(Class<T>) - Method in class org.axonframework.serialization.UnknownSerializedType
- 
Indicates whether the given desiredFormatis supported as a representation for this type.
 
- supportsReset() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-  
- supportsReset() - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
- 
Indicates whether the handlers managed by this invoker support a reset. 
- supportsReset() - Method in interface org.axonframework.eventhandling.EventMessageHandler
- 
Indicates whether the handlers managed by this invoker support a reset. 
- supportsReset() - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
-  
- supportsReset() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor
-  
- supportsReset() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-  
- supportsReset() - Method in interface org.axonframework.eventhandling.StreamingEventProcessor
- 
- supportsReset() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-  
- supportsReset() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-  
- supportsReset() - Method in interface org.axonframework.modelling.saga.Saga
-  
- suppressDownloadMessage() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-  
- suppressExceptionInGivenPhase(boolean) - Method in interface org.axonframework.test.saga.FixtureConfiguration
- 
Configure whether the fixture should suppress exceptions thrown during the given-phase. 
- suppressExceptionInGivenPhase(boolean) - Method in class org.axonframework.test.saga.SagaTestFixture
-  
- suspect() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-  
- suspect() - Method in interface org.axonframework.commandhandling.distributed.Member
- 
Mark this member as suspect, i.e. 
- suspect() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-  
- validate() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventScheduler.Builder
-  
- validate() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler.Builder
- 
Validate the fields. 
- validate() - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.commandhandling.SimpleCommandBus.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.deadline.jobrunr.JobRunrDeadlineManager.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.AbstractEventBus.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.AbstractEventProcessor.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.deadletter.DeadLetteringEventHandlerInvoker.Builder
- 
Validate whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.deadletter.jpa.JpaSequencedDeadLetterQueue.Builder
- 
Validate whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.deadletter.legacyjpa.JpaSequencedDeadLetterQueue.Builder
- 
Deprecated. Validate whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.pooled.PooledStreamingEventProcessor.Builder
-  
- validate() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.scheduling.jobrunr.JobRunrEventScheduler.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.SimpleEventBus.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.tokenstore.legacyjpa.JpaTokenStore.Builder
- 
Deprecated. Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-  
- validate() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.EmbeddedEventStore.Builder
- 
Deprecated. Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.eventstore.legacyjpa.JpaEventStorageEngine.Builder
- 
Deprecated. Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.eventsourcing.snapshotting.RevisionSnapshotFilter.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.messaging.deadletter.InMemorySequencedDeadLetterQueue.Builder
-  
- validate() - Method in class org.axonframework.metrics.MessageTimerMonitor.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.micrometer.EventProcessorLatencyMonitor.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.micrometer.MessageTimerMonitor.Builder
- 
Validate whether the fields contained in this Builder as set accordingly. 
- validate() - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
-  
- validate() - Method in class org.axonframework.modelling.command.legacyjpa.GenericJpaRepository.Builder
- 
Deprecated. 
- validate() - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate(String, MessageHandlingMember<T>) - Method in interface org.axonframework.modelling.saga.AssociationResolver
- 
Validates that the associationPropertyName supplied is compatible with the handler. 
- validate(String, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.MetaDataAssociationResolver
- 
Does nothing because we can only check for existence of property in the metadata during event handling. 
- validate(String, MessageHandlingMember<T>) - Method in class org.axonframework.modelling.saga.PayloadAssociationResolver
- 
Validates that the association property name exists as checked with the payload type. 
- validate() - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.modelling.saga.repository.legacyjpa.JpaSagaStore.Builder
- 
Deprecated. Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.queryhandling.DefaultQueryGateway.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.queryhandling.SimpleQueryBus.Builder
- 
Validate whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.serialization.JavaSerializer.Builder
- 
Deprecated. Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validate() - Method in class org.axonframework.tracing.NestingSpanFactory.Builder
- 
Validates whether the fields contained in this Builder are set accordingly. 
- validateMessage(Object, Validator) - Method in class org.axonframework.messaging.interceptors.BeanValidationInterceptor
- 
Validate the given messageusing the givenvalidator.
 
- validateMessage(Object, Validator) - Method in class org.axonframework.messaging.interceptors.legacyvalidation.BeanValidationInterceptor
- 
Deprecated. Validate the given messageusing the givenvalidator.
 
- validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-  
- validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-  
- validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.modelling.command.AbstractRepository
- 
Checks the aggregate for concurrent changes. 
- validatePositions() - Method in interface org.axonframework.eventhandling.EventTrackerStatusChangeListener
- 
- validateSegment(String, Segment) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
- 
Validate a segmentby checking for the existence of a split or merge candidate segment.
 
- valueOf(String) - Static method in enum org.axonframework.axonserver.connector.ErrorCode
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.common.lock.NullLockFactory
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.common.transaction.NoTransactionManager
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.eventhandling.DirectEventProcessingStrategy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.eventhandling.ReplayStatus
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.eventhandling.TrackingEventProcessor.State
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.messaging.unitofwork.RollbackConfigurationType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.modelling.command.AggregateCreationPolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.modelling.saga.repository.NoResourceInjector
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.modelling.saga.SagaCreationPolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.serialization.upcasting.event.NoOpEventUpcaster
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.spring.config.MessageHandlerConfigurer.Type
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.springboot.EventProcessorProperties.Mode
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.axonframework.springboot.SerializerProperties.SerializerType
- 
Returns the enum constant of this type with the specified name. 
- values() - Static method in enum org.axonframework.axonserver.connector.ErrorCode
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.common.lock.NullLockFactory
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.common.transaction.NoTransactionManager
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.eventhandling.DirectEventProcessingStrategy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.eventhandling.ReplayStatus
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.eventhandling.TrackingEventProcessor.State
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.eventsourcing.conflictresolution.NoConflictResolver
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Method in class org.axonframework.messaging.MetaData
-  
- values() - Static method in enum org.axonframework.messaging.unitofwork.RollbackConfigurationType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.modelling.command.AggregateCreationPolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.modelling.saga.repository.NoResourceInjector
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.modelling.saga.SagaCreationPolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.serialization.upcasting.event.NoOpEventUpcaster
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.spring.config.MessageHandlerConfigurer.Type
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.springboot.EventProcessorProperties.Mode
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.axonframework.springboot.SerializerProperties.SerializerType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- version() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
- 
Returns the version of this consistent hash instance. 
- version() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-  
- version() - Method in interface org.axonframework.modelling.command.Aggregate
- 
Get the aggregate's version. 
- version() - Method in class org.axonframework.modelling.command.AggregateLifecycle
- 
Gets the version of the aggregate. 
- version() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-  
- version() - Method in class org.axonframework.modelling.command.LockAwareAggregate
-  
- version() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-  
- VersionedAggregateIdentifier - Class in org.axonframework.modelling.command
- 
Structure that holds an Aggregate Identifier and an expected version of an aggregate. 
- VersionedAggregateIdentifier(String, Long) - Constructor for class org.axonframework.modelling.command.VersionedAggregateIdentifier
- 
- VersionedAggregateIdentifier(Object, Long) - Constructor for class org.axonframework.modelling.command.VersionedAggregateIdentifier
- 
Initializes a VersionedAggregateIdentifier with the given identifierandversion.