jar

org.axonframework : axon-core

Maven & Gradle

Jul 08, 2022
89 usages
3k stars

Axon Framework core

Table Of Contents

Latest Version

Download org.axonframework : axon-core JAR file - Latest Versions:

All Versions

Download org.axonframework : axon-core JAR file - All Versions:

Version Vulnerabilities Size Updated
4.0
3.4.x
3.4
3.3.x
3.3
3.2.x
3.2
3.1.x
3.1
3.0.x
3.0
2.4.x
2.4
2.3.x
2.3
2.2
2.1.x
2.1
2.0.x
2.0
1.4
1.3.x
1.3
1.2.x
1.2
1.1.x
1.1
1.0.x
1.0
0.7.x
0.7
0.6.x
0.6
0.5.x
0.5

View Java Class Source Code in JAR file

  1. Download JD-GUI to open JAR file and explore Java source code file (.class .java)
  2. Click menu "File → Open File..." or just drag-and-drop the JAR file in the JD-GUI window axon-core-3.4.4.jar file.
    Once you open a JAR file, all the java classes in the JAR file will be displayed.

org.axonframework.commandhandling.conflictresolution

├─ org.axonframework.commandhandling.conflictresolution.ConflictDescription.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.ConflictExceptionSupplier.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.ConflictResolution.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.ConflictResolver.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.Conflicts.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.ContextAwareConflictExceptionSupplier.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.DefaultConflictDescription.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.DefaultConflictResolver.class - [JAR]

├─ org.axonframework.commandhandling.conflictresolution.NoConflictResolver.class - [JAR]

org.axonframework.common.jdbc

├─ org.axonframework.common.jdbc.ConnectionProvider.class - [JAR]

├─ org.axonframework.common.jdbc.ConnectionWrapperFactory.class - [JAR]

├─ org.axonframework.common.jdbc.DataSourceConnectionProvider.class - [JAR]

├─ org.axonframework.common.jdbc.JdbcException.class - [JAR]

├─ org.axonframework.common.jdbc.JdbcUtils.class - [JAR]

├─ org.axonframework.common.jdbc.Oracle11Utils.class - [JAR]

├─ org.axonframework.common.jdbc.PersistenceExceptionResolver.class - [JAR]

├─ org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper.class - [JAR]

org.axonframework.eventhandling.tokenstore

├─ org.axonframework.eventhandling.tokenstore.AbstractTokenEntry.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.GenericTokenEntry.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.TokenStore.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.UnableToClaimTokenException.class - [JAR]

org.axonframework.serialization.upcasting

├─ org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.GenericUpcasterChain.class - [JAR]

├─ org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.SingleEntryUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.Upcaster.class - [JAR]

org.axonframework.eventhandling.saga.repository.jdbc

├─ org.axonframework.eventhandling.saga.repository.jdbc.GenericSagaSqlSchema.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jdbc.HsqlSagaSqlSchema.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jdbc.JdbcSagaStore.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jdbc.Oracle11SagaSqlSchema.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jdbc.PostgresSagaSqlSchema.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jdbc.SagaSchema.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jdbc.SagaSqlSchema.class - [JAR]

org.axonframework.queryhandling

├─ org.axonframework.queryhandling.CompletedEmitterException.class - [JAR]

├─ org.axonframework.queryhandling.DefaultQueryGateway.class - [JAR]

├─ org.axonframework.queryhandling.DefaultSubscriptionQueryResult.class - [JAR]

├─ org.axonframework.queryhandling.FluxSinkWrapper.class - [JAR]

├─ org.axonframework.queryhandling.GenericQueryMessage.class - [JAR]

├─ org.axonframework.queryhandling.GenericQueryResponseMessage.class - [JAR]

├─ org.axonframework.queryhandling.GenericSubscriptionQueryMessage.class - [JAR]

├─ org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage.class - [JAR]

├─ org.axonframework.queryhandling.LoggingQueryInvocationErrorHandler.class - [JAR]

├─ org.axonframework.queryhandling.MonoSinkWrapper.class - [JAR]

├─ org.axonframework.queryhandling.MonoWrapper.class - [JAR]

├─ org.axonframework.queryhandling.NoHandlerForQueryException.class - [JAR]

├─ org.axonframework.queryhandling.QueryBus.class - [JAR]

├─ org.axonframework.queryhandling.QueryExecutionException.class - [JAR]

├─ org.axonframework.queryhandling.QueryGateway.class - [JAR]

├─ org.axonframework.queryhandling.QueryHandler.class - [JAR]

├─ org.axonframework.queryhandling.QueryHandlerAdapter.class - [JAR]

├─ org.axonframework.queryhandling.QueryInvocationErrorHandler.class - [JAR]

├─ org.axonframework.queryhandling.QueryMessage.class - [JAR]

├─ org.axonframework.queryhandling.QueryResponseMessage.class - [JAR]

├─ org.axonframework.queryhandling.QuerySubscription.class - [JAR]

├─ org.axonframework.queryhandling.QueryUpdateEmitter.class - [JAR]

├─ org.axonframework.queryhandling.SimpleQueryBus.class - [JAR]

├─ org.axonframework.queryhandling.SubscriptionQueryBackpressure.class - [JAR]

├─ org.axonframework.queryhandling.SubscriptionQueryMessage.class - [JAR]

├─ org.axonframework.queryhandling.SubscriptionQueryResult.class - [JAR]

├─ org.axonframework.queryhandling.SubscriptionQueryUpdateMessage.class - [JAR]

org.axonframework.eventsourcing.eventstore.jdbc

