Skip navigation links
A C D E F G H I J L M O P R S T U V W 

A

AbstractAggregateEventTest<A extends Aggregate<A>,T extends Event> - Class in io.eventuate.testutil
 
AbstractAggregateEventTest(Class<A>, Class<T>) - Constructor for class io.eventuate.testutil.AbstractAggregateEventTest
 
AbstractJdbcAggregateCrud - Class in io.eventuate.javaclient.jdbc
 
AbstractJdbcAggregateCrud(EventuateJdbcAccess) - Constructor for class io.eventuate.javaclient.jdbc.AbstractJdbcAggregateCrud
 
AbstractTestEventHandler - Class in io.eventuate.testutil
 
AbstractTestEventHandler() - Constructor for class io.eventuate.testutil.AbstractTestEventHandler
 
add(RegisteredSubscription) - Method in class io.eventuate.SubscriptionsRegistry
 
add(DispatchedEvent<T>) - Method in class io.eventuate.testutil.AbstractTestEventHandler
 
add(EventHandlerContext<T>) - Method in class io.eventuate.testutil.AbstractTestEventHandler
 
add(DispatchedEvent<T>) - Method in class io.eventuate.testutil.EventTracker
 
add(EventHandlerContext<T>) - Method in class io.eventuate.testutil.EventTracker
 
addStrategy(SnapshotStrategy) - Method in class io.eventuate.SnapshotManagerImpl
 
Aggregate<T extends Aggregate> - Interface in io.eventuate
Base interface for an Aggregate that uses event sourcing
aggregate - Variable in class io.eventuate.testutil.AggregateTest
 
aggregateCrud(AggregateCrud) - Method in class io.eventuate.javaclient.micronaut.jdbc.EmbeddedTestAggregateStoreFactory
 
aggregateCrud(AggregateCrud) - Method in class io.eventuate.javaclient.spring.jdbc.EmbeddedTestAggregateStoreConfiguration
 
aggregateEvents(AggregateEvents) - Method in class io.eventuate.javaclient.micronaut.jdbc.EmbeddedTestAggregateStoreFactory
 
aggregateEvents(AggregateEvents) - Method in class io.eventuate.javaclient.spring.jdbc.EmbeddedTestAggregateStoreConfiguration
 
aggregateEvents(EventuateKafkaConfigurationProperties, EventuateKafkaConsumerConfigurationProperties, KafkaConsumerFactory) - Method in class io.eventuate.local.java.spring.common.jdbckafkastore.EventuateLocalConfiguration
 
aggregateEventStore(MissingApplyEventMethodStrategy[], SerializedEventDeserializer, AggregateCrud, AggregateEvents, SnapshotManager, EventuateEventSchemaManager) - Method in class io.eventuate.javaclient.micronaut.common.EventuateCommonFactory
 
aggregateEventStore(AggregateCrud, AggregateEvents, SnapshotManager, EventuateEventSchemaManager) - Method in class io.eventuate.javaclient.spring.common.EventuateCommonConfiguration
 
AggregateOperationInvocation<T extends CommandProcessingAggregate<T,CT>,CT extends Command,C extends CT> - Interface in io.eventuate.testutil
 
AggregateRepository<T extends CommandProcessingAggregate<T,CT>,CT extends Command> - Class in io.eventuate
A convenience class, with a reactive-style API that provides a simplified interface for creating and updating aggregates.
AggregateRepository(Class<T>, EventuateAggregateStore) - Constructor for class io.eventuate.AggregateRepository
Constructs a new AggregateRepository for the specified aggregate class and aggregate store
AggregateRepository<T extends CommandProcessingAggregate<T,CT>,CT extends Command> - Class in io.eventuate.sync
A convenience class, with a synchronous-style API that provides a simplified interface for creating and updating aggregates.
AggregateRepository(Class<T>, EventuateAggregateStore) - Constructor for class io.eventuate.sync.AggregateRepository
Constructs a new AggregateRepository for the specified aggregate class and aggregate store
AggregateRepositoryBeanPostProcessor - Class in io.eventuate.javaclient.spring.common
 
AggregateRepositoryBeanPostProcessor(CompositeMissingApplyEventMethodStrategy) - Constructor for class io.eventuate.javaclient.spring.common.AggregateRepositoryBeanPostProcessor
 
aggregateRepositoryBeanPostProcessor() - Method in class io.eventuate.javaclient.spring.common.EventuateCommonConfiguration
 
AggregateRepositoryInitializer - Class in io.eventuate.javaclient.micronaut.common
 
AggregateRepositoryInitializer(CompositeMissingApplyEventMethodStrategy, AggregateRepository[], AggregateRepository[]) - Constructor for class io.eventuate.javaclient.micronaut.common.AggregateRepositoryInitializer
 
AggregateRepositoryInterceptor<T extends CommandProcessingAggregate<T,CT>,CT extends Command> - Interface in io.eventuate
 
Aggregates - Class in io.eventuate
 
Aggregates() - Constructor for class io.eventuate.Aggregates
 
AggregateTest<T extends ReflectiveMutableCommandProcessingAggregate<T,CT>,CT extends Command> - Class in io.eventuate.testutil
Abstract base class for writing unit tests for aggregates
AggregateTest(Class<T>) - Constructor for class io.eventuate.testutil.AggregateTest
 
applyEvent(Event) - Method in interface io.eventuate.Aggregate
Update the aggregate
applyEvent(Event) - Method in class io.eventuate.ReflectiveMutableCommandProcessingAggregate
Apply an event by invoking an apply() method whose parameter class matches the event's class
applyEventsToMutableAggregate(T, List<Event>, MissingApplyEventMethodStrategy) - Static method in class io.eventuate.Aggregates
 
assertEventsEquals(Event...) - Method in class io.eventuate.testutil.AggregateTest
 
assertMessagePublished(String, Class<T>) - Method in class io.eventuate.testutil.AbstractTestEventHandler
 
assertMessagePublished(String, Predicate<ReceivedEvent>) - Method in class io.eventuate.testutil.AbstractTestEventHandler
 
assertMessagePublished(String, Class<T>) - Method in class io.eventuate.testutil.EventTracker
 
assertMessagePublished(String, Predicate<ReceivedEvent>) - Method in class io.eventuate.testutil.EventTracker
 
asyncAggregateCrud(AggregateCrud) - Method in class io.eventuate.local.java.spring.common.jdbckafkastore.EventuateLocalConfiguration
 
AsyncUtil - Class in io.eventuate.testutil
 
AsyncUtil() - Constructor for class io.eventuate.testutil.AsyncUtil
 
await(CompletableFuture<T>) - Static method in class io.eventuate.testutil.AsyncUtil
 

C

checkSnapshotForDuplicateEvent(LoadedSnapshot, EventContext) - Method in class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
clasz - Variable in class io.eventuate.CommonAggregateRepository
 
clear() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
Command - Interface in io.eventuate
Base interface for event sourcing commands
CommandOutcome - Class in io.eventuate
 
CommandOutcome(List<Event>) - Constructor for class io.eventuate.CommandOutcome
 
CommandOutcome(Throwable) - Constructor for class io.eventuate.CommandOutcome
 
CommandProcessingAggregate<T extends CommandProcessingAggregate,CT extends Command> - Interface in io.eventuate
An aggregate that processes commands by returning (state changing) events
CommonAggregateRepository<T extends CommandProcessingAggregate<T,CT>,CT extends Command> - Class in io.eventuate
 
CommonAggregateRepository(Class<T>) - Constructor for class io.eventuate.CommonAggregateRepository
 
