- AbstractAggregateFactory<T> - Class in org.axonframework.eventsourcing
-
Abstract AggregateFactory implementation that is aware of snapshot events.
- AbstractAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
-
Initialize an aggregateFactory for the given aggregateBaseType
.
- AbstractAnnotatedParameterResolverFactory<A extends Annotation,P> - Class in org.axonframework.messaging.annotation
-
ParameterResolverFactory that will supply a parameter resolver when a matching parameter annotation is paired
with a suitable type of parameter.
- AbstractAnnotatedParameterResolverFactory(Class<A>, Class<P>) - Constructor for class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-
Initialize a ParameterResolverFactory instance that resolves parameters of type
declaredParameterType
annotated with the given annotationType
.
- AbstractCacheAdapter<L> - Class in org.axonframework.common.caching
-
Abstract implementation of the Cache interface which makes it easier to implement Adapters.
- AbstractCacheAdapter() - Constructor for class org.axonframework.common.caching.AbstractCacheAdapter
-
- AbstractCommandGateway - Class in org.axonframework.commandhandling.gateway
-
Abstract implementation of a CommandGateway, which handles the dispatch interceptors and retrying on failure.
- AbstractCommandGateway(CommandBus, RetryScheduler, List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Constructor for class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Initialize the AbstractCommandGateway with given commandBus
, retryScheduler
and
commandDispatchInterceptors
.
- AbstractDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
-
Abstract base class of a serialized domain event.
- AbstractDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
-
Construct a new event entry from a published domain event message to enable storing the event or sending it to a
remote location.
- AbstractDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
-
Reconstruct an event entry from a stored object.
- AbstractDomainEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
-
Default constructor required by JPA
- AbstractEventBus - Class in org.axonframework.eventhandling
-
Base class for the Event Bus.
- AbstractEventBus() - Constructor for class org.axonframework.eventhandling.AbstractEventBus
-
- AbstractEventBus(MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.AbstractEventBus
-
Initializes an event bus.
- AbstractEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
-
Abstract base class of a serialized event.
- AbstractEventEntry(EventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
-
Construct a new event entry from a published event message to enable storing the event or sending it to a remote
location.
- AbstractEventEntry(String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
-
Reconstruct an event entry from a stored object.
- AbstractEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
-
Default constructor required by JPA
- AbstractEventProcessor - Class in org.axonframework.eventhandling
-
- AbstractEventProcessor(String, EventHandlerInvoker, RollbackConfiguration, ErrorHandler, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.AbstractEventProcessor
-
Initializes an event processor with given name
.
- AbstractEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
-
Abstract event storage implementation that takes care of event serialization and upcasting.
- AbstractEventStorageEngine(Serializer, EventUpcaster, PersistenceExceptionResolver) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Initializes an EventStorageEngine with given serializer
, upcasterChain
and persistenceExceptionResolver
.
- AbstractEventStore - Class in org.axonframework.eventsourcing.eventstore
-
- AbstractEventStore(EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- AbstractEventStore(EventStorageEngine, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
Initializes an event store with given storageEngine
and messageMonitor
.
- AbstractEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
-
Abstract implementation of an
EventTableFactory
that provides Jdbc "create table" statements compatible
with most databases.
- AbstractEventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
- AbstractMessage<T> - Class in org.axonframework.messaging
-
Abstract base class for Messages.
- AbstractMessage(String) - Constructor for class org.axonframework.messaging.AbstractMessage
-
Initializes a new message with given identifier.
- AbstractMethodPropertyAccessStrategy - Class in org.axonframework.common.property
-
Abstract implementation of the PropertyAccessStrategy that uses a no-arg, public method to access the property
value.
- AbstractMethodPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-
- AbstractRepository<T,A extends Aggregate<T>> - Class in org.axonframework.commandhandling.model
-
Abstract implementation of the
Repository
that takes care of the dispatching of events when an aggregate is
persisted.
- AbstractRepository(Class<T>) - Constructor for class org.axonframework.commandhandling.model.AbstractRepository
-
Initializes a repository that stores aggregate of the given aggregateType
.
- AbstractRepository(Class<T>, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.model.AbstractRepository
-
Initializes a repository that stores aggregate of the given aggregateType
.
- AbstractResourceInjector - Class in org.axonframework.eventhandling.saga
-
Abstract implementation of a
ResourceInjector
for sagas that injects field and method resources.
- AbstractResourceInjector() - Constructor for class org.axonframework.eventhandling.saga.AbstractResourceInjector
-
- AbstractRoutingStrategy - Class in org.axonframework.commandhandling.distributed
-
Abstract implementation of the RoutingStrategy interface that uses a policy to prescribe what happens when a routing
cannot be resolved.
- AbstractRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
-
Initializes the strategy using given unresolvedRoutingKeyPolicy
prescribing what happens when a
routing key cannot be resolved.
- AbstractSagaManager<T> - Class in org.axonframework.eventhandling.saga
-
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager
implementations.
- AbstractSagaManager(Class<T>, SagaRepository<T>, Supplier<T>) - Constructor for class org.axonframework.eventhandling.saga.AbstractSagaManager
-
Initializes the SagaManager with the given sagaRepository
.
- AbstractSequencedDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
-
Abstract base class of a serialized domain event.
- AbstractSequencedDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSequencedDomainEventEntry
-
Construct a new default domain event entry from a published domain event message to enable storing the event or
sending it to a remote location.
- AbstractSequencedDomainEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSequencedDomainEventEntry
-
Default constructor required by JPA
- AbstractSnapshotEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
-
Abstract base class of a serialized snapshot event storing the state of an aggregate.
- AbstractSnapshotEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
Construct a new event entry from a published domain event message to enable storing the event or sending it to a
remote location.
- AbstractSnapshotEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
Reconstruct an event entry from a stored object.
- AbstractSnapshotEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
Default constructor required by JPA
- AbstractSnapshotEventEntry.PK - Class in org.axonframework.eventsourcing.eventstore
-
Primary key definition of the AbstractEventEntry class.
- AbstractSnapshotter - Class in org.axonframework.eventsourcing
-
Abstract implementation of the
Snapshotter
that uses a task executor to
creates snapshots.
- AbstractSnapshotter(EventStore) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
-
Initializes the Snapshotter to append snapshots in the given eventStore
.
- AbstractSnapshotter(EventStore, TransactionManager) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
-
Initializes the Snapshotter to append snapshots in the given eventStore
.
- AbstractSnapshotter(EventStore, Executor, TransactionManager) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
-
Initializes the Snapshotter to append snapshots in the given eventStore
.
- AbstractTokenEntry<T> - Class in org.axonframework.eventhandling.tokenstore
-
Abstract base class of a JPA entry containing a serialized tracking token belonging to a given process.
- AbstractTokenEntry(TrackingToken, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Initializes a new token entry for given token
, process
and segment
.
- AbstractTokenEntry(T, String, String, String) - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Initializes a token entry from existing data.
- AbstractTokenEntry() - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Default constructor required for JPA
- AbstractUnitOfWork<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
-
Abstract implementation of the Unit of Work.
- AbstractUnitOfWork() - Constructor for class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- AbstractXStreamSerializer - Class in org.axonframework.serialization
-
Abstract implementation for XStream based serializers.
- AbstractXStreamSerializer(XStream) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
-
Initialize a generic serializer using the UTF-8 character set.
- AbstractXStreamSerializer(XStream, RevisionResolver) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
-
Initialize a generic serializer using the UTF-8 character set.
- AbstractXStreamSerializer(Charset, XStream) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
-
Initialize the serializer using the given charset
and xStream
instance.
- AbstractXStreamSerializer(Charset, XStream, RevisionResolver) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
-
Initialize the serializer using the given charset
and xStream
instance.
- AbstractXStreamSerializer(Charset, XStream, RevisionResolver, Converter) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
-
Initialize the serializer using the given charset
, xStream
instance,
revisionResolver
and converter
.
- AcceptAll - Enum in org.axonframework.commandhandling.distributed.commandfilter
-
A command filter that accepts all CommandMessages
- add(AssociationValue) - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
Adds the given associationValue
, if it has not been previously added.
- add(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- add(AssociationValue, String, String) - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
-
Adds an association between the given associationValue
and sagaIdentifier
.
- addAlias(String, Class) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Adds an alias to use instead of the fully qualified class name.
- addCachedAssociations(Iterable<AssociationValue>, String, Class<?>) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
-
Registers the associations of a saga with given sagaIdentifier
and given sagaType
with the
associations cache.
- addedAssociations() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
- addedAssociations() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- addFieldAlias(String, Class, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Adds an alias to use for a given field in the given class.
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Register the given handler
with the Unit of Work.
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Adds a handler to the collection.
- addPackageAlias(String, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Add an alias for a package.
- advanceTo(long, int) - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
-
- afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
Process given events
after the Unit of Work has been committed.
- afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.SimpleEventBus
-
- afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-
- afterCommit(Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- afterCommit(Consumer<UnitOfWork<T>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Register given handler
with the Unit of Work.
- afterShutdown(EventProcessorTask) - Method in interface org.axonframework.eventhandling.async.EventProcessorTask.ShutdownCallback
-
Called when event processing is complete.
- Aggregate<T> - Interface in org.axonframework.commandhandling.model
-
Interface that describes an aggregate.
- AggregateAnnotationCommandHandler<T> - Class in org.axonframework.commandhandling
-
Command handler that handles commands based on
CommandHandler
annotations on an aggregate.
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>) - Constructor for class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
-
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType
, using the
given repository
to add and load aggregate instances.
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandTargetResolver) - Constructor for class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
-
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType
, using the
given repository
to add and load aggregate instances and the default ParameterResolverFactory.
- AggregateAnnotationCommandHandler(Class<T>, Repository<T>, CommandTargetResolver, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
-
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType
, using the
given repository
to add and load aggregate instances and the given
parameterResolverFactory
.
- AggregateAnnotationCommandHandler(Repository<T>, CommandTargetResolver, AggregateModel<T>) - Constructor for class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
-
Initializes an AnnotationCommandHandler based on the annotations on given aggregateType
, using the
given repository
to add and load aggregate instances and the given
parameterResolverFactory
.
- AggregateBlacklistedException - Exception in org.axonframework.commandhandling.disruptor
-
Exception indicating that an aggregate has been blacklisted by the DisruptorCommandBus.
- AggregateBlacklistedException(String, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateBlacklistedException
-
Initializes the exception with given aggregateIdentifier
, given explanatory message
and cause
.
- AggregateConfiguration<A> - Interface in org.axonframework.config
-
Specialization of the Module Configuration for modules that define an Aggregate Configuration.
- AggregateConfigurer<A> - Class in org.axonframework.config
-
Axon Configuration API extension that allows the definition of an Aggregate.
- AggregateConfigurer(Class<A>) - Constructor for class org.axonframework.config.AggregateConfigurer
-
- AggregateDeletedException - Exception in org.axonframework.eventsourcing
-
Special case of the
AggregateNotFoundException
that indicates that historic
information of an aggregate was found, but the aggregate has been deleted.
- AggregateDeletedException(String, String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
-
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier
and
given message
.
- AggregateDeletedException(String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
-
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier
and
a default message
.
- AggregateFactory<T> - Interface in org.axonframework.eventsourcing
-
Interface describing objects capable of creating instances of aggregates to be initialized with an event stream.
- AggregateIdentifier - Annotation Type in org.axonframework.commandhandling.model
-
Field annotation that identifies the field containing the identifier of the Aggregate.
- aggregateIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the aggregate identifier of the event.
- AggregateInvocationException - Exception in org.axonframework.commandhandling.model
-
Exception thrown when an invocation on a method of an aggregate gives rise to an exception.
- AggregateInvocationException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.AggregateInvocationException
-
Initializes the exception using the given message
and cause
.
- AggregateLifecycle - Class in org.axonframework.commandhandling.model
-
Abstract base class of a component that models an aggregate's life cycle.
- AggregateLifecycle() - Constructor for class org.axonframework.commandhandling.model.AggregateLifecycle
-
- AggregateMember - Annotation Type in org.axonframework.commandhandling.model
-
Marker annotation for a field that references one or more Entities capable of handling Commands or Events.
- AggregateMemberAnnotatedChildEntityCollectionDefinition - Class in org.axonframework.commandhandling.model.inspection
-
- AggregateMemberAnnotatedChildEntityCollectionDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-
- AggregateMemberAnnotatedChildEntityDefinition - Class in org.axonframework.commandhandling.model.inspection
-
- AggregateMemberAnnotatedChildEntityDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityDefinition
-
- AggregateMemberAnnotatedChildEntityMapDefinition - Class in org.axonframework.commandhandling.model.inspection
-
- AggregateMemberAnnotatedChildEntityMapDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
-
- aggregateModel() - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Returns the aggregate model stored by this repository.
- AggregateModel<T> - Interface in org.axonframework.commandhandling.model.inspection
-
Specialized EntityModel that describes the capabilities and properties of an aggregate root of type T
.
- AggregateNotFoundException - Exception in org.axonframework.commandhandling.model
-
Exception indicating that the an aggregate could not be found in the repository.
- AggregateNotFoundException(String, String) - Constructor for exception org.axonframework.commandhandling.model.AggregateNotFoundException
-
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier
and given message
.
- AggregateNotFoundException(String, String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.AggregateNotFoundException
-
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier
and
with the given message
and cause
.
- AggregateRoot - Annotation Type in org.axonframework.commandhandling.model
-
Annotation placed on types that should be treated as the root of an aggregate.
- AggregateSnapshotter - Class in org.axonframework.eventsourcing
-
Implementation of a snapshotter that uses the actual aggregate and its state to create a snapshot event.
- AggregateSnapshotter(EventStore, AggregateFactory<?>...) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
-
Initializes a snapshotter using the ParameterResolverFactory instances available on the classpath.
- AggregateSnapshotter(EventStore, List<AggregateFactory<?>>) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
-
Initializes a snapshotter using the ParameterResolverFactory instances available on the classpath.
- AggregateSnapshotter(EventStore, List<AggregateFactory<?>>, ParameterResolverFactory) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
-
Initializes a snapshotter using the given parameterResolverFactory
.
- AggregateSnapshotter(EventStore, List<AggregateFactory<?>>, ParameterResolverFactory, Executor, TransactionManager) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
-
Initializes a snapshotter that stores snapshots using the given executor
.
- AggregateStateCorruptedException - Exception in org.axonframework.commandhandling.disruptor
-
Exception indicating that the changes in an aggregate (generated events) are ignored by the DisruptorCommandBus,
because it cannot guarantee that these changes have been applied to an aggregate instance with the correct state.
- AggregateStateCorruptedException(String, String) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
-
Initializes the exception with given aggregateIdentifier
and given explanatory
message
.
- AggregateStateCorruptedException(String, String, Throwable) - Constructor for exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
-
Initializes the exception with given aggregateIdentifier
, given explanatory message
and cause
.
- aggregateType() - Method in interface org.axonframework.config.AggregateConfiguration
-
Returns the type of Aggregate defined in this Configuration.
- aggregateType() - Method in class org.axonframework.config.AggregateConfigurer
-
- AggregateVersion - Annotation Type in org.axonframework.commandhandling.model
-
Field annotation that indicates the field contains the value that represents the version of the Aggregate, used for
optimistic locking, as well as state validation for commands.
- and(Predicate<? super CommandMessage<?>>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
-
- and(Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-
- and(Predicate<? super CommandMessage<?>>) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
-
- and(Predicate<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
-
- and(String, Object) - Method in class org.axonframework.messaging.MetaData
-
Returns a MetaData instances containing the current entries, and the given key
and given
value
.
- andIfNotPresent(String, Supplier<Object>) - Method in class org.axonframework.messaging.MetaData
-
Returns a MetaData instances containing the current entries, and the given key
if it was
not yet present in this MetaData.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandMessage
-
Returns a copy of this CommandMessage with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.EventMessage
-
Returns a copy of this EventMessage with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericEventMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventsourcing.DomainEventMessage
-
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.AbstractMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.Message
-
Returns a copy of this Message with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.serialization.SerializedMessage
-
- andThen(Runnable) - Method in interface org.axonframework.commandhandling.model.ApplyMore
-
Execute the given runnable
after applying the previous event.
- andThen(Runnable) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- andThenApply(Supplier<?>) - Method in interface org.axonframework.commandhandling.model.ApplyMore
-
Apply a subsequent event to the aggregate after applying another event.
- andThenApply(Supplier<?>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- AnnotatedAggregate<T> - Class in org.axonframework.commandhandling.model.inspection
-
Implementation of the
Aggregate
interface that allows for an aggregate root to be a POJO with annotations on
its Command and Event Handler methods.
- AnnotatedAggregate(T, AggregateModel<T>, EventBus) - Constructor for class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Initialize an Aggregate instance for the given aggregateRoot
, described by the given
aggregateModel
that will publish events to the given eventBus
.
- AnnotatedAggregate(AggregateModel<T>, EventBus) - Constructor for class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Initialize an Aggregate instance for the given aggregateRoot
, described by the given
aggregateModel
that will publish events to the given eventBus
.
- AnnotatedChildEntity<P,C> - Class in org.axonframework.commandhandling.model.inspection
-
Implementation of a
ChildEntity
that uses annotations on a target entity to resolve event and command
handlers.
- AnnotatedChildEntity(EntityModel<C>, boolean, boolean, BiFunction<CommandMessage<?>, P, C>, BiFunction<EventMessage<?>, P, Iterable<C>>) - Constructor for class org.axonframework.commandhandling.model.inspection.AnnotatedChildEntity
-
Initiates a new AnnotatedChildEntity instance that uses the provided entityModel
to delegate command
and event handling to an annotated child entity.
- AnnotatedHandlerInspector<T> - Class in org.axonframework.messaging.annotation
-
Inspector for a message handling target of type T
that uses annotations on the target to inspect the
capabilities of the target.
- AnnotatedMessageHandlingMember<T> - Class in org.axonframework.messaging.annotation
-
Implementation of a
MessageHandlingMember
that is used to invoke message handler methods on the target type.
- AnnotatedMessageHandlingMember(Executable, Class<? extends Message>, Class<?>, ParameterResolverFactory) - Constructor for class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
Initializes a new instance that will invoke the given executable
(method) on a target to handle a message
of the given messageType
.
- AnnotatedMessageHandlingMemberDefinition - Class in org.axonframework.messaging.annotation
-
The default HandlerDefinition implementation in Axon.
- AnnotatedMessageHandlingMemberDefinition() - Constructor for class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
-
- AnnotatedSaga<T> - Class in org.axonframework.eventhandling.saga
-
Implementation of the
interface
that allows for a POJO instance with annotated message handlers to act
as a Saga.
- AnnotatedSaga(String, Set<AssociationValue>, T, TrackingToken, SagaModel<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSaga
-
Creates an AnnotatedSaga instance to wrap the given annotatedSaga
, identifier with the given
sagaId
and associated with the given associationValues
.
- AnnotatedSagaManager<T> - Class in org.axonframework.eventhandling.saga
-
Implementation of the SagaManager that uses annotations on the Sagas to describe the lifecycle management.
- AnnotatedSagaManager(Class<T>, SagaRepository<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSagaManager
-
Initialize the AnnotatedSagaManager using given repository
to load sagas.
- AnnotatedSagaManager(Class<T>, SagaRepository<T>, Supplier<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSagaManager
-
Initialize the AnnotatedSagaManager using given repository
to load sagas and sagaFactory
to
create new sagas.
- AnnotatedSagaManager(Class<T>, SagaRepository<T>, Supplier<T>, SagaModel<T>) - Constructor for class org.axonframework.eventhandling.saga.AnnotatedSagaManager
-
Initialize the AnnotatedSagaManager using given repository
to load sagas, the sagaFactory
to
create new sagas and the sagaMetaModel
to delegate messages to the saga instances.
- AnnotatedSagaRepository<T> - Class in org.axonframework.eventhandling.saga.repository
-
Abstract implementation for saga repositories.
- AnnotatedSagaRepository(Class<T>, SagaStore<? super T>) - Constructor for class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
Initializes an AnnotatedSagaRepository for given sagaType
that stores sagas in the given sagaStore
.
- AnnotatedSagaRepository(Class<T>, SagaStore<? super T>, ResourceInjector) - Constructor for class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
Initializes an AnnotatedSagaRepository for given sagaType
that stores sagas in the given sagaStore
.
- AnnotatedSagaRepository(Class<T>, SagaStore<? super T>, SagaModel<T>, ResourceInjector, LockFactory) - Constructor for class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
Initializes an AnnotatedSagaRepository for given sagaType
that stores sagas in the given sagaStore
.
- annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
- annotationAttributes(Class<? extends Annotation>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
-
Get the attributes of an annotation of given annotationType
on the method of the target entity.
- annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-
- AnnotationCommandHandlerAdapter - Class in org.axonframework.commandhandling
-
- AnnotationCommandHandlerAdapter(Object) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
Wraps the given annotatedCommandHandler
, allowing it to be subscribed to a Command Bus.
- AnnotationCommandHandlerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
Wraps the given annotatedCommandHandler
, allowing it to be subscribed to a Command Bus.
- AnnotationCommandTargetResolver - Class in org.axonframework.commandhandling
-
CommandTargetResolver that uses annotations on the command to identify the methods that provide the
Aggregate Identifier of the targeted Aggregate and optionally the expected version of the aggregate.
- AnnotationCommandTargetResolver() - Constructor for class org.axonframework.commandhandling.AnnotationCommandTargetResolver
-
- AnnotationEventListenerAdapter - Class in org.axonframework.eventhandling
-
- AnnotationEventListenerAdapter(Object) - Constructor for class org.axonframework.eventhandling.AnnotationEventListenerAdapter
-
Wraps the given annotatedEventListener
, allowing it to be subscribed to an Event Bus.
- AnnotationEventListenerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.AnnotationEventListenerAdapter
-
Wraps the given annotatedEventListener
, allowing it to be subscribed to an Event Bus.
- AnnotationRevisionResolver - Class in org.axonframework.serialization
-
Revision Resolver implementation that checks for the presence of an
@Revision
annotation.
- AnnotationRevisionResolver() - Constructor for class org.axonframework.serialization.AnnotationRevisionResolver
-
- AnnotationRoutingStrategy - Class in org.axonframework.commandhandling.distributed
-
- AnnotationRoutingStrategy() - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that fails when an incoming command does not define an AggregateIdentifier to
base the routing key on.
- AnnotationRoutingStrategy(Class<? extends Annotation>) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier.
- AnnotationRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that uses the given unresolvedRoutingKeyPolicy
when an incoming
command does not define an AggregateIdentifier to base the routing key on.
- AnnotationRoutingStrategy(Class<? extends Annotation>, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier and the given
unresolvedRoutingKeyPolicy
when an incoming command does not define an AggregateIdentifier to base
the routing key on.
- AnnotationUtils - Class in org.axonframework.common.annotation
-
Utility class for locating annotations and attribute values on elements.
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Append given events
to the backing database.
- appendEvents(EventMessage<?>...) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Append one or more events to the event storage.
- appendEvents(List<? extends EventMessage<?>>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Append a list of events to the event storage.
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- appendSnapshot(Connection, DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Creates a statement to append the given snapshot
to the event storage using given connection
to
the database.
- apply(Object, MetaData) - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Apply a
DomainEventMessage
with given payload and metadata (metadata from interceptors will be combined
with the provided metadata).
- apply(Object) - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Apply a
DomainEventMessage
with given payload without metadata (though interceptors can also be used to
provide metadata).
- apply(Connection) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlFunction
-
- apply(ResultSet) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlResultConverter
-
Convert the given resultSet to a result of type R
.
- applyMessageOrPayload(Object) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Apply a new event message to the aggregate and then publish this message to external systems.
- ApplyMore - Interface in org.axonframework.commandhandling.model
-
Interface that describes a mechanism that enables the application of an additional event after another event is
applied.
- asCommandMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandMessage
-
Returns the given command as a CommandMessage.
- asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
-
- asEventMessage(Object) - Static method in class org.axonframework.eventhandling.GenericEventMessage
-
Returns the given event as an EventMessage.
- Assert - Class in org.axonframework.common
-
Utility class (inspired by Springs Assert class) for doing assertions on parameters and object state.
- asSet() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
Returns this instance as a Set of Association Values.
- asSet() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- assignHandlersMatching(String, Predicate<Object>) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Configures a rule to assign Event Handler beans that match the given criteria
to the Event Processor
with given name
, with neutral priority (value 0).
- assignHandlersMatching(String, int, Predicate<Object>) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Configures a rule to assign Event Handler beans that match the given criteria
to the Event Processor
with given name
, with given priority
.
- associateWith(String, String) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
Registers a AssociationValue with the currently active saga.
- associateWith(String, Number) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
Registers a AssociationValue with the currently active saga.
- associateWith(AssociationValue) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
Registers a AssociationValue with the currently active saga.
- AssociationValue - Class in org.axonframework.eventhandling.saga
-
A combination of key and value by which a Saga can be found.
- AssociationValue(String, String) - Constructor for class org.axonframework.eventhandling.saga.AssociationValue
-
Creates a Association Value instance with the given key
and value
.
- AssociationValueEntry - Class in org.axonframework.eventhandling.saga.repository.jpa
-
JPA wrapper around an Association Value.
- AssociationValueEntry(String, String, AssociationValue) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
-
Initialize a new AssociationValueEntry for a saga with given sagaIdentifier
and
associationValue
.
- AssociationValueEntry() - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
-
Constructor required by JPA.
- associationValueEntryTable() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
-
Returns the name of the associationValueEntry table
- AssociationValueMap - Class in org.axonframework.eventhandling.saga.repository
-
In-memory storage for AssociationValue to Saga mappings.
- AssociationValueMap() - Constructor for class org.axonframework.eventhandling.saga.repository.AssociationValueMap
-
Initializes a new and empty AssociationValueMap.
- AssociationValues - Interface in org.axonframework.eventhandling.saga
-
- associationValues() - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore.Entry
-
Returns the Set of association values of the fetched Saga entry.
- AssociationValuesImpl - Class in org.axonframework.eventhandling.saga
-
Default implementation of the AssociationValues interface.
- AssociationValuesImpl() - Constructor for class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
Initializes a new AssociationValues object without initial associations.
- AssociationValuesImpl(Set<AssociationValue>) - Constructor for class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
Initializes a new AssociationValues object with given initial associations.
- asStream() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
Returns this DomainEventStream as a
Stream
of DomainEventMessages.
- asStream(DomainEventStream) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
-
Convert the given
domainEventStream
to a regular java
Stream
of domain event messages.
- asStream() - Method in interface org.axonframework.messaging.MessageStream
-
Returns this MessageStream as a
Stream
of Messages.
- asStream(MessageStream<M>) - Static method in class org.axonframework.messaging.StreamUtils
-
Convert the given
messageStream
to a regular java
Stream
of messages.
- asTrackedEventMessage(EventMessage<T>, TrackingToken) - Static method in class org.axonframework.eventsourcing.eventstore.EventUtils
-
- AsynchronousCommandBus - Class in org.axonframework.commandhandling
-
Specialization of the SimpleCommandBus that processed Commands asynchronously from the calling thread.
- AsynchronousCommandBus() - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
-
Initialize the AsynchronousCommandBus, using a Cached Thread Pool.
- AsynchronousCommandBus(Executor) - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
-
Initialize the AsynchronousCommandBus using the given executor
.
- AsynchronousEventProcessingStrategy - Class in org.axonframework.eventhandling.async
-
- 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.
- awaitCompletion(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Wait for completion of the command, or for the timeout to expire.
- AxonConfigurationException - Exception in org.axonframework.common
-
Exception indicating that a configuration error has been made in the Axon configuration.
- AxonConfigurationException(String) - Constructor for exception org.axonframework.common.AxonConfigurationException
-
Initializes the exception using the given message
.
- AxonConfigurationException(String, Throwable) - Constructor for exception org.axonframework.common.AxonConfigurationException
-
Initializes the exception using the given message
and cause
.
- AxonException - Exception in org.axonframework.common
-
Base exception of all Axon Framework related exceptions.
- AxonException(String) - Constructor for exception org.axonframework.common.AxonException
-
Initializes the exception using the given message
.
- AxonException(String, Throwable) - Constructor for exception org.axonframework.common.AxonException
-
Initializes the exception using the given message
and cause
.
- AxonNonTransientException - Exception in org.axonframework.common
-
Exception indicating an error has been cause that cannot be resolved without intervention.
- AxonNonTransientException(String) - Constructor for exception org.axonframework.common.AxonNonTransientException
-
Initializes the exception using the given message
.
- AxonNonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonNonTransientException
-
Initializes the exception using the given message
and cause
.
- AxonThreadFactory - Class in org.axonframework.common
-
Thread factory that created threads in a given group.
- AxonThreadFactory(String) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that creates each thread in a group with given groupName
with
default priority.
- AxonThreadFactory(ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that create each thread in the given group
with default
priority.
- AxonThreadFactory(int, ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that create each thread in the given group
with given
priority
.
- AxonTransientException - Exception in org.axonframework.common
-
Exception indicating an error occurred that might be resolved by retrying the operation that caused the exception.
- AxonTransientException(String) - Constructor for exception org.axonframework.common.AxonTransientException
-
Initializes the exception using the given message
.
- AxonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonTransientException
-
Initializes the exception using the given message
and cause
.
- Cache - Interface in org.axonframework.common.caching
-
Abstraction for a Caching mechanism.
- Cache.EntryListener - Interface in org.axonframework.common.caching
-
Interface describing callback methods, which are invoked when changes are made in the underlying cache.
- Cache.EntryListenerAdapter - Class in org.axonframework.common.caching
-
Adapter implementation for the EntryListener, allowing for overriding only specific callback methods.
- CachingEventSourcingRepository<T> - Class in org.axonframework.eventsourcing
-
Implementation of the event sourcing repository that uses a cache to improve loading performance.
- CachingEventSourcingRepository(AggregateFactory<T>, EventStore, Cache) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Initializes a repository with a the given aggregateFactory
and a pessimistic locking strategy.
- CachingEventSourcingRepository(AggregateFactory<T>, EventStore, Cache, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Initializes a repository with a the given aggregateFactory
and a pessimistic locking strategy.
- CachingEventSourcingRepository(AggregateFactory<T>, EventStore, LockFactory, Cache, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Initializes a repository with a the given aggregateFactory
and a pessimistic locking strategy.
- CachingEventSourcingRepository(AggregateFactory<T>, EventStore, LockFactory, Cache, ParameterResolverFactory, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Initializes a repository with a the given aggregateFactory
and a pessimistic locking strategy.
- CachingSagaStore<T> - Class in org.axonframework.eventhandling.saga.repository
-
Saga Repository implementation that adds caching behavior to the repository it wraps.
- CachingSagaStore(SagaStore<T>, Cache, Cache) - Constructor for class org.axonframework.eventhandling.saga.repository.CachingSagaStore
-
Initializes an instance delegating to the given delegate
, storing associations in the given
associationsCache
and Saga instances in the given sagaCache
.
- CachingSupplier<T> - Class in org.axonframework.serialization
-
A Supplier that caches its result, useful if the supplier operation is expensive and expected to always yield the
same result.
- calculateChain(Class<S>, Class<T>, Collection<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serialization.ChainedConverter
-
Returns a converter that can convert an IntermediateRepresentation from the given sourceType
to the
given targetType
using a chain formed with given candidates
.
- callbacks() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
Returns the callbacks mapped by callback identifier.
- cancel() - Method in interface org.axonframework.common.Registration
-
Cancels this Registration.
- cancelCallbacks(A) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
Removes all callbacks for a given channel.
- cancelSchedule(ScheduleToken) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Cancel the publication of a scheduled event.
- cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- canConvert(Class<S>, Class<T>, List<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serialization.ChainedConverter
-
Indicates whether this converter is capable of converting the given sourceContentType
into
targetContentType
, using the given converters
.
- canConvert(Class<?>, Class<?>) - Method in class org.axonframework.serialization.ChainingConverter
-
- canConvert(Class<?>, Class<?>) - Method in interface org.axonframework.serialization.Converter
-
Indicates whether this converter is capable of converting the given sourceType
to the targetType
.
- canHandle(Message<?>) - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- canHandle(Message<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
- canHandle(Message<?>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
-
Checks if this handler is capable of handling the given message
.
- canHandle(Message<?>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-
- CannotConvertBetweenTypesException - Exception in org.axonframework.serialization
-
Exception indicating that a conversion is required between to upcasters, but there is no converter capable of doing
the conversion.
- CannotConvertBetweenTypesException(String) - Constructor for exception org.axonframework.serialization.CannotConvertBetweenTypesException
-
Initializes the exception with the given message
.
- CannotConvertBetweenTypesException(String, Throwable) - Constructor for exception org.axonframework.serialization.CannotConvertBetweenTypesException
-
Initializing the exception with given message
and cause
.
- canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.MessageSerializer
-
- canSerializeTo(Class<T>) - Method in interface org.axonframework.serialization.Serializer
-
Indicates whether this Serializer is capable of serializing to the given expectedRepresentation
.
- canUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryUpcaster
-
Checks if this upcaster can upcast the given intermediateRepresentation
.
- ChainedConverter<S,T> - Class in org.axonframework.serialization
-
A converter that delegates to a chain of other ContentTypeConverters to convert from a source to a target for which
there is not necessarily a single converter available.
- ChainedConverter(List<ContentTypeConverter<?, ?>>) - Constructor for class org.axonframework.serialization.ChainedConverter
-
Creates a new instance that uses the given delegates
to form a chain of converters.
- ChainingConverter - Class in org.axonframework.serialization
-
Converter implementation that will combine converters to form chains of converters to be able to convert
from one type to another, for which there is no suitable single converter.
- ChainingConverter() - Constructor for class org.axonframework.serialization.ChainingConverter
-
Initialize a new ChainingConverter with the context ClassLoader for this thread.
- ChainingConverter(ClassLoader) - Constructor for class org.axonframework.serialization.ChainingConverter
-
Initialize a new ChainingConverter.
- changePhase(UnitOfWork.Phase...) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Ask the unit of work to transition to the given phases
sequentially.
- ChildEntity<T> - Interface in org.axonframework.commandhandling.model.inspection
-
Interface describing en entity that is a child of another entity.
- ChildEntityDefinition - Interface in org.axonframework.commandhandling.model.inspection
-
Interface describing the definition of a Child Entity.
- ChildForwardingCommandMessageHandlingMember<P,C> - Class in org.axonframework.commandhandling.model.inspection
-
- ChildForwardingCommandMessageHandlingMember(String, MessageHandlingMember<? super C>, BiFunction<CommandMessage<?>, P, C>) - Constructor for class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- claim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Attempt to claim ownership of this token.
- claimToken(ResultSet, AbstractTokenEntry<?>) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Tries to claim the given token entry
.
- classForType(SerializedType) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
- classForType(SerializedType) - Method in class org.axonframework.serialization.JavaSerializer
-
- classForType(SerializedType) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- classForType(SerializedType) - Method in class org.axonframework.serialization.MessageSerializer
-
- classForType(SerializedType) - Method in interface org.axonframework.serialization.Serializer
-
Returns the class for the given type identifier.
- ClasspathParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
ParameterResolverFactory instance that locates other ParameterResolverFactory instances on the class path.
- clear() - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
-
Clears all the associations.
- clear() - Method in class org.axonframework.messaging.MetaData
-
This operation is not supported.
- clear(UnitOfWork<?>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Clears the UnitOfWork currently bound to the current thread, if that UnitOfWork is the given
unitOfWork
.
- clock - Static variable in class org.axonframework.eventhandling.GenericEventMessage
-
Clock
instance used to set the time on new events.
- clock - Static variable in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
The clock used to persist timestamps in this entry.
- clone() - Method in interface org.axonframework.common.caching.Cache.EntryListener
-
Clone operation used by some Cache implementations.
- clone() - Method in class org.axonframework.common.caching.Cache.EntryListenerAdapter
-
- close(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
-
Close the given connection
, which was wrapped by the ConnectionWrapperFactory.
- close(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
-
- close() - Method in interface org.axonframework.common.lock.Lock
-
Releases this lock.
- close() - Method in interface org.axonframework.common.Registration
-
Cancels this Registration.
- close() - Method in interface org.axonframework.messaging.MessageStream
-
- closeQuietly(AutoCloseable) - Static method in class org.axonframework.common.io.IOUtils
-
Closes any AutoCloseable object, while suppressing any IOExceptions it will generate.
- closeQuietly(ResultSet) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given resultSet
, if possible.
- closeQuietly(Statement) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given statement
, if possible.
- closeQuietly(Connection) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given connection
, if possible.
- closeQuietlyIfCloseable(Object) - Static method in class org.axonframework.common.io.IOUtils
-
Closes any object if that object implements
Closeable
, while suppressing any IOExceptions it will
generate.
- CollectionUtils - Class in org.axonframework.common
-
Utility methods for operations on collections.
- CommandBus - Interface in org.axonframework.commandhandling
-
The mechanism that dispatches Command objects to their appropriate CommandHandler.
- commandBus() - Method in interface org.axonframework.config.Configuration
-
Returns the Command Bus defined in this Configuration.
- CommandBusConnector - Interface in org.axonframework.commandhandling.distributed
-
Interface describing the component that remotely connects multiple CommandBus instances.
- CommandBusConnectorCommunicationException - Exception in org.axonframework.commandhandling.distributed
-
Exception thrown when the CommandBusConnector has a communication failure
- CommandBusConnectorCommunicationException(String) - Constructor for exception org.axonframework.commandhandling.distributed.CommandBusConnectorCommunicationException
-
Initializes the CommandBusConnectorCommunicationException
- CommandBusConnectorCommunicationException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.CommandBusConnectorCommunicationException
-
Initializes the CommandBusConnectorCommunicationException
- CommandCallback<C,R> - Interface in org.axonframework.commandhandling
-
Interface describing a callback that is invoked when command handler execution has finished.
- CommandCallbackRepository<A> - Class in org.axonframework.commandhandling.distributed
-
This class retains a list of callbacks for CommandCallbackConnectors to use.
- CommandCallbackRepository() - Constructor for class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
- CommandCallbackWrapper<A,C,R> - Class in org.axonframework.commandhandling.distributed
-
Wrapper for a Command callback.
- CommandCallbackWrapper(A, CommandMessage<C>, CommandCallback<? super C, R>) - Constructor for class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
-
Initializes a
CommandCallbackWrapper
which wraps the original callback and holds on to the
command
message
and
channelId
of the channel on which the message is sent.
- CommandDispatchException - Exception in org.axonframework.commandhandling.distributed
-
Exception indicating that an error has occurred while trying to dispatch a command to another (potentially remote)
segment of the CommandBus.
- CommandDispatchException(String) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
-
Initializes the exception using the given message
.
- CommandDispatchException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
-
Initializes the exception using the given message
and cause
.
- CommandExecutionException - Exception in org.axonframework.commandhandling
-
Indicates that an exception has occurred while handling a command.
- CommandExecutionException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
-
Initializes the exception with given message
and cause
.
- CommandGateway - 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.
- CommandGatewayFactory - Class in org.axonframework.commandhandling.gateway
-
Factory that creates Gateway implementations from custom interface definitions.
- CommandGatewayFactory(CommandBus, MessageDispatchInterceptor<CommandMessage<?>>...) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
Initialize the factory sending Commands to the given commandBus
, optionally intercepting them with
given dispatchInterceptors
.
- CommandGatewayFactory(CommandBus, RetryScheduler, MessageDispatchInterceptor<CommandMessage<?>>...) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
Initialize the factory sending Commands to the given commandBus
, optionally intercepting them with
given dispatchInterceptors
.
- CommandGatewayFactory(CommandBus, RetryScheduler, List<MessageDispatchInterceptor<CommandMessage<?>>>) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
Initialize the factory sending Commands to the given commandBus
, optionally intercepting them with
given dispatchInterceptors
.
- CommandGatewayFactory.InvocationHandler<R> - Interface in org.axonframework.commandhandling.gateway
-
Interface towards the mechanism that handles a method call on a gateway interface method.
- CommandHandler - Annotation Type in org.axonframework.commandhandling
-
Marker annotation to mark any method on an object as being a CommandHandler.
- commandHandler(String) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
-
- commandHandler(String) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- CommandHandlerInvoker - Class in org.axonframework.commandhandling.disruptor
-
Component of the DisruptorCommandBus that invokes the command handler.
- CommandHandlerInvoker(EventStore, Cache, int) - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
-
Create an aggregate invoker instance that uses the given eventStore
and cache
to
retrieve aggregate instances.
- commandHandlers() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedChildEntity
-
- commandHandlers() - Method in interface org.axonframework.commandhandling.model.inspection.ChildEntity
-
Returns the commands and their respective handler that this entity declares
- commandHandlers() - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
-
- commandHandlers() - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- CommandHandlingEntry - Class in org.axonframework.commandhandling.disruptor
-
DataHolder for the DisruptorCommandBus.
- CommandHandlingEntry() - Constructor for class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Initializes the CommandHandlingEntry
- commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- CommandMessage<T> - Interface in org.axonframework.commandhandling
-
Represents a Message carrying a command as its payload.
- CommandMessageHandlingMember<T> - Interface in org.axonframework.commandhandling.model.inspection
-
Interface describing a message handler capable of handling a specific command.
- commandName - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- commandName() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- commandName() - Method in interface org.axonframework.commandhandling.model.inspection.CommandMessageHandlingMember
-
Returns the name of the command that can be handled.
- CommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
-
A filter for CommandMessages which filters CommandMessages by a Command Name.
- CommandNameFilter(Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-
- CommandNameFilter(String) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-
- CommandRouter - Interface in org.axonframework.commandhandling.distributed
-
Interface describing a mechanism used to find a suitable member of a cluster capable of handling given command
message.
- CommandTargetResolver - Interface in org.axonframework.commandhandling
-
Interface towards a mechanism that is capable of extracting an Aggregate Identifier and Version form a command that
identifies the aggregate instance the command should be invoked on.
- commit(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
-
Commits the underlying transaction
- commit(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
-
- commit() - Method in interface org.axonframework.common.transaction.Transaction
-
Commit this transaction.
- commit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
Process given events
while the Unit of Work root is being committed.
- commit() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
Resets the tracked changes.
- commit() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- commit(AnnotatedSaga<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
Commits the given modified saga
to the underlying saga store.
- commit() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- commit() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Commits the current UnitOfWork.
- commit() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Commits the Unit of Work.
- CompactDriver - Class in org.axonframework.serialization.xml
-
XStream HierarchicalStreamDriver implementation that uses a CompactWriter to write XML without newlines and
indentation, while writing it using the (default) XPPReader.
- CompactDriver() - Constructor for class org.axonframework.serialization.xml.CompactDriver
-
- compare(T, T) - Method in class org.axonframework.common.annotation.PriorityAnnotationComparator
-
- compareTo(PropertyAccessStrategy) - Method in class org.axonframework.common.property.PropertyAccessStrategy
-
- compareTo(GlobalSequenceTrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
-
- Component<B> - Class in org.axonframework.config
-
A Component used in the Axon Configurer.
- Component(Configuration, String, Function<Configuration, ? extends B>) - Constructor for class org.axonframework.config.Component
-
Creates a component for the given config
with given name
created by the given
builderFunction
.
- Component(Supplier<Configuration>, String, Function<Configuration, ? extends B>) - Constructor for class org.axonframework.config.Component
-
Creates a component for the given config
with given name
created by the given
builderFunction
.
- concat(DomainEventStream, DomainEventStream) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
Concatenate two DomainEventStreams.
- ConcludesBatch - Annotation Type in org.axonframework.eventhandling
-
Annotation indication that a parameter on an
EventHandler
method should be
injected with a value that informs whether the event is the last event of a processed batch of events.
- ConcludesBatchParameterResolverFactory - Class in org.axonframework.eventhandling
-
Paramater resolver factory for boolean event handler parameters annotated with
ConcludesBatch
.
- ConcludesBatchParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-
Initialize a ConcludesBatchParameterResolverFactory.
- ConcurrencyException - Exception in org.axonframework.commandhandling.model
-
Exception indicating that concurrent access to a repository was detected.
- ConcurrencyException(String) - Constructor for exception org.axonframework.commandhandling.model.ConcurrencyException
-
Initialize a ConcurrencyException with the given message
.
- ConcurrencyException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.ConcurrencyException
-
Initialize a ConcurrencyException with the given message
and cause
.
- Configuration - Interface in org.axonframework.config
-
Interface describing the Global Configuration for Axon components.
- ConfigurationResourceInjector - Class in org.axonframework.config
-
ResourceInjector implementation that injects resources defined in the Axon Configuration.
- ConfigurationResourceInjector(Configuration) - Constructor for class org.axonframework.config.ConfigurationResourceInjector
-
Initializes the ResourceInjector to inject the resources found in the given configuration
.
- configureAggregate(AggregateConfiguration<A>) - Method in interface org.axonframework.config.Configurer
-
Configures an Aggregate in this configuration based on the given aggregateConfiguration
.
- configureAggregate(Class<A>) - Method in interface org.axonframework.config.Configurer
-
Configures an Aggregate using default settings.
- configureAggregate(AggregateConfiguration<A>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureAggregateFactory(Function<Configuration, AggregateFactory<A>>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the factory to use to to create new Aggregates instances of the type under configuration.
- configureCommandBus(Function<Configuration, CommandBus>) - Method in interface org.axonframework.config.Configurer
-
Configure the given Command Bus to use in this configuration.
- configureCommandHandler(Function<Configuration, AggregateAnnotationCommandHandler>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the AggregateAnnotationCommandHandler instance to use.
- configureCommandTargetResolver(Function<Configuration, CommandTargetResolver>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the CommandTargetResolver to use for the Aggregate type under configuration.
- configureCorrelationDataProviders(Function<Configuration, List<CorrelationDataProvider>>) - Method in interface org.axonframework.config.Configurer
-
Configures the CorrelationDataProviders that Message processing components should use to attach correlation data
to outgoing messages.
- configureCorrelationDataProviders(Function<Configuration, List<CorrelationDataProvider>>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureEmbeddedEventStore(Function<Configuration, EventStorageEngine>) - Method in interface org.axonframework.config.Configurer
-
Configure an Embedded Event Store which uses the given Event Storage Engine to store its events.
- configureEmbeddedEventStore(Function<Configuration, EventStorageEngine>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureEventBus(Function<Configuration, EventBus>) - Method in interface org.axonframework.config.Configurer
-
Configure the given Event Bus to use in this configuration.
- configureEventStore(Function<Configuration, EventStore>) - Method in interface org.axonframework.config.Configurer
-
Configure the given Event Store to use in this configuration.
- configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in interface org.axonframework.config.Configurer
-
Configure the Message Monitor to use for the Message processing components in this configuration.
- configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in class org.axonframework.config.DefaultConfigurer
-
- Configurer - Interface in org.axonframework.config
-
Entry point of the Axon Configuration API.
- configureRepository(Function<Configuration, Repository<A>>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the repository to use to load and store Aggregates of this type.
- configureResourceInjector(Function<Configuration, ResourceInjector>) - Method in interface org.axonframework.config.Configurer
-
Configure the given Resource Injector to use for Sagas in this configuration.
- configureSagaStore(Function<Configuration, SagaStore<? super S>>) - Method in class org.axonframework.config.SagaConfiguration
-
Configures the Saga Store to use to store Saga instances of this type.
- configureSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
-
Configure the given Serializer to use in this configuration.
- configureTransactionManager(Function<Configuration, TransactionManager>) - Method in interface org.axonframework.config.Configurer
-
Configure the given Transaction Manager to use in this configuration.
- ConflictExceptionSupplier<T extends Exception> - Interface in org.axonframework.commandhandling.conflictresolution
-
Interface describing a factory for exceptions that indicate an unresolved conflict in an aggregate instance.
- ConflictingAggregateVersionException - Exception in org.axonframework.commandhandling.model
-
Exception indicating that the (actual) version of a loaded aggregate did not match the given expected version number.
- ConflictingAggregateVersionException(String, long, long) - Constructor for exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
-
Initializes the exception using the given message
.
- ConflictingAggregateVersionException(String, long, long, Throwable) - Constructor for exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
-
Initializes the exception using the given message
and cause
.
- ConflictingModificationException - Exception in org.axonframework.commandhandling.model
-
Root of a hierarchy of exceptions indicating the detection of conflicting concurrent modifications.
- ConflictingModificationException(String) - Constructor for exception org.axonframework.commandhandling.model.ConflictingModificationException
-
Initializes the exception using the given message
.
- ConflictingModificationException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.model.ConflictingModificationException
-
Initializes the exception using the given message
and cause
.
- ConflictResolution - Class in org.axonframework.commandhandling.conflictresolution
-
ParameterResolverFactory that add support for the ConflictResolver parameter type in annotated handlers.
- ConflictResolution() - Constructor for class org.axonframework.commandhandling.conflictresolution.ConflictResolution
-
- ConflictResolver - Interface in org.axonframework.commandhandling.conflictresolution
-
Interface describing an object that is capable of detecting conflicts between changes to be applied to an aggregate,
and unseen changes made to the aggregate.
- Conflicts - Class in org.axonframework.commandhandling.conflictresolution
-
Utility class providing common Predicates used to detect conflicts between the actual state of an event sourced
aggregate and the expected state of the aggregate.
- ConnectionProvider - Interface in org.axonframework.common.jdbc
-
Interface towards a mechanism that provides access to a JDBC Connection.
- ConnectionWrapperFactory - Class in org.axonframework.common.jdbc
-
Factory for creating wrappers around a Connection, allowing one to override the behavior of the
Connection.close()
method.
- ConnectionWrapperFactory.ConnectionCloseHandler - Interface in org.axonframework.common.jdbc
-
Interface defining an operation to close the wrapped connection
- ConnectionWrapperFactory.NoOpCloseHandler - Class in org.axonframework.common.jdbc
-
Implementation of ConnectionCloseHandler that does nothing on close.
- ConsistentHash - Class in org.axonframework.commandhandling.distributed
-
Component used by command routers to find members capable of handling a given command.
- ConsistentHash() - Constructor for class org.axonframework.commandhandling.distributed.ConsistentHash
-
- ConsistentHash.ConsistentHashMember - Class in org.axonframework.commandhandling.distributed
-
- ContainerManagedEntityManagerProvider - Class in org.axonframework.common.jpa
-
EntityManagerProvider implementation that expects the container to inject the default container managed
EntityManager
instance.
- ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
-
- contains(AssociationValue) - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
Indicates whether this instance contains the given associationValue
.
- contains(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- containsKey(K) - Method in interface org.axonframework.common.caching.Cache
-
Indicates whether there is an item stored under given key
.
- containsKey(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- containsKey(K) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- containsKey(Object) - Method in class org.axonframework.common.caching.NoCache
-
- containsKey(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- containsKey(Object) - Method in class org.axonframework.messaging.MetaData
-
- containsValue(Object) - Method in class org.axonframework.messaging.MetaData
-
- ContentTypeConverter<S,T> - Interface in org.axonframework.serialization
-
Interface describing a mechanism that converts the data type of IntermediateRepresentations of SerializedObjects for
Upcasters.
- 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(S, Class<S>, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Convert the given source
, of type sourceType
to the given targetType
.
- convert(S) - Method in class org.axonframework.serialization.ChainedConverter
-
- convert(Object, Class<?>, Class<T>) - Method in class org.axonframework.serialization.ChainingConverter
-
- convert(S) - Method in interface org.axonframework.serialization.ContentTypeConverter
-
Converts the given object into another.
- convert(Object, Class<T>) - Method in interface org.axonframework.serialization.Converter
-
Converts the given object into another.
- convert(Object, Class<?>, Class<T>) - Method in interface org.axonframework.serialization.Converter
-
Converts the given object into another using the source type to find the conversion path.
- convert(SerializedObject<?>, Class<T>) - Method in interface org.axonframework.serialization.Converter
-
Converts the data format of the given original
IntermediateRepresentation to the target data type.
- convert(Blob) - Method in class org.axonframework.serialization.converters.BlobToInputStreamConverter
-
- convert(byte[]) - Method in class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
-
- convert(byte[]) - Method in class org.axonframework.serialization.converters.ByteArrayToStringConverter
-
- convert(InputStream) - Method in class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
-
- convert(String) - Method in class org.axonframework.serialization.converters.StringToByteArrayConverter
-
- convert(byte[]) - Method in class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
-
- convert(JsonNode) - Method in class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
-
- convert(Document) - Method in class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
-
- convert(InputStream) - Method in class org.axonframework.serialization.xml.InputStreamToDom4jConverter
-
- convert(InputStream) - Method in class org.axonframework.serialization.xml.InputStreamToXomConverter
-
- convert(Document) - Method in class org.axonframework.serialization.xml.XomToStringConverter
-
- Converter - Interface in org.axonframework.serialization
-
Interface describing a mechanism that can convert data from one to another type.
- 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(Collection<CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
-
Initializes the interceptor that registers given correlationDataProvider
with the current Unit of Work.
- CorrelationDataProvider - Interface in org.axonframework.messaging.correlation
-
Object defining the 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.
- 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.
- createChildDefinition(Field, EntityModel<T>) - Method in class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-
- createChildDefinition(Field, EntityModel<T>) - Method in class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityDefinition
-
- createChildDefinition(Field, EntityModel<T>) - Method in class org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
-
- createChildDefinition(Field, EntityModel<T>) - Method in interface org.axonframework.commandhandling.model.inspection.ChildEntityDefinition
-
Inspect the given field
, which is declared on the given declaringEntity
for the presence of a
Child Entity.
- createDomainEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
- createDomainEventTable(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory
-
Creates a PreparedStatement that allows for the creation of the table to store Event entries.
- createDomainEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-
- createEventEntity(EventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Returns a Jpa event entity for given eventMessage
.
- createEventProcessor(Configuration, String, List<?>) - Method in interface org.axonframework.config.EventHandlingConfiguration.EventProcessorBuilder
-
Builder function for an Event Processor.
- createGateway(Class<T>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
Creates a gateway instance for the given gatewayInterface
.
- createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
-
- createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in interface org.axonframework.messaging.annotation.HandlerDefinition
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-
- createInstance(String, Supplier<T>) - Method in class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
-
Creates a new Saga instance.
- createInstance(String, Supplier<T>) - Method in interface org.axonframework.eventhandling.saga.SagaRepository
-
Creates a new Saga instance.
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventsourcing.eventstore.TrackingTokenParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.DefaultParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in interface org.axonframework.messaging.annotation.ParameterResolverFactory
-
If available, creates a ParameterResolver instance that can provide a parameter of type
parameterType
for a given message.
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
-
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
-
Creates an adapter for the given cacheEntryListener
.
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- createMessage(P, MetaData) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- createMessage(P, MetaData) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
- createNullStatement(Connection) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
-
Creates a prepared statement that acts as a null object.
- createReader(Reader) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createReader(InputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createReader(URL) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createReader(File) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createRepository(AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
-
Create a repository instance for an aggregate created by the given aggregateFactory
.
- createRepository(AggregateFactory<T>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
.
- createRepository(AggregateFactory<T>, SnapshotTriggerDefinition) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
.
- createRepository(AggregateFactory<T>, ParameterResolverFactory) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
.
- createRepository(AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
.
- createSchema() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
-
Creates the SQL Schema required to store Sagas and their associations,.
- createSchema(TokenTableFactory) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Performs the DDL queries to create the schema necessary for this token store implementation.
- createSchema(EventTableFactory) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Performs the DDL queries to create the schema necessary for this storage engine implementation.
- createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Creates a snapshot event for an aggregate of which passed events are available in the given eventStream
.
- createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-
- createSnapshotEntity(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Returns a Jpa snapshot entity for given snapshot
of an aggregate.
- createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
- createSnapshotEventTable(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory
-
Creates a PreparedStatement that allows for the creation of the table to store Snapshots.
- createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-
- createSnapshotterTask(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Creates an instance of a task that contains the actual snapshot creation logic.
- createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
-
- createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory
-
- createTable(Connection, TokenSchema) - Method in interface org.axonframework.eventhandling.tokenstore.jdbc.TokenTableFactory
-
Creates a PreparedStatement that allows for the creation of the table to store tracking token entries.
- createWriter(Writer) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createWriter(OutputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- 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
-
- DataSourceConnectionProvider - Class in org.axonframework.common.jdbc
-
ConnectionProvider implementation that obtains a connection from a given DataSource.
- DataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.common.jdbc.DataSourceConnectionProvider
-
Initialize the Connection Provider, using given dataSource
to obtain new connections.
- DeadlockException - Exception in org.axonframework.common.lock
-
Exception indicating that a deadlock has been detected while a thread was attempting to acquire a lock.
- DeadlockException(String) - Constructor for exception org.axonframework.common.lock.DeadlockException
-
Initializes the exception with given message
.
- declaringClass(Class<?>, String, Class<?>...) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns the class on which the method with name "getter
" and parameters of type
parameterTypes
is declared.
- DEFAULT_BUFFER_SIZE - Static variable in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
The default size of the buffer in this configuration
- defaultCommandBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
-
Provides the default CommandBus implementation.
- DefaultCommandGateway - Class in org.axonframework.commandhandling.gateway
-
Default implementation of the CommandGateway interface.
- DefaultCommandGateway(CommandBus, MessageDispatchInterceptor<? super CommandMessage<?>>...) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Initializes a command gateway that dispatches commands to the given commandBus
after they have been
handles by the given commandDispatchInterceptors
.
- DefaultCommandGateway(CommandBus, RetryScheduler, MessageDispatchInterceptor<? super CommandMessage<?>>...) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Initializes a command gateway that dispatches commands to the given commandBus
after they have been
handles by the given commandDispatchInterceptors
.
- DefaultCommandGateway(CommandBus, RetryScheduler, List<MessageDispatchInterceptor<? super CommandMessage<?>>>) - Constructor for class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Initializes a command gateway that dispatches commands to the given commandBus
after they have been
handles by the given commandDispatchInterceptors
.
- defaultCommandGateway(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
-
- 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
-
- DefaultConfigurer - Class in org.axonframework.config
-
Entry point of the Axon Configuration API.
- DefaultConfigurer() - Constructor for class org.axonframework.config.DefaultConfigurer
-
Initialize the Configurer
- DefaultConflictResolver - Class in org.axonframework.commandhandling.conflictresolution
-
- DefaultConflictResolver(EventStore, String, long, long) - Constructor for class org.axonframework.commandhandling.conflictresolution.DefaultConflictResolver
-
Initializes a
DefaultConflictResolver
using the given
eventStore
to load unseen events since
given
expectedVersion
.
- defaultEventBus(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
-
Provides the default EventBus implementation.
- DefaultIdentifierFactory - Class in org.axonframework.common
-
Default IdentifierFactory implementation that uses generates random java.util.UUID
based identifiers.
- DefaultIdentifierFactory() - Constructor for class org.axonframework.common.DefaultIdentifierFactory
-
- DefaultInterceptorChain<T extends Message<?>> - Class in org.axonframework.messaging
-
Mechanism that takes care of interceptor and handler execution.
- DefaultInterceptorChain(UnitOfWork<? extends T>, Iterable<? extends MessageHandlerInterceptor<? super T>>, MessageHandler<? super T>) - Constructor for class org.axonframework.messaging.DefaultInterceptorChain
-
Initialize the default interceptor chain to dispatch the given message
, through the
chain
, to the handler
.
- defaultParameterResolverFactory(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
-
Provides the default ParameterResolverFactory.
- DefaultParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
Factory for the default parameter resolvers.
- DefaultParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.DefaultParameterResolverFactory
-
- defaultResourceInjector(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
-
- DefaultSagaMetaModelFactory - Class in org.axonframework.eventhandling.saga.metamodel
-
- DefaultSagaMetaModelFactory() - Constructor for class org.axonframework.eventhandling.saga.metamodel.DefaultSagaMetaModelFactory
-
- DefaultSagaMetaModelFactory(ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.saga.metamodel.DefaultSagaMetaModelFactory
-
- defaultSerializer(Configuration) - Method in class org.axonframework.config.DefaultConfigurer
-
Provides the default Serializer implementation.
- DefaultUnitOfWork<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
-
Implementation of the UnitOfWork that processes a single message.
- DefaultUnitOfWork(T) - Constructor for class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
Initializes a Unit of Work (without starting it).
- deleteSaga(AnnotatedSaga<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
Remove the given saga as well as all known association values pointing to it from the repository.
- deleteSaga(Class<? extends T>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
-
- deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
-
- deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
-
- deleteSaga(Class<?>, String, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
-
- deleteSaga(Class<? extends T>, String, Set<AssociationValue>) - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore
-
Deletes a Saga with given sagaType
and sagaIdentifier
and all its associations.
- deleteSnapshots(Connection, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Creates a statement to delete all snapshots of the aggregate with given aggregateIdentifier
.
- deleteSnapshots(String) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Deletes all snapshots from the underlying storage with given aggregateIdentifier
.
- DenyAll - Enum in org.axonframework.commandhandling.distributed.commandfilter
-
A Command Message predicate that denies all CommandMessages
- DenyCommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
-
A Predicate for CommandMessage's that can deny commands based on their name.
- DenyCommandNameFilter(Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
-
- DenyCommandNameFilter(String) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
-
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.JavaSerializer
-
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- deserialize(JsonParser, DeserializationContext) - Method in class org.axonframework.serialization.json.MetaDataDeserializer
-
- deserialize(SerializedObject<S>) - Method in class org.axonframework.serialization.MessageSerializer
-
- deserialize(SerializedObject<S>) - Method in interface org.axonframework.serialization.Serializer
-
Deserializes the first object read from the given bytes
.
- deserializeWithType(JsonParser, DeserializationContext, TypeDeserializer) - Method in class org.axonframework.serialization.json.MetaDataDeserializer
-
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in interface org.axonframework.commandhandling.conflictresolution.ConflictResolver
-
Resolve conflicts between unseen changes made to the aggregate and new changes that are about to be made.
- detectConflicts(Predicate<List<DomainEventMessage<?>>>) - Method in interface org.axonframework.commandhandling.conflictresolution.ConflictResolver
-
Resolve conflicts between changes to be applied to the aggregate and unseen changes made to the aggregate.
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in class org.axonframework.commandhandling.conflictresolution.DefaultConflictResolver
-
- detectConflicts(Predicate<List<DomainEventMessage<?>>>, ConflictExceptionSupplier<T>) - Method in enum org.axonframework.commandhandling.conflictresolution.NoConflictResolver
-
- Digester - Class in org.axonframework.common.digest
-
Utility class for generating hashes for values using several algorithms.
- digestHex() - Method in class org.axonframework.common.digest.Digester
-
Returns the hex representation of the digest of all data that has been provided so far.
- DirectEventJobDataBinder() - Constructor for class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
-
- DirectEventProcessingStrategy - Enum in org.axonframework.eventhandling
-
Event processing strategy that directly initiates event processing.
- DirectExecutor - Class in org.axonframework.common
-
Simple executor implementation that runs a given Runnable immediately in the calling thread.
- DirectExecutor() - Constructor for class org.axonframework.common.DirectExecutor
-
- DirectlyAccessedProperty<T> - Class in org.axonframework.common.property
-
Property implementation that accesses public field to obtain a value of a property for a given instance.
- DirectlyAccessedProperty(Field, String) - Constructor for class org.axonframework.common.property.DirectlyAccessedProperty
-
- DirectPropertyAccessStrategy - Class in org.axonframework.common.property
-
Implementation of PropertyAccessStrategy that scans class hierarchy to get public field named "property"
- DirectPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.DirectPropertyAccessStrategy
-
- dispatch(CommandMessage<C>) - Method in interface org.axonframework.commandhandling.CommandBus
-
Dispatch the given command
to the CommandHandler subscribed to that type of command
.
- dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in interface org.axonframework.commandhandling.CommandBus
-
Dispatch the given command
to the CommandHandler subscribed to that type of command
.
- dispatch(CommandMessage<C>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
- dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
- dispatch(CommandMessage<C>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
- dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Dispatch the given command
to the CommandHandler subscribed to that type of command
.
- dispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
- DispatchMessage - Class in org.axonframework.commandhandling.distributed
-
Base class for dispatch messages which may be used in the
CommandBusConnector
upon dispatching a command
to other nodes.
- DispatchMessage() - Constructor for class org.axonframework.commandhandling.distributed.DispatchMessage
-
Default constructor required for de-/serialization of extending classes.
- DispatchMessage(CommandMessage<?>, Serializer, boolean) - Constructor for class org.axonframework.commandhandling.distributed.DispatchMessage
-
Initialized a DispatchMessage for the given commandMessage
, which uses the given
serializer
to deserialize its contents.
- DisruptorCommandBus - Class in org.axonframework.commandhandling.disruptor
-
Asynchronous CommandBus implementation with very high performance characteristics.
- DisruptorCommandBus(EventStore) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Initialize the DisruptorCommandBus with given resources, using default configuration settings.
- DisruptorCommandBus(EventStore, DisruptorConfiguration) - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Initialize the DisruptorCommandBus with given resources and settings.
- DisruptorConfiguration - Class in org.axonframework.commandhandling.disruptor
-
Configuration object for the DisruptorCommandBus.
- DisruptorConfiguration() - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Initializes a configuration instance with default settings: ring-buffer size: 4096, blocking wait strategy and
multi-threaded producer type.
- DisruptorUnitOfWork<T extends Message<?>> - Class in org.axonframework.commandhandling.disruptor
-
- DisruptorUnitOfWork() - Constructor for class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- DistributedCommandBus - Class in org.axonframework.commandhandling.distributed
-
Implementation of a
CommandBus
that is aware of multiple instances of a CommandBus working together to
spread load.
- DistributedCommandBus(CommandRouter, CommandBusConnector) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Initializes the command bus with the given commandRouter
and connector
.
- DistributedCommandBus(CommandRouter, CommandBusConnector, MessageMonitor<? super CommandMessage<?>>) - Constructor for class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Initializes the command bus with the given commandRouter
, connector
and messageMonitor
.
- doApply(T, MetaData) - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Apply a
DomainEventMessage
with given payload and metadata (metadata from interceptors will be combined
with the provided metadata).
- doApply(P, MetaData) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- doApply(P, MetaData) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
- doAssociateWith(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
Registers a AssociationValue with the given saga.
- doAssociateWith(AssociationValue) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
SagaLifecycle
instance method to register the given
associationValue
.
- doCreateAggregate(String, DomainEventMessage) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
Create an uninitialized Aggregate instance with the given aggregateIdentifier
.
- doCreateAggregate(String, DomainEventMessage) - Method in class org.axonframework.eventsourcing.GenericAggregateFactory
-
Create an uninitialized Aggregate instance with the given aggregateIdentifier
.
- doCreateInstance(String, Supplier<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
- doCreateInstance(String, Supplier<T>) - Method in class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
-
Creates a new Saga instance.
- doCreateNew(Callable<T>) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Creates a new aggregate instance using the given factoryMethod
.
- doCreateNew(Callable<T>) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
-
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
Creates a new aggregate instance using the given factoryMethod
.
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
- doCreateNewForLock(Callable<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
- doDelete(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Removes the aggregate from the repository.
- doDelete(LockAwareAggregate<T, A>) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
- doDeleteWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
-
- doDeleteWithLock(A) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
Perform the actual deleting of the aggregate.
- doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
- doDeleteWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
- doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Deserialize the given serializedObject
.
- doDeserialize(SerializedObject, XStream) - Method in class org.axonframework.serialization.xml.XStreamSerializer
-
- doDispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
-
- doDispatch(CommandMessage<C>, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Performs the actual dispatching logic.
- doEnd() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
Marks the saga as ended.
- doEnd() - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
- doLoad(String, Long) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Loads and initialized the aggregate with the given aggregateIdentifier.
- doLoad(String, Long) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
Perform the actual loading of an aggregate.
- doLoad(String) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
- doLoad(String) - Method in class org.axonframework.eventhandling.saga.repository.LockingSagaRepository
-
Loads a known Saga instance by its unique identifier.
- doLoadSaga(String) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
Loads the saga with given
sagaIdentifier
from the underlying saga store and returns it as a
AnnotatedSaga
.
- doLoadWithLock(String, Long) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
-
- doLoadWithLock(String, Long) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
Loads the aggregate with the given aggregateIdentifier.
- doLoadWithLock(String, Long) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
Perform the actual loading of an aggregate.
- doLoadWithLock(String, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Perform the actual loading of an aggregate.
- Dom4JToByteArrayConverter - Class in org.axonframework.serialization.xml
-
Converter that converts Dom4j Document instances to a byte array.
- Dom4JToByteArrayConverter() - Constructor for class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
-
- DomainEventData<T> - Interface in org.axonframework.eventsourcing.eventstore
-
Interface describing the properties of serialized Domain Event Messages.
- DomainEventEntry - Class in org.axonframework.eventsourcing.eventstore.jpa
-
Default implementation of a tracked domain event entry.
- DomainEventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.DomainEventEntry
-
Construct a new default domain event entry from a published domain event message to enable storing the event or
sending it to a remote location.
- DomainEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.DomainEventEntry
-
Default constructor required by JPA
- domainEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Returns the name of the Jpa event entity.
- domainEventFields() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Returns a comma separated list of domain event column names to select from an event or snapshot entry.
- DomainEventMessage<T> - Interface in org.axonframework.eventsourcing
-
Represents a Message that wraps a DomainEvent and an Event representing an important change in the Domain.
- DomainEventStream - Interface in org.axonframework.eventsourcing.eventstore
-
The DomainEventStream represents a stream of historical events published by an Aggregate.
- domainEventTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Returns the name of the domain event table.
- doMarkDeleted() - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Marks this aggregate as deleted.
- doMarkDeleted() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- doRegisterListener(L) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
-
Registers the given listener with the cache implementation
- doRegisterListener(CacheEventListener) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- doRegisterListener(CacheEntryListenerConfiguration) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- doRemoveAssociation(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
Removes the given association from this Saga.
- doRemoveAssociation(AssociationValue) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
SagaLifecycle
instance method to remove the given
associationValue
.
- doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
-
Resolve the Routing Key for the given command
.
- doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
- doResolveRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
-
- doSave(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Performs the actual saving of the aggregate.
- doSave(LockAwareAggregate<T, A>) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
- doSaveWithLock(AnnotatedAggregate<T>) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
-
- doSaveWithLock(A) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
Perform the actual saving of the aggregate.
- doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
- doSaveWithLock(EventSourcedAggregate<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
- doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Serialize the given object
to the given expectedFormat
.
- doSerialize(Object, Class<T>, XStream) - Method in class org.axonframework.serialization.xml.XStreamSerializer
-
- doUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryUpcaster
-
Upcasts the given intermediateRepresentation
.
- EhCacheAdapter - Class in org.axonframework.common.caching
-
Cache implementation that delegates all calls to an EhCache instance.
- EhCacheAdapter(Ehcache) - Constructor for class org.axonframework.common.caching.EhCacheAdapter
-
Initialize the adapter to forward all call to the given ehCache
instance
- EmbeddedEventStore - Class in org.axonframework.eventsourcing.eventstore
-
- EmbeddedEventStore(EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-
- EmbeddedEventStore(EventStorageEngine, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-
Initializes an
EmbeddedEventStore
with given
storageEngine
and
monitor
and default
settings.
- EmbeddedEventStore(EventStorageEngine, MessageMonitor<? super EventMessage<?>>, int, long, long, TimeUnit) - Constructor for class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-
Initializes an
EmbeddedEventStore
with given
storageEngine
and
monitor
and custom
settings.
- empty() - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
Create an empty DomainEventStream.
- emptyInstance() - Static method in class org.axonframework.messaging.MetaData
-
Returns an empty MetaData instance.
- end() - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
Marks the saga as ended.
- endpoint() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-
Returns this Member's endpoint.
- EndSaga - Annotation Type in org.axonframework.eventhandling.saga
-
Indicates that the annotated
SagaEventHandler
method indicates the end of a
Saga instance's lifecycle.
- ensureAccessible(T) - Static method in class org.axonframework.common.ReflectionUtils
-
Makes the given member
accessible via reflection if it is not the case already.
- ensureConflictsResolved() - Method in class org.axonframework.commandhandling.conflictresolution.DefaultConflictResolver
-
- EntityId - Annotation Type in org.axonframework.commandhandling.model
-
Field annotation that marks the field containing the identifier of an Entity.
- entityManager() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Provides an EntityManager
instance for storing and fetching event data.
- EntityManagerProvider - Interface in org.axonframework.common.jpa
-
Provides components with an EntityManager to access the persistence mechanism.
- EntityModel<T> - Interface in org.axonframework.commandhandling.model.inspection
-
Interface of an entity model that describes the properties and capabilities of an entity of type T
.
- EntryListenerAdapter() - Constructor for class org.axonframework.common.caching.Cache.EntryListenerAdapter
-
- entrySet() - Method in class org.axonframework.messaging.MetaData
-
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
-
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
-
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- equals(Object) - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-
- equals(Object) - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
-
- equals(Object) - Method in class org.axonframework.eventhandling.saga.AssociationValue
-
- equals(Object) - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
-
- equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
-
- equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
-
- equals(Object) - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
-
- equals(Object) - Method in class org.axonframework.messaging.MetaData
-
- equals(Object) - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
-
- equals(Object) - Method in class org.axonframework.serialization.SerializedMetaData
-
- equals(Object) - Method in class org.axonframework.serialization.SimpleSerializedObject
-
- equals(Object) - Method in class org.axonframework.serialization.SimpleSerializedType
-
- error() - Method in class org.axonframework.eventhandling.ErrorContext
-
Returns the error that was raised in the processor
- ErrorContext - Class in org.axonframework.eventhandling
-
Describes the context of an error.
- ErrorContext(String, Exception, List<? extends EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.ErrorContext
-
- ErrorHandler - Interface in org.axonframework.eventhandling
-
Interface of the error handler that will be invoked if event processing fails.
- EVENT_BUS_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
-
The key used to locate the Event Bus in the scheduler context.
- EVENT_JOB_DATA_BINDER_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
-
- EVENT_KEY - Static variable in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.DirectEventJobDataBinder
-
The key used to locate the event in the JobDataMap
.
- 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.
- EventCountSnapshotTriggerDefinition - Class in org.axonframework.eventsourcing
-
Snapshotter trigger mechanism that counts the number of events to decide when to create a snapshot.
- EventCountSnapshotTriggerDefinition(Snapshotter, int) - Constructor for class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
-
Initialized the SnapshotTriggerDefinition to threshold snapshots using the given snapshotter
when threshold
events have been applied to an Aggregate instance
- EventData<T> - Interface in org.axonframework.eventsourcing.eventstore
-
Interface describing the properties of serialized Event Messages.
- eventHandled(EventMessage<?>) - Method in interface org.axonframework.eventsourcing.SnapshotTrigger
-
Invoked when an event is handled by an aggregate.
- EventHandler - Annotation Type in org.axonframework.eventhandling
-
Annotation to be placed on methods that can handle events.
- EventHandlerInvoker - Interface in org.axonframework.eventhandling
-
Interface for an event message handler that defers handling to one or more other handlers.
- EventHandlingConfiguration - Class in org.axonframework.config
-
Module Configuration implementation that defines an Event Handling component.
- EventHandlingConfiguration() - Constructor for class org.axonframework.config.EventHandlingConfiguration
-
Creates a default configuration for an Event Handling module that assigns Event Handlers to Subscribing Event
Processors based on the package they're in.
- EventHandlingConfiguration.EventProcessorBuilder - Interface in org.axonframework.config
-
Interface describing a Builder function for Event Processors.
- eventIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the identifier of the event.
- EventJobDataBinder - Interface in org.axonframework.eventhandling.scheduling.quartz
-
Strategy towards reading/writing an Axon EventMessage from/to a Quartz JobDataMap
.
- EventListener - Interface in org.axonframework.eventhandling
-
Interface to be implemented by classes that can handle events.
- EventListenerProxy - Interface in org.axonframework.eventhandling
-
Specialist interface for implementations of an event listener that redirect actual processing to another instance.
- EventLoggingInterceptor - Class in org.axonframework.eventhandling.interceptors
-
Message Dispatch Interceptor that logs published events to a SLF4J logger.
- EventLoggingInterceptor() - Constructor for class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
-
Initialize the LoggingInterceptor with the default logger name, which is the fully qualified class name of this
logger.
- EventLoggingInterceptor(String) - Constructor for class org.axonframework.eventhandling.interceptors.EventLoggingInterceptor
-
Initialize the interceptor with the given loggerName
.
- eventMatching(Predicate<? super T>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
-
Returns a
Predicate
for a
ConflictResolver
that responds affirmative if any event in a list of
unseen events matches the given
messageFilter
.
- EventMessage<T> - Interface in org.axonframework.eventhandling
-
Represents a Message wrapping an Event, which is represented by its payload.
- EventProcessingException - Exception in org.axonframework.eventhandling
-
Exception thrown when an
EventProcessor
failed to handle a batch of events.
- EventProcessingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.EventProcessingException
-
Initialize the exception with given message
and cause
.
- EventProcessingStrategy - Interface in org.axonframework.eventhandling
-
Interface describing a strategy for the processing of a batch of events.
- eventProcessor() - Method in class org.axonframework.eventhandling.ErrorContext
-
Returns the name of the Event Processor where the error occurred.
- EventProcessor - Interface in org.axonframework.eventhandling
-
An Event Processor processes event messages from an event queue or event bus.
- 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.
- EventPublisher - Class in org.axonframework.commandhandling.disruptor
-
Component of the DisruptorCommandBus that stores and publishes events generated by the command's execution.
- EventPublisher(Executor, TransactionManager, RollbackConfiguration, int) - Constructor for class org.axonframework.commandhandling.disruptor.EventPublisher
-
Initializes the EventPublisher to publish Events to the given eventStore
and eventBus
for aggregate of given aggregateType
.
- EventScheduler - Interface in org.axonframework.eventhandling.scheduling
-
Interface towards a mechanism capable of scheduling the publication of events.
- EventSchema - Class in org.axonframework.eventsourcing.eventstore.jdbc
-
Schema of an event entry to be stored using Jdbc.
- EventSchema() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Initializes the default Event Schema
- EventSchema.Builder - Class in org.axonframework.eventsourcing.eventstore.jdbc
-
Builder for an
EventSchema
that gets initialized with default values.
- EventSourcedAggregate<T> - Class in org.axonframework.eventsourcing
-
Implementation of an
Aggregate
that is sourced from events that have
been published by the aggregate.
- EventSourcedAggregate(T, AggregateModel<T>, EventBus, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
-
Initializes an Aggregate instance for the given aggregateRoot
, based on the given model
, which
publishes events to the given eventBus
.
- EventSourcedAggregate(AggregateModel<T>, EventBus, SnapshotTrigger) - Constructor for class org.axonframework.eventsourcing.EventSourcedAggregate
-
Creates a new EventSourcedAggregate instance based on the given model
, which publishes events to the
given eventBus
.
- EventSourcingHandler - Annotation Type in org.axonframework.eventsourcing
-
Annotation that marks a method in an Aggregate (either the root, or an entity) as a handler for Events generated by
that aggregate.
- EventSourcingRepository<T> - Class in org.axonframework.eventsourcing
-
Abstract repository implementation that allows easy implementation of an Event Sourcing mechanism.
- EventSourcingRepository(Class<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initializes a repository with the default locking strategy, using a GenericAggregateFactory to create new
aggregate instances of given aggregateType
.
- EventSourcingRepository(Class<T>, EventStore, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initializes a repository with the default locking strategy, using a GenericAggregateFactory to create new
aggregate instances of given aggregateType
.
- EventSourcingRepository(AggregateFactory<T>, EventStore) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initializes a repository with the default locking strategy, using the given aggregateFactory
to
create new aggregate instances.
- EventSourcingRepository(AggregateFactory<T>, EventStore, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initializes a repository with the default locking strategy, using the given aggregateFactory
to
create new aggregate instances and triggering snapshots using the given snapshotTriggerDefinition
- EventSourcingRepository(AggregateFactory<T>, EventStore, ParameterResolverFactory, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initializes a repository with the default locking strategy, using the given aggregateFactory
to
create new aggregate instances.
- EventSourcingRepository(AggregateFactory<T>, EventStore, LockFactory, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initialize a repository with the given locking strategy.
- EventSourcingRepository(AggregateFactory<T>, EventStore, LockFactory, ParameterResolverFactory, SnapshotTriggerDefinition) - Constructor for class org.axonframework.eventsourcing.EventSourcingRepository
-
Initialize a repository with the given locking strategy and parameter resolver factory.
- EventStorageEngine - Interface in org.axonframework.eventsourcing.eventstore
-
Provides a mechanism to append as well as retrieve events from an underlying storage like a database.
- eventStore() - Method in interface org.axonframework.config.Configuration
-
Returns the Event Store in this Configuration, if it is defined.
- EventStore - Interface in org.axonframework.eventsourcing.eventstore
-
Provides a mechanism to open streams from events in the the underlying event storage.
- EventStoreException - Exception in org.axonframework.eventsourcing.eventstore
-
Indicates that the given events stream could not be stored or read due to an underlying exception.
- EventStoreException(String) - Constructor for exception org.axonframework.eventsourcing.eventstore.EventStoreException
-
Initialize the exception with the given message
.
- EventStoreException(String, Throwable) - Constructor for exception org.axonframework.eventsourcing.eventstore.EventStoreException
-
Initialize the exception with the given message
and cause
- EventTableFactory - Interface in org.axonframework.eventsourcing.eventstore.jdbc
-
Interface describing a factory for JDBC to create the Domain and Snapshot Event tables.
- EventUpcaster - Interface in org.axonframework.serialization.upcasting.event
-
Interface that is used for upcasters of event data.
- EventUpcasterChain - Class in org.axonframework.serialization.upcasting.event
-
- EventUpcasterChain(EventUpcaster...) - Constructor for class org.axonframework.serialization.upcasting.event.EventUpcasterChain
-
Initializes an upcaster chain from one or more upcasters.
- EventUpcasterChain(List<? extends EventUpcaster>) - Constructor for class org.axonframework.serialization.upcasting.event.EventUpcasterChain
-
Initializes an upcaster chain from the given list of upcasters.
- EventUtils - Class in org.axonframework.eventsourcing.eventstore
-
Utility class for dealing with events and event streams.
- ExceptionUtils - Class in org.axonframework.common
-
Exception utility methods.
- execute(Consumer<T>) - Method in interface org.axonframework.commandhandling.model.Aggregate
-
Execute a method on the underlying aggregate or one of its instances.
- execute(Runnable) - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Executes the given task.
- execute(Consumer<T>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- execute(Consumer<AR>) - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
- execute(Runnable) - Method in class org.axonframework.common.DirectExecutor
-
Executes the given command
immediately in the current thread.
- execute(Consumer<T>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
- execute(Consumer<T>) - Method in interface org.axonframework.eventhandling.saga.Saga
-
Execute the given invocation
against the root object of this Saga instance.
- execute(Runnable) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
SagaLifecycle
instance method to execute given
task
in the context of this SagaLifeCycle.
- execute(JobExecutionContext) - Method in class org.axonframework.eventhandling.scheduling.quartz.FireEventJob
-
- execute(Runnable) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Execute the given task
in the context of this Unit of Work.
- execute(Runnable, RollbackConfiguration) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Execute the given task
in the context of this Unit of Work.
- executeBatch(Connection, JdbcUtils.SqlFunction, Consumer<SQLException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Execute the a batch update or insert statement produced by the given sqlFunction
.
- executeInTransaction(Runnable) - Method in interface org.axonframework.common.transaction.TransactionManager
-
- executeQuery(Connection, JdbcUtils.SqlFunction, JdbcUtils.SqlResultConverter<R>, Function<SQLException, RuntimeException>) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Execute the query given by the sqlFunction
.
- executeUpdates(Connection, Consumer<SQLException>, JdbcUtils.SqlFunction...) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Execute the update statements produced by the given sqlFunctions
.
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Execute the given task
in the context of this Unit of Work.
- executeWithResult(Callable<V>) - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Executes the given task and returns the result of the task.
- executeWithResult(Callable<V>) - Method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
SagaLifecycle
instance method to execute given
task
in the context of this SagaLifeCycle.
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
Execute the given task
in the context of this Unit of Work.
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- executeWithResult(Callable<R>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Execute the given task
in the context of this Unit of Work.
- executeWithResult(Callable<R>, RollbackConfiguration) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Execute the given task
in the context of this Unit of Work.
- ExecutionException - Exception in org.axonframework.messaging
-
Exception thrown to indicate that execution of a task has failed.
- ExecutionException(String, Throwable) - Constructor for exception org.axonframework.messaging.ExecutionException
-
Initialize an ExecutionException with the given message
and cause
.
- ExecutionResult - Class in org.axonframework.messaging.unitofwork
-
Class of objects that contain the result of an executed task.
- ExecutionResult(Object) - Constructor for class org.axonframework.messaging.unitofwork.ExecutionResult
-
- expectedSourceType() - Method in class org.axonframework.serialization.ChainedConverter
-
- expectedSourceType() - Method in interface org.axonframework.serialization.ContentTypeConverter
-
The expected type of input data.
- expectedSourceType() - Method in class org.axonframework.serialization.converters.BlobToInputStreamConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.converters.ByteArrayToStringConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.converters.StringToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.xml.InputStreamToDom4jConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.xml.InputStreamToXomConverter
-
- expectedSourceType() - Method in class org.axonframework.serialization.xml.XomToStringConverter
-
- expectReply - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- 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.
- extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
-
Extracts the AssociationValues from the given event
as relevant for a Saga of given
sagaType
.
- extractAssociationValues(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSagaManager
-
- GapAwareTrackingToken - Class in org.axonframework.eventsourcing.eventstore
-
Implementation of a
TrackingToken
that uses the global insertion sequence number of the event to determine
tracking order and additionally stores a set of possible gaps that have been detected while tracking the event
store.
- generateIdentifier() - Method in class org.axonframework.common.DefaultIdentifierFactory
-
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
- generateIdentifier() - Method in class org.axonframework.common.IdentifierFactory
-
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
- GenericAggregateFactory<T> - Class in org.axonframework.eventsourcing
-
Aggregate factory that uses a convention to create instances of aggregates.
- GenericAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
-
Initialize the AggregateFactory for creating instances of the given aggregateType
.
- GenericCommandMessage<T> - Class in org.axonframework.commandhandling
-
Implementation of the CommandMessage that takes all properties as constructor parameters.
- GenericCommandMessage(T) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload and empty metaData
- GenericCommandMessage(T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload.
- GenericCommandMessage(Message<T>, String) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage from the given delegate
message containing payload, metadata and message
identifier, and the given commandName
.
- GenericDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
-
Generic implementation of a serialized domain event entry.
- GenericDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.GenericDomainEventEntry
-
Reconstruct an event entry from a stored object.
- GenericDomainEventMessage<T> - Class in org.axonframework.eventsourcing
-
- GenericDomainEventMessage(String, String, long, T) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
and payload
.
- GenericDomainEventMessage(String, String, long, T, Map<String, ?>) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
and payload
and metaData
.
- GenericDomainEventMessage(String, String, long, T, Map<String, ?>, String, Instant) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate using existing data.
- GenericDomainEventMessage(String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate using existing data.
- GenericDomainEventMessage(String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventsourcing.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
and payload
, metaData
and timestamp
.
- GenericEventMessage<T> - Class in org.axonframework.eventhandling
-
Generic implementation of the EventMessage interface.
- GenericEventMessage(T) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Creates a GenericEventMessage with given payload
, and an empty MetaData.
- GenericEventMessage(T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Creates a GenericEventMessage with given payload
and given metaData
.
- GenericEventMessage(String, T, Map<String, ?>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Constructor to reconstruct an EventMessage using existing data.
- GenericEventMessage(Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Constructor to reconstruct an EventMessage using existing data.
- GenericEventMessage(Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
- GenericJpaRepository<T> - Class in org.axonframework.commandhandling.model
-
Generic repository implementation that stores JPA annotated aggregates.
- GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
-
Initialize a repository for storing aggregates of the given aggregateType
.
- GenericJpaRepository(EntityManagerProvider, Class<T>, EventBus, LockFactory) - Constructor for class org.axonframework.commandhandling.model.GenericJpaRepository
-
Initialize a repository for storing aggregates of the given aggregateType
with an additional LockFactory
.
- GenericMessage<T> - Class in org.axonframework.messaging
-
Generic implementation of a
Message
that contains the payload and metadata as unserialized values.
- GenericMessage(T) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructs a Message for the given payload
using the correlation data of the current Unit of Work, if
present.
- GenericMessage(T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructs a Message for the given payload
and meta data
.
- GenericMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructor to reconstruct a Message using existing data.
- GenericSagaSqlSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
-
Generic SagaSqlSchema implementation, for use in most databases.
- GenericSagaSqlSchema() - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
Initialize a GenericSagaSqlSchema using default settings.
- GenericSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
Initialize a GenericSagaSqlSchema.
- GenericTokenEntry<T> - Class in org.axonframework.eventhandling.tokenstore
-
Generic implementation of a token entry.
- GenericTokenEntry(TrackingToken, Serializer, Class<T>, String, int) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
Initializes a new token entry for given token
, process
and segment
.
- GenericTokenEntry(T, String, String, String, String, int, Class<T>) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
Initializes a token entry from existing data.
- GenericTokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
-
Jdbc token entry table factory compatible with most databases.
- GenericTokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
-
- GenericTrackedDomainEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
-
Generic implementation of a serialized domain event entry with tracking token.
- GenericTrackedDomainEventEntry(TrackingToken, String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.GenericTrackedDomainEventEntry
-
Reconstruct an event entry from a stored object.
- GenericTrackedDomainEventEntry(long, String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.GenericTrackedDomainEventEntry
-
Reconstruct an event entry from a stored object.
- GenericTrackedDomainEventMessage<T> - Class in org.axonframework.eventsourcing
-
- GenericTrackedDomainEventMessage(TrackingToken, DomainEventMessage<T>) - Constructor for class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
-
Initialize a DomainEventMessage originating from an aggregate.
- GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate using existing data.
- GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventsourcing.GenericTrackedDomainEventMessage
-
Initialize a DomainEventMessage originating from an aggregate.
- GenericTrackedEventMessage<T> - Class in org.axonframework.eventhandling
-
- GenericTrackedEventMessage(TrackingToken, EventMessage<T>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
-
Creates a GenericTrackedEventMessage with given trackingToken
and delegate event message.
- GenericTrackedEventMessage(TrackingToken, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
-
Creates a GenericTrackedEventMessage with given trackingToken
and delegate event message.
- GenericTrackedEventMessage(TrackingToken, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
-
- GenericUpcasterChain<T> - Class in org.axonframework.serialization.upcasting
-
Implementation of an
Upcaster
that is formed of a chain of other upcasters which are combined to upcast a
stream of intermediate objects.
- GenericUpcasterChain(Upcaster<T>...) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
-
Initializes an upcaster chain from one or more upcasters.
- GenericUpcasterChain(List<? extends Upcaster<T>>) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
-
Initializes an upcaster chain from the given list of upcasters.
- get(K) - Method in interface org.axonframework.common.caching.Cache
-
Returns an item from the cache, or null
if no item was stored under that key
- get(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- get(K) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- get(K) - Method in class org.axonframework.common.caching.NoCache
-
- get(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- get() - Method in class org.axonframework.config.Component
-
Retrieves the object contained in this component, triggering the builder function if the component hasn't been
built yet.
- get(Object) - Method in class org.axonframework.messaging.MetaData
-
- get() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Gets the UnitOfWork bound to the current thread.
- get() - Method in class org.axonframework.serialization.CachingSupplier
-
- getActualVersion() - Method in exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
-
Returns the actual version of the aggregate, as loaded by the repository.
- getAggregateFactory(Class<?>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-
Returns the AggregateFactory registered for the given aggregateType
, or null
if no such
AggregateFactory is known.
- getAggregateFactory() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Returns the factory used by this repository.
- getAggregateIdentifier() - Method in exception org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException
-
Returns the identifier of the blacklisted aggregate.
- getAggregateIdentifier() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the identifier of the aggregate to recover.
- getAggregateIdentifier() - Method in exception org.axonframework.commandhandling.model.AggregateNotFoundException
-
Returns the identifier of the aggregate that could not be found.
- getAggregateIdentifier() - Method in exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
-
Returns the identifier of the aggregate which version is not as expected.
- getAggregateIdentifier() - Method in interface org.axonframework.eventsourcing.DomainEventMessage
-
Returns the identifier of the Aggregate that generated this DomainEvent.
- getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
-
- getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
- getAggregateIdentifier() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventData
-
Returns the Identifier of the Aggregate to which the Event was applied.
- getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
-
- getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getAggregateIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the Identifier of the Aggregate to which the Event owning the object to upcast, was applied.
- getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getAggregateRoot() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Get the annotated aggregate instance.
- getAggregateType() - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Returns the aggregate type stored by this repository.
- getAggregateType() - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
- getAggregateType() - Method in interface org.axonframework.eventsourcing.AggregateFactory
-
Returns the type of aggregate this factory creates.
- getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getAggregateType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the Type of the Aggregate to which the Event owning the object to upcast, was applied.
- getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getAssociationValue() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
-
Returns the association value contained in this entry.
- getAssociationValue(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
-
The AssociationValue to find the saga instance with, or null
if no AssociationValue can be found on
the given eventMessage
.
- getAssociationValues() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
- getAssociationValues() - Method in interface org.axonframework.eventhandling.saga.Saga
-
Returns a view on the Association Values for this saga instance.
- getBufferSize() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the buffer size to use.
- getCache() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the cache used to store Aggregates loaded by the DisruptorCommandBus.
- getCallback() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the CommandCallback instance for the executed command.
- getChannelIdentifier() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
-
Returns the identifier of the channel over which the command message was sent.
- getCharset() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Returns the character set used to convert character to bytes and vice versa.
- getCommandBus() - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Returns the CommandBus used by this gateway.
- getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the identifier of the command carried by this instance.
- getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the identifier of the command for which this message is a reply.
- getCommandMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the CommandMessage wrapped in this Message.
- getCommandName() - Method in interface org.axonframework.commandhandling.CommandMessage
-
Returns the name of the command to execute.
- getCommandName() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the command name of the command carried by this instance.
- getCommandName() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- getCommandTargetResolver() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the CommandTargetResolver that is used to find out which Aggregate is to be invoked for a given Command.
- getComponent(Class<T>) - Method in interface org.axonframework.config.Configuration
-
Returns the Component declared under the given componentType
, typically the interface the component
implements.
- getComponent(Class<T>, Supplier<T>) - Method in interface org.axonframework.config.Configuration
-
Returns the Component declared under the given componentType
, typically the interface the component
implements, reverting to the given defaultImpl
if no such component is defined.
- 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.
- 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
-
- 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
-
- getContentType() - Method in class org.axonframework.serialization.SerializedMetaData
-
- getContentType() - Method in interface org.axonframework.serialization.SerializedObject
-
Returns the type of this representation's data.
- getContentType() - Method in class org.axonframework.serialization.SimpleSerializedObject
-
- getConverter() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Returns the Converter used by this serialized.
- getConverter() - Method in class org.axonframework.serialization.JavaSerializer
-
- getConverter() - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- getConverter() - Method in class org.axonframework.serialization.MessageSerializer
-
- getConverter() - Method in interface org.axonframework.serialization.Serializer
-
Returns the
Converter
used by this Serializer to convert between serialized representations.
- getCoolingDownPeriod() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the cooling down period for the shutdown of the DisruptorCommandBus, in milliseconds.
- getCorrelationData() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- getCorrelationData() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Get the correlation data contained in the
message
being processed by the Unit of Work.
- getCreationPolicy() - Method in class org.axonframework.eventhandling.saga.SagaInitializationPolicy
-
Returns the creation policy
- getCreationPolicy() - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
-
Returns the creation policy of the inspected method.
- 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
-
- getDefaultCorrelationKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
-
Returns the default metadata key for the correlation id of a message.
- getDefaultTraceKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
-
Returns the default metadata key for the trace id of a message.
- getDelegate() - Method in class org.axonframework.messaging.MessageDecorator
-
Returns the wrapped message delegate.
- getDelegates() - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
-
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
- getDispatchInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the dispatch interceptors for the DisruptorCommandBus.
- getDomainEventData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Extracts the next domain event entry from the given resultSet
.
- getEntityManager() - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
-
- getEntityManager() - Method in interface org.axonframework.common.jpa.EntityManagerProvider
-
Returns the EntityManager instance to use.
- getEntityManager() - Method in class org.axonframework.common.jpa.SimpleEntityManagerProvider
-
- getError(Serializer) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the error of the command processing.
- getEventIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
-
- getEventIdentifier() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
-
Returns the identifier of the serialized event.
- getEventStore() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Returns the event store this snapshotter uses to load domain events and store snapshot events.
- getExceptionResult() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the exception that occurred while processing the incoming command, or null
if
processing did not result in an exception or if execution is not yet finished.
- getExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
-
Get the execution result in case the result is an exception.
- getExecutionResult() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Get the result of processing the
Message
.
- getExecutionResult() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Get the result of the task that was executed by this Unit of Work.
- getExecutionResults() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- getExecutor() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the Executor providing the processing resources (Threads) for the DisruptorCommandBus.
- getExecutor() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Returns the executor that executes snapshot taking tasks.
- getExpectedVersion() - Method in exception org.axonframework.commandhandling.model.ConflictingAggregateVersionException
-
Returns the version expected by the component loading the aggregate.
- getFieldValue(Field, Object) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns the value of the given field
in the given object
.
- getGaps() - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
-
- getGlobalIndex() - Method in class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
-
Get the global sequence number of the event
- getGroupIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
-
Returns the Quartz group identifier.
- getHandler(Message<?>) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- getHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
-
Returns a list of detected members of the inspected entity that are capable of handling certain messages.
- getId() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
-
The unique identifier of this entry.
- getIdentifier(T) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
-
Get the identifier of the given target
entity.
- getIdentifier(T) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- getIdentifier() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
-
Returns the identifier of the targeted Aggregate.
- getIdentifier() - Method in interface org.axonframework.eventhandling.EventMessage
-
Returns the identifier of this event.
- getIdentifier() - Method in class org.axonframework.messaging.AbstractMessage
-
- getIdentifier() - Method in interface org.axonframework.messaging.Message
-
Returns the identifier of this message.
- getIdentifier() - Method in class org.axonframework.messaging.MessageDecorator
-
- getIndex() - Method in class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
-
Get the highest global sequence of events seen up until the point of this tracking token.
- getInitialAssociationValue() - Method in class org.axonframework.eventhandling.saga.SagaInitializationPolicy
-
Returns the initial association value for a newly created saga.
- getInstance() - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
- getInstance() - Static method in class org.axonframework.common.annotation.PriorityAnnotationComparator
-
Returns the instance of the comparator.
- getInstance() - Static method in class org.axonframework.common.IdentifierFactory
-
Returns an instance of the IdentifierFactory discovered on the classpath.
- getInstance() - Static method in class org.axonframework.common.IdentifierValidator
-
Returns the singleton instance of the IdentifierValidator.
- getInstance() - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
- getInvocationInterceptorChain() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the InterceptorChain for the invocation process registered with this entry, or null
if none
is available.
- getInvokerId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the Identifier of the invoker that is chosen to handle this entry.
- getInvokerInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the interceptors for the DisruptorCommandBus.
- getInvokerThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the number of threads to use for Command Handler invocation.
- getIsLive() - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Indicates whether this Aggregate instance is 'live'.
- getIsLive() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- getIsLive() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
- getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
-
Returns the Quartz job identifier.
- getKey() - Method in class org.axonframework.eventhandling.saga.AssociationValue
-
Returns the key of this association value.
- getLastSequenceNumber() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
Get the highest known sequence number in the upstream event entry stream.
- getLoadFactor() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Returns the current load factor of this node.
- getMember(String, CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
-
Returns the member instance to which the given message
should be routed.
- getMembers() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
-
Returns the set of members registered with this consistent hash instance.
- getMessage() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- getMessage() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
-
Returns the command message that was sent.
- getMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- getMessage() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- getMessage() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Get the Message that is being processed in this context.
- getMessage() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Get the message that is being processed by the Unit of Work.
- getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getMessageIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the identifier of the message wrapping the object to upcast.
- getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getMessageMonitor() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the message monitor to use.
- getMessages() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
Get the batch of messages that is being processed (or has been processed) by this unit of work.
- getMetaData() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
-
- getMetaData() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
-
Returns the serialized data of the MetaData of the serialized Event.
- getMetaData() - Method in class org.axonframework.messaging.GenericMessage
-
- getMetaData() - Method in interface org.axonframework.messaging.Message
-
Returns the meta data for this event.
- getMetaData() - Method in class org.axonframework.messaging.MessageDecorator
-
- getMetaData() - Method in class org.axonframework.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
-
- 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
-
- getObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
De-serializes the object and returns the result.
- getObjectMapper() - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Returns the ObjectMapper used by this serializer, allowing for configuration of the serialization settings.
- getOrComputeResource(String, Function<? super String, R>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns the resource attached under given name
.
- getOrDefault(T, Supplier<T>) - Static method in class org.axonframework.common.ObjectUtils
-
Returns the given instance, if not null
, or otherwise the value provided by defaultProvider
.
- getOrDefault(T, T) - Static method in class org.axonframework.common.ObjectUtils
-
Returns the given instance, if not null
, or otherwise the given defaultValue
.
- getOwner() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the identifier of the process (JVM) having a claim on this token, or null
if the token isn't
claimed.
- getPayload() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
-
- getPayload() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
-
Returns the serialized data of the Event Message's payload.
- getPayload() - Method in class org.axonframework.messaging.GenericMessage
-
- getPayload() - Method in interface org.axonframework.messaging.Message
-
Returns the payload of this Event.
- getPayload() - Method in class org.axonframework.messaging.MessageDecorator
-
- getPayload() - Method in class org.axonframework.serialization.SerializedMessage
-
- getPayloadRevision() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the payload revision of the serialized payload of the command carried by this instance.
- getPayloadType() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the payload type of the serialized payload of the command carried by this instance.
- getPayloadType() - Method in class org.axonframework.messaging.GenericMessage
-
- getPayloadType() - Method in interface org.axonframework.messaging.Message
-
Returns the type of the payload.
- getPayloadType() - Method in class org.axonframework.messaging.MessageDecorator
-
- getPayloadType() - Method in class org.axonframework.serialization.SerializedMessage
-
- getPriority() - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-
- getPriority() - Method in class org.axonframework.common.property.DirectPropertyAccessStrategy
-
- getPriority() - Method in class org.axonframework.common.property.PropertyAccessStrategy
-
The priority of this strategy.
- getPriority() - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the name of the process to which this token belongs.
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
-
- getProducerType() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the producer type to use.
- getProperty(Class<? extends T>, String) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
-
Iterates over all known PropertyAccessStrategy implementations to create a
Property
instance for the
given parameters.
- getPublisherId() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the Identifier of the publisher that is chosen to handle this entry.
- getPublisherInterceptorChain() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the InterceptorChain for the publication process registered with this entry, or null
if
none
is available.
- getPublisherInterceptors() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the interceptors for the DisruptorCommandBus.
- getPublisherThreadCount() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the number of threads to use for storing and publication of generated Events.
- getReader(Class<?>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Provides the ObjectReader, with which objects are read from the JSON form.
- getRepository(Class<?>) - Static method in class org.axonframework.commandhandling.disruptor.CommandHandlerInvoker
-
Returns the Repository instance for Aggregate with given typeIdentifier
used by the
CommandHandlerInvoker that is running on the current thread.
- getRescheduleCommandsOnCorruptState() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Indicates whether commands that failed due to potentially corrupt Aggregate state should be automatically
rescheduled for processing.
- getResolver() - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.eventhandling.TimestampParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
-
- getResource(String) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns the resource attached under given name
, or null
if no such resource is
available.
- getResult() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for the command handling to complete, and then returns its result.
- getResult(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for at most the given time for the command handling to complete, and then retrieves its
result, if available.
- getResult() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Returns the result of the command's execution, or null
if the command is not yet executed or
resulted in an exception.
- getResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
-
Returns the execution result.
- getResultRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the result revision of the serialized result for which this message is a reply.
- getResultType() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the result type of the serialized result for which this message is a reply.
- getReturnValue(Serializer) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the returnValue of the command processing.
- getRevision() - Method in class org.axonframework.eventhandling.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.
- getRollbackConfiguration() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the RollbackConfiguration indicating for which Exceptions the DisruptorCommandBus should perform a
rollback, and which exceptions should result in a Commit.
- getRoutingKey(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
.
- getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
-
Returns the Saga Initialization Policy for a Saga of the given sagaType
and event
.
- getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSagaManager
-
- getSagaId() - Method in class org.axonframework.eventhandling.saga.repository.jpa.SagaEntry
-
Returns the identifier of the saga contained in this entry
- getSagaIdentifier() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
- getSagaIdentifier() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
-
Returns the Saga Identifier contained in this entry.
- getSagaIdentifier() - Method in interface org.axonframework.eventhandling.saga.Saga
-
Returns the unique identifier of this saga.
- getSagaType() - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
-
Returns the class of Saga managed by this SagaManager
- getSagaType() - Method in class org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry
-
Returns the type (fully qualified class name) of the Saga this association value belongs to
- getSagaType() - Method in class org.axonframework.eventhandling.saga.repository.jpa.SagaEntry
-
Returns the type identifier of the serialized saga
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the segment index of the process to which this token belongs.
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
-
- getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.FullConcurrencyPolicy
-
- getSequenceIdentifierFor(T) - Method in interface org.axonframework.eventhandling.async.SequencingPolicy
-
Returns the sequence identifier for the given event
.
- getSequenceIdentifierFor(EventMessage) - Method in class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-
- getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.SequentialPolicy
-
- getSequenceNumber() - Method in interface org.axonframework.eventsourcing.DomainEventMessage
-
Returns the sequence number that allows DomainEvents originating from the same Aggregate to be placed in the
order of generation.
- getSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
-
- getSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
- getSequenceNumber() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventData
-
Returns the sequence number of the event in the aggregate.
- getSequenceNumber() - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
-
- getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getSequenceNumber() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the sequence number of the event in the aggregate, or an empty Optional if the message wrapping the
object being upcast does not contain a sequence number.
- getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the serialized metadata of the command carried by this instance.
- getSerializedObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
Returns the serialized object to deserialize upon request
- getSerializedPayload() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the serialized payload of the command carried by this instance.
- getSerializedResult() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the serialized result for which this message is a reply.
- getSerializedSaga() - Method in class org.axonframework.eventhandling.saga.repository.jpa.SagaEntry
-
Returns the serialized form of the Saga.
- getSerializedToken() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the serialized token.
- getSerializer() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the serializer to perform pre-serialization with, or null
if no pre-serialization should be
done.
- getSerializer() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Get the serializer used by this storage engine when storing and retrieving events.
- getSerializer() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
Returns the serializer to deserialize this object
- getSnapshotData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Extracts the next snapshot entry from the given resultSet
.
- getSnapshotTrigger() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
The trigger instance that monitors this aggregate to trigger a snapshot
- getState() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Get the state of the event processor.
- getTargetType() - Method in class org.axonframework.eventhandling.AnnotationEventListenerAdapter
-
- getTargetType() - Method in interface org.axonframework.eventhandling.EventListenerProxy
-
Returns the instance type that this proxy delegates all event handling to.
- getterName(String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-
Returns the name of the method that is used to access the property.
- getterName(String) - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-
- getterName(String) - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-
- getTimestamp() - Method in interface org.axonframework.eventhandling.EventMessage
-
Returns the timestamp of this event.
- getTimestamp() - Method in class org.axonframework.eventhandling.GenericEventMessage
-
- getTimestamp() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventEntry
-
- getTimestamp() - Method in interface org.axonframework.eventsourcing.eventstore.EventData
-
Returns the timestamp at which the event was first created.
- getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getTimestamp() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the timestamp at which the event was first created.
- getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getToken(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the token, deserializing it with given serializer
- getTokenId() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
-
Returns the identifier of the scheduled task.
- getTokenType() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
- getTrackedEventData(ResultSet, TrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Extracts the next tracked event entry from the given resultSet
.
- getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getTrackingToken() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the tracking token of the event, or an empty Optional if the message wrapping the object being upcast
does not contain a tracking token.
- getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getTransactionManager() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the transaction manager to use to manage a transaction around the storage and publication of events.
- getType() - Method in interface org.axonframework.eventsourcing.DomainEventMessage
-
Returns the type of the Aggregate that generated this DomainEvent.
- getType() - Method in class org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry
-
- getType() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
- getType() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventData
-
Returns the type identifier of the aggregate.
- getType() - Method in class org.axonframework.eventsourcing.GenericDomainEventMessage
-
- 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.
- getValue(T) - Method in class org.axonframework.common.property.DirectlyAccessedProperty
-
- getValue(T) - Method in class org.axonframework.common.property.MethodAccessedProperty
-
- getValue(T) - Method in interface org.axonframework.common.property.Property
-
Returns the value of the property on given target
.
- getValue() - Method in class org.axonframework.eventhandling.saga.AssociationValue
-
Returns the value of this association.
- getVersion(T) - Method in interface org.axonframework.commandhandling.model.inspection.AggregateModel
-
Get the current version number of the given aggregate
.
- getVersion(T) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- getVersion() - Method in class org.axonframework.commandhandling.VersionedAggregateIdentifier
-
Returns the version of the targeted Aggregate, or null
if the version is irrelevant.
- getViolatingMethod() - Method in exception org.axonframework.messaging.annotation.UnsupportedHandlerException
-
A reference to the method that violated the event handler rules.
- getViolations() - Method in exception org.axonframework.messaging.interceptors.JSR303ViolationException
-
Returns the violations that were detected when this exception was thrown.
- getWaitStrategy() - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the WaitStrategy currently configured.
- getWrappedAggregate() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
Get the delegate aggregate wrapped by this instance.
- getWriter() - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Provides the ObjectWriter, with which objects are serialized to JSON form.
- getXStream() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Returns a reference to the underlying XStream
instance, that does the actual
serialization.
- globalIndexColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the global index of the event.
- GlobalSequenceTrackingToken - Class in org.axonframework.eventsourcing.eventstore
-
Tracking token based on the global sequence number of an event.
- GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
-
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
Returns the sql to register the auto incrementing global sequence column.
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
-
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
-
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-
- idColumnType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
-
- identifier() - Method in interface org.axonframework.commandhandling.model.Aggregate
-
Get the unique identifier of this aggregate
- identifier() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- identifier() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
- identifierAsString() - Method in interface org.axonframework.commandhandling.model.Aggregate
-
Get the unique identifier of this aggregate, represented as a String.
- IdentifierFactory - Class in org.axonframework.common
-
Abstract Factory class that provides access to an IdentifierFactory implementation.
- IdentifierFactory() - Constructor for class org.axonframework.common.IdentifierFactory
-
- IdentifierValidator - Class in org.axonframework.common
-
Validates the structure of an object passed as Aggregate Identifier.
- ifStarted(Consumer<UnitOfWork<?>>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
If a UnitOfWork is started, invokes the given consumer
with the active Unit of Work.
- IncompatibleAggregateException - Exception in org.axonframework.eventsourcing
-
- IncompatibleAggregateException(String, Exception) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
-
Initialize the exception with given message
and cause
.
- IncompatibleAggregateException(String) - Constructor for exception org.axonframework.eventsourcing.IncompatibleAggregateException
-
Initialize the exception with given message
.
- 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 interface org.axonframework.eventsourcing.SnapshotTrigger
-
Invoked when the initialization of the aggregate based on passed events is completed.
- initialize(ConflictResolver) - Static method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
-
Initialize conflict resolution in the context of the current Unit of Work dealing with a command on an event
sourced aggregate.
- initialize(Callable<T>, AggregateModel<T>, EventBus) - Static method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Initialize an aggregate created by the given aggregateFactory
which is described in the given
aggregateModel
.
- initialize(T, AggregateModel<T>, EventBus) - Static method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Initialize an aggregate with the given aggregateRoot
which is described in the given
aggregateModel
.
- initialize(Configuration) - Method in class org.axonframework.config.AggregateConfigurer
-
- initialize(Configuration) - Method in class org.axonframework.config.EventHandlingConfiguration
-
- initialize(Configuration) - Method in interface org.axonframework.config.ModuleConfiguration
-
Initialize the module configuration using the given global config
- initialize(Configuration) - Method in class org.axonframework.config.SagaConfiguration
-
- initialize() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Initializes the QuartzEventScheduler.
- initialize(T, AggregateModel<T>, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
Initializes an EventSourcedAggregate instance for the given aggregateRoot
, based on the given inspector
, which publishes events to the given eventBus
.
- initialize(Callable<T>, AggregateModel<T>, EventBus, SnapshotTrigger) - Static method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
Initializes an EventSourcedAggregate instance using the given aggregateFactory
, based on the given inspector
, which publishes events to the given eventBus
and stores events in the given eventStore
.
- initializeState(DomainEventStream) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
Initialize the state of this Event Sourced Aggregate with the events from the given eventStream
.
- injectResources(Object) - Method in class org.axonframework.eventhandling.saga.AbstractResourceInjector
-
- injectResources(Object) - Method in enum org.axonframework.eventhandling.saga.repository.NoResourceInjector
-
- injectResources(Object) - Method in interface org.axonframework.eventhandling.saga.ResourceInjector
-
Inject required resources into the given saga
.
- InMemoryEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore.inmemory
-
Thread-safe event storage engine that stores events and snapshots in memory.
- InMemoryEventStorageEngine() - Constructor for class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- InMemorySagaStore - Class in org.axonframework.eventhandling.saga.repository.inmemory
-
SagaRepository implementation that stores all Saga instances in memory.
- InMemorySagaStore() - Constructor for class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
-
- InMemoryTokenStore - Class in org.axonframework.eventhandling.tokenstore.inmemory
-
Implementation of a
TokenStore
that stores tracking tokens in memory.
- InMemoryTokenStore() - Constructor for class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-
- InputStreamToByteArrayConverter - Class in org.axonframework.serialization.converters
-
Converter that converts an InputStream to a byte array.
- InputStreamToByteArrayConverter() - Constructor for class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
-
- InputStreamToDom4jConverter - Class in org.axonframework.serialization.xml
-
Converter that converts an input stream to a Dom4J document.
- InputStreamToDom4jConverter() - Constructor for class org.axonframework.serialization.xml.InputStreamToDom4jConverter
-
- InputStreamToXomConverter - Class in org.axonframework.serialization.xml
-
Converter that converts an input stream to a XOM document.
- InputStreamToXomConverter() - Constructor for class org.axonframework.serialization.xml.InputStreamToXomConverter
-
- insertOrUpdateToken(ResultSet, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
If the given resultSet
has no items this method should insert a new token entry.
- insertSaga(Class<? extends T>, String, T, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.CachingSagaStore
-
- insertSaga(Class<?>, String, Object, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
-
- insertSaga(Class<?>, String, Object, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
-
- insertSaga(Class<?>, String, Object, TrackingToken, Set<AssociationValue>) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
-
- insertSaga(Class<? extends T>, String, T, TrackingToken, Set<AssociationValue>) - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore
-
Adds a new Saga and its initial association values to the store.
- insertTokenEntry(ResultSet, TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Inserts a new token entry via the given updatable resultSet
.
- inspect(Class<? extends C>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
-
Inspect another handler type and register the result to the inspector registry of this inspector.
- inspectAggregate(Class<AT>) - Static method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- inspectAggregate(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
Create an inspector for given aggregateType
that uses given parameterResolverFactory
to resolve
method parameters.
- inspectType(Class<T>) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
-
- inspectType(Class<T>, ParameterResolverFactory) - Static method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
-
Create an inspector for given handlerType
that uses given parameterResolverFactory
to resolve
method parameters.
- INSTANCE - Static variable in class org.axonframework.commandhandling.callbacks.LoggingCallback
-
The singleton instance for this callback
- INSTANCE - Static variable in class org.axonframework.commandhandling.callbacks.NoOpCallback
-
A statically available instance of the NoOpCallback.
- INSTANCE - Static variable in class org.axonframework.common.caching.NoCache
-
Creates a singleton reference the the NoCache implementation.
- INSTANCE - Static variable in class org.axonframework.common.DirectExecutor
-
Returns a singleton instance of the DirectExecutor.
- instance() - Static method in enum org.axonframework.common.transaction.NoTransactionManager
-
Returns the singleton instance of this TransactionManager
- instance() - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
-
- INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
-
Singleton HsqlEventTableFactory instance
- INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
-
Singleton MySqlEventTableFactory instance
- INSTANCE - Static variable in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
-
Singleton PostgresEventTableFactory instance
- instance() - Static method in class org.axonframework.messaging.annotation.HandlerComparator
-
Returns the singleton comparator managed by the HandlerComparator class.
- instance() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
-
Returns the instance of {@link NoOpMessageMonitor}
.
- intercept(CommandMessage<C>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Invokes all the dispatch interceptors.
- intercept(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
Invokes all the dispatch interceptors.
- InterceptorChain - Interface in org.axonframework.messaging
-
The interceptor chain manages the flow of a message through a chain of interceptors and ultimately to the message
handler.
- IntermediateEventRepresentation - Interface in org.axonframework.serialization.upcasting.event
-
Interface describing the intermediate representation of an event during upcasting.
- IntervalRetryScheduler - Class in org.axonframework.commandhandling.gateway
-
RetryScheduler implementation that retries commands at regular intervals when they fail because of an exception that
is not explicitly non-transient.
- IntervalRetryScheduler(ScheduledExecutorService, int, int) - Constructor for class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
-
Initializes the retry scheduler to schedule retries on the given executor
using the given
interval
and allowing maxRetryCount
retries before giving up permanently.
- invoke(Object, Method, Object[]) - Method in interface org.axonframework.commandhandling.gateway.CommandGatewayFactory.InvocationHandler
-
Handle the invocation of the given invokedMethod
, invoked on given proxy
with
given
args
.
- invoke(Function<T, R>) - Method in interface org.axonframework.commandhandling.model.Aggregate
-
Invoke a method on the underlying aggregate root or one of its instances.
- invoke(Function<T, R>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- invoke(Function<AR, R>) - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
- invoke(Function<T, R>) - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
- invoke(Function<T, R>) - Method in interface org.axonframework.eventhandling.saga.Saga
-
Execute the given invocation
against the root object of this Saga instance.
- invokeInitHandlers() - Method in class org.axonframework.config.DefaultConfigurer
-
Calls all registered init handlers.
- invokeShutdownHandlers() - Method in class org.axonframework.config.DefaultConfigurer
-
Invokes all registered shutdown handlers
- invokeStartHandlers() - Method in class org.axonframework.config.DefaultConfigurer
-
Invokes all registered start handlers
- IOUtils - Class in org.axonframework.common.io
-
Utility methods for IO operations.
- isAccessible(AccessibleObject) - Static method in class org.axonframework.common.ReflectionUtils
-
Indicates whether the given member
is accessible.
- isActive() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
- isActive() - Method in interface org.axonframework.eventhandling.saga.Saga
-
Indicates whether or not this saga is active.
- isActive() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Indicates whether this UnitOfWork is started.
- isAfter(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
-
Check if this Phase comes after given other phase
.
- isBefore(UnitOfWork.Phase) - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
-
Check if this Phase comes before given other phase
.
- isCauseOf(Throwable) - Static method in exception org.axonframework.common.AxonNonTransientException
-
Indicates whether the given throwable
is a AxonNonTransientException exception or indicates to be
caused by one.
- isCurrent() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
- isDeleted() - Method in interface org.axonframework.commandhandling.model.Aggregate
-
Check if this aggregate has been deleted.
- isDeleted() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- isDeleted() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
- isDeserialized() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
Indicates whether this object has already been deserialized.
- isDuplicateKeyViolation(Exception) - Method in interface org.axonframework.common.jdbc.PersistenceExceptionResolver
-
Indicates whether the given exception
represents a duplicate key violation.
- isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcSQLErrorCodesResolver
-
- isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
- isDuplicateKeyViolation(Exception) - Method in class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
-
- isEmpty() - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
-
Indicates whether any elements are contained within this map.
- isEmpty() - Method in class org.axonframework.messaging.MetaData
-
- isEndingHandler() - Method in class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
-
Indicates whether this handler is one that ends the Saga lifecycle
- isExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
-
Check if the result of the execution yielded an exception.
- isExpectReply() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Indicates whether the sender of this message requests a reply.
- isExplicitlyNonTransient(Throwable) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
-
Indicates whether the given failure
is clearly non-transient.
- isFactoryHandler() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- isFactoryHandler() - Method in interface org.axonframework.commandhandling.model.inspection.CommandMessageHandlingMember
-
Check if this message handler creates a new instance of the entity of type T
to handle this command.
- isFalse(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
-
Asserts that the given expression
is false.
- isHeld() - Method in interface org.axonframework.common.lock.Lock
-
Indicates whether the lock is still owned true
, or whether it has been released false
.
- isLastMessage(Message<?>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
Checks if the given message
is the last of the batch being processed in this unit of work.
- isLive() - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Indicates whether this Aggregate instance is 'live'.
- isLockHeld() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
Check if the aggregate currently holds a lock.
- isMetaDataDeserialized() - Method in class org.axonframework.serialization.SerializedMessage
-
Indicates whether the metaData of this message has already been deserialized.
- isNonFinalPublicMember(Member) - Static method in class org.axonframework.common.ReflectionUtils
-
Checks whether the given member
is public and non-final.
- isPayloadDeserialized() - Method in class org.axonframework.serialization.SerializedMessage
-
Indicates whether the payload of this message has already been deserialized.
- isRecoverEntry() - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Indicates whether this entry is a recovery entry.
- isReverseCallbackOrder() - Method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
-
Check whether registered handlers for this phase should be invoked in the order of registration (first
registered handler is invoked first) or in the reverse order of registration (last registered handler is
invoked first).
- isRolledBack() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- isRolledBack() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Check if the Unit of Work has been rolled back.
- isRoot() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Check that returns true
if this Unit of Work has not got a parent.
- isSerializedMetaData(SerializedObject<?>) - Static method in class org.axonframework.serialization.SerializedMetaData
-
- 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.
- isSuccess() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Whether the reply message represents a successfully executed command.
- isTransient(Field) - Static method in class org.axonframework.common.ReflectionUtils
-
Indicates whether the given field has the "transient" modifier
- isTrue(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
-
Asserts that the given expression
is true.
- isValidIdentifier(Class<?>) - Method in class org.axonframework.common.IdentifierValidator
-
Indicates whether or not the given identifierType
is safe to use as aggregate identifier
- iterator() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- map(Function<UnitOfWork<?>, T>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
If a Unit of Work is started, execute the given function
on it.
- markDeleted() - Static method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Marks this aggregate as deleted, instructing a repository to remove that aggregate at an appropriate time.
- matches(Message<?>) - Method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
-
- matches(Message) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-
- matches(Message<?>) - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-
- matches(Message) - Method in class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
-
- matches(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
-
- matches(Message<?>) - Method in interface org.axonframework.messaging.annotation.ParameterResolver
-
Indicates whether this resolver is capable of providing a value for the given message
.
- matches(Message) - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
-
- MavenArtifactRevisionResolver - Class in org.axonframework.serialization
-
RevisionResolver that uses Maven meta data to retrieve the application version.
- MavenArtifactRevisionResolver(String, String) - Constructor for class org.axonframework.serialization.MavenArtifactRevisionResolver
-
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given
groupId
and artifactId
.
- MavenArtifactRevisionResolver(String, String, ClassLoader) - Constructor for class org.axonframework.serialization.MavenArtifactRevisionResolver
-
Initialize the RevisionResolver to look for the version in the Meta Data of the artifact with given
groupId
and artifactId
.
- mayClaim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Check if given owner
may claim this token.
- md5Hex(String) - Static method in class org.axonframework.common.digest.Digester
-
Utility method that creates a hex string of the MD5 hash of the given input
- Member - Interface in org.axonframework.commandhandling.distributed
-
Member of a cluster of connected command endpoints.
- MemberAccessibilityCallback - Class in org.axonframework.common
-
PrivilegedAction that makes the given method accessible for reflection.
- MemberAccessibilityCallback(AccessibleObject) - Constructor for class org.axonframework.common.MemberAccessibilityCallback
-
Initialize the callback to make the given method
accessible for reflection.
- merge(T, T, Supplier<T>) - Static method in class org.axonframework.common.CollectionUtils
-
Merge two collections into a new collection instance.
- mergedWith(Map<String, ?>) - Method in class org.axonframework.messaging.MetaData
-
Returns a MetaData instance containing values of this
, combined with the given
additionalEntries
.
- Message<T> - Interface in org.axonframework.messaging
-
Representation of a Message, containing a Payload and MetaData.
- MessageDecorator<T> - Class in org.axonframework.messaging
-
Abstract implementation of a
Message
that delegates to an existing message.
- MessageDecorator(Message<T>) - Constructor for class org.axonframework.messaging.MessageDecorator
-
Initializes a new decorator with given delegate
message.
- MessageDispatchInterceptor<T extends Message<?>> - Interface in org.axonframework.messaging
-
Interceptor that allows messages to be intercepted and modified before they are dispatched.
- MessageHandler - Annotation Type in org.axonframework.messaging.annotation
-
Annotation indicating that a member method should be able to respond to
Message
s.
- MessageHandler<T extends Message<?>> - Interface in org.axonframework.messaging
-
Interface for a component that processes Messages.
- MessageHandlerInterceptor<T extends Message<?>> - Interface in org.axonframework.messaging
-
Workflow interface that allows for customized message handler invocation chains.
- MessageHandlerInvocationException - Exception in org.axonframework.messaging.annotation
-
MessageHandlerInvocationException is a runtime exception that wraps an exception thrown by an invoked message
handler.
- MessageHandlerInvocationException(String, Throwable) - Constructor for exception org.axonframework.messaging.annotation.MessageHandlerInvocationException
-
Initialize the MessageHandlerInvocationException using given message
and cause
.
- MessageHandlingMember<T> - Interface in org.axonframework.messaging.annotation
-
Interface describing a handler for specific messages targeting entities of a specific type.
- MessageIdentifier - Annotation Type in org.axonframework.messaging.annotation
-
Annotation indication that a parameter on a Message Handler method should be
injected with the identifier of a Message.
- MessageIdentifierParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
An extension of the AbstractAnnotatedParameterResolverFactory that accepts
parameters of a
String
type that are annotated with the
MessageIdentifier
annotation and assigns the identifier of the Message.
- MessageIdentifierParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
-
- messageMonitor(Class<?>, String) - Method in interface org.axonframework.config.Configuration
-
Returns the message monitor configured for a component of given componentType
and componentName
.
- MessageMonitor<T extends Message<?>> - Interface in org.axonframework.monitoring
-
Specifies a mechanism to monitor message processing.
- MessageMonitor.MonitorCallback - Interface in org.axonframework.monitoring
-
An interface to let the message processor inform the message monitor of the result
of processing the message
- MessageOriginProvider - 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
-
- MessageProcessingContext<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
-
Maintains the context around the processing of a single Message.
- MessageProcessingContext(T) - Constructor for class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Creates a new processing context for the given message
.
- MessageSerializer - Class in org.axonframework.serialization
-
- MessageSerializer(Serializer) - Constructor for class org.axonframework.serialization.MessageSerializer
-
Initializes the MessageSerializer as a wrapper around the given serializer.
- MessageStream<M extends Message<?>> - Interface in org.axonframework.messaging
-
Interface for a tracked stream of
Messages
.
- MetaData - Class in org.axonframework.messaging
-
Represents MetaData that is passed along with a payload in a Message.
- MetaData(Map<String, ?>) - Constructor for class org.axonframework.messaging.MetaData
-
Initializes a MetaData instance with the given items
as content.
- metaDataColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the serialized metadata of the event.
- MetaDataCommandTargetResolver - Class in org.axonframework.commandhandling
-
CommandTargetResolver implementation that uses MetaData entries to extract the identifier and optionally the version
of the aggregate that the command targets.
- MetaDataCommandTargetResolver(String) - Constructor for class org.axonframework.commandhandling.MetaDataCommandTargetResolver
-
Initializes the MetaDataCommandTargetResolver to use the given identifierKey
as the MetaData
key to the aggregate identifier, and a null
(ignored) version.
- MetaDataCommandTargetResolver(String, String) - Constructor for class org.axonframework.commandhandling.MetaDataCommandTargetResolver
-
Initializes the MetaDataCommandTargetResolver to use the given identifierKey
as the MetaData
key to the aggregate identifier, and the given versionKey
as key to the (optional) version entry.
- MetaDataDeserializer - Class in org.axonframework.serialization.json
-
JsonDeserializer implementation that deserializes MetaData instances.
- MetaDataDeserializer() - Constructor for class org.axonframework.serialization.json.MetaDataDeserializer
-
- MetaDataRoutingStrategy - Class in org.axonframework.commandhandling.distributed
-
RoutingStrategy implementation that uses the value in the MetaData of a CommandMessage assigned to a given key.
- MetaDataRoutingStrategy(String) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
-
Initializes the MetaDataRoutingStrategy where the given metaDataKey
is used to get the Meta Data
value.
- MetaDataRoutingStrategy(String, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy
-
Initializes the MetaDataRoutingStrategy where the given metaDataKey
is used to get the Meta Data
value.
- MetaDataValue - Annotation Type in org.axonframework.messaging.annotation
-
Annotation that indicates the parameter needs to be resolved to the value of the Message MetaData stored under the
given key
.
- MethodAccessedProperty<T> - Class in org.axonframework.common.property
-
Property implementation that invokes a method to obtain a value of a property for a given instance.
- MethodAccessedProperty(Method, String) - Constructor for class org.axonframework.common.property.MethodAccessedProperty
-
Initialize a reader that uses given accessorMethod
to access a property with given
propertyName
.
- MethodCommandHandlerDefinition - Class in org.axonframework.commandhandling.model.inspection
-
- MethodCommandHandlerDefinition() - Constructor for class org.axonframework.commandhandling.model.inspection.MethodCommandHandlerDefinition
-
- methodsOf(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns an
Iterable
of all the methods declared on the given class and its super classes.
- modelFactory() - Method in interface org.axonframework.eventhandling.saga.metamodel.SagaModel
-
Returns the factory that created this model.
- ModelInspector<T> - Class in org.axonframework.commandhandling.model.inspection
-
Inspector of an entity of type T
that creates command and event handlers that delegate to a target entity and
its child entities.
- modelOf(Class<? extends C>) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
-
Get the EntityModel of an entity of type childEntityType
in case it is the child of the modeled entity.
- modelOf(Class<? extends C>) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- modelOf(Class<T>) - Method in class org.axonframework.eventhandling.saga.metamodel.DefaultSagaMetaModelFactory
-
- modelOf(Class<T>) - Method in interface org.axonframework.eventhandling.saga.metamodel.SagaMetaModelFactory
-
Create a saga meta model for the given sagaType
.
- ModuleConfiguration - Interface in org.axonframework.config
-
Interface describing a module for the Axon Configuration API.
- MonitorAwareCallback<C,R> - Class in org.axonframework.commandhandling
-
Wrapper for a callback that notifies a Message Monitor of the message execution result.
- MonitorAwareCallback(CommandCallback<C, R>, MessageMonitor.MonitorCallback) - Constructor for class org.axonframework.commandhandling.MonitorAwareCallback
-
Initialize a callback wrapped around the delegate
which will notify a Message Monitor for the given messageMonitorCallback
.
- MultiCorrelationDataProvider<T extends Message> - Class in org.axonframework.messaging.correlation
-
CorrelationDataProvider that combines the data of multiple other correlation providers.
- MultiCorrelationDataProvider(List<? extends CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.correlation.MultiCorrelationDataProvider
-
Initialize the correlation data provider, delegating to given correlationDataProviders
.
- MultiMessageMonitor<T extends Message<?>> - Class in org.axonframework.monitoring
-
Delegates messages and callbacks to the given list of message monitors
- MultiMessageMonitor(MessageMonitor<? super T>...) - Constructor for class org.axonframework.monitoring.MultiMessageMonitor
-
Initialize a message monitor with the given messageMonitors
- MultiMessageMonitor(List<MessageMonitor<? super T>>) - Constructor for class org.axonframework.monitoring.MultiMessageMonitor
-
Initialize a message monitor with the given list of messageMonitors
- MultiParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
ParameterResolverFactory instance that delegates to multiple other instances, in the order provided.
- MultiParameterResolverFactory(ParameterResolverFactory...) - Constructor for class org.axonframework.messaging.annotation.MultiParameterResolverFactory
-
Initializes an instance that delegates to the given delegates
, in the order provided.
- MultiParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.messaging.annotation.MultiParameterResolverFactory
-
Initializes an instance that delegates to the given delegates
, in the order provided.
- MySqlEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
-
Jdbc event entry table factory for MySql databases.
- MySqlEventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
-
- ParameterResolver<T> - Interface in org.axonframework.messaging.annotation
-
Interface for a mechanism that resolves handler method parameter values from a given
Message
.
- parameterResolverFactory() - Method in interface org.axonframework.config.Configuration
-
Returns the Parameter Resolver Factory defined in this Configuration
- ParameterResolverFactory - Interface in org.axonframework.messaging.annotation
-
Interface for objects capable of creating Parameter Resolver instances for annotated handler methods.
- parametersMatch(Message<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
Checks if the parameter resolvers of this member are compatible with the given message
.
- parent() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- parent() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- parent() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns an optional for the parent of this Unit of Work.
- pause() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- payloadColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the serialized payload of the event.
- payloadMatching(Predicate<Object>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
-
Returns a
Predicate
for a
ConflictResolver
that responds affirmative if the payload of any event
in a list of unseen events matches the given
messageFilter
.
- payloadMatching(Class<T>, Predicate<? super T>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
-
Returns a
Predicate
for a
ConflictResolver
that responds affirmative if the payload of any event
in a list of unseen events is of given
payloadType
and matches the given
messageFilter
.
- PayloadParameterResolver - Class in org.axonframework.messaging.annotation
-
Implementation of a
ParameterResolver
that resolves the Message payload as parameter in a handler method.
- PayloadParameterResolver(Class<?>) - Constructor for class org.axonframework.messaging.annotation.PayloadParameterResolver
-
- payloadRevision - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- payloadRevisionColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the revision number of the serialized payload.
- payloadType - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- payloadType() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
Returns the sql to describe the type of payload column.
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory
-
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory
-
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-
- payloadType() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory
-
- payloadType() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
- payloadType() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
-
Returns the payload type of messages that can be processed by this handler.
- payloadType() - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-
- payloadTypeColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the event payload type.
- payloadTypeOf(Class<T>) - Static method in class org.axonframework.commandhandling.conflictresolution.Conflicts
-
Returns a
Predicate
for a
ConflictResolver
that responds affirmative if the payload type of any
event in a list of unseen events is assignable to given
payloadType
.
- 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 interface org.axonframework.messaging.MessageStream
-
Checks whether or not the next message in the stream is immediately available.
- PersistenceExceptionResolver - Interface in org.axonframework.common.jdbc
-
The PersistenceExceptionResolver is used to find out if an exception is caused by duplicate keys.
- PessimisticLockFactory - Class in org.axonframework.common.lock
-
Implementation of a
LockFactory
that uses a pessimistic locking strategy.
- PessimisticLockFactory() - Constructor for class org.axonframework.common.lock.PessimisticLockFactory
-
Creates a new IdentifierBasedLock instance.
- phase() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- phase() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns the current phase of the Unit of Work.
- PK() - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
-
Constructor for JPA
- PK(String, int) - Constructor for class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.PK
-
Constructs a primary key for a TokenEntry
- PK() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.PK
-
Constructor for JPA.
- postDelete(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Perform action that needs to be done directly after deleting an aggregate and committing the aggregate's
uncommitted events.
- PostgresEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
-
Jdbc table factory for Postgress databases.
- PostgresSagaSqlSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
-
SQL schema supporting postgres databases.
- PostgresSagaSqlSchema() - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
-
Initialize a PostgresSagaSqlSchema using the default schema configuration.
- PostgresSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
-
Initialize a PostgresSagaSqlSchema using the given sagaSchema
.
- PostgresTokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
-
Jdbc token entry table factory for Postgres databases.
- PostgresTokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.PostgresTokenTableFactory
-
- postProcessInstance(T) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
Perform any processing that must be done on an aggregate instance that was reconstructed from a Snapshot
Event.
- postSave(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Perform action that needs to be done directly after updating an aggregate and committing the aggregate's
uncommitted events.
- prepareCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
Process given events
while the Unit of Work root is preparing for commit.
- prepareCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- prepareForCommit(A) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Register handlers with the current Unit of Work that save or delete the given aggregate
when
the Unit of Work is committed.
- prepareForCommit(LockAwareAggregate<T, A>) - Method in class org.axonframework.commandhandling.model.LockingRepository
-
- prepareForCommit(LockAwareAggregate<T, EventSourcedAggregate<T>>) - Method in class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
- prepareTrigger(Class<?>) - Method in class org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition
-
- prepareTrigger(Class<?>) - Method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
-
- prepareTrigger(Class<?>) - Method in interface org.axonframework.eventsourcing.SnapshotTriggerDefinition
-
Prepares a new trigger for an aggregate with the given aggregateIdentifier
and aggregateType
.
- priority() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- Priority - Annotation Type in org.axonframework.common
-
Indicates the relative priority of the annotated component.
- priority() - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
- priority() - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
-
Returns a number representing the priority of this handler over other handlers capable of processing the same
message.
- priority() - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-
- PriorityAnnotationComparator<T> - Class in org.axonframework.common.annotation
-
Comparator that compares objects based on the value on an
@Priority
annotation.
- proceed() - Method in class org.axonframework.messaging.DefaultInterceptorChain
-
- proceed() - Method in interface org.axonframework.messaging.InterceptorChain
-
Signals the Interceptor Chain to continue processing the message.
- process(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-
Process a batch of events.
- process(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-
- ProcessingGroup - Annotation Type in org.axonframework.config
-
Hint for the Configuration API that the annotated Event Handler object should be assigned to an Event Processor with
the specified name.
- processingLoop() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Fetch and process event batches continuously for as long as the processor is not shutting down.
- processInterceptors(CommandMessage<C>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Invokes all the dispatch interceptors and returns the CommandMessage instance that should be dispatched.
- processorNameColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
-
Returns the name of the column containing the name of the processor to which the token belongs.
- PropagatingErrorHandler - Enum in org.axonframework.eventhandling
-
Singleton ErrorHandler implementation that does not do anything.
- Property<T> - Interface in org.axonframework.common.property
-
Interface describing a mechanism that can read a predefined property from a given instance.
- PropertyAccessException - Exception in org.axonframework.common.property
-
Exception indicating that a predefined property is not accessible.
- PropertyAccessException(String, Throwable) - Constructor for exception org.axonframework.common.property.PropertyAccessException
-
Initializes the PropertyAccessException with given message
and cause
.
- PropertyAccessStrategy - Class in org.axonframework.common.property
-
Abstract Strategy that provides access to all PropertyAccessStrategy implementations.
- PropertyAccessStrategy() - Constructor for class org.axonframework.common.property.PropertyAccessStrategy
-
- propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-
- propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.DirectPropertyAccessStrategy
-
- propertyFor(Class<? extends T>, String) - Method in class org.axonframework.common.property.PropertyAccessStrategy
-
Returns a Property instance for the given property
, defined in given
targetClass
, or null
if no such property is found on the class.
- publish(EventMessage<?>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Publish an event to the aggregate root and its entities first and external event handlers (using the given
event bus) later.
- publish(EventMessage<?>, P) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedChildEntity
-
- publish(EventMessage<?>, T) - Method in interface org.axonframework.commandhandling.model.inspection.ChildEntity
-
Publish the given msg
to the appropriate handlers on the given declaringInstance
- publish(EventMessage<?>, T) - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
-
Publish given event message
on the given target
entity.
- publish(EventMessage<?>, T) - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- publish(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
- publish(EventMessage<?>...) - Method in interface org.axonframework.eventhandling.EventBus
-
Publish a collection of events on this bus (one, or multiple).
- publish(List<? extends EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventBus
-
Publish a collection of events on this bus (one, or multiple).
- publish(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
- publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Publish an event to external event handlers using the given event bus.
- publishOnEventBus(EventMessage<?>) - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
- put(K, V) - Method in interface org.axonframework.common.caching.Cache
-
Stores the given value
in the cache, under given key
.
- put(K, V) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- put(K, V) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- put(Object, Object) - Method in class org.axonframework.common.caching.NoCache
-
- put(K, V) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- put(String, Object) - Method in class org.axonframework.messaging.MetaData
-
This operation is not supported.
- putAll(Map<? extends String, ?>) - Method in class org.axonframework.messaging.MetaData
-
This operation is not supported.
- putIfAbsent(K, V) - Method in interface org.axonframework.common.caching.Cache
-
Stores the given value
in the cache, under given key
, if no element is yet available
under that key.
- putIfAbsent(K, V) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- putIfAbsent(K, V) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- putIfAbsent(Object, Object) - Method in class org.axonframework.common.caching.NoCache
-
- putIfAbsent(K, V) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- readAssociationValues(ResultSet) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- readAssociationValues(ResultSet) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
- 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) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Creates a statement to read domain event entries for an aggregate with given identifier starting with the first
entry having a sequence number that is equal or larger than the given firstSequenceNumber
.
- readEventData(Connection, TrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Creates a statement to read tracked event entries stored since given tracking token.
- 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
-
- readPayload(ResultSet, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Reads a serialized object from the given resultSet
at given columnIndex
.
- readResolve() - Method in class org.axonframework.messaging.MetaData
-
Java Serialization specification method that will ensure that deserialization will maintain a single instance of
empty MetaData.
- readSerializedData(ResultSet, String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Returns the serialized token data from the given resultSet
at given columnName
.
- readSerializedSaga(ResultSet) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- readSerializedSaga(ResultSet) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
- readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
- readSnapshot(String) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Try to load a snapshot event of the aggregate with given aggregateIdentifier
.
- readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- readSnapshot(String) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Returns an optional serialized event entry for given aggregateIdentifier
if the backing database
contains a snapshot of the aggregate.
- readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- readSnapshotData(Connection, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Creates a statement to read the snapshot entry of an aggregate with given identifier
- readSnapshotData(String) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- readTimeStamp(ResultSet, String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Reads a timestamp from the given resultSet
at given columnIndex
.
- readToken(ResultSet) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- readToken(ResultSet) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Reads a token from the given resultSet
.
- readTokenEntry(ResultSet) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
- 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
.
- ReflectionUtils - Class in org.axonframework.common
-
Utility class for working with Java Reflection API.
- register(PropertyAccessStrategy) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
-
Registers a PropertyAccessStrategy implementation at runtime.
- registerAggregateFactory(AggregateFactory<?>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-
Registers the given aggregateFactory
with this snapshotter.
- registerAggregateIdentifier(String) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Registers the identifier of the aggregate that will process the next command.
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
-
- registerCacheEntryListener(Cache.EntryListener) - Method in interface org.axonframework.common.caching.Cache
-
Registers the given cacheEntryListener
to listen for Cache changes.
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.NoCache
-
- registerCacheEntryListener(Cache.EntryListener) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- registerCommandCallback(CommandCallback<C, R>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
Registers the callback
, which is invoked for each sent command, unless Axon is able to detect that
the result of the command does not match the type accepted by the callback.
- registerCommandHandler(Function<Configuration, Object>) - Method in interface org.axonframework.config.Configurer
-
Registers a command handler bean with this configuration.
- registerCommandHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.DefaultConfigurer
-
- registerComponent(Class<C>, Function<Configuration, ? extends C>) - Method in interface org.axonframework.config.Configurer
-
Register a component which should be made available to other components or modules in this Configuration.
- registerComponent(Class<C>, Function<Configuration, ? extends C>) - Method in class org.axonframework.config.DefaultConfigurer
-
- registerConverter(ContentTypeConverter) - Method in class org.axonframework.serialization.ChainingConverter
-
Registers the given converter
with this factory.
- registerConverter(Class<? extends ContentTypeConverter>) - Method in class org.axonframework.serialization.ChainingConverter
-
Registers a convert of the given converterType
with this factory, only if initialization of such a
converter is possible.
- registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Registers any converters that are specific to the type of content written by this serializer.
- registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Registers converters with the given converter
which depend on the actual contents of the
serialized for to represent a JSON format.
- registerConverters(ChainingConverter) - Method in class org.axonframework.serialization.xml.XStreamSerializer
-
- registerCorrelationDataProvider(CorrelationDataProvider) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- registerCorrelationDataProvider(CorrelationDataProvider) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Register given correlationDataProvider
with this Unit of Work.
- registerDispatchInterceptor(MessageDispatchInterceptor<CommandMessage<?>>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
Registers the given dispatchInterceptor
which is invoked for each Command dispatched through the
Command Gateways created by this factory.
- registerDispatchInterceptor(MessageDispatchInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Registers the given list of dispatch interceptors to the command bus.
- registerDispatchInterceptor(MessageDispatchInterceptor<EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
Register the given interceptor
with this bus.
- registerDispatchInterceptor(MessageDispatchInterceptor<EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventBus
-
Register the given interceptor
with this bus.
- registerEventHandler(Function<Configuration, Object>) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Register an Event Handler Bean with this configuration.
- registerEventProcessor(String, EventHandlingConfiguration.EventProcessorBuilder) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Defines the Event Processor builder for an Event Processor with the given name
.
- registerEventProcessorFactory(EventHandlingConfiguration.EventProcessorBuilder) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Allows for more fine-grained definition of the Event Processor to use for each group of Event Listeners.
- registerHandlerInterceptor(MessageHandlerInterceptor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Registers the given interceptor to the command bus.
- registerInterceptor(MessageHandlerInterceptor<EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-
- registerInterceptor(MessageHandlerInterceptor<EventMessage<?>>) - Method in interface org.axonframework.eventhandling.EventProcessor
-
Registers the given interceptor
to this event processor.
- registerModule(ModuleConfiguration) - Method in interface org.axonframework.config.Configurer
-
Register an Axon module with this configuration.
- registerModule(ModuleConfiguration) - Method in class org.axonframework.config.DefaultConfigurer
-
- registerRoot(Callable<T>) - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
Registers the aggregate root created by the given aggregateFactory
with this aggregate.
- registerSubscribingEventProcessor(String) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Register a subscribing processor with given name
that subscribes to the Event Bus.
- registerSubscribingEventProcessor(String, Function<Configuration, SubscribableMessageSource<? extends EventMessage<?>>>) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Register a subscribing processor with given name
that subscribes to the given messageSource
.
- registerTrackingProcessor(String) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Register a TrackingProcessor using default configuration for the given name
.
- registerTrackingProcessor(String, Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in class org.axonframework.config.EventHandlingConfiguration
-
Registers a TrackingProcessor using the given source
to read messages from.
- registerWithUnitOfWork() - Method in class org.axonframework.commandhandling.model.AggregateLifecycle
-
Registers this aggregate with the current unit of work if one is started.
- Registration - Interface in org.axonframework.common
-
Interface that provides a mechanism to cancel a registration.
- release() - Method in interface org.axonframework.common.lock.Lock
-
Releases this lock.
- releaseClaim(String) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Release any claim of ownership currently active on this Token, if owned by the given owner
.
- releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-
- releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
- releaseClaim(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Creates a new
PreparedStatement
to release the current claim this node has on a token belonging to a
processor with given
processorName
and
segment
.
- releaseClaim(String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-
- releaseClaim(String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
-
Release a claim of the token for given processorName
and segment
.
- RemoteCommandHandlingException - Exception in org.axonframework.commandhandling.distributed
-
Exception indicating that an error has occurred while remotely handling a command.
- RemoteCommandHandlingException(String) - Constructor for exception org.axonframework.commandhandling.distributed.RemoteCommandHandlingException
-
Initializes the exception using the given message
.
- RemoteCommandHandlingException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.RemoteCommandHandlingException
-
Initializes the exception using the given message
and cause
.
- remove(K) - Method in interface org.axonframework.common.caching.Cache
-
Removes the entry stored under given key
.
- remove(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- remove(K) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- remove(Object) - Method in class org.axonframework.common.caching.NoCache
-
- remove(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- remove(AssociationValue) - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
Removes the given associationValue
, if it is contained by this instance.
- remove(AssociationValue) - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- remove(AssociationValue, String, String) - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
-
Removes an association between the given associationValue
and sagaIdentifier
.
- remove() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
- remove(Object) - Method in class org.axonframework.messaging.MetaData
-
This operation is not supported.
- removeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
-
Removes the given associationValue
of the saga with given sagaIdentifier
and sagaType
.
- removeAssociationWith(String, String) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
Removes the given association from the currently active Saga.
- removeAssociationWith(String, Number) - Static method in class org.axonframework.eventhandling.saga.SagaLifecycle
-
Removes the given association from the currently active Saga.
- removedAssociations() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
- removedAssociations() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- ReplyMessage - Class in org.axonframework.commandhandling.distributed
-
Base class for reply messages which may be used in the
CommandBusConnector
for replying on received
commands from other nodes.
- ReplyMessage() - Constructor for class org.axonframework.commandhandling.distributed.ReplyMessage
-
Default constructor required for de-/serialization of extending classes.
- ReplyMessage(String, boolean, Object, Serializer) - Constructor for class org.axonframework.commandhandling.distributed.ReplyMessage
-
Initializes a ReplyMessage containing a reply to the command with given {commandIdentifier} and given
returnValue
.
- reportFailure(Throwable) - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
-
Notify the monitor that a failure occurred during processing of the message
- reportFailure(Throwable) - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
-
- reportIgnored() - Method in interface org.axonframework.monitoring.MessageMonitor.MonitorCallback
-
Notify the monitor that the message was ignored
- reportIgnored() - Method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
-
- 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
-
- Repository<T> - Interface in org.axonframework.commandhandling.model
-
The repository provides an abstraction of the storage of aggregates.
- repository() - Method in interface org.axonframework.config.AggregateConfiguration
-
Returns the repository defined to load instances of the Aggregate type defined in this configuration
- repository() - Method in class org.axonframework.config.AggregateConfigurer
-
- repository(Class<T>) - Method in interface org.axonframework.config.Configuration
-
Returns the Repository configured for the given aggregateType
.
- reschedule(ScheduleToken, Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Cancel a scheduled event and schedule another in its place.
- reset(CommandMessage<?>, MessageHandler<? super CommandMessage<?>>, int, int, BlacklistDetectingCallback, List<MessageHandlerInterceptor<? super CommandMessage<?>>>, List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Resets this entry, preparing it for use for another command.
- reset(T) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
Resets the state of this Unit of Work, by setting its phase to NOT_STARTED
, replacing the message
of this Unit of Work with given message
, and clearing its collection of registered handlers.
- reset(T) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Reset the processing context.
- resetAsRecoverEntry(String) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Resets this entry, preparing it for use as a recovery entry.
- resolveAssociation(EventMessage<?>) - Method in interface org.axonframework.eventhandling.saga.metamodel.SagaModel
-
Returns the
AssociationValue
used to find sagas of type
T
that can handle the given
eventMessage
.
- resolveClassName(SerializedType) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Resolve the class name from the given serializedType
.
- resolveGenericType(Field, int) - Static method in class org.axonframework.common.ReflectionUtils
-
Resolve a generic type parameter from a field declaration
- resolveParameterValue(Message<?>) - Method in class org.axonframework.commandhandling.conflictresolution.ConflictResolution
-
- resolveParameterValue(Message) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-
- resolveParameterValue(Message<?>) - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-
- resolveParameterValue(Message) - Method in class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
-
- resolveParameterValue(Message) - Method in class org.axonframework.messaging.annotation.FixedValueParameterResolver
-
- resolveParameterValue(Message<?>) - Method in interface org.axonframework.messaging.annotation.ParameterResolver
-
Resolves the parameter value to use for the given message
, or null
if no suitable
parameter value can be resolved.
- resolveParameterValue(Message) - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
-
- resolvePrimitiveWrapperType(Class<?>) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns the boxed wrapper type for the given primitiveType
.
- resolveReturnValue(CommandMessage<?>, Aggregate<T>) - Method in class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
-
Resolves the value to return when the given command
has created the given aggregate
.
- resolveTarget(CommandMessage<?>) - Method in class org.axonframework.commandhandling.AnnotationCommandTargetResolver
-
- resolveTarget(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.CommandTargetResolver
-
Returns the Aggregate Identifier and optionally the expected version of the aggregate on which the given command
should be executed.
- resolveTarget(CommandMessage<?>) - Method in class org.axonframework.commandhandling.MetaDataCommandTargetResolver
-
- resourceInjector() - Method in interface org.axonframework.config.Configuration
-
Returns the ResourceInjector used to provide resources to Saga instances.
- ResourceInjector - Interface in org.axonframework.eventhandling.saga
-
Interface describing a mechanism to inject resources into Saga instances.
- 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.
- resultRevision - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- resultType - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- resume() - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- RetryingCallback<C,R> - Class in org.axonframework.commandhandling.gateway
-
Callback implementation that will invoke a retry scheduler if a command results in a runtime exception.
- RetryingCallback(CommandCallback<C, R>, RetryScheduler, CommandBus) - Constructor for class org.axonframework.commandhandling.gateway.RetryingCallback
-
Initialize the RetryingCallback with the given delegate
, representing the actual callback passed as
a parameter to dispatch, the given commandMessage
, retryScheduler
and
commandBus
.
- RetryScheduler - Interface in org.axonframework.commandhandling.gateway
-
Interface towards a mechanism that decides whether to schedule a command for execution when a previous attempts
resulted in an exception.
- Revision - Annotation Type in org.axonframework.serialization
-
Annotation that attaches revision information to a Serializable object.
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.AnnotationRevisionResolver
-
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.FixedValueRevisionResolver
-
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.MavenArtifactRevisionResolver
-
- revisionOf(Class<?>) - Method in interface org.axonframework.serialization.RevisionResolver
-
Returns the revision for the given payloadType
.
- revisionOf(Class<?>) - Method in class org.axonframework.serialization.SerialVersionUIDRevisionResolver
-
- RevisionResolver - Interface in org.axonframework.serialization
-
Interface towards a mechanism that resolves the revision of a given payload type.
- rollback() - Method in interface org.axonframework.common.transaction.Transaction
-
Roll back this transaction.
- rollback(Throwable) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- rollback() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
- rollback(Throwable) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
- RollbackConfiguration - Interface in org.axonframework.messaging.unitofwork
-
The RollbackConfiguration defines if a Unit of Work should be rolled back when an exception is raised during the
processing of a Message.
- RollbackConfigurationType - Enum in org.axonframework.messaging.unitofwork
-
Enum containing common rollback configurations for the Unit of Work.
- rollBackOn(Throwable) - Method in interface org.axonframework.messaging.unitofwork.RollbackConfiguration
-
Decides whether the given throwable
should trigger a rollback.
- root() - Method in class org.axonframework.eventhandling.saga.AnnotatedSaga
-
Returns the (annotated) Saga instance.
- root() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns the root of this Unit of Work.
- rootType() - Method in interface org.axonframework.commandhandling.model.Aggregate
-
Get the class type of the wrapped aggregate root that the Aggregate defers to for command handling.
- rootType() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- rootType() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
- routingKey() - Method in class org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember
-
- routingKey() - Method in interface org.axonframework.commandhandling.model.inspection.CommandMessageHandlingMember
-
Returns the property of the command that is to be used as routing key towards this command handler instance.
- routingKey() - Method in interface org.axonframework.commandhandling.model.inspection.EntityModel
-
Get the name of the routing key property on commands and events that provides the identifier that should be used
to target entities of this kind.
- routingKey() - Method in class org.axonframework.commandhandling.model.inspection.ModelInspector
-
- RoutingStrategy - Interface in org.axonframework.commandhandling.distributed
-
Interface describing a mechanism that generates a routing key for a given command.
- run() - Method in class org.axonframework.common.MemberAccessibilityCallback
-
- run() - Method in class org.axonframework.eventhandling.async.EventProcessorTask
-
- saga() - Method in interface org.axonframework.eventhandling.saga.repository.SagaStore.Entry
-
Returns the Saga instance in unserialized form.
- Saga<T> - Interface in org.axonframework.eventhandling.saga
-
Interface describing an implementation of a Saga.
- SagaConfiguration<S> - Class in org.axonframework.config
-
Module Configuration implementation that defines a Saga.
- SagaCreationException - Exception in org.axonframework.eventhandling.saga.repository
-
Exception triggered when a new saga instance could not be instantiated.
- SagaCreationException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.repository.SagaCreationException
-
Initializes the exception using the given message
and cause
.
- SagaCreationPolicy - Enum in org.axonframework.eventhandling.saga
-
Enumeration containing the possible Creation Policies for Sagas.
- SagaEntry<T> - Class in org.axonframework.eventhandling.saga.repository.jpa
-
Java Persistence Entity allowing sagas to be stored in a relational database.
- SagaEntry(T, String, Serializer) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.SagaEntry
-
Constructs a new SagaEntry for the given saga
.
- SagaEntry() - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.SagaEntry
-
Constructor required by JPA.
- sagaEntryTable() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
-
Returns the name of the sagaEntry table
- SagaEventHandler - Annotation Type in org.axonframework.eventhandling.saga
-
Method-level annotation indicating that the annotated method is an event handler method for the saga instance.
- SagaExecutionException - Exception in org.axonframework.eventhandling.saga
-
Exception triggered by a saga while it is processing an event or processing a task.
- SagaExecutionException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.SagaExecutionException
-
Initializes the exception using the given message
and cause
.
- SagaInitializationPolicy - Class in org.axonframework.eventhandling.saga
-
Describes the conditions under which a Saga should be created, and which AssociationValue it should be initialized
with.
- SagaInitializationPolicy(SagaCreationPolicy, AssociationValue) - Constructor for class org.axonframework.eventhandling.saga.SagaInitializationPolicy
-
Creates an instance using the given creationPolicy
and initialAssociationValue
.
- SagaInstantiationException - Exception in org.axonframework.eventhandling.saga
-
Exception triggered during initialization of a Saga.
- SagaInstantiationException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.SagaInstantiationException
-
Initializes the exception using the given message
and cause
.
- SagaLifecycle - Class in org.axonframework.eventhandling.saga
-
Abstract base class of a component that models a saga's life cycle.
- SagaLifecycle() - Constructor for class org.axonframework.eventhandling.saga.SagaLifecycle
-
- SagaMetaModelFactory - Interface in org.axonframework.eventhandling.saga.metamodel
-
Interface of a factory for a
SagaModel
for any given saga type.
- SagaMethodMessageHandlerDefinition - Class in org.axonframework.eventhandling.saga
-
Utility class that inspects annotation on a Saga instance and returns the relevant configuration for its Event
Handlers.
- SagaMethodMessageHandlerDefinition() - Constructor for class org.axonframework.eventhandling.saga.SagaMethodMessageHandlerDefinition
-
- SagaMethodMessageHandlingMember<T> - Class in org.axonframework.eventhandling.saga
-
- SagaMethodMessageHandlingMember(MessageHandlingMember<T>, SagaCreationPolicy, String, Property, boolean) - Constructor for class org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember
-
Creates a SagaMethodMessageHandler.
- SagaModel<T> - Interface in org.axonframework.eventhandling.saga.metamodel
-
Interface of a model that describes a Saga of type T
.
- SagaRepository<T> - Interface in org.axonframework.eventhandling.saga
-
Interface towards the storage mechanism of Saga instances.
- sagaSchema() - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
Returns the
SagaSchema
used to configure this sql saga schema.
- SagaSchema - Class in org.axonframework.eventhandling.saga.repository.jdbc
-
SagaSchema allows specification of custom storage locations for the saga repositories.
- SagaSchema() - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
-
Initialize SagaSchema with default values.
- SagaSchema(String, String) - Constructor for class org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema
-
Initialize SagaSchema with custom locations for event entry tables.
- SagaSqlSchema - Interface in org.axonframework.eventhandling.saga.repository.jdbc
-
Interface describing the SQL statements that the JdbcSagaRepository needs to execute against the underlying
database.
- SagaStorageException - Exception in org.axonframework.eventhandling.saga
-
Exception indicating that an error has occurred while storing a Saga.
- SagaStorageException(String) - Constructor for exception org.axonframework.eventhandling.saga.SagaStorageException
-
Initialize a SagaStorageException with the given descriptive message
.
- SagaStorageException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.saga.SagaStorageException
-
Initialize a SagaStorageException with the given descriptive message
and cause
.
- SagaStore<T> - Interface in org.axonframework.eventhandling.saga.repository
-
Provides a mechanism to find, load update and delete sagas of type T
from an underlying storage like a
database.
- SagaStore.Entry<T> - Interface in org.axonframework.eventhandling.saga.repository
-
Interface describing a Saga entry fetched from a SagaStore.
- schedule(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
-
Schedules this task for execution when all pre-conditions have been met.
- schedule(Instant, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Schedule the given event
for publication at the given triggerDateTime
.
- schedule(Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Schedule the given event
for publication after the given triggerDuration
.
- schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- scheduleEvents(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.EventProcessorTask
-
Schedules a batch of events for processing.
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
-
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in interface org.axonframework.commandhandling.gateway.RetryScheduler
-
Inspect the given commandMessage
that failed with given lastFailure
.
- scheduleSnapshot(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
- scheduleSnapshot(Class<?>, String) - Method in interface org.axonframework.eventsourcing.Snapshotter
-
Schedules snapshot taking for an aggregate with given aggregateIdentifier
.
- ScheduleToken - Interface in org.axonframework.eventhandling.scheduling
-
Token that identifies a single scheduled Event.
- SchedulingException - Exception in org.axonframework.eventhandling.scheduling
-
Exception indicating a problem in the Event Scheduling mechanism.
- SchedulingException(String) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
-
Initialize a SchedulingException with the given message
.
- SchedulingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
-
Initialize a SchedulingException with the given message
and cause
.
- schema() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Returns the
EventSchema
that defines the table and column names of event tables in the database.
- segmentColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
-
Returns the name of the column containing the segment of the processor to which the token belongs.
- segmentCount() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-
Returns this member's segment count which relates to the relative load factor of the member.
- selectForUpdate(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
- send(Member, CommandMessage<? extends C>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
-
Sends the given command
to the node assigned to handle messages with the given
routingKey
.
- send(Member, CommandMessage<C>, CommandCallback<? super C, R>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
-
Sends the given command
to the node assigned to handle messages with the given
routingKey
.
- send(C, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Sends the given command
, and invokes the callback
when the command is processed.
- send(C, CommandCallback<? super C, R>) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
, and have the result of the command's execution reported to the given
callback
.
- send(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and returns immediately, without waiting for the command to execute.
- send(C, CommandCallback<? super C, R>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
- send(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
- sendAndForget(Object) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Dispatches a command without callback.
- sendAndWait(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and wait for it to execute.
- sendAndWait(Object, long, TimeUnit) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and wait for it to execute.
- sendAndWait(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Sends the given command
and waits for its execution to complete, or until the waiting thread is
interrupted.
- sendAndWait(Object, long, TimeUnit) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Sends the given command
and waits for its execution to complete, or until the given
timeout
has expired, or the waiting thread is interrupted.
- SequenceEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
-
EventStorageEngine implementation that combines the streams of two event storage engines.
- SequenceEventStorageEngine(EventStorageEngine, EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- SequenceNumber - Annotation Type in org.axonframework.eventsourcing
-
Annotation indication that a parameter on an Event Handler method should be injected with the SequenceNumber of
a DomainEventMessage.
- sequenceNumberColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the aggregate sequence number of the event.
- SequenceNumberParameterResolver() - Constructor for class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
-
- SequenceNumberParameterResolverFactory - Class in org.axonframework.eventsourcing
-
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a
Long
type
annotated with the
SequenceNumber
annotation and assigns the sequenceNumber of the DomainEventMessage.
- SequenceNumberParameterResolverFactory() - Constructor for class org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory
-
- SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver - Class in org.axonframework.eventsourcing
-
ParameterResolver that resolves SequenceNumber parameters
- SequencingPolicy<T> - Interface in org.axonframework.eventhandling.async
-
Interface to a policy definition for concurrent processing, for example event handling.
- SequentialPerAggregatePolicy - Class in org.axonframework.eventhandling.async
-
Concurrency policy that requires sequential processing of events raised by the same aggregate.
- SequentialPerAggregatePolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-
- SequentialPolicy - Class in org.axonframework.eventhandling.async
-
SequencingPolicy that requires serialized handling of all events delivered to an event handler.
- SequentialPolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPolicy
-
- SerializationAware - Interface in org.axonframework.serialization
-
Marker interface for messages that have special serialization awareness.
- SerializationException - Exception in org.axonframework.serialization
-
Indicates that an exception occurred while serializing or deserializing an object.
- SerializationException(String) - Constructor for exception org.axonframework.serialization.SerializationException
-
Initializes the exception using the given message
.
- SerializationException(String, Throwable) - Constructor for exception org.axonframework.serialization.SerializationException
-
Initializes the exception using the given message
and cause
.
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.MessageSerializer
-
- serialize(Object, Class<T>) - Method in interface org.axonframework.serialization.Serializer
-
Serialize the given object
into a Serialized Object containing the given
expectedRepresentation
.
- SerializedMessage<T> - Class in org.axonframework.serialization
-
A message containing serialized payload data and metadata.
- SerializedMessage(String, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serialization.SerializedMessage
-
Initializes a
SerializedMessage
with given
identifier
from the given serialized payload and
metadata.
- SerializedMessage(String, LazyDeserializingObject<T>, LazyDeserializingObject<MetaData>) - Constructor for class org.axonframework.serialization.SerializedMessage
-
Initializes a
SerializedMessage
with given
identifier
from the given lazily deserializing payload
and metadata.
- serializedMetaData - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- SerializedMetaData<T> - Class in org.axonframework.serialization
-
Represents the serialized form of a
MetaData
instance.
- SerializedMetaData(T, Class<T>) - Constructor for class org.axonframework.serialization.SerializedMetaData
-
Construct an instance with given
bytes
representing the serialized form of a
MetaData
instance.
- SerializedObject<T> - Interface in org.axonframework.serialization
-
Interface describing the structure of a serialized object.
- SerializedObjectHolder - Class in org.axonframework.serialization
-
Holder that keeps references to serialized representations of a payload and meta data of a specific message.
- SerializedObjectHolder(Message) - Constructor for class org.axonframework.serialization.SerializedObjectHolder
-
Initialize the holder for the serialized representations of the payload and meta data of given
message
- serializedPayload - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- serializedResult - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- SerializedSaga - Class in org.axonframework.eventhandling.saga.repository.jpa
-
Specialization of the SerializedObject for Sagas represented as byte array.
- SerializedSaga(byte[], String, String) - Constructor for class org.axonframework.eventhandling.saga.repository.jpa.SerializedSaga
-
Initialize a SerializedSaga instance with given data
, of given type
and
revision
.
- SerializedType - Interface in org.axonframework.serialization
-
Describes the type of a serialized object.
- serializeMetaData(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
-
- serializeMetaData(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serialization.MessageSerializer
-
Utility method that serializes the meta data of the given message
using given
serializer
and expectedRepresentation
.
- serializeMetaData(Message<?>, Class<T>) - Method in class org.axonframework.serialization.MessageSerializer
-
Serialize the meta data of given message
to the given expectedRepresentation
.
- serializeMetaData(Serializer, Class<T>) - Method in interface org.axonframework.serialization.SerializationAware
-
Serialize the meta data of this message using given serializer
, using given
expectedRepresentation
.
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
-
- serializeMetaData(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
-
- serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
-
- serializePayload(Message<?>, Serializer, Class<T>) - Static method in class org.axonframework.serialization.MessageSerializer
-
Utility method that serializes the payload of the given message
using given serializer
and expectedRepresentation
.
- serializePayload(Message<?>, Class<T>) - Method in class org.axonframework.serialization.MessageSerializer
-
Serialize the payload of given message
to the given expectedRepresentation
.
- serializePayload(Serializer, Class<T>) - Method in interface org.axonframework.serialization.SerializationAware
-
Serialize the payload of this message using given serializer
, using given
expectedRepresentation
.
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
-
- serializePayload(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
-
- serializer() - Method in interface org.axonframework.config.Configuration
-
Returns the serializer defined in this Configuration
- Serializer - Interface in org.axonframework.serialization
-
Interface describing a serialization mechanism.
- SerialVersionUIDRevisionResolver - Class in org.axonframework.serialization
-
RevisionResolver implementation that returns the (String representation of the) serialVersionUID of a class.
- SerialVersionUIDRevisionResolver() - Constructor for class org.axonframework.serialization.SerialVersionUIDRevisionResolver
-
- ServiceRegistryException - Exception in org.axonframework.commandhandling.distributed
-
Exception that is triggered when an error occurs that is related to the registration or deregistration of a member to
the distributed command bus service registry.
- ServiceRegistryException(String) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
-
Initializes the exception using the given message
.
- ServiceRegistryException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
-
Initializes the exception using the given message
and cause
.
- set(UnitOfWork<?>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Binds the given unitOfWork
to the current thread.
- setAdditionalConverters(List<ContentTypeConverter>) - Method in class org.axonframework.serialization.ChainingConverter
-
Setter for dependency injection frameworks that require property methods.
- setBufferSize(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the buffer size to use.
- setCache(Cache) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the cache in which loaded aggregates will be stored.
- setCommandDispatchInterceptors(Collection<MessageDispatchInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Sets the interceptors that intercept commands just prior to dispatching them.
- setCommandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the CommandTargetResolver that must be used to indicate which Aggregate instance will be invoked by an
incoming command.
- setCoolingDownPeriod(long) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the cooling down period in milliseconds.
- setDispatchInterceptors(List<MessageDispatchInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Configures the CommandDispatchInterceptor to use with the DisruptorCommandBus when commands are dispatched.
- setEntityManager(EntityManager) - Method in class org.axonframework.common.jpa.ContainerManagedEntityManagerProvider
-
Sets the container managed entityManager to use.
- setEventBus(EventBus) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the event bus to which scheduled events need to be published.
- setEventJobDataBinder(EventJobDataBinder) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the
EventJobDataBinder
instance which reads / writes the event message to publish to the
JobDataMap
.
- setExceptionResult(Exception) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Registers the exception that occurred while processing the incoming command.
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Set the execution result of processing the current
Message
.
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Set the execution result of processing the current
Message
.
- setExecutor(Executor) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the Executor that provides the processing resources (Threads) for the components of the DisruptorCommandBus.
- setFieldValue(Field, Object, T) - Static method in class org.axonframework.common.ReflectionUtils
-
Set the field
of object
to a certain value
.
- setForceFlushOnSave(boolean) - Method in class org.axonframework.commandhandling.model.GenericJpaRepository
-
Indicates whether the EntityManager's state should be flushed each time an aggregate is saved.
- setGroupIdentifier(String) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the group identifier to use when scheduling jobs with Quartz.
- setInvokerInterceptors(List<MessageHandlerInterceptor<? super CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during in the invocation thread.
- setInvokerThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the number of Threads that should be used to invoke the Command Handlers.
- setMessageMonitor(MessageMonitor<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the message monitor to use.
- setOwnerColum(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the owner column.
- 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.
- setProducerType(ProducerType) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the producer type to use.
- setPublisherInterceptors(List<MessageHandlerInterceptor<CommandMessage<?>>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Configures the CommandHandlerInterceptors to use with the DisruptorCommandBus during the publication of changes.
- setPublisherThreadCount(int) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the number of Threads that should be used to store and publish the generated Events.
- setRescheduleCommandsOnCorruptState(boolean) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Indicates whether commands that failed because they were executed against potentially corrupted aggregate state
should be automatically rescheduled.
- setResult(Object) - Method in class org.axonframework.commandhandling.disruptor.CommandHandlingEntry
-
Registers the result of the command's execution, if successful.
- setRollbackCause(Throwable) - Method in class org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork
-
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Sets the cause for rolling back this Unit of Work.
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the rollback configuration for the DisruptorCommandBus to use.
- setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Sets the RollbackConfiguration that allows you to change when the UnitOfWork is committed.
- setScheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the backing Quartz Scheduler for this timer.
- setSegmentColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the processor segment column.
- setSerializer(Serializer) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Returns the serializer to perform pre-serialization with, or null
if no pre-serialization should be
done.
- setSerializer(Serializer) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore
-
Sets the Serializer instance to serialize Sagas with.
- setSuppressExceptions(boolean) - Method in class org.axonframework.eventhandling.saga.AbstractSagaManager
-
Sets whether or not to suppress any exceptions that are cause by invoking Sagas.
- setTimestampColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the timestamp column.
- setTokenColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the serialized token column.
- setTokenTable(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the token entry table.
- setTokenTypeColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the token type column.
- setTransactionManager(TransactionManager) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the transaction manager to use to manage a transaction around the storage and publication of events.
- setTransactionManager(TransactionManager) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the transaction manager that manages a transaction around the publication of an event.
- setUseExplicitFlush(boolean) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
-
Sets whether or not to do an explicit EntityManager.flush()
after each data modifying
operation on the backing storage.
- setWaitStrategy(WaitStrategy) - Method in class org.axonframework.commandhandling.disruptor.DisruptorConfiguration
-
Sets the WaitStrategy
, which used to make dependent threads wait for tasks to be completed.
- shutdown() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
-
Shuts down the Executor used to asynchronously dispatch incoming commands.
- shutdown() - Method in class org.axonframework.config.AggregateConfigurer
-
- shutdown() - Method in interface org.axonframework.config.Configuration
-
Shuts down the components defined in this Configuration
- shutdown() - Method in class org.axonframework.config.EventHandlingConfiguration
-
- shutdown() - Method in interface org.axonframework.config.ModuleConfiguration
-
Invoked prior to shutdown of the application.
- shutdown() - Method in class org.axonframework.config.SagaConfiguration
-
- shutDown() - Method in interface org.axonframework.eventhandling.EventProcessor
-
Stop processing events.
- shutDown() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-
Shut down this processor.
- shutDown() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Shut down the processor.
- shutDown() - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-
Method to invoke when the application shuts down.
- SimpleCommandBus - Class in org.axonframework.commandhandling
-
Implementation of the CommandBus that dispatches commands to the handlers subscribed to that specific type of
command.
- SimpleCommandBus() - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
-
Initializes the SimpleCommandBus.
- SimpleCommandBus(TransactionManager, MessageMonitor<? super CommandMessage<?>>) - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
-
Initializes the SimpleCommandBus with the given transactionManager
and messageMonitor
- SimpleCorrelationDataProvider - Class in org.axonframework.messaging.correlation
-
CorrelationDataProvider implementation defines correlation headers by the header names.
- SimpleCorrelationDataProvider(String...) - Constructor for class org.axonframework.messaging.correlation.SimpleCorrelationDataProvider
-
Initializes the CorrelationDataProvider to return the meta data of messages with given metaDataKeys
as correlation data.
- SimpleEntityManagerProvider - Class in org.axonframework.common.jpa
-
Simple implementation of the EntityManagerProvider that returns the EntityManager instance provided at construction
time.
- SimpleEntityManagerProvider(EntityManager) - Constructor for class org.axonframework.common.jpa.SimpleEntityManagerProvider
-
Initializes an instance that always returns the given entityManager
.
- SimpleEventBus - Class in org.axonframework.eventhandling
-
- SimpleEventBus() - Constructor for class org.axonframework.eventhandling.SimpleEventBus
-
- SimpleEventBus(int, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SimpleEventBus
-
Initializes an event bus.
- SimpleEventHandlerInvoker - Class in org.axonframework.eventhandling
-
- SimpleEventHandlerInvoker(Object...) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- SimpleEventHandlerInvoker(List<?>, ListenerInvocationErrorHandler) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- SimpleEventScheduler - Class in org.axonframework.eventhandling.scheduling.java
-
An
EventScheduler
implementation that uses Java's ScheduledExecutorService as scheduling and triggering
mechanism.
- SimpleEventScheduler(ScheduledExecutorService, EventBus) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
Initialize the SimpleEventScheduler using the given executorService
as trigger and execution
mechanism, and publishes events to the given eventBus
.
- SimpleEventScheduler(ScheduledExecutorService, EventBus, TransactionManager) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
Initialize the SimpleEventScheduler using the given executorService
as trigger and execution
mechanism, and publishes events to the given eventBus
.
- SimpleMember<E> - Class in org.axonframework.commandhandling.distributed
-
An endpoint in the network for a command handling service.
- SimpleMember(String, E, Consumer<SimpleMember<E>>) - Constructor for class org.axonframework.commandhandling.distributed.SimpleMember
-
Create the service member
- SimpleResourceInjector - Class in org.axonframework.eventhandling.saga
-
A resource injector that checks for javax.inject.Inject
annotated fields and setter methods to inject
resources.
- SimpleResourceInjector(Object...) - Constructor for class org.axonframework.eventhandling.saga.SimpleResourceInjector
-
Initializes the resource injector to inject to given resources
.
- SimpleResourceInjector(Collection<?>) - Constructor for class org.axonframework.eventhandling.saga.SimpleResourceInjector
-
Initializes the resource injector to inject to given resources
.
- SimpleResourceParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
- SimpleResourceParameterResolverFactory(Iterable<?>) - Constructor for class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
-
Initialize the ParameterResolverFactory to inject the given resource
in applicable parameters.
- SimpleScheduleToken - Class in org.axonframework.eventhandling.scheduling.java
-
ScheduleToken for tasks event scheduled using the SimpleEventScheduler.
- SimpleScheduleToken(String) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
-
Creates a SimpleScheduleToken with the given tokenId
.
- SimpleSerializedObject<T> - Class in org.axonframework.serialization
-
SerializedObject implementation that takes all properties as constructor parameters.
- SimpleSerializedObject(T, Class<T>, SerializedType) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
-
Initializes a SimpleSerializedObject using given data
and serializedType
.
- SimpleSerializedObject(T, Class<T>, String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
-
Initializes a SimpleSerializedObject using given data
and a serialized type identified by given
type
and revision
.
- SimpleSerializedType - Class in org.axonframework.serialization
-
SerializedType implementation that takes its properties as constructor parameters.
- SimpleSerializedType(String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedType
-
Initialize with given objectType
and revisionNumber
- simulateAutoIncrement(Connection, String, String) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
-
Oracle11 does not have auto incremented values.
- SingleEntryUpcaster<T> - Class in org.axonframework.serialization.upcasting
-
Abstract implementation of an
Upcaster
that eases the common process of upcasting one intermediate
representation to another representation by applying a simple mapping function to the input stream of intermediate
representations.
- SingleEntryUpcaster() - Constructor for class org.axonframework.serialization.upcasting.SingleEntryUpcaster
-
- SingleEventUpcaster - Class in org.axonframework.serialization.upcasting.event
-
Abstract implementation of an event
Upcaster
that eases the common process of upcasting one intermediate
event representation to another representation by applying a simple mapping function to the input stream of
intermediate representations.
- SingleEventUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.SingleEventUpcaster
-
- size() - Method in interface org.axonframework.eventhandling.saga.AssociationValues
-
Returns the number of AssociationValue instances available in this container
- size() - Method in class org.axonframework.eventhandling.saga.AssociationValuesImpl
-
- size() - Method in class org.axonframework.eventhandling.saga.repository.AssociationValueMap
-
Returns an approximation of the size of this map.
- size() - Method in class org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore
-
Returns the number of Sagas currently contained in this repository.
- size() - Method in class org.axonframework.messaging.MetaData
-
- SnapshotEventEntry - Class in org.axonframework.eventsourcing.eventstore.jpa
-
Default implementation of an event entry containing a serialized snapshot of an aggregate.
- SnapshotEventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
-
Construct a new default snapshot event entry from an aggregate.
- SnapshotEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
-
Default constructor required by JPA
- snapshotEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Returns the name of the Snaphot event entity.
- snapshotTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Returns the name of the snapshot event table.
- Snapshotter - Interface in org.axonframework.eventsourcing
-
Interface describing instances that are capable of creating snapshot events for aggregates.
- SnapshotTrigger - Interface in org.axonframework.eventsourcing
-
Interface describing a mechanism that keeps track of an Aggregate's activity in order to trigger a snapshot.
- SnapshotTriggerDefinition - Interface in org.axonframework.eventsourcing
-
Interface describing the mechanism for triggering Snapshots.
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.HsqlSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.Oracle11SagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that creates the table for storing Association Values for Sagas.
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.Oracle11SagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that creates the table for storing Sagas.
- sql_deleteAssociationEntries(Connection, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_deleteAssociationEntries(Connection, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that deletes all association entries for a Saga with given
sagaIdentifier
.
- sql_deleteSagaEntry(Connection, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_deleteSagaEntry(Connection, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that deletes a Saga with given sagaIdentifier
.
- sql_findAssociations(Connection, String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_findAssociations(Connection, String, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that finds the associations of a Saga of given sagaType
and given sagaIdentifier
.
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that finds identifiers of Sagas of given sagaType
associated with the
given association key
and value
.
- sql_loadSaga(Connection, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_loadSaga(Connection, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that loads a single Saga, with given sagaId
.
- sql_removeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_removeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that removes an association value for given sagaIdentifier
, where the
association is identified with given key
and value
.
- sql_storeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_storeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that stores an association with given key
and value
, for a
Saga of given type
and identifier
.
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that inserts a Saga entry, of given sagaType
and with given
sagaIdentifier
.
- sql_updateSaga(Connection, String, byte[], String, String) - Method in class org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_updateSaga(Connection, String, byte[], String, String) - Method in interface org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that updates the serialized form of an existing Saga entry, of given
sagaType
and with given sagaIdentifier
.
- SQLErrorCodesResolver - Class in org.axonframework.eventsourcing.eventstore.jpa
-
SQLErrorCodesResolver is an implementation of PersistenceExceptionResolver used to resolve sql error codes to see if
it is an duplicate key constraint violation.
- SQLErrorCodesResolver(List<Integer>) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initializes the SQLErrorCodesResolver using the given list of SQL Codes representing Key Constraint Violations.
- SQLErrorCodesResolver(DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(Properties, String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(Properties, DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize the SQLErrorCodesResolver with the given properties
and use the dataSource
to automatically retrieve the database product name.
- SQLStateResolver - Class in org.axonframework.eventsourcing.eventstore.jpa
-
SQLStateResolver is an implementation of PersistenceExceptionResolver used to resolve sql state values to see if it
violates a unique key constraint.
- SQLStateResolver() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
-
Constructor that uses the standard SQL state category for the check.
- SQLStateResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
-
Constructor that can be used to supply a specific SQL state code for the check.
- start() - Method in class org.axonframework.config.AggregateConfigurer
-
- start() - Method in interface org.axonframework.config.Configuration
-
Starts this configuration.
- start() - Method in class org.axonframework.config.EventHandlingConfiguration
-
- start() - Method in interface org.axonframework.config.ModuleConfiguration
-
Invoked when the Configuration is started.
- start() - Method in class org.axonframework.config.SagaConfiguration
-
- start() - Method in interface org.axonframework.eventhandling.EventProcessor
-
Start processing events.
- start() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-
Start this processor.
- start() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Start this processor.
- start() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- start() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Starts the current unit of work.
- startAndGet(T) - Static method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork.
- StartSaga - Annotation Type in org.axonframework.eventhandling.saga
-
Indicates that the annotated
SagaEventHandler
method can trigger the
creation of a new Saga instance.
- startTransaction() - Method in enum org.axonframework.common.transaction.NoTransactionManager
-
- startTransaction() - Method in interface org.axonframework.common.transaction.TransactionManager
-
Starts a transaction.
- state(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
-
Asserts that the value of state
is true.
- stop() - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
Shuts down the command bus.
- storageEngine() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- store(String, CommandCallbackWrapper<E, C, R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
Stores a callback
- storeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore
-
Stores the given associationValue
of the saga with given sagaIdentifier
and sagaType
.
- storeSaga(AnnotatedSaga<T>) - Method in class org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository
-
Stores a newly created Saga instance.
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Store the given snapshot
of an Aggregate.
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Store an event that contains a snapshot of an aggregate.
- storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
-
Stores the given (temporary) snapshot
event.
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-
- storeToken(TrackingToken, String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
-
Stores the given token
in the store.
- StreamableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
-
Interface for a source of
messages
that processors can track.
- StreamUtils - Class in org.axonframework.messaging
-
Utility class for working with Streams.
- StringToByteArrayConverter - Class in org.axonframework.serialization.converters
-
ContentTypeConverter that converts String into byte arrays.
- StringToByteArrayConverter() - Constructor for class org.axonframework.serialization.converters.StringToByteArrayConverter
-
- SubscribableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
-
Interface for a source of
messages
to which message processors can subscribe.
- subscribe(CommandBus) - Method in class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
-
Subscribe this command handler to the given commandBus
.
- subscribe(CommandBus) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
Subscribe this command handler to the given commandBus
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.CommandBus
-
Subscribe the given handler
to commands of type commandType
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.disruptor.DisruptorCommandBus
-
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
-
Subscribes a command message handler for commands with given commandName
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Subscribe the given handler
to commands of type commandType
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Subscribe the given handler
to commands of type commandType
.
- subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
- subscribe(Consumer<List<? extends M>>) - Method in interface org.axonframework.messaging.SubscribableMessageSource
-
Subscribe the given messageProcessor
to this message source.
- SubscribingEventProcessor - Class in org.axonframework.eventhandling
-
- SubscribingEventProcessor(String, EventHandlerInvoker, SubscribableMessageSource<EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
-
Initializes an EventProcessor with given name
that subscribes to the given messageSource
for
events.
- SubscribingEventProcessor(String, EventHandlerInvoker, SubscribableMessageSource<EventMessage<?>>, EventProcessingStrategy, ErrorHandler) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
-
Initializes an EventProcessor with given name
that subscribes to the given messageSource
for
events.
- SubscribingEventProcessor(String, EventHandlerInvoker, SubscribableMessageSource<? extends EventMessage<?>>, EventProcessingStrategy, ErrorHandler, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
-
Initializes an EventProcessor with given name
that subscribes to the given messageSource
for
events.
- SubscribingEventProcessor(String, EventHandlerInvoker, RollbackConfiguration, SubscribableMessageSource<? extends EventMessage<?>>, EventProcessingStrategy, ErrorHandler, MessageMonitor<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
-
Initializes an EventProcessor with given name
that subscribes to the given messageSource
for
events.
- subscribingSagaManager(Class<S>) - Static method in class org.axonframework.config.SagaConfiguration
-
Initialize a configuration for a Saga of given sagaType
, using a Subscribing Event Processor to process
incoming Events.
- subset(String...) - Method in class org.axonframework.messaging.MetaData
-
Returns a MetaData instance containing a subset of the keys
in this instance.
- success(R) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
-
- success - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- supplyException(String, long, long) - Method in interface org.axonframework.commandhandling.conflictresolution.ConflictExceptionSupplier
-
Creaates an instance of an exception indicating a conflict in an aggregate with given aggregateIdentifier
,
the given expectedVersion
and actualVersion
.
- supportedCommandNames() - Method in class org.axonframework.commandhandling.AggregateAnnotationCommandHandler
-
- supportedCommandNames() - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
- supportedCommandNames() - Method in interface org.axonframework.commandhandling.SupportedCommandNamesAware
-
Returns the set of command names this component supports.
- SupportedCommandNamesAware - Interface in org.axonframework.commandhandling
-
Describes a component capable of specifying which commands it is able to handle.
- supportedPayloadType() - Method in interface org.axonframework.messaging.annotation.ParameterResolver
-
Returns the class of the payload that is supported by this resolver.
- supportedPayloadType() - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
-
- suspect() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-
- suspect() - Method in interface org.axonframework.commandhandling.distributed.Member
-
Mark this member as suspect, i.e.
- suspect() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-
- validateMessage(Object, Validator) - Method in class org.axonframework.messaging.interceptors.BeanValidationInterceptor
-
Validate the given message
using the given validator
.
- validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.commandhandling.model.AbstractRepository
-
Checks the aggregate for concurrent changes.
- validateOnLoad(Aggregate<T>, Long) - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
- valueOf(String) - Static method in enum org.axonframework.commandhandling.conflictresolution.NoConflictResolver
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.common.lock.NullLockFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.common.transaction.NoTransactionManager
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.eventhandling.DirectEventProcessingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.eventhandling.saga.repository.NoResourceInjector
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.eventhandling.saga.SagaCreationPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.eventhandling.ThrowingListenerErrorHandler
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.messaging.unitofwork.RollbackConfigurationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.axonframework.serialization.upcasting.event.NoOpEventUpcaster
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.axonframework.commandhandling.conflictresolution.NoConflictResolver
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.common.lock.NullLockFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.common.transaction.NoTransactionManager
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.eventhandling.DirectEventProcessingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.eventhandling.PropagatingErrorHandler
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.eventhandling.saga.repository.NoResourceInjector
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.eventhandling.saga.SagaCreationPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.eventhandling.ThrowingListenerErrorHandler
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.eventsourcing.NoSnapshotTriggerDefinition
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.axonframework.messaging.MetaData
-
- values() - Static method in enum org.axonframework.messaging.unitofwork.RollbackConfigurationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.messaging.unitofwork.UnitOfWork.Phase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitor
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.monitoring.NoOpMessageMonitorCallback
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.axonframework.serialization.upcasting.event.NoOpEventUpcaster
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- version() - Method in interface org.axonframework.commandhandling.model.Aggregate
-
Get the aggregate's version.
- version() - Method in class org.axonframework.commandhandling.model.inspection.AnnotatedAggregate
-
- version() - Method in class org.axonframework.commandhandling.model.LockAwareAggregate
-
- version() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
- VersionedAggregateIdentifier - Class in org.axonframework.commandhandling
-
Structure that holds an Aggregate Identifier and an expected version of an aggregate.
- VersionedAggregateIdentifier(String, Long) - Constructor for class org.axonframework.commandhandling.VersionedAggregateIdentifier
-
Initializes a VersionedAggregateIdentifier with the given identifier
and version
.
- VoidCallback<C> - Class in org.axonframework.commandhandling.callbacks
-
Abstract callback that can be extended when no result is expected from the command handler execution.
- VoidCallback() - Constructor for class org.axonframework.commandhandling.callbacks.VoidCallback
-