├─ org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.HsqlEventTableFactory.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.JdbcSQLErrorCodesResolver.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.MySqlEventTableFactory.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jdbc.PostgresEventTableFactory.class - [JAR]

org.axonframework.eventsourcing.eventstore.jpa

├─ org.axonframework.eventsourcing.eventstore.jpa.DomainEventEntry.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry.class - [JAR]

org.axonframework.messaging.unitofwork

├─ org.axonframework.messaging.unitofwork.AbstractUnitOfWork.class - [JAR]

├─ org.axonframework.messaging.unitofwork.BatchingUnitOfWork.class - [JAR]

├─ org.axonframework.messaging.unitofwork.CurrentUnitOfWork.class - [JAR]

├─ org.axonframework.messaging.unitofwork.DefaultUnitOfWork.class - [JAR]

├─ org.axonframework.messaging.unitofwork.ExecutionResult.class - [JAR]

├─ org.axonframework.messaging.unitofwork.MessageProcessingContext.class - [JAR]

├─ org.axonframework.messaging.unitofwork.RollbackConfiguration.class - [JAR]

├─ org.axonframework.messaging.unitofwork.RollbackConfigurationType.class - [JAR]

├─ org.axonframework.messaging.unitofwork.UnitOfWork.class - [JAR]

org.axonframework.commandhandling.distributed

├─ org.axonframework.commandhandling.distributed.AbstractRoutingStrategy.class - [JAR]

├─ org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy.class - [JAR]

├─ org.axonframework.commandhandling.distributed.CommandBusConnector.class - [JAR]

├─ org.axonframework.commandhandling.distributed.CommandBusConnectorCommunicationException.class - [JAR]

├─ org.axonframework.commandhandling.distributed.CommandCallbackRepository.class - [JAR]

├─ org.axonframework.commandhandling.distributed.CommandCallbackWrapper.class - [JAR]

├─ org.axonframework.commandhandling.distributed.CommandDispatchException.class - [JAR]

├─ org.axonframework.commandhandling.distributed.CommandRouter.class - [JAR]

├─ org.axonframework.commandhandling.distributed.ConsistentHash.class - [JAR]

├─ org.axonframework.commandhandling.distributed.ConsistentHashChangeListener.class - [JAR]

├─ org.axonframework.commandhandling.distributed.DispatchMessage.class - [JAR]

├─ org.axonframework.commandhandling.distributed.DistributedCommandBus.class - [JAR]

├─ org.axonframework.commandhandling.distributed.Member.class - [JAR]

├─ org.axonframework.commandhandling.distributed.MetaDataRoutingStrategy.class - [JAR]

├─ org.axonframework.commandhandling.distributed.RemoteCommandHandlingException.class - [JAR]

├─ org.axonframework.commandhandling.distributed.ReplyMessage.class - [JAR]

├─ org.axonframework.commandhandling.distributed.RoutingStrategy.class - [JAR]

├─ org.axonframework.commandhandling.distributed.ServiceRegistryException.class - [JAR]

├─ org.axonframework.commandhandling.distributed.SimpleMember.class - [JAR]

├─ org.axonframework.commandhandling.distributed.UnresolvedRoutingKeyPolicy.class - [JAR]

org.axonframework.commandhandling.model

├─ org.axonframework.commandhandling.model.AbstractRepository.class - [JAR]

├─ org.axonframework.commandhandling.model.Aggregate.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateEntityNotFoundException.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateIdentifier.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateInvocationException.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateLifecycle.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateMember.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateNotFoundException.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateRolledBackException.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateRoot.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateScopeDescriptor.class - [JAR]

├─ org.axonframework.commandhandling.model.AggregateVersion.class - [JAR]

├─ org.axonframework.commandhandling.model.ApplyMore.class - [JAR]

├─ org.axonframework.commandhandling.model.CommandHandlerInterceptor.class - [JAR]

├─ org.axonframework.commandhandling.model.ConcurrencyException.class - [JAR]

├─ org.axonframework.commandhandling.model.ConflictingAggregateVersionException.class - [JAR]

├─ org.axonframework.commandhandling.model.ConflictingModificationException.class - [JAR]

├─ org.axonframework.commandhandling.model.EntityId.class - [JAR]

├─ org.axonframework.commandhandling.model.ForwardMatchingInstances.class - [JAR]

├─ org.axonframework.commandhandling.model.ForwardNone.class - [JAR]

├─ org.axonframework.commandhandling.model.ForwardToAll.class - [JAR]

├─ org.axonframework.commandhandling.model.ForwardingMode.class - [JAR]

├─ org.axonframework.commandhandling.model.GenericJpaRepository.class - [JAR]

├─ org.axonframework.commandhandling.model.LockAwareAggregate.class - [JAR]

├─ org.axonframework.commandhandling.model.LockingRepository.class - [JAR]

├─ org.axonframework.commandhandling.model.Repository.class - [JAR]

├─ org.axonframework.commandhandling.model.RepositoryProvider.class - [JAR]

org.axonframework.deadline

├─ org.axonframework.deadline.AbstractDeadlineManager.class - [JAR]

├─ org.axonframework.deadline.DeadlineException.class - [JAR]

├─ org.axonframework.deadline.DeadlineManager.class - [JAR]

├─ org.axonframework.deadline.DeadlineMessage.class - [JAR]

├─ org.axonframework.deadline.GenericDeadlineMessage.class - [JAR]

├─ org.axonframework.deadline.SimpleDeadlineManager.class - [JAR]

org.axonframework.serialization.xml

├─ org.axonframework.serialization.xml.CompactDriver.class - [JAR]