CommonEventuateJdbcAccessImplTest - Class in io.eventuate.javaclient.jdbc.common.tests
 
CommonEventuateJdbcAccessImplTest() - Constructor for class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
CompletableFutureUtil - Class in io.eventuate
 
CompletableFutureUtil() - Constructor for class io.eventuate.CompletableFutureUtil
 
completeSomehow(CompletableFuture<T>, T, Throwable) - Static method in class io.eventuate.CompletableFutureUtil
 
CompositeMissingApplyEventMethodStrategy - Class in io.eventuate
 
CompositeMissingApplyEventMethodStrategy(MissingApplyEventMethodStrategy[]) - Constructor for class io.eventuate.CompositeMissingApplyEventMethodStrategy
 
compositeMissingApplyEventMethodStrategy(MissingApplyEventMethodStrategy[]) - Method in class io.eventuate.javaclient.micronaut.common.EventuateCommonFactory
 
create(CT) - Method in class io.eventuate.testutil.AggregateTest
Process a command that creates an aggregate

D

DefaultAggregateRepositoryInterceptor<T extends CommandProcessingAggregate<T,CT>,CT extends Command> - Class in io.eventuate
 
DefaultAggregateRepositoryInterceptor() - Constructor for class io.eventuate.DefaultAggregateRepositoryInterceptor
 
DefaultMissingApplyEventMethodStrategy - Class in io.eventuate
 
DefaultMissingApplyEventMethodStrategy() - Constructor for class io.eventuate.DefaultMissingApplyEventMethodStrategy
 
DEFAULTS - Static variable in class io.eventuate.SubscriberOptions
 
DispatchedEvent<T extends Event> - Class in io.eventuate
 
DispatchedEvent(String, Int128, T, Integer, Long, EventContext, Optional<Map<String, String>>) - Constructor for class io.eventuate.DispatchedEvent
 
DuplicateTriggeringEventException - Exception in io.eventuate
 
DuplicateTriggeringEventException() - Constructor for exception io.eventuate.DuplicateTriggeringEventException
 

E

EmbeddedTestAggregateStoreConfiguration - Class in io.eventuate.javaclient.spring.jdbc
 
EmbeddedTestAggregateStoreConfiguration() - Constructor for class io.eventuate.javaclient.spring.jdbc.EmbeddedTestAggregateStoreConfiguration
 
EmbeddedTestAggregateStoreFactory - Class in io.eventuate.javaclient.micronaut.jdbc
 
EmbeddedTestAggregateStoreFactory() - Constructor for class io.eventuate.javaclient.micronaut.jdbc.EmbeddedTestAggregateStoreFactory
 
EnableEventHandlers - Annotation Type in io.eventuate.javaclient.spring
Configures event handling Spring beans
EndOfCurrentEventsReachedEvent - Class in io.eventuate
 
EndOfCurrentEventsReachedEvent() - Constructor for class io.eventuate.EndOfCurrentEventsReachedEvent
 
EntityAlreadyExistsException - Exception in io.eventuate
 
EntityAlreadyExistsException() - Constructor for exception io.eventuate.EntityAlreadyExistsException
 
entityEventShouldReferenceAggregateClass() - Method in class io.eventuate.testutil.AbstractAggregateEventTest
 
EntityIdAndType - Class in io.eventuate
 
EntityIdAndType() - Constructor for class io.eventuate.EntityIdAndType
 
EntityIdAndType(String, String) - Constructor for class io.eventuate.EntityIdAndType
 
EntityIdAndVersion - Class in io.eventuate
 
EntityIdAndVersion(String, Int128) - Constructor for class io.eventuate.EntityIdAndVersion
 
EntityNotFoundException - Exception in io.eventuate
 
EntityNotFoundException() - Constructor for exception io.eventuate.EntityNotFoundException
 
EntityNotFoundException(String, String) - Constructor for exception io.eventuate.EntityNotFoundException
 
EntityTemporarilyUnavailableException - Exception in io.eventuate
 
EntityTemporarilyUnavailableException() - Constructor for exception io.eventuate.EntityTemporarilyUnavailableException
 
EntityWithIdAndVersion<T> - Class in io.eventuate
 
EntityWithIdAndVersion(EntityIdAndVersion, T) - Constructor for class io.eventuate.EntityWithIdAndVersion
 
EntityWithMetadata<T extends Aggregate> - Class in io.eventuate
 
EntityWithMetadata(EntityIdAndVersion, Optional<Int128>, List<EventWithMetadata>, T) - Constructor for class io.eventuate.EntityWithMetadata
 
equals(Object) - Method in class io.eventuate.EntityIdAndVersion
 
equals(Object) - Method in class io.eventuate.EventContext
 
equals(Object) - Method in class io.eventuate.FindOptions
 
equals(Object) - Method in class io.eventuate.UpdateOptions
 
Event - Interface in io.eventuate
Base interface for event sourcing events
event - Variable in class io.eventuate.javaclient.jdbc.EventAndTrigger
 
EventAndTrigger - Class in io.eventuate.javaclient.jdbc
 
EventAndTrigger(EventIdTypeAndData, String) - Constructor for class io.eventuate.javaclient.jdbc.EventAndTrigger
 
EventContext - Class in io.eventuate
 
EventContext() - Constructor for class io.eventuate.EventContext
 
EventContext(String) - Constructor for class io.eventuate.EventContext
 
EventDispatcherInitializer - Class in io.eventuate.javaclient.eventdispatcher
 
EventDispatcherInitializer(EventHandlerProcessor[], EventuateAggregateStore, Executor, SubscriptionsRegistry) - Constructor for class io.eventuate.javaclient.eventdispatcher.EventDispatcherInitializer
 
eventDispatcherInitializer(EventHandlerProcessor[], EventuateAggregateStore, SubscriptionsRegistry) - Method in class io.eventuate.javaclient.micronaut.EventuateJavaClientDomainFactory
 
eventDispatcherInitializer(EventHandlerProcessor[], EventuateAggregateStore, SubscriptionsRegistry) - Method in class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
EventEntity - Annotation Type in io.eventuate
Used on an Event class or interface to specify the aggregate that publishes the event

   @EventEntity(entity="io.eventuate.example.banking.domain.Account")
   public interface AccountEvent extends Event {
   }
EventEntityUtil - Class in io.eventuate.javaclient.eventdispatcher
 
EventEntityUtil() - Constructor for class io.eventuate.javaclient.eventdispatcher.EventEntityUtil
 
EventEnvelope<T extends Event> - Interface in io.eventuate
A container of an event and it's metadata
EventHandlerBeanPostProcessor - Class in io.eventuate.javaclient.spring
Registers Spring beans annotated with @EventSubscriber as event handlers
EventHandlerBeanPostProcessor(EventDispatcherInitializer) - Constructor for class io.eventuate.javaclient.spring.EventHandlerBeanPostProcessor
 
eventHandlerBeanPostProcessor(EventDispatcherInitializer) - Method in class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
EventHandlerContext<T extends Event> - Interface in io.eventuate
Wraps the event that is passed to a command-side event handler
EventHandlerContext<T extends Event> - Interface in io.eventuate.sync
Wraps the event that is passed to a command-side event handler
EventHandlerMethod - Annotation Type in io.eventuate
 
eventHandlerProcessorDispatchedEventReturningCompletableFuture() - Method in class io.eventuate.javaclient.micronaut.EventuateJavaClientDomainFactory
 
