Uses of Interface
org.axonframework.common.infra.DescribableComponent
Packages that use DescribableComponent
Package
Description
Classes related to message processing in Axon Framework.
Classes related to event sourcing.
Definitions and implementations of the Event store, the mechanism that can load event streams and append events to
them.
JPA Implementation of the EventStore.
Classes that implement the concept of command handling using explicit command objects.
Classes related to event handling and dispatching, such as
and the
invalid reference
Event Listeners
Event Bus.A collection of classes which may prove useful when testing Axon-based classes.
-
Uses of DescribableComponent in org.axonframework.axonserver.connector.command
Classes in org.axonframework.axonserver.connector.command that implement DescribableComponentModifier and TypeClassDescriptionclassAn implementation of theCommandBusConnectorthat connects to an Axon Server instance to send and receive commands. -
Uses of DescribableComponent in org.axonframework.axonserver.connector.event
Classes in org.axonframework.axonserver.connector.event that implement DescribableComponentModifier and TypeClassDescriptionclassEvent Storage Engine implementation that uses the aggregate-oriented APIs of Axon Server, allowing it to interact with versions that do not have DCB support.classAnEventStorageEngineimplementation using Axon Server through theaxonserver-connector-javaproject.classAComponentFactoryimplementation that generatesAxonServerEventStorageEngineinstances.classWrapper around the Axon FrameworkEventConverterthat can convertTaggedEventMessages(Axon Framework representation) toTaggedEvents(Axon Server representation). -
Uses of DescribableComponent in org.axonframework.axonserver.connector.query
Classes in org.axonframework.axonserver.connector.query that implement DescribableComponentModifier and TypeClassDescriptionclassAxonServerQueryBusConnector is an implementation ofQueryBusConnectorthat connects to AxonServer to enable the dispatching and receiving of queries. -
Uses of DescribableComponent in org.axonframework.common.configuration
Subinterfaces of DescribableComponent in org.axonframework.common.configurationModifier and TypeInterfaceDescriptioninterfaceThe configuration of any Axon Framework application.interfaceComponent<C>Describes a component defined in aConfiguration, that may depend on other component for its initialization or during it's startup/shutdown operations.interfaceA factory of components of type genericC.interfaceThe starting point when configuring any Axon Framework application.interfaceInterface providing access to all configuredcomponentsin an Axon Framework application.Classes in org.axonframework.common.configuration that implement DescribableComponentModifier and TypeClassDescriptionclassAbstractComponent<C,A extends C> Base implementation of aComponentandComponentDefinition.ComponentCreatorto simplify definition and creation of components through aComponentDefinition.classclassDefault implementation of theComponentRegistryallowing for reuse ofComponent,ComponentDecorator,ConfigurationEnhancer, andModuleregistration for theApplicationConfigurerandModuleimplementations alike.classImplementation ofComponentandComponentDefinitionthat wraps a pre-instantiated component.classLazyInitializedComponentDefinition<C,A extends C> Implementation ofComponentandComponentDefinitionthat instantiates a component using a configured builder. -
Uses of DescribableComponent in org.axonframework.conversion
Subinterfaces of DescribableComponent in org.axonframework.conversionModifier and TypeInterfaceDescriptioninterfaceInterface describing a mechanism that can convert data from one to another type.Classes in org.axonframework.conversion that implement DescribableComponentModifier and TypeClassDescriptionclassAConverterimplementation that will combineContentTypeConvertersto form chains of converters to be able to convert from one type to another, for which there is no suitable single converter.final classAConverterimplementation that only "passes through" input object if thesourceTypeandtargetTypeare the identical. -
Uses of DescribableComponent in org.axonframework.conversion.avro
Subinterfaces of DescribableComponent in org.axonframework.conversion.avroModifier and TypeInterfaceDescriptioninterfaceStrategy for Avro Converter.Classes in org.axonframework.conversion.avro that implement DescribableComponentModifier and TypeClassDescriptionclassConverter providing support for Apache Avro, using Single Object Encoded binary encoding.classAvro strategy responsible for operations onSpecificRecordBaseas a superclass of all objects you are working on. -
Uses of DescribableComponent in org.axonframework.conversion.json
Classes in org.axonframework.conversion.json that implement DescribableComponentModifier and TypeClassDescriptionclassAConverterimplementation that uses Jackson'sObjectMapperto convert objects into and from a JSON format. -
Uses of DescribableComponent in org.axonframework.eventsourcing
Classes in org.axonframework.eventsourcing that implement DescribableComponentModifier and TypeClassDescriptionclassEventSourcingRepository<ID,E> Repositoryimplementation that loads entities based on their historic event streams, provided by anEventStore. -
Uses of DescribableComponent in org.axonframework.eventsourcing.annotation
Classes in org.axonframework.eventsourcing.annotation that implement DescribableComponentModifier and TypeClassDescriptionclassAnnotation-basedCriteriaResolverimplementation which resolvesEventCriteriabased on the givenidfor loading the entity. -
Uses of DescribableComponent in org.axonframework.eventsourcing.eventstore
Subinterfaces of DescribableComponent in org.axonframework.eventsourcing.eventstoreModifier and TypeInterfaceDescriptioninterfaceInterface for providing storage engines for theStorageEngineBackedEventStore.interfaceInfrastructure component providing the means to start anEventStoreTransactiontoappend eventsandevent sourcemodels from the underlying storage solution.Classes in org.axonframework.eventsourcing.eventstore that implement DescribableComponentModifier and TypeClassDescriptionclassDecorator around theEventStoreintercepting alleventsbefore they areappendedorpublishedwithdispatch interceptors.classAnEventStoreimplementation which uses anEventStorageEngineas its storage solution. -
Uses of DescribableComponent in org.axonframework.eventsourcing.eventstore.inmemory
Classes in org.axonframework.eventsourcing.eventstore.inmemory that implement DescribableComponentModifier and TypeClassDescriptionclassThread-safeEventStorageEngineimplementation storing events in memory. -
Uses of DescribableComponent in org.axonframework.eventsourcing.eventstore.jpa
Classes in org.axonframework.eventsourcing.eventstore.jpa that implement DescribableComponentModifier and TypeClassDescriptionclassAnEventStorageEngineimplementation that uses JPA to store and fetch events from an aggregate-based event storage solution. -
Uses of DescribableComponent in org.axonframework.extension.spring.config
Classes in org.axonframework.extension.spring.config that implement DescribableComponentModifier and TypeClassDescriptionclassAComponentRegistryimplementation that connects into Spring's ecosystem by means of being aBeanPostProcessor,BeanFactoryPostProcessor, andInitializingBean. -
Uses of DescribableComponent in org.axonframework.messaging.commandhandling
Subinterfaces of DescribableComponent in org.axonframework.messaging.commandhandlingModifier and TypeInterfaceDescriptioninterfaceThe mechanism that dispatchescommandsto their appropriatecommand handler.interfaceInterface describing a group ofCommandHandlersbelonging to a single component.Classes in org.axonframework.messaging.commandhandling that implement DescribableComponentModifier and TypeClassDescriptionclassImplementation of theCommandBusthatdispatchescommands to the handlers subscribed to that specific command'sname.classA simple implementation of theCommandHandlingComponentinterface, allowing for easy registration ofCommandHandlersand otherCommandHandlingComponents. -
Uses of DescribableComponent in org.axonframework.messaging.commandhandling.annotation
Classes in org.axonframework.messaging.commandhandling.annotation that implement DescribableComponentModifier and TypeClassDescriptionclassAdapter that turns classes withCommandHandlerannotated methods into aCommandHandlingComponent. -
Uses of DescribableComponent in org.axonframework.messaging.commandhandling.distributed
Subinterfaces of DescribableComponent in org.axonframework.messaging.commandhandling.distributedModifier and TypeInterfaceDescriptioninterfaceTheCommandBusConnectorinterface defines the contract for connecting multipleCommandBusinstances.Classes in org.axonframework.messaging.commandhandling.distributed that implement DescribableComponentModifier and TypeClassDescriptionclassACommandBusConnectorimplementation that wraps anotherCommandBusConnectorand delegates all calls to it.classImplementation of aCommandBusthat is aware of multiple instances of aCommandBusworking together to spread load.classConnector implementation that converts the payload of outgoing messages into the expected format. -
Uses of DescribableComponent in org.axonframework.messaging.commandhandling.gateway
Subinterfaces of DescribableComponent in org.axonframework.messaging.commandhandling.gatewayModifier and TypeInterfaceDescriptioninterfaceComponent that dispatches commands to aCommandGatewayin a predefinedcontext.interfaceInterface towards the Command Handling components of an application.Classes in org.axonframework.messaging.commandhandling.gateway that implement DescribableComponentModifier and TypeClassDescriptionclassclassACommandGatewayimplementation that wraps theCommandResultof the delegate into a result that can convert the payload of the result using a providedMessageConverter.classDefault implementation of theCommandGatewayinterface. -
Uses of DescribableComponent in org.axonframework.messaging.commandhandling.interception
Classes in org.axonframework.messaging.commandhandling.interception that implement DescribableComponentModifier and TypeClassDescriptionclass -
Uses of DescribableComponent in org.axonframework.messaging.commandhandling.retry
Classes in org.axonframework.messaging.commandhandling.retry that implement DescribableComponentModifier and TypeClassDescriptionclassACommandBuswrapper that will retry dispatchingcommandsthat resulted in a failure. -
Uses of DescribableComponent in org.axonframework.messaging.commandhandling.tracing
Classes in org.axonframework.messaging.commandhandling.tracing that implement DescribableComponentModifier and TypeClassDescriptionclassACommandBuswrapper that adds tracing for outgoing and incomingcommands. -
Uses of DescribableComponent in org.axonframework.messaging.core.conversion
Subinterfaces of DescribableComponent in org.axonframework.messaging.core.conversionModifier and TypeInterfaceDescriptioninterfaceA converter specific forMessages, acting on the payload.Classes in org.axonframework.messaging.core.conversion that implement DescribableComponentModifier and TypeClassDescriptionclassAMessageConverterimplementation delegating conversion operations to aConverter. -
Uses of DescribableComponent in org.axonframework.messaging.core.interception
Subinterfaces of DescribableComponent in org.axonframework.messaging.core.interceptionModifier and TypeInterfaceDescriptioninterfaceA registry ofMessageDispatchInterceptors, acting as a collection ofregistered MessageDispatchInterceptors components.interfaceA registry ofMessageHandlerInterceptors, acting as a collection ofregistered MessageHandlerInterceptors components.Classes in org.axonframework.messaging.core.interception that implement DescribableComponentModifier and TypeClassDescriptionclassDefault implementation of theDispatchInterceptorRegistry, maintaining lists ofCommandMessage,EventMessage, andQueryMessage-specificMessageDispatchInterceptors.classDefault implementation of theHandlerInterceptorRegistry, maintaining lists ofCommandMessage,EventMessage, andQueryMessage-specificMessageHandlerInterceptors. -
Uses of DescribableComponent in org.axonframework.messaging.core.retry
Subinterfaces of DescribableComponent in org.axonframework.messaging.core.retryModifier and TypeInterfaceDescriptioninterfaceDescribes a policy for retrying failed messages.Classes in org.axonframework.messaging.core.retry that implement DescribableComponentModifier and TypeClassDescriptionclassRetryScheduler implementation that schedules retries on aScheduledExecutorServicebased on a givenpolicy.classA RetryScheduler that uses a backoff strategy, doubling the retry delay after each attempt.classA RetryPolicy that delegates to another RetryPolicy when the latest exception matches a given predicate.classA retry policy that caps another policy to maximum number of retries -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling
Subinterfaces of DescribableComponent in org.axonframework.messaging.eventhandlingModifier and TypeInterfaceDescriptioninterfaceSpecification of the mechanism on which the Event Listeners can subscribe for events and event publishers can publish their events.interfaceInterface describing a group ofEventHandlersbelonging to a single component.interfaceInterface describing the option to publishevents.Classes in org.axonframework.messaging.eventhandling that implement DescribableComponentModifier and TypeClassDescriptionclassAbstract implementation of anEventBusthat delegates all calls to a given delegate.classAbstract implementation of anEventHandlingComponentthat delegates calls to a given delegate.classDecorator around theEventBusinterceptors alleventsbefore they arepublishedwithdispatch interceptors.classDecorator around theEventSinkintercepting alleventsbefore they arepublishedwithdispatch interceptors.classSimple implementation of theEventBusthat provides synchronous event publication with optionalProcessingContextintegration for transactional event handling.classSimple implementation of theEventHandlingComponent, containing a collection ofEventHandlersto invoke onSimpleEventHandlingComponent.handle(EventMessage, ProcessingContext). -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.annotation
Classes in org.axonframework.messaging.eventhandling.annotation that implement DescribableComponentModifier and TypeClassDescriptionclassAdapter that turns classes withEventHandlerannotated methods into aEventHandlingComponent. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.configuration
Classes in org.axonframework.messaging.eventhandling.configuration that implement DescribableComponentModifier and TypeClassDescriptionclassConfiguration class to be used forEventProcessorimplementations. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.conversion
Subinterfaces of DescribableComponent in org.axonframework.messaging.eventhandling.conversionModifier and TypeInterfaceDescriptioninterfaceA converter specific forEventMessages, acting on thepayload.Classes in org.axonframework.messaging.eventhandling.conversion that implement DescribableComponentModifier and TypeClassDescriptionclassAnEventConverterimplementation delegating conversion operations to aMessageConverter. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.gateway
Subinterfaces of DescribableComponent in org.axonframework.messaging.eventhandling.gatewayModifier and TypeInterfaceDescriptioninterfaceComponent that appends events to anEventSinkin the context of aProcessingContext.Classes in org.axonframework.messaging.eventhandling.gateway that implement DescribableComponentModifier and TypeClassDescriptionclassComponent that publishes events to anEventSinkin the context of aProcessingContext. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.interception
Classes in org.axonframework.messaging.eventhandling.interception that implement DescribableComponentModifier and TypeClassDescriptionclassAnEventHandlingComponentimplementation that supports intercepting event handling through MessageHandlerInterceptors. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.processing
Subinterfaces of DescribableComponent in org.axonframework.messaging.eventhandling.processingModifier and TypeInterfaceDescriptioninterfaceAn Event Processor processes event messages from an event queue or event bus. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.processing.streaming
Subinterfaces of DescribableComponent in org.axonframework.messaging.eventhandling.processing.streamingModifier and TypeInterfaceDescriptioninterfaceAnEventProcessorwhich processes an event stream in segments. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.processing.streaming.pooled
Classes in org.axonframework.messaging.eventhandling.processing.streaming.pooled that implement DescribableComponentModifier and TypeClassDescriptionclassAStreamingEventProcessorimplementation which pools its resources to enhance processing speed.classConfiguration class for aPooledStreamingEventProcessor. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.processing.streaming.segmenting
Classes in org.axonframework.messaging.eventhandling.processing.streaming.segmenting that implement DescribableComponentModifier and TypeClassDescriptionclassDecorator forEventHandlingComponent.classDecorator implementation ofEventHandlingComponentthat uses a configurableSequencingPolicyto determine the sequence identifier for events, while delegating all other operations to an underlyingEventHandlingComponent.classAnEventHandlingComponentwrapper that ensures events with the same sequence identifier are handled sequentially. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.processing.subscribing
Classes in org.axonframework.messaging.eventhandling.processing.subscribing that implement DescribableComponentModifier and TypeClassDescriptionclassEvent processor implementation thatsubscribesto theEventBusfor events.classConfiguration class for aSubscribingEventProcessor. -
Uses of DescribableComponent in org.axonframework.messaging.eventhandling.tracing
Classes in org.axonframework.messaging.eventhandling.tracing that implement DescribableComponentModifier and TypeClassDescriptionclassAnEventHandlingComponentthat tracks the handling of events using aSpansupplier. -
Uses of DescribableComponent in org.axonframework.messaging.monitoring.configuration
Subinterfaces of DescribableComponent in org.axonframework.messaging.monitoring.configurationModifier and TypeInterfaceDescriptioninterfaceA registry ofMessageMonitors, acting as a collection ofregistered MessageMonitor components.Classes in org.axonframework.messaging.monitoring.configuration that implement DescribableComponentModifier and TypeClassDescriptionclassTheDefaultMessageMonitorRegistryis a default implementation of theMessageMonitorRegistryinterface responsible for managing and providing components ofMessageMonitorfor various message types such asCommandMessage,EventMessage, andQueryMessage. -
Uses of DescribableComponent in org.axonframework.messaging.queryhandling
Subinterfaces of DescribableComponent in org.axonframework.messaging.queryhandlingModifier and TypeInterfaceDescriptioninterfaceThe mechanism that dispatchesqueriesto their appropriatequery handler.interfaceInterface describing a group ofQueryHandlersbelonging to a single component.interfaceQuery-specific component that interacts withsubscription queriesaboutupdate,errors, and when there areno more update.Classes in org.axonframework.messaging.queryhandling that implement DescribableComponentModifier and TypeClassDescriptionclassImplementation of theQueryBusthat dispatches queries (throughSimpleQueryBus.query(QueryMessage, ProcessingContext)orSimpleQueryBus.subscriptionQuery(QueryMessage, ProcessingContext, int)) to theQueryHandlerssubscribed to that specific query'snameandresponse typecombination.classA simple implementation of theQueryHandlingComponentinterface, allowing for easy registration ofQueryHandlersand otherQueryHandlingComponents.classSimple implementation of theQueryUpdateEmitter, delegating operations to aQueryBusfor emitting update, completing subscription queries, and completing subscription queries exceptionally. -
Uses of DescribableComponent in org.axonframework.messaging.queryhandling.annotation
Classes in org.axonframework.messaging.queryhandling.annotation that implement DescribableComponentModifier and TypeClassDescriptionclassAdapter that turns classes withQueryHandlerannotated methods into aQueryHandlingComponent. -
Uses of DescribableComponent in org.axonframework.messaging.queryhandling.distributed
Subinterfaces of DescribableComponent in org.axonframework.messaging.queryhandling.distributedModifier and TypeInterfaceDescriptioninterfaceTheQueryBusConnectorinterface defines the contract for connecting multipleQueryBusinstances.Classes in org.axonframework.messaging.queryhandling.distributed that implement DescribableComponentModifier and TypeClassDescriptionclassAQueryBusConnectorimplementation that wraps anotherQueryBusConnectorand delegates all calls to it.classImplementation of aQueryBusthat is aware of multiple instances of aQueryBusworking together to spread the load.classConnector implementation that converts the payload of outgoing messages into the expected format. -
Uses of DescribableComponent in org.axonframework.messaging.queryhandling.gateway
Subinterfaces of DescribableComponent in org.axonframework.messaging.queryhandling.gatewayModifier and TypeInterfaceDescriptioninterfaceInterface towards the Query Handling components of an application.Classes in org.axonframework.messaging.queryhandling.gateway that implement DescribableComponent -
Uses of DescribableComponent in org.axonframework.messaging.queryhandling.interception
Classes in org.axonframework.messaging.queryhandling.interception that implement DescribableComponentModifier and TypeClassDescriptionclass -
Uses of DescribableComponent in org.axonframework.modelling
Classes in org.axonframework.modelling that implement DescribableComponentModifier and TypeClassDescriptionclassImplementation ofEntityEvolvingComponentthat evolves a givenentityof typeEby searching a specificEntityEvolverbased on theQualifiedNamein theevent's type.classSimple implementation of theStateManager. -
Uses of DescribableComponent in org.axonframework.modelling.entity
Subinterfaces of DescribableComponent in org.axonframework.modelling.entityModifier and TypeInterfaceDescriptioninterfaceThe messaging metamodel of entity typeE, containing the information needed to handle commands and events.Classes in org.axonframework.modelling.entity that implement DescribableComponentModifier and TypeClassDescriptionclassImplementation of theEntityMetamodelinterface that enables the definition of command handlers and child entities for a given entity typeE.classACommandHandlingComponentthat handles commands for an entity.classPolymorphicEntityMetamodelthat represents an entity that can have multiple concrete types. -
Uses of DescribableComponent in org.axonframework.modelling.entity.annotation
Classes in org.axonframework.modelling.entity.annotation that implement DescribableComponentModifier and TypeClassDescriptionclassImplementation of theEntityIdResolverthat converts the payload through the configuredMessageConverterthen takes the expected representation of the message handler from theAnnotatedEntityMetamodel.classAnEntityMetamodelimplementation that uses reflection to inspect the entity. -
Uses of DescribableComponent in org.axonframework.modelling.entity.child
Classes in org.axonframework.modelling.entity.child that implement DescribableComponentModifier and TypeClassDescriptionclassAChildEntityFieldDefinitionthat uses a field to access the child entity. -
Uses of DescribableComponent in org.axonframework.modelling.repository
Subinterfaces of DescribableComponent in org.axonframework.modelling.repositoryModifier and TypeInterfaceDescriptioninterfaceRepository<ID,E> TheRepositoryprovides an abstraction for the storage of entities.static interfaceSpecialization of theRepositoryinterface that must be implemented by all implementations of theRepository.Classes in org.axonframework.modelling.repository that implement DescribableComponentModifier and TypeClassDescriptionclassRepository implementation that ensures safe concurrent access to entities stored in it.classInMemoryRepository<ID,E> In-memory implementation of theRepositoryinterface that stores entities in aConcurrentHashMap.classSimpleRepository<ID,E> Simple implementation of anRepositorythat can load and persist entities of a given type. -
Uses of DescribableComponent in org.axonframework.test.fixture
Classes in org.axonframework.test.fixture that implement DescribableComponentModifier and TypeClassDescriptionclassAn CommandBus implementation recording all the commands that are dispatched.classclassclassAnEventStoreimplementation recording all the events that arepublished. -
Uses of DescribableComponent in org.axonframework.test.util
Classes in org.axonframework.test.util that implement DescribableComponentModifier and TypeClassDescriptionclassCommandBus implementation that does not perform any actions on subscriptions or dispatched commands, but records them instead.