├─ org.axonframework.serialization.xml.Dom4JToByteArrayConverter.class - [JAR]

├─ org.axonframework.serialization.xml.InputStreamToDom4jConverter.class - [JAR]

├─ org.axonframework.serialization.xml.InputStreamToXomConverter.class - [JAR]

├─ org.axonframework.serialization.xml.XStreamSerializer.class - [JAR]

├─ org.axonframework.serialization.xml.XomToStringConverter.class - [JAR]

org.axonframework.common.jpa

├─ org.axonframework.common.jpa.ContainerManagedEntityManagerProvider.class - [JAR]

├─ org.axonframework.common.jpa.EntityManagerProvider.class - [JAR]

├─ org.axonframework.common.jpa.SimpleEntityManagerProvider.class - [JAR]

org.axonframework.messaging

├─ org.axonframework.messaging.AbstractMessage.class - [JAR]

├─ org.axonframework.messaging.DefaultInterceptorChain.class - [JAR]

├─ org.axonframework.messaging.EventPublicationFailedException.class - [JAR]

├─ org.axonframework.messaging.ExecutionException.class - [JAR]

├─ org.axonframework.messaging.GenericMessage.class - [JAR]

├─ org.axonframework.messaging.Headers.class - [JAR]

├─ org.axonframework.messaging.InterceptorChain.class - [JAR]

├─ org.axonframework.messaging.Message.class - [JAR]

├─ org.axonframework.messaging.MessageDecorator.class - [JAR]

├─ org.axonframework.messaging.MessageDispatchInterceptor.class - [JAR]

├─ org.axonframework.messaging.MessageDispatchInterceptorSupport.class - [JAR]

├─ org.axonframework.messaging.MessageHandler.class - [JAR]

├─ org.axonframework.messaging.MessageHandlerInterceptor.class - [JAR]

├─ org.axonframework.messaging.MessageHandlerInterceptorSupport.class - [JAR]

├─ org.axonframework.messaging.MessageStream.class - [JAR]

├─ org.axonframework.messaging.MetaData.class - [JAR]

├─ org.axonframework.messaging.Scope.class - [JAR]

├─ org.axonframework.messaging.ScopeAware.class - [JAR]

├─ org.axonframework.messaging.ScopeAwareProvider.class - [JAR]

├─ org.axonframework.messaging.ScopeDescriptor.class - [JAR]

├─ org.axonframework.messaging.StreamUtils.class - [JAR]

├─ org.axonframework.messaging.StreamableMessageSource.class - [JAR]

├─ org.axonframework.messaging.SubscribableMessageSource.class - [JAR]

org.axonframework.common.annotation

├─ org.axonframework.common.annotation.AnnotationUtils.class - [JAR]

├─ org.axonframework.common.annotation.PriorityAnnotationComparator.class - [JAR]

org.axonframework.commandhandling.model.inspection

├─ org.axonframework.commandhandling.model.inspection.AbstractChildEntityDefinition.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityDefinition.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AggregateMemberAnnotatedChildEntityMapDefinition.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AggregateMetaModelFactory.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AggregateModel.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AnnotatedAggregate.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AnnotatedAggregateMetaModelFactory.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AnnotatedChildEntity.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.AnnotatedCommandHandlerInterceptor.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.ChildEntity.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.ChildEntityDefinition.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.ChildForwardingCommandMessageHandlingMember.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.CommandHandlerInterceptorHandlingMember.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.CommandMessageHandlingMember.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.EntityModel.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.MethodCommandHandlerDefinition.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.MethodCommandHandlerInterceptorDefinition.class - [JAR]

├─ org.axonframework.commandhandling.model.inspection.ModelInspector.class - [JAR]

org.axonframework.commandhandling.gateway

├─ org.axonframework.commandhandling.gateway.AbstractCommandGateway.class - [JAR]

├─ org.axonframework.commandhandling.gateway.CommandGateway.class - [JAR]

├─ org.axonframework.commandhandling.gateway.CommandGatewayFactory.class - [JAR]

├─ org.axonframework.commandhandling.gateway.DefaultCommandGateway.class - [JAR]

├─ org.axonframework.commandhandling.gateway.IntervalRetryScheduler.class - [JAR]

├─ org.axonframework.commandhandling.gateway.RetryScheduler.class - [JAR]

├─ org.axonframework.commandhandling.gateway.RetryingCallback.class - [JAR]

├─ org.axonframework.commandhandling.gateway.Timeout.class - [JAR]

org.axonframework.eventhandling.scheduling.java

├─ org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.class - [JAR]

├─ org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken.class - [JAR]

org.axonframework.eventsourcing

├─ org.axonframework.eventsourcing.AbstractAggregateFactory.class - [JAR]

├─ org.axonframework.eventsourcing.AbstractSnapshotter.class - [JAR]

├─ org.axonframework.eventsourcing.AggregateCacheEntry.class - [JAR]

├─ org.axonframework.eventsourcing.AggregateDeletedException.class - [JAR]

├─ org.axonframework.eventsourcing.AggregateFactory.class - [JAR]

├─ org.axonframework.eventsourcing.AggregateSnapshotter.class - [JAR]

├─ org.axonframework.eventsourcing.CachingEventSourcingRepository.class - [JAR]

├─ org.axonframework.eventsourcing.DomainEventMessage.class - [JAR]

├─ org.axonframework.eventsourcing.EventCountSnapshotTriggerDefinition.class - [JAR]

├─ org.axonframework.eventsourcing.EventSourcedAggregate.class - [JAR]

├─ org.axonframework.eventsourcing.EventSourcingHandler.class - [JAR]