eventHandlerProcessorDispatchedEventReturningCompletableFuture() - Method in class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
eventHandlerProcessorDispatchedEventReturningVoid() - Method in class io.eventuate.javaclient.micronaut.EventuateJavaClientDomainFactory
 
eventHandlerProcessorDispatchedEventReturningVoid() - Method in class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
eventHandlerProcessorEventHandlerContextReturningCompletableFuture(EventuateAggregateStore) - Method in class io.eventuate.javaclient.micronaut.EventuateJavaClientDomainFactory
 
eventHandlerProcessorEventHandlerContextReturningCompletableFuture(EventuateAggregateStore) - Method in class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
eventHandlerProcessorEventHandlerContextReturningVoid(EventuateAggregateStore) - Method in class io.eventuate.javaclient.micronaut.EventuateJavaClientDomainFactory
 
eventHandlerProcessorEventHandlerContextReturningVoid(EventuateAggregateStore) - Method in class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
eventHandlerRecoveryScheduler() - Method in class io.eventuate.javaclient.micronaut.jdbc.EmbeddedTestAggregateStoreFactory
 
eventHandlerRecoveryScheduler() - Method in class io.eventuate.javaclient.spring.jdbc.EmbeddedTestAggregateStoreConfiguration
 
EventHandlerRegistrar - Class in io.eventuate.javaclient.micronaut
 
EventHandlerRegistrar(EventDispatcherInitializer, Subscriber[]) - Constructor for class io.eventuate.javaclient.micronaut.EventHandlerRegistrar
 
EventIdAndType - Class in io.eventuate
 
EventIdAndType() - Constructor for class io.eventuate.EventIdAndType
 
EventIdAndType(Int128, String) - Constructor for class io.eventuate.EventIdAndType
 
events(Event...) - Static method in class io.eventuate.EventUtil
 
events - Variable in class io.eventuate.testutil.AggregateTest
 
eventSchemaMetadataManager(EventSchemaConfigurer[]) - Method in class io.eventuate.javaclient.micronaut.common.EventuateCommonFactory
 
eventSchemaMetadataManager() - Method in class io.eventuate.javaclient.spring.common.EventuateCommonConfiguration
 
EventSubscriber - Annotation Type in io.eventuate
 
eventTracker - Variable in class io.eventuate.testutil.AbstractTestEventHandler
 
EventTracker - Class in io.eventuate.testutil
 
EventTracker() - Constructor for class io.eventuate.testutil.EventTracker
 
Eventually - Class in io.eventuate.testutil
 
Eventually() - Constructor for class io.eventuate.testutil.Eventually
 
eventually(Runnable) - Static method in class io.eventuate.testutil.Eventually
 
eventually(int, int, TimeUnit, Runnable) - Static method in class io.eventuate.testutil.Eventually
 
eventuallyContains(String, Predicate<ReceivedEvent>) - Method in class io.eventuate.testutil.AbstractTestEventHandler
 
eventuallyContains(String, Int128) - Method in class io.eventuate.testutil.AbstractTestEventHandler
 
EventuallyException - Exception in io.eventuate.testutil
 
EventuallyException(String, Throwable) - Constructor for exception io.eventuate.testutil.EventuallyException
 
eventuallyReturning(int, int, TimeUnit, Supplier<T>) - Static method in class io.eventuate.testutil.Eventually
 
EventuateAggregateStore - Interface in io.eventuate
The reactive-style interface to the event store
EventuateAggregateStore - Interface in io.eventuate.sync
The synchronous-style interface to the event store
EventuateApplyEventFailedUnexpectedlyException - Exception in io.eventuate
 
EventuateApplyEventFailedUnexpectedlyException(Throwable) - Constructor for exception io.eventuate.EventuateApplyEventFailedUnexpectedlyException
 
EventuateAuthenticationFailedException - Exception in io.eventuate
 
EventuateAuthenticationFailedException() - Constructor for exception io.eventuate.EventuateAuthenticationFailedException
 
EventuateClientException - Exception in io.eventuate
 
EventuateClientException() - Constructor for exception io.eventuate.EventuateClientException
 
EventuateClientException(Throwable) - Constructor for exception io.eventuate.EventuateClientException
 
EventuateClientException(String) - Constructor for exception io.eventuate.EventuateClientException
 
EventuateCommandProcessingFailedException - Exception in io.eventuate
 
EventuateCommandProcessingFailedException(Throwable) - Constructor for exception io.eventuate.EventuateCommandProcessingFailedException
 
EventuateCommandProcessingFailedUnexpectedlyException - Exception in io.eventuate
 
EventuateCommandProcessingFailedUnexpectedlyException(Throwable) - Constructor for exception io.eventuate.EventuateCommandProcessingFailedUnexpectedlyException
 
EventuateCommonConfiguration - Class in io.eventuate.javaclient.spring.common
 
EventuateCommonConfiguration() - Constructor for class io.eventuate.javaclient.spring.common.EventuateCommonConfiguration
 
EventuateCommonFactory - Class in io.eventuate.javaclient.micronaut.common
 
EventuateCommonFactory() - Constructor for class io.eventuate.javaclient.micronaut.common.EventuateCommonFactory
 
eventuateCommonInMemoryScriptSupplierForEventuateLocal() - Method in class io.eventuate.javaclient.micronaut.jdbc.EmbeddedTestAggregateStoreFactory
 
eventuateCommonInMemoryScriptSupplierForEventuateLocal() - Method in class io.eventuate.javaclient.spring.jdbc.EmbeddedTestAggregateStoreConfiguration
 
EventuateDriverConfiguration - Class in io.eventuate.local.java.spring.javaclient.driver
 
EventuateDriverConfiguration() - Constructor for class io.eventuate.local.java.spring.javaclient.driver.EventuateDriverConfiguration
 
EventuateEmbeddedTestAggregateStore - Class in io.eventuate.javaclient.jdbc
 
EventuateEmbeddedTestAggregateStore(EventuateJdbcAccess) - Constructor for class io.eventuate.javaclient.jdbc.EventuateEmbeddedTestAggregateStore
 
eventuateEmbeddedTestAggregateStore(EventuateJdbcAccess) - Method in class io.eventuate.javaclient.micronaut.jdbc.EmbeddedTestAggregateStoreFactory
 
eventuateEmbeddedTestAggregateStore(EventuateJdbcAccess) - Method in class io.eventuate.javaclient.spring.jdbc.EmbeddedTestAggregateStoreConfiguration
 
EventuateException - Exception in io.eventuate
 
EventuateException() - Constructor for exception io.eventuate.EventuateException
 
EventuateException(String) - Constructor for exception io.eventuate.EventuateException
 
EventuateException(String, Throwable) - Constructor for exception io.eventuate.EventuateException
 
EventuateException(Throwable) - Constructor for exception io.eventuate.EventuateException
 
EventuateJavaClientDomainConfiguration - Class in io.eventuate.javaclient.spring
Defines the Spring beans that support event processing
EventuateJavaClientDomainConfiguration() - Constructor for class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
EventuateJavaClientDomainFactory - Class in io.eventuate.javaclient.micronaut
 
EventuateJavaClientDomainFactory() - Constructor for class io.eventuate.javaclient.micronaut.EventuateJavaClientDomainFactory
 
eventuateJdbcAccess - Variable in class io.eventuate.javaclient.jdbc.AbstractJdbcAggregateCrud
 
EventuateJdbcAccess - Interface in io.eventuate.javaclient.jdbc
 
eventuateJdbcAccess(EventuateTransactionTemplate, EventuateJdbcStatementExecutor, EventuateCommonJdbcOperations, EventuateSchema) - Method in class io.eventuate.javaclient.micronaut.jdbc.EmbeddedTestAggregateStoreFactory
 