├─ org.axonframework.eventsourcing.EventSourcingRepository.class - [JAR]

├─ org.axonframework.eventsourcing.FilteringEventStorageEngine.class - [JAR]

├─ org.axonframework.eventsourcing.GenericAggregateFactory.class - [JAR]

├─ org.axonframework.eventsourcing.GenericDomainEventMessage.class - [JAR]

├─ org.axonframework.eventsourcing.GenericTrackedDomainEventMessage.class - [JAR]

├─ org.axonframework.eventsourcing.IncompatibleAggregateException.class - [JAR]

├─ org.axonframework.eventsourcing.NoSnapshotTriggerDefinition.class - [JAR]

├─ org.axonframework.eventsourcing.SequenceNumber.class - [JAR]

├─ org.axonframework.eventsourcing.SequenceNumberParameterResolverFactory.class - [JAR]

├─ org.axonframework.eventsourcing.SnapshotTrigger.class - [JAR]

├─ org.axonframework.eventsourcing.SnapshotTriggerDefinition.class - [JAR]

├─ org.axonframework.eventsourcing.Snapshotter.class - [JAR]

org.axonframework.messaging.interceptors

├─ org.axonframework.messaging.interceptors.BeanValidationInterceptor.class - [JAR]

├─ org.axonframework.messaging.interceptors.CorrelationDataInterceptor.class - [JAR]

├─ org.axonframework.messaging.interceptors.JSR303ViolationException.class - [JAR]

├─ org.axonframework.messaging.interceptors.LoggingInterceptor.class - [JAR]

├─ org.axonframework.messaging.interceptors.TransactionManagingInterceptor.class - [JAR]

org.axonframework.eventhandling.saga.repository

├─ org.axonframework.eventhandling.saga.repository.AnnotatedSagaRepository.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.AssociationValueMap.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.CachingSagaStore.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.LockingSagaRepository.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.NoResourceInjector.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.SagaCreationException.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.SagaStore.class - [JAR]

org.axonframework.common.lock

├─ org.axonframework.common.lock.DeadlockException.class - [JAR]

├─ org.axonframework.common.lock.Lock.class - [JAR]

├─ org.axonframework.common.lock.LockAcquisitionFailedException.class - [JAR]

├─ org.axonframework.common.lock.LockFactory.class - [JAR]

├─ org.axonframework.common.lock.NullLockFactory.class - [JAR]

├─ org.axonframework.common.lock.PessimisticLockFactory.class - [JAR]

org.axonframework.serialization.json

├─ org.axonframework.serialization.json.ByteArrayToJsonNodeConverter.class - [JAR]

├─ org.axonframework.serialization.json.JacksonSerializer.class - [JAR]

├─ org.axonframework.serialization.json.JsonNodeToByteArrayConverter.class - [JAR]

├─ org.axonframework.serialization.json.MetaDataDeserializer.class - [JAR]

org.axonframework.queryhandling.responsetypes

├─ org.axonframework.queryhandling.responsetypes.AbstractResponseType.class - [JAR]

├─ org.axonframework.queryhandling.responsetypes.InstanceResponseType.class - [JAR]

├─ org.axonframework.queryhandling.responsetypes.MultipleInstancesResponseType.class - [JAR]

├─ org.axonframework.queryhandling.responsetypes.ResponseType.class - [JAR]

├─ org.axonframework.queryhandling.responsetypes.ResponseTypes.class - [JAR]

org.axonframework.commandhandling.disruptor

├─ org.axonframework.commandhandling.disruptor.AggregateBlacklistedException.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.AggregateStateCorruptedException.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.BlacklistDetectingCallback.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.CommandHandlerInvoker.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.CommandHandlingEntry.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.DisruptorCommandBus.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.DisruptorConfiguration.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.DisruptorUnitOfWork.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.EventPublisher.class - [JAR]

├─ org.axonframework.commandhandling.disruptor.FirstLevelCache.class - [JAR]

org.axonframework.eventhandling.scheduling

├─ org.axonframework.eventhandling.scheduling.EventScheduler.class - [JAR]

├─ org.axonframework.eventhandling.scheduling.ScheduleToken.class - [JAR]

├─ org.axonframework.eventhandling.scheduling.SchedulingException.class - [JAR]

org.axonframework.eventsourcing.eventstore.inmemory

├─ org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine.class - [JAR]

org.axonframework.common.caching

├─ org.axonframework.common.caching.AbstractCacheAdapter.class - [JAR]

├─ org.axonframework.common.caching.Cache.class - [JAR]

├─ org.axonframework.common.caching.EhCacheAdapter.class - [JAR]

├─ org.axonframework.common.caching.JCacheAdapter.class - [JAR]

├─ org.axonframework.common.caching.NoCache.class - [JAR]

├─ org.axonframework.common.caching.WeakReferenceCache.class - [JAR]

org.axonframework.config

├─ org.axonframework.config.AggregateConfiguration.class - [JAR]

├─ org.axonframework.config.AggregateConfigurer.class - [JAR]

├─ org.axonframework.config.Component.class - [JAR]

├─ org.axonframework.config.Configuration.class - [JAR]

├─ org.axonframework.config.ConfigurationParameterResolverFactory.class - [JAR]

├─ org.axonframework.config.ConfigurationResourceInjector.class - [JAR]

├─ org.axonframework.config.ConfigurationScopeAwareProvider.class - [JAR]

├─ org.axonframework.config.Configurer.class - [JAR]

├─ org.axonframework.config.ConfigurerModule.class - [JAR]

├─ org.axonframework.config.DefaultConfigurer.class - [JAR]

├─ org.axonframework.config.EventHandlingConfiguration.class - [JAR]

├─ org.axonframework.config.EventProcessingConfiguration.class - [JAR]

├─ org.axonframework.config.MessageMonitorFactory.class - [JAR]

├─ org.axonframework.config.MessageMonitorFactoryBuilder.class - [JAR]

├─ org.axonframework.config.ModuleConfiguration.class - [JAR]

├─ org.axonframework.config.ProcessingGroup.class - [JAR]

├─ org.axonframework.config.SagaConfiguration.class - [JAR]

org.axonframework.eventhandling.interceptors

├─ org.axonframework.eventhandling.interceptors.EventLoggingInterceptor.class - [JAR]

org.axonframework.common.digest

├─ org.axonframework.common.digest.Digester.class - [JAR]

org.axonframework.messaging.annotation

├─ org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory.class - [JAR]

├─ org.axonframework.messaging.annotation.AnnotatedHandlerInspector.class - [JAR]

├─ org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember.class - [JAR]

├─ org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition.class - [JAR]

├─ org.axonframework.messaging.annotation.ClasspathHandlerDefinition.class - [JAR]

├─ org.axonframework.messaging.annotation.ClasspathHandlerEnhancerDefinition.class - [JAR]

├─ org.axonframework.messaging.annotation.ClasspathParameterResolverFactory.class - [JAR]

├─ org.axonframework.messaging.annotation.DefaultParameterResolverFactory.class - [JAR]

├─ org.axonframework.messaging.annotation.FixedValueParameterResolver.class - [JAR]

├─ org.axonframework.messaging.annotation.HandlerComparator.class - [JAR]

├─ org.axonframework.messaging.annotation.HandlerDefinition.class - [JAR]

├─ org.axonframework.messaging.annotation.HandlerEnhancerDefinition.class - [JAR]

├─ org.axonframework.messaging.annotation.MessageHandler.class - [JAR]

├─ org.axonframework.messaging.annotation.MessageHandlerInvocationException.class - [JAR]

├─ org.axonframework.messaging.annotation.MessageHandlingMember.class - [JAR]

├─ org.axonframework.messaging.annotation.MessageIdentifier.class - [JAR]

├─ org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory.class - [JAR]

├─ org.axonframework.messaging.annotation.MetaDataValue.class - [JAR]

├─ org.axonframework.messaging.annotation.MultiHandlerDefinition.class - [JAR]

├─ org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition.class - [JAR]

├─ org.axonframework.messaging.annotation.MultiParameterResolverFactory.class - [JAR]

├─ org.axonframework.messaging.annotation.ParameterResolver.class - [JAR]

├─ org.axonframework.messaging.annotation.ParameterResolverFactory.class - [JAR]

├─ org.axonframework.messaging.annotation.PayloadParameterResolver.class - [JAR]

├─ org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory.class - [JAR]

├─ org.axonframework.messaging.annotation.UnsupportedHandlerException.class - [JAR]

├─ org.axonframework.messaging.annotation.WrappedMessageHandlingMember.class - [JAR]

org.axonframework.eventhandling.tokenstore.inmemory

├─ org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore.class - [JAR]

org.axonframework.deadline.quartz

├─ org.axonframework.deadline.quartz.DeadlineJob.class - [JAR]

├─ org.axonframework.deadline.quartz.QuartzDeadlineManager.class - [JAR]

org.axonframework.queryhandling.annotation

├─ org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter.class - [JAR]

├─ org.axonframework.queryhandling.annotation.MethodQueryMessageHandlerDefinition.class - [JAR]

├─ org.axonframework.queryhandling.annotation.QueryHandlingMember.class - [JAR]

org.axonframework.commandhandling.distributed.commandfilter

├─ org.axonframework.commandhandling.distributed.commandfilter.AcceptAll.class - [JAR]

├─ org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter.class - [JAR]

├─ org.axonframework.commandhandling.distributed.commandfilter.DenyAll.class - [JAR]

├─ org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter.class - [JAR]

org.axonframework.eventhandling.saga.repository.inmemory

├─ org.axonframework.eventhandling.saga.repository.inmemory.InMemorySagaStore.class - [JAR]

org.axonframework.common.io

├─ org.axonframework.common.io.IOUtils.class - [JAR]

org.axonframework.eventhandling.replay

├─ org.axonframework.eventhandling.replay.ReplayAwareMessageHandlerWrapper.class - [JAR]

├─ org.axonframework.eventhandling.replay.ReplayParameterResolverFactory.class - [JAR]

org.axonframework.eventhandling.tokenstore.jpa

├─ org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.jpa.TokenEntry.class - [JAR]

org.axonframework.eventsourcing.eventstore

├─ org.axonframework.eventsourcing.eventstore.AbstractDomainEventEntry.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.AbstractEventEntry.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.AbstractEventStore.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.AbstractSequencedDomainEventEntry.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.DomainEventData.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.DomainEventStream.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.EqualRevisionPredicate.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.EventData.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.EventStorageEngine.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.EventStore.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.EventStoreException.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.EventUtils.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.FilteringDomainEventStream.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.GenericDomainEventEntry.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.GenericTrackedDomainEventEntry.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.TrackedDomainEventData.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.TrackedEventData.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.TrackingEventStream.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.TrackingToken.class - [JAR]

├─ org.axonframework.eventsourcing.eventstore.TrackingTokenParameterResolverFactory.class - [JAR]

org.axonframework.serialization.upcasting.event