eventuateJdbcAccess(EventuateTransactionTemplate, EventuateJdbcStatementExecutor, EventuateCommonJdbcOperations, EventuateSchema) - Method in class io.eventuate.javaclient.spring.jdbc.EmbeddedTestAggregateStoreConfiguration
 
eventuateJdbcAccess(EventuateTransactionTemplate, EventuateJdbcStatementExecutor, EventuateCommonJdbcOperations, EventuateSchema) - Method in class io.eventuate.local.java.spring.common.jdbckafkastore.EventuateLocalConfiguration
 
EventuateJdbcAccessImpl - Class in io.eventuate.javaclient.jdbc
 
EventuateJdbcAccessImpl(EventuateTransactionTemplate, EventuateJdbcStatementExecutor, EventuateCommonJdbcOperations) - Constructor for class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
EventuateJdbcAccessImpl(EventuateTransactionTemplate, EventuateJdbcStatementExecutor, EventuateCommonJdbcOperations, EventuateSchema) - Constructor for class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
EventuateJdbcEventStoreConfiguration - Class in io.eventuate.javaclient.spring.jdbc
EventuateJdbcEventStoreConfiguration() - Constructor for class io.eventuate.javaclient.spring.jdbc.EventuateJdbcEventStoreConfiguration
Deprecated.
 
eventuateLocalAggregateCrud(TransactionTemplate, EventuateJdbcAccess) - Method in class io.eventuate.local.java.spring.common.jdbckafkastore.EventuateLocalConfiguration
 
EventuateLocalConfiguration - Class in io.eventuate.local.java.spring.common.jdbckafkastore
Defines the Spring beans for the JDBC-based aggregate store
EventuateLocalConfiguration() - Constructor for class io.eventuate.local.java.spring.common.jdbckafkastore.EventuateLocalConfiguration
 
EventuateRestoreFromSnapshotFailedUnexpectedlyException - Exception in io.eventuate
 
EventuateRestoreFromSnapshotFailedUnexpectedlyException(ReflectiveOperationException) - Constructor for exception io.eventuate.EventuateRestoreFromSnapshotFailedUnexpectedlyException
 
EventuateServerException - Exception in io.eventuate
 
EventuateServerException() - Constructor for exception io.eventuate.EventuateServerException
 
EventuateServiceUnavailableException - Exception in io.eventuate
 
EventuateServiceUnavailableException() - Constructor for exception io.eventuate.EventuateServiceUnavailableException
 
EventuateSubscriptionFailedException - Exception in io.eventuate
 
EventuateSubscriptionFailedException(String, Exception) - Constructor for exception io.eventuate.EventuateSubscriptionFailedException
 
EventuateUnknownResponseException - Exception in io.eventuate
 
EventuateUnknownResponseException(int, String) - Constructor for exception io.eventuate.EventuateUnknownResponseException
 
EventUtil - Class in io.eventuate
 
EventUtil() - Constructor for class io.eventuate.EventUtil
 
EventWithMetadata - Class in io.eventuate
An event with it's id
EventWithMetadata(Event, Int128, Optional<Map<String, String>>) - Constructor for class io.eventuate.EventWithMetadata
 
executeSql(List<String>) - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
expectSave(Class<T>, Class<C>, Optional<String>) - Method in class io.eventuate.testutil.MockEventHandlerContextBuilder.MockEventHandlerContextBuilderWithEvent
 
expectUpdate(Class<T>, String, Class<C>) - Method in class io.eventuate.testutil.MockEventHandlerContextBuilder.MockEventHandlerContextBuilderWithEvent
 

F

failedFuture(Throwable) - Static method in class io.eventuate.CompletableFutureUtil
 
find(String) - Method in class io.eventuate.AggregateRepository
Find an aggregate
find(String, FindOptions) - Method in class io.eventuate.AggregateRepository
Find an aggregate
find(String, Optional<FindOptions>) - Method in class io.eventuate.AggregateRepository
Find an aggregate
find(Class<T>, String) - Method in interface io.eventuate.EventuateAggregateStore
 
find(Class<T>, String, FindOptions) - Method in interface io.eventuate.EventuateAggregateStore
 
find(Class<T>, String, Optional<FindOptions>) - Method in interface io.eventuate.EventuateAggregateStore
 
find(String, String, Optional<AggregateCrudFindOptions>) - Method in class io.eventuate.javaclient.jdbc.AbstractJdbcAggregateCrud
 
find(String, String, Optional<AggregateCrudFindOptions>) - Method in interface io.eventuate.javaclient.jdbc.EventuateJdbcAccess
 
find(String, String, Optional<AggregateCrudFindOptions>) - Method in class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
find(String) - Method in class io.eventuate.sync.AggregateRepository
Find an aggregate
find(String, FindOptions) - Method in class io.eventuate.sync.AggregateRepository
Find an aggregate
find(String, Optional<FindOptions>) - Method in class io.eventuate.sync.AggregateRepository
Find an aggregate
find(Class<T>, String) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
find(Class<T>, String, FindOptions) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
find(Class<T>, String, Optional<FindOptions>) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
FindOptions - Class in io.eventuate
 
FindOptions() - Constructor for class io.eventuate.FindOptions
 
forEvent(E) - Static method in class io.eventuate.testutil.MockEventHandlerContext
 
forEvent(E) - Static method in class io.eventuate.testutil.MockEventHandlerContextBuilder
 
fromEntityId(String) - Method in class io.eventuate.testutil.MockEventHandlerContextBuilder.MockEventHandlerContextBuilderWithEvent
 

G

getAggregate() - Method in class io.eventuate.EntityWithIdAndVersion
 
getAggregateClass() - Method in interface io.eventuate.SnapshotStrategy
The aggregate class that this is a strategy for
getAggregatesAndEvents() - Method in class io.eventuate.RegisteredSubscription
 
getAggregateType() - Method in class io.eventuate.javaclient.jdbc.PublishableEvents
 
getCommand() - Method in exception io.eventuate.MissingProcessMethodException
 
getCommand() - Method in interface io.eventuate.testutil.AggregateOperationInvocation
 
getCommand() - Method in class io.eventuate.testutil.MockEventHandlerContext
 
getCommand() - Method in class io.eventuate.testutil.SaveInvocation
 
getCommand() - Method in class io.eventuate.testutil.UpdateInvocation
 
getDurability() - Method in class io.eventuate.SubscriberOptions
 
getEntity() - Method in class io.eventuate.EntityWithMetadata
 
getEntity() - Method in interface io.eventuate.testutil.AggregateOperationInvocation
 
getEntity() - Method in class io.eventuate.testutil.SaveInvocation
 
getEntity() - Method in class io.eventuate.testutil.UpdateInvocation
 
getEntityId() - Method in class io.eventuate.DispatchedEvent
 
getEntityId() - Method in class io.eventuate.EntityIdAndType
 
getEntityId() - Method in class io.eventuate.EntityIdAndVersion
 
getEntityId() - Method in class io.eventuate.EntityWithIdAndVersion
 
getEntityId() - Method in interface io.eventuate.EventEnvelope
The id of the aggregate that published the event
getEntityId() - Method in class io.eventuate.javaclient.jdbc.PublishableEvents
 
getEntityId() - Method in class io.eventuate.SaveOptions
 
getEntityId() - Method in class io.eventuate.testutil.ReceivedEvent
 
getEntityIdAndType() - Method in exception io.eventuate.OptimisticLockingException
 