├─ org.axonframework.serialization.upcasting.event.ContextAwareEventMultiUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.ContextAwareSingleEventUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.EventMultiUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.EventUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.EventUpcasterChain.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.InitialEventRepresentation.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.NoOpEventUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.SingleEventUpcaster.class - [JAR]

├─ org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation.class - [JAR]

org.axonframework.common.property

├─ org.axonframework.common.property.AbstractMethodPropertyAccessStrategy.class - [JAR]

├─ org.axonframework.common.property.BeanPropertyAccessStrategy.class - [JAR]

├─ org.axonframework.common.property.DirectPropertyAccessStrategy.class - [JAR]

├─ org.axonframework.common.property.DirectlyAccessedProperty.class - [JAR]

├─ org.axonframework.common.property.MethodAccessedProperty.class - [JAR]

├─ org.axonframework.common.property.Property.class - [JAR]

├─ org.axonframework.common.property.PropertyAccessException.class - [JAR]

├─ org.axonframework.common.property.PropertyAccessStrategy.class - [JAR]

├─ org.axonframework.common.property.UniformPropertyAccessStrategy.class - [JAR]

org.axonframework.common.transaction

├─ org.axonframework.common.transaction.NoTransactionManager.class - [JAR]

├─ org.axonframework.common.transaction.Transaction.class - [JAR]

├─ org.axonframework.common.transaction.TransactionManager.class - [JAR]

org.axonframework.eventhandling.scheduling.quartz

├─ org.axonframework.eventhandling.scheduling.quartz.EventJobDataBinder.class - [JAR]

├─ org.axonframework.eventhandling.scheduling.quartz.FireEventJob.class - [JAR]

├─ org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.class - [JAR]

├─ org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken.class - [JAR]

org.axonframework.deadline.annotation

├─ org.axonframework.deadline.annotation.DeadlineHandler.class - [JAR]

├─ org.axonframework.deadline.annotation.DeadlineHandlingMember.class - [JAR]

├─ org.axonframework.deadline.annotation.DeadlineMethodMessageHandlerDefinition.class - [JAR]

org.axonframework.eventhandling.async

├─ org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy.class - [JAR]

├─ org.axonframework.eventhandling.async.EventProcessorTask.class - [JAR]

├─ org.axonframework.eventhandling.async.FullConcurrencyPolicy.class - [JAR]

├─ org.axonframework.eventhandling.async.SequencingPolicy.class - [JAR]

├─ org.axonframework.eventhandling.async.SequentialPerAggregatePolicy.class - [JAR]

├─ org.axonframework.eventhandling.async.SequentialPolicy.class - [JAR]

org.axonframework.eventhandling.saga.metamodel

├─ org.axonframework.eventhandling.saga.metamodel.AnnotationSagaMetaModelFactory.class - [JAR]

├─ org.axonframework.eventhandling.saga.metamodel.DefaultSagaMetaModelFactory.class - [JAR]

├─ org.axonframework.eventhandling.saga.metamodel.SagaMetaModelFactory.class - [JAR]

├─ org.axonframework.eventhandling.saga.metamodel.SagaModel.class - [JAR]

org.axonframework.commandhandling

├─ org.axonframework.commandhandling.AggregateAnnotationCommandHandler.class - [JAR]

├─ org.axonframework.commandhandling.AnnotationCommandHandlerAdapter.class - [JAR]

├─ org.axonframework.commandhandling.AnnotationCommandTargetResolver.class - [JAR]

├─ org.axonframework.commandhandling.AsynchronousCommandBus.class - [JAR]

├─ org.axonframework.commandhandling.CommandBus.class - [JAR]

├─ org.axonframework.commandhandling.CommandCallback.class - [JAR]

├─ org.axonframework.commandhandling.CommandExecutionException.class - [JAR]

├─ org.axonframework.commandhandling.CommandHandler.class - [JAR]

├─ org.axonframework.commandhandling.CommandMessage.class - [JAR]

├─ org.axonframework.commandhandling.CommandTargetResolver.class - [JAR]

├─ org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory.class - [JAR]

├─ org.axonframework.commandhandling.GenericCommandMessage.class - [JAR]

├─ org.axonframework.commandhandling.InterceptorChainParameterResolverFactory.class - [JAR]

├─ org.axonframework.commandhandling.MetaDataCommandTargetResolver.class - [JAR]

├─ org.axonframework.commandhandling.MonitorAwareCallback.class - [JAR]

├─ org.axonframework.commandhandling.NoHandlerForCommandException.class - [JAR]

├─ org.axonframework.commandhandling.SimpleCommandBus.class - [JAR]

├─ org.axonframework.commandhandling.SupportedCommandNamesAware.class - [JAR]

├─ org.axonframework.commandhandling.TargetAggregateIdentifier.class - [JAR]

├─ org.axonframework.commandhandling.TargetAggregateVersion.class - [JAR]

├─ org.axonframework.commandhandling.VersionedAggregateIdentifier.class - [JAR]

org.axonframework.common

├─ org.axonframework.common.Assert.class - [JAR]

├─ org.axonframework.common.AxonConfigurationException.class - [JAR]

├─ org.axonframework.common.AxonException.class - [JAR]

├─ org.axonframework.common.AxonNonTransientException.class - [JAR]

├─ org.axonframework.common.AxonThreadFactory.class - [JAR]

├─ org.axonframework.common.AxonTransientException.class - [JAR]

├─ org.axonframework.common.CollectionUtils.class - [JAR]

├─ org.axonframework.common.DateTimeUtils.class - [JAR]

├─ org.axonframework.common.DefaultIdentifierFactory.class - [JAR]

├─ org.axonframework.common.DirectExecutor.class - [JAR]