getEntityIdAndVersion() - Method in class io.eventuate.EntityWithIdAndVersion
 
getEntityIdAndVersion() - Method in class io.eventuate.EntityWithMetadata
 
getEntityIdVersionAndEventIds() - Method in class io.eventuate.javaclient.jdbc.SaveUpdateResult
 
getEntityType() - Method in class io.eventuate.EndOfCurrentEventsReachedEvent
 
getEntityType() - Method in class io.eventuate.EntityIdAndType
 
getEntityVersion() - Method in class io.eventuate.EntityIdAndVersion
 
getEntityVersion() - Method in class io.eventuate.EntityWithIdAndVersion
 
getEntityVersion() - Method in exception io.eventuate.OptimisticLockingException
 
getErrorCode() - Method in exception io.eventuate.EventuateUnknownResponseException
 
getEvent() - Method in class io.eventuate.DispatchedEvent
 
getEvent() - Method in interface io.eventuate.EventEnvelope
The event
getEvent() - Method in class io.eventuate.EventWithMetadata
 
getEvent() - Method in exception io.eventuate.MissingApplyMethodException
 
getEvent() - Method in class io.eventuate.testutil.ReceivedEvent
 
getEventContext() - Method in class io.eventuate.DispatchedEvent
 
getEventContext() - Method in interface io.eventuate.EventEnvelope
An opaque token that can used to update aggregates idempotently
getEventId() - Method in class io.eventuate.DispatchedEvent
 
getEventId() - Method in interface io.eventuate.EventEnvelope
The event id
getEventId() - Method in class io.eventuate.testutil.ReceivedEvent
 
getEventMetadata() - Method in class io.eventuate.DispatchedEvent
 
getEventMetadata() - Method in interface io.eventuate.EventEnvelope
 
getEventMetadata() - Method in class io.eventuate.SaveOptions
 
getEventMetadata() - Method in class io.eventuate.testutil.ReceivedEvent
 
getEventMetadata() - Method in class io.eventuate.UpdateOptions
 
getEvents() - Method in class io.eventuate.EntityWithMetadata
 
getEvents() - Method in class io.eventuate.testutil.EventTracker
 
getEvents() - Method in class io.eventuate.UpdateEventsAndOptions
 
getEventSubscriberClass() - Method in class io.eventuate.RegisteredSubscription
 
getEventsWithIds() - Method in class io.eventuate.javaclient.jdbc.PublishableEvents
 
getEventToken() - Method in class io.eventuate.EventContext
 
getEventType() - Method in class io.eventuate.DispatchedEvent
 
getEventType() - Method in interface io.eventuate.EventEnvelope
The event type
getEventType() - Method in class io.eventuate.EventIdAndType
 
getEventType() - Method in class io.eventuate.testutil.ReceivedEvent
 
getEventuateJdbcAccess() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
getEventuateJdbcStatementExecutor() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
getEventuateSchema() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
getHttpStatusCode() - Method in exception io.eventuate.EventuateUnknownResponseException
 
getId() - Method in class io.eventuate.EventIdAndType
 
getId() - Method in class io.eventuate.EventWithMetadata
 
getInterceptor() - Method in class io.eventuate.UpdateOptions
 
getMetadata() - Method in class io.eventuate.EventWithMetadata
 
getOffset() - Method in class io.eventuate.DispatchedEvent
 
getOffset() - Method in interface io.eventuate.EventEnvelope
A monotonically increasing offset within the swimlane
getOptions() - Method in class io.eventuate.UpdateEventsAndOptions
 
getPublishableEvents() - Method in class io.eventuate.javaclient.jdbc.SaveUpdateResult
 
getReadFrom() - Method in class io.eventuate.SubscriberOptions
 
getRegisteredSubscriptions() - Method in class io.eventuate.SubscriptionsRegistry
 
getSerializedSnapshot() - Method in class io.eventuate.javaclient.jdbc.LoadedSnapshot
 
getSnapshot() - Method in class io.eventuate.UpdateOptions
 
getSnapshotVersion() - Method in class io.eventuate.EntityWithMetadata
 
getSubscriberId() - Method in class io.eventuate.RegisteredSubscription
 
getSwimlane() - Method in class io.eventuate.DispatchedEvent
 
getSwimlane() - Method in class io.eventuate.EndOfCurrentEventsReachedEvent
 
getSwimlane() - Method in interface io.eventuate.EventEnvelope
Each aggregate (the sender) is assigned a swimlane, which can be used for concurrent event processing
getTriggeringEvent() - Method in class io.eventuate.FindOptions
 
getTriggeringEvent() - Method in class io.eventuate.SaveOptions
 
getTriggeringEvent() - Method in class io.eventuate.UpdateOptions
 
getTriggeringEvents() - Method in class io.eventuate.javaclient.jdbc.LoadedSnapshot
 

H

handle(Aggregate, MissingApplyMethodException) - Method in class io.eventuate.CompositeMissingApplyEventMethodStrategy
 
handle(Aggregate, MissingApplyMethodException) - Method in class io.eventuate.DefaultMissingApplyEventMethodStrategy
 
handle(Aggregate, MissingApplyMethodException) - Method in interface io.eventuate.MissingApplyEventMethodStrategy
 
handleException(T, Throwable, Optional<UpdateOptions>) - Method in interface io.eventuate.AggregateRepositoryInterceptor
 
hashCode() - Method in class io.eventuate.EntityIdAndVersion
 
hashCode() - Method in class io.eventuate.EventContext
 
hashCode() - Method in class io.eventuate.FindOptions
 
hashCode() - Method in class io.eventuate.UpdateOptions
 

I

INSTANCE - Static variable in class io.eventuate.DefaultMissingApplyEventMethodStrategy
 
interceptor - Variable in class io.eventuate.CommonAggregateRepository
 
io.eventuate - package io.eventuate
The Java API for the Eventuate platform.
io.eventuate.javaclient.eventdispatcher - package io.eventuate.javaclient.eventdispatcher
 
io.eventuate.javaclient.jdbc - package io.eventuate.javaclient.jdbc
An embedded JDBC-based version of the event store that can be used for testing
io.eventuate.javaclient.jdbc.common.tests - package io.eventuate.javaclient.jdbc.common.tests
 
io.eventuate.javaclient.micronaut - package io.eventuate.javaclient.micronaut
The Micronaut framework integration for the Eventuate Java API
io.eventuate.javaclient.micronaut.common - package io.eventuate.javaclient.micronaut.common
 
io.eventuate.javaclient.micronaut.jdbc - package io.eventuate.javaclient.micronaut.jdbc
An embedded JDBC-based version of the event store that can be used for testing
io.eventuate.javaclient.spring - package io.eventuate.javaclient.spring
The Spring framework integration for the Eventuate Java API
io.eventuate.javaclient.spring.common - package io.eventuate.javaclient.spring.common
 
io.eventuate.javaclient.spring.jdbc - package io.eventuate.javaclient.spring.jdbc
An embedded JDBC-based version of the event store that can be used for testing
io.eventuate.local.java.spring.common.jdbckafkastore - package io.eventuate.local.java.spring.common.jdbckafkastore
 
io.eventuate.local.java.spring.javaclient.driver - package io.eventuate.local.java.spring.javaclient.driver
 
io.eventuate.sync - package io.eventuate.sync
 
io.eventuate.testutil - package io.eventuate.testutil
 
isFailure() - Method in class io.eventuate.CommandOutcome
 
isProgressNotifications() - Method in class io.eventuate.SubscriberOptions
 

J

JdkTimerBasedEventuateClientScheduler - Class in io.eventuate.javaclient.jdbc
 
JdkTimerBasedEventuateClientScheduler() - Constructor for class io.eventuate.javaclient.jdbc.JdkTimerBasedEventuateClientScheduler
 

L

LoadedSnapshot - Class in io.eventuate.javaclient.jdbc
 
LoadedSnapshot(SerializedSnapshotWithVersion, String) - Constructor for class io.eventuate.javaclient.jdbc.LoadedSnapshot
 
loadSqlScriptAsListOfLines(String) - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
logger - Variable in class io.eventuate.javaclient.eventdispatcher.EventDispatcherInitializer
 
logger - Variable in class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
logger - Variable in class io.eventuate.testutil.AbstractTestEventHandler
 

M

missingApplyEventMethodStrategy - Variable in class io.eventuate.CommonAggregateRepository
 
MissingApplyEventMethodStrategy - Interface in io.eventuate
 
MissingApplyMethodException - Exception in io.eventuate
 
MissingApplyMethodException(Throwable, Event) - Constructor for exception io.eventuate.MissingApplyMethodException
 
MissingProcessMethodException - Exception in io.eventuate
 
MissingProcessMethodException(Throwable, Command) - Constructor for exception io.eventuate.MissingProcessMethodException
 
mock - Variable in class io.eventuate.testutil.MockAggregateRepository
The mock AggregateRepository
mock - Variable in class io.eventuate.testutil.MockEventHandlerContext
 
mock - Variable in class io.eventuate.testutil.MockEventHandlerContextInternal
 
MockAggregateRepository<T extends CommandProcessingAggregate<T,CT>,CT extends Command> - Class in io.eventuate.testutil
A Test helper that simplifies the mocking of AggregateRepositories
MockAggregateRepository() - Constructor for class io.eventuate.testutil.MockAggregateRepository
 
MockEventHandlerContext<T extends CommandProcessingAggregate<T,CT>,CT extends Command,E extends Event,C extends CT> - Class in io.eventuate.testutil
 
MockEventHandlerContext(EntityWithIdAndVersion<T>, AggregateOperationInvocation<T, CT, C>, EventHandlerContext<E>) - Constructor for class io.eventuate.testutil.MockEventHandlerContext
 
MockEventHandlerContextBuilder - Class in io.eventuate.testutil
 
MockEventHandlerContextBuilder() - Constructor for class io.eventuate.testutil.MockEventHandlerContextBuilder
 
MockEventHandlerContextBuilder.MockEventHandlerContextBuilderWithEvent<E extends Event> - Class in io.eventuate.testutil
 
MockEventHandlerContextBuilderWithEvent(E) - Constructor for class io.eventuate.testutil.MockEventHandlerContextBuilder.MockEventHandlerContextBuilderWithEvent
 
MockEventHandlerContextInternal<T extends CommandProcessingAggregate<T,CT>,CT extends Command,E extends Event> - Class in io.eventuate.testutil
 
MockEventHandlerContextInternal(Class<T>) - Constructor for class io.eventuate.testutil.MockEventHandlerContextInternal
 

O

OptimisticLockingException - Exception in io.eventuate
 
OptimisticLockingException(EntityIdAndType, Int128) - Constructor for exception io.eventuate.OptimisticLockingException
 
OptimisticLockingException() - Constructor for exception io.eventuate.OptimisticLockingException
 

P

possiblySnapshot(Aggregate, Optional<Int128>, List<EventWithMetadata>, List<Event>) - Method in interface io.eventuate.EventuateAggregateStore
Possibly generate a snapshot
possiblySnapshot(Aggregate, Optional<Int128>, List<EventWithMetadata>, List<Event>) - Method in interface io.eventuate.SnapshotManager
 
possiblySnapshot(Aggregate, Optional<Int128>, List<EventWithMetadata>, List<Event>) - Method in class io.eventuate.SnapshotManagerImpl
 
possiblySnapshot(Aggregate, Optional<Int128>, List<EventWithMetadata>, List<Event>) - Method in interface io.eventuate.SnapshotStrategy
Possibly generate a snapshot
possiblySnapshot(Aggregate, Optional<Int128>, List<EventWithMetadata>, List<Event>) - Method in interface io.eventuate.sync.EventuateAggregateStore
Possibly generate a snapshot
postProcessAfterInitialization(Object, String) - Method in class io.eventuate.javaclient.spring.common.AggregateRepositoryBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class io.eventuate.javaclient.spring.EventHandlerBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class io.eventuate.javaclient.spring.common.AggregateRepositoryBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class io.eventuate.javaclient.spring.EventHandlerBeanPostProcessor
 
processCommand(CT) - Method in interface io.eventuate.CommandProcessingAggregate
Process a command by returning events
processCommand(CT) - Method in class io.eventuate.ReflectiveMutableCommandProcessingAggregate
Processes a command by invoking a process() method whose parameter class matches the command's class
publish(PublishableEvents) - Method in class io.eventuate.javaclient.jdbc.AbstractJdbcAggregateCrud
 
publish(PublishableEvents) - Method in class io.eventuate.javaclient.jdbc.EventuateEmbeddedTestAggregateStore
 
PublishableEvents - Class in io.eventuate.javaclient.jdbc
 
PublishableEvents(String, String, List<EventIdTypeAndData>) - Constructor for class io.eventuate.javaclient.jdbc.PublishableEvents
 

R

readAllEntitiesSql() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
readAllEventsSql() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
readAllSnapshots() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
ReceivedEvent - Class in io.eventuate.testutil
 
ReceivedEvent(String, Class<Event>, Int128, Event, Optional<Map<String, String>>) - Constructor for class io.eventuate.testutil.ReceivedEvent
 
recreateAggregate(Class<T>, List<Event>, MissingApplyEventMethodStrategy) - Static method in class io.eventuate.Aggregates
 
recreateAggregate(Class<?>, Snapshot, MissingApplyEventMethodStrategy) - Method in interface io.eventuate.SnapshotStrategy
Recreate an aggregate from a snapshot
recreateFromSnapshot(Class<?>, Snapshot) - Method in interface io.eventuate.EventuateAggregateStore
Recreate an aggregate from a snapshot
recreateFromSnapshot(Class<?>, Snapshot, MissingApplyEventMethodStrategy) - Method in interface io.eventuate.SnapshotManager
 
recreateFromSnapshot(Class<?>, Snapshot, MissingApplyEventMethodStrategy) - Method in class io.eventuate.SnapshotManagerImpl
 
recreateFromSnapshot(Class<?>, Snapshot) - Method in interface io.eventuate.sync.EventuateAggregateStore
Recreate an aggregate from a snapshot
ReflectiveMutableCommandProcessingAggregate<T extends ReflectiveMutableCommandProcessingAggregate<T,CT>,CT extends Command> - Class in io.eventuate
A mutable aggregate that uses reflection to process commands and apply events
ReflectiveMutableCommandProcessingAggregate() - Constructor for class io.eventuate.ReflectiveMutableCommandProcessingAggregate
 
RegisteredSubscription - Class in io.eventuate
 
RegisteredSubscription(String, Map<String, Set<String>>, Class<?>) - Constructor for class io.eventuate.RegisteredSubscription
 
registerEventHandler(Object, String, Class<?>) - Method in class io.eventuate.javaclient.eventdispatcher.EventDispatcherInitializer
 
registerEventHandlers() - Method in class io.eventuate.javaclient.micronaut.EventHandlerRegistrar
 
result - Variable in class io.eventuate.CommandOutcome
 