├─ org.axonframework.common.ExceptionUtils.class - [JAR]

├─ org.axonframework.common.IdentifierFactory.class - [JAR]

├─ org.axonframework.common.IdentifierValidator.class - [JAR]

├─ org.axonframework.common.MemberAccessibilityCallback.class - [JAR]

├─ org.axonframework.common.ObjectUtils.class - [JAR]

├─ org.axonframework.common.Priority.class - [JAR]

├─ org.axonframework.common.ReflectionUtils.class - [JAR]

├─ org.axonframework.common.Registration.class - [JAR]

├─ org.axonframework.common.TypeReflectionUtils.class - [JAR]

org.axonframework.serialization.converters

├─ org.axonframework.serialization.converters.BlobToInputStreamConverter.class - [JAR]

├─ org.axonframework.serialization.converters.ByteArrayToInputStreamConverter.class - [JAR]

├─ org.axonframework.serialization.converters.ByteArrayToStringConverter.class - [JAR]

├─ org.axonframework.serialization.converters.InputStreamToByteArrayConverter.class - [JAR]

├─ org.axonframework.serialization.converters.StringToByteArrayConverter.class - [JAR]

org.axonframework.eventhandling.tokenstore.jdbc

├─ org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.jdbc.PostgresTokenTableFactory.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.class - [JAR]

├─ org.axonframework.eventhandling.tokenstore.jdbc.TokenTableFactory.class - [JAR]

org.axonframework.commandhandling.callbacks

├─ org.axonframework.commandhandling.callbacks.FailureLoggingCallback.class - [JAR]

├─ org.axonframework.commandhandling.callbacks.FutureCallback.class - [JAR]

├─ org.axonframework.commandhandling.callbacks.LoggingCallback.class - [JAR]

├─ org.axonframework.commandhandling.callbacks.NoOpCallback.class - [JAR]

├─ org.axonframework.commandhandling.callbacks.VoidCallback.class - [JAR]

org.axonframework.eventhandling

├─ org.axonframework.eventhandling.AbstractEventBus.class - [JAR]

├─ org.axonframework.eventhandling.AbstractEventProcessor.class - [JAR]

├─ org.axonframework.eventhandling.AllowReplay.class - [JAR]

├─ org.axonframework.eventhandling.AnnotationEventListenerAdapter.class - [JAR]

├─ org.axonframework.eventhandling.ConcludesBatch.class - [JAR]

├─ org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory.class - [JAR]

├─ org.axonframework.eventhandling.DirectEventProcessingStrategy.class - [JAR]

├─ org.axonframework.eventhandling.ErrorContext.class - [JAR]

├─ org.axonframework.eventhandling.ErrorHandler.class - [JAR]

├─ org.axonframework.eventhandling.EventBus.class - [JAR]

├─ org.axonframework.eventhandling.EventHandler.class - [JAR]

├─ org.axonframework.eventhandling.EventHandlerInvoker.class - [JAR]

├─ org.axonframework.eventhandling.EventListener.class - [JAR]

├─ org.axonframework.eventhandling.EventListenerProxy.class - [JAR]

├─ org.axonframework.eventhandling.EventMessage.class - [JAR]

├─ org.axonframework.eventhandling.EventProcessingException.class - [JAR]

├─ org.axonframework.eventhandling.EventProcessingStrategy.class - [JAR]

├─ org.axonframework.eventhandling.EventProcessor.class - [JAR]

├─ org.axonframework.eventhandling.EventTrackerStatus.class - [JAR]

├─ org.axonframework.eventhandling.GenericEventMessage.class - [JAR]

├─ org.axonframework.eventhandling.GenericTrackedEventMessage.class - [JAR]

├─ org.axonframework.eventhandling.ListenerInvocationErrorHandler.class - [JAR]

├─ org.axonframework.eventhandling.LoggingErrorHandler.class - [JAR]

├─ org.axonframework.eventhandling.MultiEventHandlerInvoker.class - [JAR]

├─ org.axonframework.eventhandling.PropagatingErrorHandler.class - [JAR]

├─ org.axonframework.eventhandling.ReplayStatus.class - [JAR]

├─ org.axonframework.eventhandling.ReplayToken.class - [JAR]

├─ org.axonframework.eventhandling.ResetHandler.class - [JAR]

├─ org.axonframework.eventhandling.ResetNotSupportedException.class - [JAR]

├─ org.axonframework.eventhandling.ResetTriggeredEvent.class - [JAR]

├─ org.axonframework.eventhandling.Segment.class - [JAR]

├─ org.axonframework.eventhandling.SimpleEventBus.class - [JAR]

├─ org.axonframework.eventhandling.SimpleEventHandlerInvoker.class - [JAR]

├─ org.axonframework.eventhandling.SubscribingEventProcessor.class - [JAR]

├─ org.axonframework.eventhandling.ThrowingListenerErrorHandler.class - [JAR]

├─ org.axonframework.eventhandling.Timestamp.class - [JAR]

├─ org.axonframework.eventhandling.TimestampParameterResolverFactory.class - [JAR]

├─ org.axonframework.eventhandling.TrackedEventMessage.class - [JAR]

├─ org.axonframework.eventhandling.TrackingEventProcessor.class - [JAR]

├─ org.axonframework.eventhandling.TrackingEventProcessorConfiguration.class - [JAR]

├─ org.axonframework.eventhandling.TransactionMethodExecutionException.class - [JAR]

├─ org.axonframework.eventhandling.WrappedToken.class - [JAR]

org.axonframework.eventhandling.saga.repository.jpa