S

save(CT) - Method in class io.eventuate.AggregateRepository
Create a new Aggregate by processing a command and persisting the events
save(CT, Optional<SaveOptions>) - Method in class io.eventuate.AggregateRepository
Create a new Aggregate by processing a command and persisting the events
save(Class<A>, CT, Optional<String>) - Method in interface io.eventuate.EventHandlerContext
Creates an aggregate in response to an event
save(Class<T>, List<Event>) - Method in interface io.eventuate.EventuateAggregateStore
Save an aggregate in the event store
save(Class<T>, List<Event>, SaveOptions) - Method in interface io.eventuate.EventuateAggregateStore
 
save(Class<T>, List<Event>, Optional<SaveOptions>) - Method in interface io.eventuate.EventuateAggregateStore
 
save(String, List<EventTypeAndData>, Optional<AggregateCrudSaveOptions>) - Method in class io.eventuate.javaclient.jdbc.AbstractJdbcAggregateCrud
 
save(String, List<EventTypeAndData>, Optional<AggregateCrudSaveOptions>) - Method in interface io.eventuate.javaclient.jdbc.EventuateJdbcAccess
 
save(String, List<EventTypeAndData>, Optional<AggregateCrudSaveOptions>) - Method in class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
save(CT) - Method in class io.eventuate.sync.AggregateRepository
Create a new Aggregate by processing a command and persisting the events
save(CT, Optional<SaveOptions>) - Method in class io.eventuate.sync.AggregateRepository
Create a new Aggregate by processing a command and persisting the events
save(Class<A>, CT, Optional<String>) - Method in interface io.eventuate.sync.EventHandlerContext
Creates an aggregate in response to an event
save(Class<T>, List<Event>) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
save(Class<T>, List<Event>, SaveOptions) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
save(Class<T>, List<Event>, Optional<SaveOptions>) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
SaveInvocation<T extends CommandProcessingAggregate<T,CT>,CT extends Command,C extends CT> - Class in io.eventuate.testutil
Provides access to the captured command and the fake created entity
SaveInvocation(ArgumentCaptor<C>, EntityWithIdAndVersion<T>) - Constructor for class io.eventuate.testutil.SaveInvocation
 
SaveOptions - Class in io.eventuate
 
SaveOptions() - Constructor for class io.eventuate.SaveOptions
 
SaveUpdateResult - Class in io.eventuate.javaclient.jdbc
 
SaveUpdateResult(EntityIdVersionAndEventIds, PublishableEvents) - Constructor for class io.eventuate.javaclient.jdbc.SaveUpdateResult
 
setEntityId(String) - Method in class io.eventuate.EntityIdAndType
 
setEntityType(String) - Method in class io.eventuate.EndOfCurrentEventsReachedEvent
 
setEntityType(String) - Method in class io.eventuate.EntityIdAndType
 
setEventToken(String) - Method in class io.eventuate.EventContext
 
setEventType(String) - Method in class io.eventuate.EventIdAndType
 
setId(Int128) - Method in class io.eventuate.EventIdAndType
 
setInterceptor(AggregateRepositoryInterceptor<T, CT>) - Method in class io.eventuate.CommonAggregateRepository
 
setMissingApplyEventMethodStrategy(MissingApplyEventMethodStrategy) - Method in class io.eventuate.CommonAggregateRepository
 
setMissingStrategies() - Method in class io.eventuate.javaclient.micronaut.common.AggregateRepositoryInitializer
 
setSwimlane(int) - Method in class io.eventuate.EndOfCurrentEventsReachedEvent
 
setTimer(long, Runnable) - Method in class io.eventuate.javaclient.jdbc.JdkTimerBasedEventuateClientScheduler
 
Snapshot - Interface in io.eventuate
A marker interface for a snapshot
snapshotManager(SnapshotStrategy[]) - Method in class io.eventuate.javaclient.micronaut.common.EventuateCommonFactory
 
snapshotManager() - Method in class io.eventuate.javaclient.spring.common.EventuateCommonConfiguration
 
SnapshotManager - Interface in io.eventuate
 
SnapshotManagerImpl - Class in io.eventuate
 
SnapshotManagerImpl() - Constructor for class io.eventuate.SnapshotManagerImpl
 
SnapshotStrategy - Interface in io.eventuate
A strategy for creating snapshots of a
snapshotTriggeringEvents(Optional<LoadedSnapshot>, List<EventAndTrigger>, Optional<EventContext>) - Method in class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
subscribe(String, Map<String, Set<String>>, SubscriberOptions, Function<DispatchedEvent<Event>, CompletableFuture<?>>) - Method in interface io.eventuate.EventuateAggregateStore
 
subscribe(String, Map<String, Set<String>>, SubscriberOptions, Function<SerializedEvent, CompletableFuture<?>>) - Method in class io.eventuate.javaclient.jdbc.EventuateEmbeddedTestAggregateStore
 
subscribe(String, Map<String, Set<String>>, SubscriberOptions, Function<DispatchedEvent<Event>, CompletableFuture<?>>) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
Subscriber - Interface in io.eventuate
 
SubscriberDurability - Enum in io.eventuate
 
SubscriberInitialPosition - Enum in io.eventuate
 
SubscriberOptions - Class in io.eventuate
 
SubscriberOptions() - Constructor for class io.eventuate.SubscriberOptions
 
SubscriberOptions(SubscriberDurability, SubscriberInitialPosition, boolean) - Constructor for class io.eventuate.SubscriberOptions
 
subscriptionsRegistry() - Method in class io.eventuate.javaclient.micronaut.EventuateJavaClientDomainFactory
 
subscriptionsRegistry() - Method in class io.eventuate.javaclient.spring.EventuateJavaClientDomainConfiguration
 
SubscriptionsRegistry - Class in io.eventuate
 
SubscriptionsRegistry() - Constructor for class io.eventuate.SubscriptionsRegistry
 
supports(Aggregate, MissingApplyMethodException) - Method in class io.eventuate.CompositeMissingApplyEventMethodStrategy
 
supports(Aggregate, MissingApplyMethodException) - Method in class io.eventuate.DefaultMissingApplyEventMethodStrategy
 
supports(Aggregate, MissingApplyMethodException) - Method in interface io.eventuate.MissingApplyEventMethodStrategy
 
syncAggregateEvents(AsyncToSyncTimeoutOptions, AggregateEvents) - Method in class io.eventuate.local.java.spring.common.jdbckafkastore.EventuateLocalConfiguration
 
syncAggregateEventStore(MissingApplyEventMethodStrategy[], SerializedEventDeserializer, AggregateCrud, AggregateEvents, SnapshotManager) - Method in class io.eventuate.javaclient.micronaut.common.EventuateCommonFactory
 
syncAggregateEventStore(AggregateCrud, AggregateEvents, SnapshotManager) - Method in class io.eventuate.javaclient.spring.common.EventuateCommonConfiguration
 

T

tap(CompletableFuture<T>, BiConsumer<T, Throwable>) - Static method in class io.eventuate.CompletableFutureUtil
 
testFind() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
testSave() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
testUpdate() - Method in class io.eventuate.javaclient.jdbc.common.tests.CommonEventuateJdbcAccessImplTest
 
throwable - Variable in class io.eventuate.CommandOutcome
 
toEntityType(Class<Event>) - Static method in class io.eventuate.javaclient.eventdispatcher.EventEntityUtil
 
toEntityTypeName(Class<Event>) - Static method in class io.eventuate.javaclient.eventdispatcher.EventEntityUtil
 