├─ org.axonframework.eventhandling.saga.repository.jpa.AbstractSagaEntry.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jpa.AssociationValueEntry.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jpa.JpaSagaStore.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jpa.SagaEntry.class - [JAR]

├─ org.axonframework.eventhandling.saga.repository.jpa.SerializedSaga.class - [JAR]

org.axonframework.messaging.correlation

├─ org.axonframework.messaging.correlation.CorrelationDataProvider.class - [JAR]

├─ org.axonframework.messaging.correlation.MessageOriginProvider.class - [JAR]

├─ org.axonframework.messaging.correlation.MultiCorrelationDataProvider.class - [JAR]

├─ org.axonframework.messaging.correlation.SimpleCorrelationDataProvider.class - [JAR]

org.axonframework.eventhandling.saga

├─ org.axonframework.eventhandling.saga.AbstractResourceInjector.class - [JAR]

├─ org.axonframework.eventhandling.saga.AbstractSagaManager.class - [JAR]

├─ org.axonframework.eventhandling.saga.AnnotatedSaga.class - [JAR]

├─ org.axonframework.eventhandling.saga.AnnotatedSagaManager.class - [JAR]

├─ org.axonframework.eventhandling.saga.AssociationResolver.class - [JAR]

├─ org.axonframework.eventhandling.saga.AssociationValue.class - [JAR]

├─ org.axonframework.eventhandling.saga.AssociationValues.class - [JAR]

├─ org.axonframework.eventhandling.saga.AssociationValuesImpl.class - [JAR]

├─ org.axonframework.eventhandling.saga.EndSaga.class - [JAR]

├─ org.axonframework.eventhandling.saga.MetaDataAssociationResolver.class - [JAR]

├─ org.axonframework.eventhandling.saga.PayloadAssociationResolver.class - [JAR]

├─ org.axonframework.eventhandling.saga.ResourceInjector.class - [JAR]

├─ org.axonframework.eventhandling.saga.Saga.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaCreationPolicy.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaEventHandler.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaExecutionException.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaInitializationPolicy.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaInstantiationException.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaLifecycle.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaMethodMessageHandlerDefinition.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaMethodMessageHandlingMember.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaRepository.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaScopeDescriptor.class - [JAR]

├─ org.axonframework.eventhandling.saga.SagaStorageException.class - [JAR]

├─ org.axonframework.eventhandling.saga.SimpleResourceInjector.class - [JAR]

├─ org.axonframework.eventhandling.saga.StartSaga.class - [JAR]

org.axonframework.serialization

├─ org.axonframework.serialization.AbstractXStreamSerializer.class - [JAR]

├─ org.axonframework.serialization.AnnotationRevisionResolver.class - [JAR]

├─ org.axonframework.serialization.CachingSupplier.class - [JAR]

├─ org.axonframework.serialization.CannotConvertBetweenTypesException.class - [JAR]

├─ org.axonframework.serialization.ChainedConverter.class - [JAR]

├─ org.axonframework.serialization.ChainingConverter.class - [JAR]

├─ org.axonframework.serialization.ContentTypeConverter.class - [JAR]

├─ org.axonframework.serialization.Converter.class - [JAR]

├─ org.axonframework.serialization.FixedValueRevisionResolver.class - [JAR]

├─ org.axonframework.serialization.JavaSerializer.class - [JAR]

├─ org.axonframework.serialization.LazyDeserializingObject.class - [JAR]

├─ org.axonframework.serialization.MavenArtifactRevisionResolver.class - [JAR]

├─ org.axonframework.serialization.MessageSerializer.class - [JAR]

├─ org.axonframework.serialization.Revision.class - [JAR]

├─ org.axonframework.serialization.RevisionResolver.class - [JAR]

├─ org.axonframework.serialization.SerialVersionUIDRevisionResolver.class - [JAR]

├─ org.axonframework.serialization.SerializationAware.class - [JAR]

├─ org.axonframework.serialization.SerializationException.class - [JAR]

├─ org.axonframework.serialization.SerializedMessage.class - [JAR]

├─ org.axonframework.serialization.SerializedMetaData.class - [JAR]

├─ org.axonframework.serialization.SerializedObject.class - [JAR]

├─ org.axonframework.serialization.SerializedObjectHolder.class - [JAR]

├─ org.axonframework.serialization.SerializedType.class - [JAR]

├─ org.axonframework.serialization.Serializer.class - [JAR]

├─ org.axonframework.serialization.SimpleSerializedObject.class - [JAR]

├─ org.axonframework.serialization.SimpleSerializedType.class - [JAR]

├─ org.axonframework.serialization.UnknownSerializedTypeException.class - [JAR]

org.axonframework.monitoring

├─ org.axonframework.monitoring.MessageMonitor.class - [JAR]

├─ org.axonframework.monitoring.MultiMessageMonitor.class - [JAR]

├─ org.axonframework.monitoring.NoOpMessageMonitor.class - [JAR]

├─ org.axonframework.monitoring.NoOpMessageMonitorCallback.class - [JAR]

Advertisement

Dependencies from Group

Jul 08, 2022
89 usages
3k stars
Aug 14, 2023
41 usages
3k stars
Aug 14, 2023
29 usages
3k stars
Aug 14, 2023
27 usages
3k stars
Aug 14, 2023
23 usages
3k stars

Discover Dependencies

May 24, 2021
73 usages
Jul 23, 2018
42 usages
433 stars
Dec 15, 2021
42 usages
686 stars
May 02, 2023
34 usages
Aug 24, 2023
34 usages
30 stars
Aug 10, 2023
43 usages
328 stars
Jul 13, 2023
33 usages
82 stars