toEntityWithIdAndVersion() - Method in class io.eventuate.EntityWithMetadata
 
toString() - Method in class io.eventuate.DispatchedEvent
 
toString() - Method in class io.eventuate.EndOfCurrentEventsReachedEvent
 
toString() - Method in class io.eventuate.EntityIdAndVersion
 
toString() - Method in class io.eventuate.EntityWithIdAndVersion
 
toString() - Method in class io.eventuate.EventContext
 
toString() - Method in class io.eventuate.SubscriberOptions
 
toString() - Method in class io.eventuate.UpdateOptions
 
transactionTemplate(PlatformTransactionManager) - Method in class io.eventuate.local.java.spring.common.jdbckafkastore.EventuateLocalConfiguration
 
transformUpdate(T, UpdateEventsAndOptions) - Method in interface io.eventuate.AggregateRepositoryInterceptor
 
transformUpdateEventsAndOptions(Optional<UpdateOptions>, T, CommandOutcome) - Method in class io.eventuate.CommonAggregateRepository
 
triggeringEvent - Variable in class io.eventuate.javaclient.jdbc.EventAndTrigger
 

U

unwrap(Throwable) - Static method in class io.eventuate.CompletableFutureUtil
 
update(String, CT) - Method in class io.eventuate.AggregateRepository
Update the specified aggregate by processing a command and saving events
update(String, CT, Optional<UpdateOptions>) - Method in class io.eventuate.AggregateRepository
Update the specified aggregate by processing a command and saving events
update(Class<A>, String, CT) - Method in interface io.eventuate.EventHandlerContext
Updates an aggregate in response to an event
update(Class<T>, EntityIdAndVersion, List<Event>) - Method in interface io.eventuate.EventuateAggregateStore
 
update(Class<T>, EntityIdAndVersion, List<Event>, UpdateOptions) - Method in interface io.eventuate.EventuateAggregateStore
 
update(Class<T>, EntityIdAndVersion, List<Event>, Optional<UpdateOptions>) - Method in interface io.eventuate.EventuateAggregateStore
 
update(EntityIdAndType, Int128, List<EventTypeAndData>, Optional<AggregateCrudUpdateOptions>) - Method in class io.eventuate.javaclient.jdbc.AbstractJdbcAggregateCrud
 
update(EntityIdAndType, Int128, List<EventTypeAndData>, Optional<AggregateCrudUpdateOptions>) - Method in interface io.eventuate.javaclient.jdbc.EventuateJdbcAccess
 
update(EntityIdAndType, Int128, List<EventTypeAndData>, Optional<AggregateCrudUpdateOptions>) - Method in class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
update(String, CT) - Method in class io.eventuate.sync.AggregateRepository
Update the specified aggregate by processing a command and saving events
update(String, CT, Optional<UpdateOptions>) - Method in class io.eventuate.sync.AggregateRepository
Update the specified aggregate by processing a command and saving events
update(Class<A>, String, CT) - Method in interface io.eventuate.sync.EventHandlerContext
Updates an aggregate in response to an event
update(Class<T>, EntityIdAndVersion, List<Event>) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
update(Class<T>, EntityIdAndVersion, List<Event>, UpdateOptions) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
update(Class<T>, EntityIdAndVersion, List<Event>, Optional<UpdateOptions>) - Method in interface io.eventuate.sync.EventuateAggregateStore
 
update(CT) - Method in class io.eventuate.testutil.AggregateTest
Process a cmd that updates an aggregate
updatedEntity - Variable in class io.eventuate.testutil.MockEventHandlerContext
 
UpdateEventsAndOptions - Class in io.eventuate
 
UpdateEventsAndOptions(List<Event>, Optional<UpdateOptions>) - Constructor for class io.eventuate.UpdateEventsAndOptions
 
UpdateInvocation<T extends CommandProcessingAggregate<T,CT>,CT extends Command,C extends CT> - Class in io.eventuate.testutil
Provides access to the captured command and the fake created entity
UpdateInvocation(ArgumentCaptor<C>, EntityWithIdAndVersion<T>) - Constructor for class io.eventuate.testutil.UpdateInvocation
 
UpdateOptions - Class in io.eventuate
 
UpdateOptions() - Constructor for class io.eventuate.UpdateOptions
 
UpdateOptions(Optional<EventContext>, Optional<Map<String, String>>, Optional<Snapshot>, Optional<AggregateRepositoryInterceptor>) - Constructor for class io.eventuate.UpdateOptions
 
updateWithoutTransaction(EntityIdAndType, Int128, List<EventTypeAndData>, Optional<AggregateCrudUpdateOptions>) - Method in class io.eventuate.javaclient.jdbc.EventuateJdbcAccessImpl
 
updateWithProvidedCommand(String, Function<T, Optional<CT>>, Optional<UpdateOptions>) - Method in class io.eventuate.AggregateRepository
Update the specified aggregate by processing a command and saving events
updateWithProvidedCommand(Class<A>, String, Function<A, Optional<CT>>) - Method in interface io.eventuate.EventHandlerContext
Updates an aggregate in response to an event
updateWithProvidedCommand(String, Function<T, Optional<CT>>, Optional<UpdateOptions>) - Method in class io.eventuate.sync.AggregateRepository
Update the specified aggregate by processing a command and saving events
updateWithProvidedCommand(Class<A>, String, Function<A, Optional<CT>>) - Method in interface io.eventuate.sync.EventHandlerContext
Updates an aggregate in response to an event

V

valueOf(String) - Static method in enum io.eventuate.SubscriberDurability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.eventuate.SubscriberInitialPosition
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.eventuate.SubscriberDurability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.eventuate.SubscriberInitialPosition
Returns an array containing the constants of this enum type, in the order they are declared.

W

whenSave(Class<C>) - Method in class io.eventuate.testutil.MockAggregateRepository
Create a stub for a call to AggregateRepository.save()
whenSave(Class<C>, Optional<String>) - Method in class io.eventuate.testutil.MockEventHandlerContextInternal
 
whenUpdate(String, Class<C>) - Method in class io.eventuate.testutil.MockEventHandlerContextInternal
 
withEvent(E) - Method in class io.eventuate.testutil.MockEventHandlerContextInternal
 
withEventContext(EventContext) - Method in class io.eventuate.SaveOptions
 
withEventId(Int128) - Method in class io.eventuate.testutil.MockEventHandlerContextInternal
 
withEventMetadata(Map<String, String>) - Method in class io.eventuate.SaveOptions
 
withEventMetadata(Map<String, String>) - Method in class io.eventuate.UpdateOptions
 
withEventType(Class<E>) - Method in class io.eventuate.testutil.MockEventHandlerContextInternal
 
withFromEntityId(String) - Method in class io.eventuate.testutil.MockEventHandlerContextInternal
 
withId(String) - Method in class io.eventuate.SaveOptions
 
withId(Optional<String>) - Method in class io.eventuate.SaveOptions
 
withIdempotencyKey(String) - Method in class io.eventuate.UpdateOptions
 
withInterceptor(AggregateRepositoryInterceptor) - Method in class io.eventuate.UpdateOptions
 
withSnapshot(Snapshot) - Method in class io.eventuate.UpdateOptions
 
withTriggeringEvent(EventContext) - Method in class io.eventuate.FindOptions
 
withTriggeringEvent(Optional<EventContext>) - Method in class io.eventuate.FindOptions
 
withTriggeringEvent(EventContext) - Method in class io.eventuate.UpdateOptions
 
A C D E F G H I J L M O P R S T U V W 
Skip navigation links