Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractEventDataMarshallingEventUpcaster - Class in com.opencqrs.framework.upcaster
-
Template implementation of
EventUpcaster
that uses a delegateEventDataMarshaller
to allow subclasses to upcastEventData.metaData()
andEventData.payload()
as pre-extracted JSON-likeMap
s. - AbstractEventDataMarshallingEventUpcaster(EventDataMarshaller) - Constructor for class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster
-
Constructor for implementations of
this
. - AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult - Record Class in com.opencqrs.framework.upcaster
-
Captures upcasted
Event.type()
, meta-data, and payload. - afterPropertiesSet() - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- andGiven(Object...) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Applies further events in order to the configured
StateRebuildingHandlerDefinition
s to update the instance state. - andGiven(Consumer<CommandHandlingTestFixture.Given.GivenEvent<I>>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Applies a further event using the
CommandHandlingTestFixture.Given.GivenEvent
consumer for more fine-grained event specification of the event and its meta-data to update the instance state. - andGivenCommand(CommandHandlingTestFixture<I, AnotherCommand, ?>, AnotherCommand) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Uses any previously configured stubbings to execute the given
Command
without meta-data using theCommandHandlerDefinition
encapsulated within the given fixture to capture any new events published, which in turn will be applied tothis
. - andGivenCommand(CommandHandlingTestFixture<I, AnotherCommand, ?>, AnotherCommand, Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Uses any previously configured stubbings to execute the given
Command
with meta-data using theCommandHandlerDefinition
encapsulated within the given fixture to capture any new events published, which in turn will be applied tothis
. - andGivenTime(Instant) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Configures a (new) time-stamp to be used, if further events shall be applied with that
Event.time()
. - andGivenTimeDelta(Duration) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Shifts the previously configured time-stamp by given duration, if further events shall be applied with that
Event.time()
. - ANTICHRONOLOGICAL - Enum constant in enum class com.opencqrs.esdb.client.Option.Order.Type
-
Specifies antichronological event order.
- apiToken() - Method in record class com.opencqrs.esdb.client.EsdbProperties.Server
-
Returns the value of the
apiToken
record component. - APPLICATION_CONTEXT - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle.Controller
-
Life-cycle is controlled by the
ApplicationContext
. - authenticate() - Method in class com.opencqrs.esdb.client.EsdbClient
-
Authenticates against the configured event store, ensuring the correct api token has been configured.
- autoStart() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Returns the value of the
autoStart
record component. - AutowiredParameter - Record Class in com.opencqrs.framework.reflection
-
Represents an
Autowired
parameter within an annotated handler definition. - AutowiredParameter(Parameter, int, Class<?>) - Constructor for record class com.opencqrs.framework.reflection.AutowiredParameter
-
Creates an instance of a
AutowiredParameter
record class. - AutowiredParameterResolver - Class in com.opencqrs.framework.reflection
-
Base class for reflective
AutowiredParameter
resolution. - AutowiredParameterResolver(Method, Set<AutowiredParameter>) - Constructor for class com.opencqrs.framework.reflection.AutowiredParameterResolver
B
- BackOff - Interface in com.opencqrs.framework.eventhandler
-
Interface to be implemented by classes providing back off semantics, e.g.
- BackOff.Execution - Interface in com.opencqrs.framework.eventhandler
-
Encapsulates back off execution state.
C
- CacheKey(String, Class<I>, SourcingMode) - Constructor for record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheKey
-
Creates an instance of a
CacheKey
record class. - CacheValue(String, I, Map<String, String>) - Constructor for record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheValue
-
Creates an instance of a
CacheValue
record class. - canUpcast(Event) - Method in interface com.opencqrs.framework.upcaster.EventUpcaster
-
Determines if
this
upcaster is relevant for upcasting the givenEvent
. - canUpcast(Event) - Method in class com.opencqrs.framework.upcaster.NoEventUpcaster
- canUpcast(Event) - Method in class com.opencqrs.framework.upcaster.TypeChangingEventUpcaster
- capacity() - Method in record class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties
-
Returns the value of the
capacity
record component. - CapturedEvent - Record Class in com.opencqrs.framework.persistence
-
Record capturing an event publication intent.
- CapturedEvent(String, Object, Map<String, ?>, List<Precondition>) - Constructor for record class com.opencqrs.framework.persistence.CapturedEvent
-
Creates an instance of a
CapturedEvent
record class. - CapturedEvent(String, Object) - Constructor for record class com.opencqrs.framework.persistence.CapturedEvent
-
Convenience constructor, if no meta-data or preconditions are needed.
- checks() - Method in record class com.opencqrs.esdb.client.Health
-
Returns the value of the
checks
record component. - CHRONOLOGICAL - Enum constant in enum class com.opencqrs.esdb.client.Option.Order.Type
-
Specifies chronological event order.
- ClassNameEventTypeResolver - Class in com.opencqrs.framework.types
- ClassNameEventTypeResolver(ClassLoader) - Constructor for class com.opencqrs.framework.types.ClassNameEventTypeResolver
- ClassNameEventTypeResolverAutoConfiguration - Class in com.opencqrs.framework.types
-
Auto-configuration for
ClassNameEventTypeResolver
. - ClassNameEventTypeResolverAutoConfiguration() - Constructor for class com.opencqrs.framework.types.ClassNameEventTypeResolverAutoConfiguration
- ClientException - Exception Class in com.opencqrs.esdb.client
-
Base class for an exception thrown from
EsdbClient
. - ClientException(String) - Constructor for exception class com.opencqrs.esdb.client.ClientException
- ClientException(String, Throwable) - Constructor for exception class com.opencqrs.esdb.client.ClientException
- ClientException(Throwable) - Constructor for exception class com.opencqrs.esdb.client.ClientException
- ClientException.HttpException - Exception Class in com.opencqrs.esdb.client
-
Base class for exceptions related to HTTP status codes returned from an event store.
- ClientException.HttpException.HttpClientException - Exception Class in com.opencqrs.esdb.client
-
Exception class thrown for HTTP status codes
4xx
. - ClientException.HttpException.HttpServerException - Exception Class in com.opencqrs.esdb.client
-
Exception class thrown for HTTP status codes
5xx
. - ClientException.InterruptedException - Exception Class in com.opencqrs.esdb.client
-
Exception class representing thread interruption.
- ClientException.InvalidUsageException - Exception Class in com.opencqrs.esdb.client
-
Exception class representing errors due to invalid
client API
usage. - ClientException.MarshallingException - Exception Class in com.opencqrs.esdb.client
-
Exception class thrown by
Marshaller
implementations due to serialization or deserialization errors. - ClientException.TransportException - Exception Class in com.opencqrs.esdb.client
-
Exception class representing network and/or connection errors.
- ClientInterruptedException - Exception Class in com.opencqrs.framework.client
-
Exception class representing thread interruption signalled by
ClientException.InterruptedException
. - ClientInterruptedException(String, Throwable) - Constructor for exception class com.opencqrs.framework.client.ClientInterruptedException
- ClientRequestErrorMapper - Class in com.opencqrs.framework.client
-
Helper class to map errors from
EsdbClient
operations toCqrsFrameworkException
. - ClientRequestErrorMapper() - Constructor for class com.opencqrs.framework.client.ClientRequestErrorMapper
- close() - Method in class com.opencqrs.esdb.client.EsdbClient
- column() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Returns the value of the
column
record component. - com.opencqrs.esdb.client - package com.opencqrs.esdb.client
-
Base package for the ESDB client.
- com.opencqrs.esdb.client.eventql - package com.opencqrs.esdb.client.eventql
-
Contains classes related to EventQL.
- com.opencqrs.esdb.client.jackson - package com.opencqrs.esdb.client.jackson
-
Contains Jackson specific components.
- com.opencqrs.framework - package com.opencqrs.framework
-
Base package for CQRS framework components.
- com.opencqrs.framework.client - package com.opencqrs.framework.client
-
Internal helper classes for accessing the
EsdbClient
. - com.opencqrs.framework.command - package com.opencqrs.framework.command
-
Components for command handling.
- com.opencqrs.framework.command.cache - package com.opencqrs.framework.command.cache
-
Contains cache components supporting command execution.
- com.opencqrs.framework.eventhandler - package com.opencqrs.framework.eventhandler
-
Contains event handler and processing components.
- com.opencqrs.framework.eventhandler.partitioning - package com.opencqrs.framework.eventhandler.partitioning
-
Contains components for dealing with partitioned event handling.
- com.opencqrs.framework.eventhandler.progress - package com.opencqrs.framework.eventhandler.progress
-
Contains progress tracking components for event handling.
- com.opencqrs.framework.metadata - package com.opencqrs.framework.metadata
-
Contains meta-data related classes.
- com.opencqrs.framework.persistence - package com.opencqrs.framework.persistence
-
Persistence layer for abstracting event consumption and publication.
- com.opencqrs.framework.reflection - package com.opencqrs.framework.reflection
-
Contains internal helper classes to support reflection.
- com.opencqrs.framework.serialization - package com.opencqrs.framework.serialization
-
Contains components for
EventCandidate.data()
orEvent.data()
s erialization and deserialization. - com.opencqrs.framework.transaction - package com.opencqrs.framework.transaction
-
Transaction support for event handlers.
- com.opencqrs.framework.types - package com.opencqrs.framework.types
-
Contains event type resolution components.
- com.opencqrs.framework.upcaster - package com.opencqrs.framework.upcaster
-
Contains event upcasting components.
- Command - Interface in com.opencqrs.framework.command
-
Interface to be implemented by commands that can be handled by
CommandHandler
s. - Command.SubjectCondition - Enum Class in com.opencqrs.framework.command
-
The subject condition checked before
CommandHandler
execution. - commandClass() - Method in record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Returns the value of the
commandClass
record component. - CommandEventCapturer<I> - Class in com.opencqrs.framework.command
-
Default implementation of
CommandEventPublisher
used byCommandRouter
to apply events to theStateRebuildingHandler
s relevant for theCommand
being executed. - CommandEventCapturer(I, String, List<StateRebuildingHandlerDefinition<I, Object>>) - Constructor for class com.opencqrs.framework.command.CommandEventCapturer
- CommandEventPublisher<I> - Interface in com.opencqrs.framework.command
-
Extension to
EventPublisher
providing additional operations for publishing events relative to theCommand.getSubject()
being handled. - CommandHandler<I,
C, - Interface in com.opencqrs.framework.commandR> -
Sealed base interface for inherited
FunctionalInterface
variants encapsulating command-handling logic. - CommandHandler.ForCommand<I,
C, - Interface in com.opencqrs.framework.commandR> -
FunctionalInterface
to be implemented, if only theCommand
is needed for execution. - CommandHandler.ForInstanceAndCommand<I,
C, - Interface in com.opencqrs.framework.commandR> -
FunctionalInterface
to be implemented, ifCommand
and event-sourced instance are needed for execution. - CommandHandler.ForInstanceAndCommandAndMetaData<I,
C, - Interface in com.opencqrs.framework.commandR> -
FunctionalInterface
to be implemented, ifCommand
, meta-data, and event-sourced instance are needed for execution. - CommandHandlerConfiguration - Annotation Interface in com.opencqrs.framework.command
-
Annotation to be used for
Configuration
s containingCommandHandling
annotated methods,CommandHandlerDefinition
Bean
s, @StateRebuilding
annotated methods, andStateRebuildingHandlerDefinition
Bean
s in order to be able to test them usingCommandHandlingTest
. - CommandHandlerDefinition<I,
C, - Record Class in com.opencqrs.framework.commandR> -
CommandHandler
definition suitable for being processed by theCommandRouter
. - CommandHandlerDefinition(Class<I>, Class<C>, CommandHandler<I, C, R>) - Constructor for record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Convenience constructor using
SourcingMode.RECURSIVE
. - CommandHandlerDefinition(Class<I>, Class<C>, CommandHandler<I, C, R>, SourcingMode) - Constructor for record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Creates an instance of a
CommandHandlerDefinition
record class. - CommandHandling - Annotation Interface in com.opencqrs.framework.command
-
Annotation to be used in favor of defining
CommandHandlerDefinition
Bean
s. - CommandHandlingAnnotationProcessingAutoConfiguration - Class in com.opencqrs.framework.command
-
Auto-configuration for
CommandHandlerDefinition
s defined viaCommandHandling
annotated bean methods. - CommandHandlingAnnotationProcessingAutoConfiguration() - Constructor for class com.opencqrs.framework.command.CommandHandlingAnnotationProcessingAutoConfiguration
- CommandHandlingCacheProperties - Record Class in com.opencqrs.framework.command.cache
- CommandHandlingCacheProperties(CommandHandlingCacheProperties.Type, Integer, String) - Constructor for record class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties
-
Creates an instance of a
CommandHandlingCacheProperties
record class. - CommandHandlingCacheProperties.Type - Enum Class in com.opencqrs.framework.command.cache
-
The pre-defined cache type.
- CommandHandlingTest - Annotation Interface in com.opencqrs.framework.command
-
Annotation that can be used for Spring Boot tests that focus only on CQRS
CommandHandlerDefinition
s in favor of initializingCommandHandlingTestFixture
manually. - CommandHandlingTestAutoConfiguration - Class in com.opencqrs.framework.command
-
Auto-configuration for
CommandHandlingTestFixture
s. - CommandHandlingTestAutoConfiguration() - Constructor for class com.opencqrs.framework.command.CommandHandlingTestAutoConfiguration
- CommandHandlingTestFixture<I,
C, - Class in com.opencqrs.framework.commandR> -
Test support for
CommandHandler
orCommandHandlerDefinition
. - CommandHandlingTestFixture.Builder<I> - Class in com.opencqrs.framework.command
-
Builder for
CommandHandlingTestFixture
. - CommandHandlingTestFixture.EventAsserter - Class in com.opencqrs.framework.command
-
Fluent API helper class for asserting a captured events.
- CommandHandlingTestFixture.Expect - Class in com.opencqrs.framework.command
-
Fluent API helper class encapsulating the results of a
CommandHandler
execution for assertion. - CommandHandlingTestFixture.Expect.StatefulAssertion - Annotation Interface in com.opencqrs.framework.command
-
Marker annotation for assertion methods within
CommandHandlingTestFixture.Expect
which proceed through the captured event stream, if invoked. - CommandHandlingTestFixture.Given<C> - Class in com.opencqrs.framework.command
-
Fluent API helper class encapsulating the current state stubbing prior to executing the
CommandHandler
under test. - CommandHandlingTestFixture.Given.GivenEvent<I> - Class in com.opencqrs.framework.command
-
Fluent API helper class for fine granular specification of a single given event.
- commandHandlingTestFixtureBuilder(StateRebuildingHandlerDefinition[]) - Method in class com.opencqrs.framework.command.CommandHandlingTestAutoConfiguration
- CommandRouter - Class in com.opencqrs.framework.command
-
Command
router implementation providing CQRS-style command execution. - CommandRouter(EventReader, ImmediateEventPublisher, List<CommandHandlerDefinition>, List<StateRebuildingHandlerDefinition>) - Constructor for class com.opencqrs.framework.command.CommandRouter
-
Creates a pre-configured instance of
this
with disabled meta-data propagation andNoStateRebuildingCache
. - CommandRouter(EventReader, ImmediateEventPublisher, List<CommandHandlerDefinition>, List<StateRebuildingHandlerDefinition>, StateRebuildingCache, PropagationMode, Set<String>) - Constructor for class com.opencqrs.framework.command.CommandRouter
-
Creates a pre-configured instance of
this
. - CommandRouterAutoConfiguration - Class in com.opencqrs.framework.command
-
Auto-configuration for
CommandRouter
andStateRebuildingCache
default implementations. - CommandRouterAutoConfiguration() - Constructor for class com.opencqrs.framework.command.CommandRouterAutoConfiguration
- commandSubject() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Verifies that the captured event was published for the
Command.getSubject()
. - CommandSubjectAlreadyExistsException - Exception Class in com.opencqrs.framework.command
-
Exception thrown if
Command.SubjectCondition.PRISTINE
is violated. - CommandSubjectAlreadyExistsException(String, Command) - Constructor for exception class com.opencqrs.framework.command.CommandSubjectAlreadyExistsException
- CommandSubjectConditionViolatedException - Exception Class in com.opencqrs.framework.command
-
Exception thrown if
Command.SubjectCondition
is violated. - CommandSubjectConditionViolatedException(String, Command, Command.SubjectCondition) - Constructor for exception class com.opencqrs.framework.command.CommandSubjectConditionViolatedException
- CommandSubjectDoesNotExistException - Exception Class in com.opencqrs.framework.command
-
Exception thrown if
Command.SubjectCondition.EXISTS
is violated. - CommandSubjectDoesNotExistException(String, Command) - Constructor for exception class com.opencqrs.framework.command.CommandSubjectDoesNotExistException
- ConcurrencyException - Exception Class in com.opencqrs.framework.client
-
Exception class representing concurrency errors, usually caused by violated preconditions, when publishing events.
- ConcurrencyException(String, Throwable) - Constructor for exception class com.opencqrs.framework.client.ConcurrencyException
- connectionTimeout() - Method in record class com.opencqrs.esdb.client.EsdbProperties
-
Returns the value of the
connectionTimeout
record component. - consumeAsObject(EventReader.ClientRequestor, BiConsumer<Map<String, ?>, Object>) - Method in interface com.opencqrs.framework.persistence.EventReader
-
Consumes upcasted and converted meta-data and Java event objects from the given
EventReader.ClientRequestor
and passes them to the given event consumer. - consumeAsObject(EventReader.ClientRequestor, Consumer<Object>) - Method in interface com.opencqrs.framework.persistence.EventReader
-
Consumes upcasted and converted Java event objects from the given
EventReader.ClientRequestor
and passes them to the given event consumer. - consumeRaw(EventReader.ClientRequestor, BiConsumer<EventReader.RawCallback, Event>) - Method in interface com.opencqrs.framework.persistence.EventReader
-
Consumes raw
Event
s from the givenEventReader.ClientRequestor
and passes them to the given event consumer. - consumeRaw(EventReader.ClientRequestor, BiConsumer<EventReader.RawCallback, Event>) - Method in class com.opencqrs.framework.persistence.EventRepository
- consumeUpcasted(EventReader.ClientRequestor, BiConsumer<EventReader.UpcastedCallback, Event>) - Method in interface com.opencqrs.framework.persistence.EventReader
-
Consumes upcasted
Event
s from the givenEventReader.ClientRequestor
and passes them to the given event consumer. - containingClass() - Method in record class com.opencqrs.framework.reflection.AutowiredParameter
-
Returns the value of the
containingClass
record component. - controller() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Returns the value of the
controller
record component. - controllerRegistration() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Returns the value of the
controllerRegistration
record component. - convert(BiConsumer<Map<String, ?>, Object>) - Method in interface com.opencqrs.framework.persistence.EventReader.UpcastedCallback
-
Converts the encapsulated
Event
to meta-data and a Java object of the type determined byEventReader.UpcastedCallback.getEventJavaClass()
and maps it to the given consumer. - convert(Consumer<Object>) - Method in interface com.opencqrs.framework.persistence.EventReader.UpcastedCallback
-
Converts the encapsulated
Event
to a Java object of the type determined byEventReader.UpcastedCallback.getEventJavaClass()
and maps it to the given consumer. - CqrsFrameworkException - Exception Class in com.opencqrs.framework
-
Base class for exceptions handled within the framework.
- CqrsFrameworkException(String) - Constructor for exception class com.opencqrs.framework.CqrsFrameworkException
- CqrsFrameworkException(String, Throwable) - Constructor for exception class com.opencqrs.framework.CqrsFrameworkException
- CqrsFrameworkException.NonTransientException - Exception Class in com.opencqrs.framework
-
Exception class representing non-recoveralbe errors.
- CqrsFrameworkException.TransientException - Exception Class in com.opencqrs.framework
-
Exception class representing potentially recoverable errors, such as communication or concurrency errors.
- current(String, long) - Method in class com.opencqrs.framework.eventhandler.progress.InMemoryProgressTracker
- current(String, long) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- current(String, long) - Method in interface com.opencqrs.framework.eventhandler.progress.ProgressTracker
-
Retrieves the current
Progress
for the specified event processing group and partition.
D
- data() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
data
record component. - data() - Method in record class com.opencqrs.esdb.client.EventCandidate
-
Returns the value of the
data
record component. - data() - Method in record class com.opencqrs.framework.upcaster.EventUpcaster.Result
-
Returns the value of the
data
record component. - dataContentType() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
dataContentType
record component. - DEFAULT_ACTIVE_PARTITIONS - Static variable in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- DEFAULT_TABLE_PREFIX - Static variable in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- DefaultPartitionKeyResolver - Class in com.opencqrs.framework.eventhandler.partitioning
-
Default implementation of
PartitionKeyResolver
which usesCRC32
checksums and modulo operation to derive partition numbers from event sequence identifiers. - DefaultPartitionKeyResolver(long) - Constructor for class com.opencqrs.framework.eventhandler.partitioning.DefaultPartitionKeyResolver
- deferredHandler() - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Row
-
Returns the value of the
deferredHandler
record component. - deserialize(Map<String, ?>, Class<E>) - Method in interface com.opencqrs.framework.serialization.EventDataMarshaller
- deserialize(Map<String, ?>, Class<E>) - Method in class com.opencqrs.framework.serialization.JacksonEventDataMarshaller
- doHealthCheck(Health.Builder) - Method in class com.opencqrs.esdb.client.EsdbHealthIndicator
- doUpcast(Event, Map<String, ?>, Map<String, ?>) - Method in class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster
-
Template method to be implemented by subclasses to upcast the given meta-data and payload.
E
- endToken() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError
-
Returns the value of the
endToken
record component. - equals(Object) - Method in record class com.opencqrs.esdb.client.EsdbProperties
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.EsdbProperties.Server
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Event
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.EventCandidate
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Health
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Error
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Row
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Marshaller.ResponseElement.Heartbeat
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Option.FromLatestEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Option.LowerBoundExclusive
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Option.LowerBoundInclusive
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Option.Order
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Option.Recursive
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Option.UpperBoundExclusive
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Option.UpperBoundInclusive
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsOnEventId
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsPristine
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheKey
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheValue
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.command.StateRebuildingHandlerDefinition
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlerDefinition
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration.Registration
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Fetch
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.progress.Progress.None
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.eventhandler.progress.Progress.Success
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.metadata.MetaDataPropagationProperties
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.persistence.CapturedEvent
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.persistence.EventSource
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.reflection.AutowiredParameter
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.serialization.EventData
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class com.opencqrs.framework.upcaster.EventUpcaster.Result
-
Indicates whether some other object is "equal to" this one.
- error() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError
-
Returns the value of the
error
record component. - Error(QueryProcessingError) - Constructor for record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Error
-
Creates an instance of a
Error
record class. - ErrorHandler - Interface in com.opencqrs.esdb.client.eventql
-
Callback interface that needs to be implement for receiving errors from calls to
EsdbClient.query(String, RowHandler, ErrorHandler)
. - esdbClient(EsdbProperties, Marshaller, HttpClient.Builder) - Method in class com.opencqrs.esdb.client.EsdbClientAutoConfiguration
- EsdbClient - Class in com.opencqrs.esdb.client
-
Client SDK for the EventSourcingDB.
- EsdbClient(URI, String, Marshaller, HttpClient.Builder) - Constructor for class com.opencqrs.esdb.client.EsdbClient
- EsdbClientAutoConfiguration - Class in com.opencqrs.esdb.client
-
Auto-configuration
forEsdbClient
. - EsdbClientAutoConfiguration() - Constructor for class com.opencqrs.esdb.client.EsdbClientAutoConfiguration
- esdbHealthContributor(EsdbClient) - Method in class com.opencqrs.esdb.client.EsdbHealthContributorAutoConfiguration
- EsdbHealthContributorAutoConfiguration - Class in com.opencqrs.esdb.client
-
Auto-configuration
forEsdbHealthIndicator
. - EsdbHealthContributorAutoConfiguration() - Constructor for class com.opencqrs.esdb.client.EsdbHealthContributorAutoConfiguration
- EsdbHealthIndicator - Class in com.opencqrs.esdb.client
-
HealthContributor
implementation based onEsdbClient.health()
. - EsdbHealthIndicator(EsdbClient) - Constructor for class com.opencqrs.esdb.client.EsdbHealthIndicator
- esdbHttpClientBuilder() - Method in class com.opencqrs.esdb.client.EsdbClientAutoConfiguration
- esdbJacksonMarshaller(ObjectMapper) - Method in class com.opencqrs.esdb.client.JacksonMarshallerAutoConfiguration
- EsdbProperties - Record Class in com.opencqrs.esdb.client
- EsdbProperties(EsdbProperties.Server, Duration) - Constructor for record class com.opencqrs.esdb.client.EsdbProperties
-
Creates an instance of a
EsdbProperties
record class. - EsdbProperties.Server - Record Class in com.opencqrs.esdb.client
-
Server configuration settings.
- event() - Method in record class com.opencqrs.framework.persistence.CapturedEvent
-
Returns the value of the
event
record component. - Event - Record Class in com.opencqrs.esdb.client
-
Event data structure retrieved from an event store, conforming to the Cloud Events Specification.
- Event(String, String, String, Map<String, ?>, String, String, Instant, String, String, String) - Constructor for record class com.opencqrs.esdb.client.Event
-
Creates an instance of a
Event
record class. - EventCandidate - Record Class in com.opencqrs.esdb.client
-
Candidate event for
publication
to a Cloud Events Specification conforming event store. - EventCandidate(String, String, String, Map<String, ?>) - Constructor for record class com.opencqrs.esdb.client.EventCandidate
-
Creates an instance of a
EventCandidate
record class. - EventCapturer - Class in com.opencqrs.framework.persistence
-
In-memory implementation of
EventPublisher
usingCapturedEvent
s. - EventCapturer() - Constructor for class com.opencqrs.framework.persistence.EventCapturer
- eventClass() - Method in record class com.opencqrs.framework.command.StateRebuildingHandlerDefinition
-
Returns the value of the
eventClass
record component. - eventClass() - Method in record class com.opencqrs.framework.eventhandler.EventHandlerDefinition
-
Returns the value of the
eventClass
record component. - EventData<E> - Record Class in com.opencqrs.framework.serialization
-
Represents unmarshalled
EventCandidate.data()
orEvent.data()
, respectively. - EventData(Map<String, ?>, E) - Constructor for record class com.opencqrs.framework.serialization.EventData
-
Creates an instance of a
EventData
record class. - EventDataMarshaller - Interface in com.opencqrs.framework.serialization
-
Interface implemented for transforming Java event objects and additional meta-data to JSON-like maps, and vice versa.
- EventHandler<E> - Interface in com.opencqrs.framework.eventhandler
-
Sealed base interface for inherited
FunctionalInterface
variants encapsulating encapsulatingEvent
handling logic. - EventHandler.ForObject<E> - Interface in com.opencqrs.framework.eventhandler
-
FunctionalInterface
to be implemented, if only the Java event is needed for processing. - EventHandler.ForObjectAndMetaData<E> - Interface in com.opencqrs.framework.eventhandler
-
FunctionalInterface
to be implemented, if the Java event and its meta-data is needed for processing. - EventHandler.ForObjectAndMetaDataAndRawEvent<E> - Interface in com.opencqrs.framework.eventhandler
-
FunctionalInterface
to be implemented, if the Java event, its meta-data, and the raw event is needed for processing. - EventHandlerDefinition<E> - Record Class in com.opencqrs.framework.eventhandler
-
EventHandler
definition suitable for being processed by an event processor. - EventHandlerDefinition(String, Class<E>, EventHandler<E>) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlerDefinition
-
Creates an instance of a
EventHandlerDefinition
record class. - EventHandling - Annotation Interface in com.opencqrs.framework.eventhandler
-
Annotation to be used in favor of defining
EventHandlerDefinition
Bean
s. - EventHandlingAnnotationProcessingAutoConfiguration - Class in com.opencqrs.framework.eventhandler
-
Auto-configuration for
EventHandlerDefinition
s defined viaEventHandling
annotated bean methods. - EventHandlingAnnotationProcessingAutoConfiguration() - Constructor for class com.opencqrs.framework.eventhandler.EventHandlingAnnotationProcessingAutoConfiguration
- EventHandlingProcessor - Class in com.opencqrs.framework.eventhandler
-
Asynchronous event processor observing an event stream to be handled by matching
EventHandlerDefinition
s all belonging to the same processing group and partition with configurable progress tracking and retry in case of errors. - EventHandlingProcessor(long, String, Boolean, EventReader, ProgressTracker, EventSequenceResolver, PartitionKeyResolver, List<EventHandlerDefinition>, BackOff) - Constructor for class com.opencqrs.framework.eventhandler.EventHandlingProcessor
-
Creates a pre-configured instance of
this
. - EventHandlingProcessorAutoConfiguration - Class in com.opencqrs.framework.eventhandler
-
Auto-configuration for
EventHandlingProcessor
and supporting beans. - EventHandlingProcessorAutoConfiguration() - Constructor for class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration - Class in com.opencqrs.framework.eventhandler
- EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration.Registration - Record Class in com.opencqrs.framework.eventhandler
- EventHandlingProcessorLifecycleController - Interface in com.opencqrs.framework.eventhandler
-
Interface to be implemented by beans responsible for managing the life-cycle of an
EventHandlingProcessor
bean. - EventHandlingProcessorLifecycleRegistration - Interface in com.opencqrs.framework.eventhandler
-
Interface to be implemented for registering
EventHandlingProcessorLifecycleController
beans. - EventHandlingProperties - Record Class in com.opencqrs.framework.eventhandler
- EventHandlingProperties(EventHandlingProperties.ProcessorSettings, Map<String, EventHandlingProperties.ProcessorSettings>) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProperties
-
Creates an instance of a
EventHandlingProperties
record class. - EventHandlingProperties.ProcessorSettings - Record Class in com.opencqrs.framework.eventhandler
-
Configuration settings for an instance of
EventHandlingProcessor
. - EventHandlingProperties.ProcessorSettings.Fetch - Record Class in com.opencqrs.framework.eventhandler
-
Configures event stream fetching.
- EventHandlingProperties.ProcessorSettings.LifeCycle - Record Class in com.opencqrs.framework.eventhandler
-
Configures life-cycle registration.
- EventHandlingProperties.ProcessorSettings.LifeCycle.Controller - Enum Class in com.opencqrs.framework.eventhandler
-
The built-in
EventHandlingProcessorLifecycleController
type. - EventHandlingProperties.ProcessorSettings.Progress - Record Class in com.opencqrs.framework.eventhandler
-
Configures which
ProgressTracker
to use. - EventHandlingProperties.ProcessorSettings.Progress.Tracker - Enum Class in com.opencqrs.framework.eventhandler
-
The built-in
ProgressTracker
type. - EventHandlingProperties.ProcessorSettings.Retry - Record Class in com.opencqrs.framework.eventhandler
-
Error handling retry configuration settings.
- EventHandlingProperties.ProcessorSettings.Retry.Policy - Enum Class in com.opencqrs.framework.eventhandler
-
The back-off policy.
- EventHandlingProperties.ProcessorSettings.Sequencing - Record Class in com.opencqrs.framework.eventhandler
-
Configures which
EventSequenceResolver
to use. - EventHandlingProperties.ProcessorSettings.Sequencing.Resolution - Enum Class in com.opencqrs.framework.eventhandler
-
The built-in
EventSequenceResolver
type. - eventId() - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsOnEventId
-
Returns the value of the
eventId
record component. - eventId() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheValue
-
Returns the value of the
eventId
record component. - EventPersistenceAutoConfiguration - Class in com.opencqrs.framework.persistence
-
Auto-configuration for
EventRepository
andEventSource
. - EventPersistenceAutoConfiguration() - Constructor for class com.opencqrs.framework.persistence.EventPersistenceAutoConfiguration
- EventPublisher - Interface in com.opencqrs.framework.persistence
-
Interface specifying operations for publishing Java event objects.
- EventReader - Interface in com.opencqrs.framework.persistence
-
Interface specifying operations for reading events from an
EsdbClient
. - EventReader.ClientRequestor - Interface in com.opencqrs.framework.persistence
-
Generically wraps
EsdbClient
calls to consumeEvent
s. - EventReader.RawCallback - Interface in com.opencqrs.framework.persistence
-
Callback interface specifying operations to deal with an encapsulated raw
Event
. - EventReader.UpcastedCallback - Interface in com.opencqrs.framework.persistence
-
Callback interface specifying operations to deal with an encapsulated upcasted
Event
. - EventRepository - Class in com.opencqrs.framework.persistence
-
Default implementation of
EventReader
andImmediateEventPublisher
. - EventRepository(EsdbClient, EventSource, EventTypeResolver, EventDataMarshaller, EventUpcasters) - Constructor for class com.opencqrs.framework.persistence.EventRepository
- EventSequenceResolver<E> - Interface in com.opencqrs.framework.eventhandler.partitioning
-
Sealed base interface for inherited
FunctionalInterface
variants encapsulating the logic to derive a sequence identifier for an event. - EventSequenceResolver.ForObjectAndMetaDataAndRawEvent<E> - Interface in com.opencqrs.framework.eventhandler.partitioning
-
FunctionalInterface
to be implemented, if an event's sequence identifier can only be derived from a fully upcasted and deserialized Java event object. - EventSequenceResolver.ForRawEvent - Interface in com.opencqrs.framework.eventhandler.partitioning
-
FunctionalInterface
to be implemented, if an event's sequence identifier can be derived from a rawEvent
, that is without any upcasting or Java object deserialization. - EventSource - Record Class in com.opencqrs.framework.persistence
-
Encapsulates a configurable
Event.source()
for event publication. - EventSource(String) - Constructor for record class com.opencqrs.framework.persistence.EventSource
-
Creates an instance of a
EventSource
record class. - EventTypeResolutionException - Exception Class in com.opencqrs.framework.types
-
CqrsFrameworkException.NonTransientException
exception capturing anEventTypeResolver
resolution error. - EventTypeResolutionException(String) - Constructor for exception class com.opencqrs.framework.types.EventTypeResolutionException
- EventTypeResolutionException(String, Throwable) - Constructor for exception class com.opencqrs.framework.types.EventTypeResolutionException
- EventTypeResolver - Interface in com.opencqrs.framework.types
-
Interface implemented for resolving Java
Class
toEventCandidate.type()
orEvent.type()
and vice versa. - EventUpcaster - Interface in com.opencqrs.framework.upcaster
-
Interface to be implemented when
Event
s need to be migrated to a new representation, so-called upcasting. - EventUpcaster.Result - Record Class in com.opencqrs.framework.upcaster
-
Captures upcasted
Event.type()
andEvent.data()
. - EventUpcasterAutoConfiguration - Class in com.opencqrs.framework.upcaster
-
Auto-configuration for
EventUpcasters
. - EventUpcasterAutoConfiguration() - Constructor for class com.opencqrs.framework.upcaster.EventUpcasterAutoConfiguration
- EventUpcasters - Class in com.opencqrs.framework.upcaster
-
Implementation class delegating to a list of configurable
EventUpcaster
s combining theEventUpcaster.Result
s appropriately. - EventUpcasters(EventUpcaster...) - Constructor for class com.opencqrs.framework.upcaster.EventUpcasters
- EventUpcasters(List<EventUpcaster>) - Constructor for class com.opencqrs.framework.upcaster.EventUpcasters
- execute(Runnable) - Method in class com.opencqrs.framework.transaction.NoTransactionOperationsAdapter
- execute(Runnable) - Method in class com.opencqrs.framework.transaction.SpringTransactionOperationsAdapter
- execute(Runnable) - Method in interface com.opencqrs.framework.transaction.TransactionOperationsAdapter
-
Executes the given runnable with transactional semantics.
- EXISTS - Enum constant in enum class com.opencqrs.framework.command.Command.SubjectCondition
-
Assures that the given subject exists, that is at least one
Event
was sourced with that specificEvent.subject()
, in spite of any recursive subjects. - expectAnyEvent(E) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that any event's payload in the remaining set of captured events is equal to the given payload.
- expectAnyEvent(Consumer<CommandHandlingTestFixture.EventAsserter>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that any of the remaining events in the set of captured events asserts successfully using the given event asserting consumer.
- expectAnyEventSatisfying(Consumer<E>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Verifies that any event in the remaining set of captured events asserts using the given custom assertion
Consumer
. - expectAnyEventType(Class<?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that any event in the remaining set of captured events Class.isAssignableFrom(Class) is assignable} to the given event type.
- expectCommandSubjectConditionViolated() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
- expectCommandSubjectConditionViolated(Command.SubjectCondition) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the
CommandHandler
could not be executed because it violates the specifiedCommand.SubjectCondition
. - expectEvents(Object...) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the next event payloads within the captured event stream are equal to the given events in order.
- expectEventsInAnyOrder(Object...) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the next event payloads within the captured event stream are equal to the given events in any order.
- expectEventsSatisfying(Consumer<List<Object>>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the next event payloads within the captured event stream are successfully asserted by the given consumer.
- expectEventTypes(Class<?>...) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the next event payloads within the captured event stream Class.isAssignableFrom(Class) are assignable} to the given event types in order.
- expectEventTypesInAnyOrder(Class<?>...) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the next event payloads within the captured event stream Class.isAssignableFrom(Class) are assignable} to the given event types in any order.
- expectException(Class<T>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the
CommandHandler
executed exceptionally by throwing an exception of the given class. - expectExceptionSatisfying(Consumer<T>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the
CommandHandler
executed exceptionally and allows for further custom assertions using the providedConsumer
. - expectNextEvent(E) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the next payload payload within the captured payload stream is equal to the given payload.
- expectNextEvent(Consumer<CommandHandlingTestFixture.EventAsserter>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts the next event within the captured event stream using the given event asserting consumer.
- expectNextEventSatisfying(Consumer<E>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that next event within the captured event stream is successfully asserted by the given
Consumer
. - expectNextEventType(Class<?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that next event within the captured event stream Class.isAssignableFrom(Class) is assignable} to the given event type.
- expectNoEvent(Consumer<CommandHandlingTestFixture.EventAsserter>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that none of the remaining events in the captured event stream satisfies the given assertion criteria.
- expectNoEventOfType(Class<?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that none of the remaining events in the captured event stream is assignable to the given type.
- expectNoEvents() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that no event was captured as part of the published event stream.
- expectNoMoreEvents() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that no more events have been captured.
- expectNumEvents(int) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that number of events captured as part of the published event stream matches the given number.
- expectResult(R) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
- expectResultSatisfying(Consumer<R>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
- expectSingleEvent(E) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that a single payload was captured as part of the published payload stream whose payload is equal to the expected one.
- expectSingleEvent(Consumer<CommandHandlingTestFixture.EventAsserter>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that a single event was captured as part of the published event stream which using the given event asserting consumer.
- expectSingleEventSatisfying(Consumer<E>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that a single event was captured as part of the published event stream which matches the custom assertion provided as
Consumer
. - expectSingleEventType(Class<?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that a single event was captured as part of the published event stream which Class.isAssignableFrom(Class) is assignable} to the given event type.
- expectState(I) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
- expectStateExtracting(Function<I, R>, R) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
- expectStateSatisfying(Consumer<I>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
- expectSuccessfulExecution() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the
CommandHandler
executed non exceptionally. - expectUnsuccessfulExecution() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Asserts that the
CommandHandler
executed exceptionally, irrespective of the exception type. - EXPONENTIAL_BACKOFF - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry.Policy
-
Back-off using exponential time interval.
F
- fail - Enum constant in enum class com.opencqrs.esdb.client.Health.Status
- fetch() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Returns the value of the
fetch
record component. - Fetch(String, Boolean) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Fetch
-
Creates an instance of a
Fetch
record class. - fetchAndMerge(StateRebuildingCache.CacheKey<I>, Function<StateRebuildingCache.CacheValue<I>, StateRebuildingCache.CacheValue<I>>) - Method in class com.opencqrs.framework.command.cache.LruInMemoryStateRebuildingCache
- fetchAndMerge(StateRebuildingCache.CacheKey<I>, Function<StateRebuildingCache.CacheValue<I>, StateRebuildingCache.CacheValue<I>>) - Method in class com.opencqrs.framework.command.cache.NoStateRebuildingCache
- fetchAndMerge(StateRebuildingCache.CacheKey<I>, Function<StateRebuildingCache.CacheValue<I>, StateRebuildingCache.CacheValue<I>>) - Method in interface com.opencqrs.framework.command.cache.StateRebuildingCache
-
Method supposed to fetch a
StateRebuildingCache.CacheValue
from the underlying cache based on the givenStateRebuildingCache.CacheKey
. - FIXED - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry.Policy
-
Back-off using fixed time interval.
- fixtureBeanDefinitionRegistryPostProcessor() - Static method in class com.opencqrs.framework.command.CommandHandlingTestAutoConfiguration
- fromEventId(String) - Static method in class com.opencqrs.esdb.client.IdUtil
-
Converts an
Event.id()
to a number. - fromHealthResponse(String) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- fromHealthResponse(String) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient.health()
to transform the HTTP response body to aHealth
. - fromJsonResponse(String) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- fromJsonResponse(String) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient
operations to transform any generic HTTP JSON response. - FromLatestEvent(String, String, Option.FromLatestEvent.IfEventIsMissing) - Constructor for record class com.opencqrs.esdb.client.Option.FromLatestEvent
-
Creates an instance of a
FromLatestEvent
record class. - fromQueryResponseLine(String) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- fromQueryResponseLine(String) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient
to transform an ND-JSON line from the HTTP response stream to aMarshaller.QueryResponseElement
. - fromReadOrObserveResponseLine(String) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- fromReadOrObserveResponseLine(String) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient
to transform an ND-JSON line from the HTTP response stream to aMarshaller.ResponseElement
. - fromWriteEventsResponse(String) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- fromWriteEventsResponse(String) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient.write(List, List)
to transform the HTTP response body to a list ofEvent
s.
G
- getCommand() - Method in exception class com.opencqrs.framework.command.CommandSubjectConditionViolatedException
- getEventJavaClass() - Method in interface com.opencqrs.framework.persistence.EventReader.UpcastedCallback
- getEvents() - Method in class com.opencqrs.framework.persistence.EventCapturer
-
Retrieves the list of events captured by this
EventPublisher
. - getEventType(Class<?>) - Method in class com.opencqrs.framework.types.ClassNameEventTypeResolver
- getEventType(Class<?>) - Method in interface com.opencqrs.framework.types.EventTypeResolver
-
Resolves the given event type for the given
Class
. - getEventType(Class<?>) - Method in class com.opencqrs.framework.types.PreconfiguredAssignableClassEventTypeResolver
- getGroupId() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessor
- getJavaClass(String) - Method in class com.opencqrs.framework.types.ClassNameEventTypeResolver
- getJavaClass(String) - Method in interface com.opencqrs.framework.types.EventTypeResolver
-
Resolved the Java
Class
for the given event type. - getJavaClass(String) - Method in class com.opencqrs.framework.types.PreconfiguredAssignableClassEventTypeResolver
- getKeepLevels() - Method in class com.opencqrs.framework.eventhandler.partitioning.PerConfigurableLevelSubjectEventSequenceResolver
- getPartition() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessor
- getStatusCode() - Method in exception class com.opencqrs.esdb.client.ClientException.HttpException
- getSubject() - Method in interface com.opencqrs.framework.command.Command
-
Specifies the subject of this command, needed to source the necessary events for the command execution.
- getSubjectCondition() - Method in interface com.opencqrs.framework.command.Command
-
Specifies the condition to check for the given
Command.getSubject()
before aCommandHandler
will be executed. - getSubjectCondition() - Method in exception class com.opencqrs.framework.command.CommandSubjectConditionViolatedException
- given(Object...) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Initializes the
CommandHandlingTestFixture
with the given event payloads applied in order to the configuredStateRebuildingHandlerDefinition
s to reconstruct the instance state. - given(Consumer<CommandHandlingTestFixture.Given.GivenEvent<I>>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Initializes the
CommandHandlingTestFixture
using theCommandHandlingTestFixture.Given.GivenEvent
consumer for more fine-grained event specification of the events and their meta-data, which will be applied in order to the configuredStateRebuildingHandlerDefinition
s to reconstruct the instance state. - givenCommand(CommandHandlingTestFixture<I, AnotherCommand, ?>, AnotherCommand) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Execute the given
Command
without meta-data using theCommandHandlerDefinition
encapsulated within the given fixture to capture any new events published, which in turn will be applied tothis
. - givenCommand(CommandHandlingTestFixture<I, AnotherCommand, ?>, AnotherCommand, Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Execute the given
Command
with meta-data using theCommandHandlerDefinition
encapsulated within the given fixture to capture any new events published, which in turn will be applied tothis
. - givenNothing() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Initializes the
CommandHandlingTestFixture
with no prior state. - givenState(I) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Initializes the
CommandHandlingTestFixture
with the given instance state. - givenTime(Instant) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Initializes the
CommandHandlingTestFixture
with no prior state, but a specific time-stamp. - group() - Method in record class com.opencqrs.framework.eventhandler.EventHandlerDefinition
-
Returns the value of the
group
record component. - group() - Element in annotation interface com.opencqrs.framework.eventhandler.EventHandling
-
Specifies the
EventHandlerDefinition.group()
for the annotated method. - groups() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties
-
Returns the value of the
groups
record component.
H
- handle(C, CommandEventPublisher<I>) - Method in interface com.opencqrs.framework.command.CommandHandler.ForCommand
-
Handles the given command without having access to the event-sourced instance representing the current state (aka write model).
- handle(E) - Method in interface com.opencqrs.framework.eventhandler.EventHandler.ForObject
-
Handles the given event.
- handle(E, Map<String, ?>) - Method in interface com.opencqrs.framework.eventhandler.EventHandler.ForObjectAndMetaData
-
Handles the given event and its meta-data.
- handle(E, Map<String, ?>, Event) - Method in interface com.opencqrs.framework.eventhandler.EventHandler.ForObjectAndMetaDataAndRawEvent
-
Handles the given event, its meta-data, and the raw event.
- handle(I, C, CommandEventPublisher<I>) - Method in interface com.opencqrs.framework.command.CommandHandler.ForInstanceAndCommand
-
Handles the given command on an event-sourced instance representing the current state (aka write model).
- handle(I, C, Map<String, ?>, CommandEventPublisher<I>) - Method in interface com.opencqrs.framework.command.CommandHandler.ForInstanceAndCommandAndMetaData
-
Handles the given command and meta-data on an event-sourced instance representing the current state (aka write model).
- handleMappingExceptionsIfNecessary(Supplier<T>) - Method in class com.opencqrs.framework.client.ClientRequestErrorMapper
-
Handles and maps suitable
ClientException
s thrown from the given handler to suitable subclasses ofCqrsFrameworkException
. - handler() - Method in record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Returns the value of the
handler
record component. - handler() - Method in record class com.opencqrs.framework.command.StateRebuildingHandlerDefinition
-
Returns the value of the
handler
record component. - handler() - Method in record class com.opencqrs.framework.eventhandler.EventHandlerDefinition
-
Returns the value of the
handler
record component. - hash() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
hash
record component. - hashCode() - Method in record class com.opencqrs.esdb.client.EsdbProperties
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.EsdbProperties.Server
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Event
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.EventCandidate
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Health
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Error
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Row
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Marshaller.ResponseElement.Heartbeat
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Option.FromLatestEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Option.LowerBoundExclusive
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Option.LowerBoundInclusive
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Option.Order
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Option.Recursive
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Option.UpperBoundExclusive
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Option.UpperBoundInclusive
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsOnEventId
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsPristine
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheKey
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheValue
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.command.StateRebuildingHandlerDefinition
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlerDefinition
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration.Registration
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Fetch
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.progress.Progress.None
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.eventhandler.progress.Progress.Success
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.metadata.MetaDataPropagationProperties
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.persistence.CapturedEvent
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.persistence.EventSource
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.reflection.AutowiredParameter
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.serialization.EventData
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult
-
Returns a hash code value for this object.
- hashCode() - Method in record class com.opencqrs.framework.upcaster.EventUpcaster.Result
-
Returns a hash code value for this object.
- health() - Method in class com.opencqrs.esdb.client.EsdbClient
-
Checks the healthiness of the configured event store.
- Health - Record Class in com.opencqrs.esdb.client
-
Represents the current health status of the configured ESDB.
- Health(Health.Status, Map<String, ?>) - Constructor for record class com.opencqrs.esdb.client.Health
-
Creates an instance of a
Health
record class. - Health.Status - Enum Class in com.opencqrs.esdb.client
-
Health status.
- Heartbeat() - Constructor for record class com.opencqrs.esdb.client.Marshaller.ResponseElement.Heartbeat
-
Creates an instance of a
Heartbeat
record class. - HttpClientException(String, int) - Constructor for exception class com.opencqrs.esdb.client.ClientException.HttpException.HttpClientException
- HttpException(String, int) - Constructor for exception class com.opencqrs.esdb.client.ClientException.HttpException
- HttpServerException(String, int) - Constructor for exception class com.opencqrs.esdb.client.ClientException.HttpException.HttpServerException
I
- id() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
id
record component. - id() - Method in record class com.opencqrs.esdb.client.Option.LowerBoundExclusive
-
Returns the value of the
id
record component. - id() - Method in record class com.opencqrs.esdb.client.Option.LowerBoundInclusive
-
Returns the value of the
id
record component. - id() - Method in record class com.opencqrs.esdb.client.Option.UpperBoundExclusive
-
Returns the value of the
id
record component. - id() - Method in record class com.opencqrs.esdb.client.Option.UpperBoundInclusive
-
Returns the value of the
id
record component. - id() - Method in record class com.opencqrs.framework.eventhandler.progress.Progress.Success
-
Returns the value of the
id
record component. - id(String) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given.GivenEvent
-
Specifies the
Event.id()
to be used. - IdUtil - Class in com.opencqrs.esdb.client
-
Static helper methods related to
Event.id()
. - IdUtil() - Constructor for class com.opencqrs.esdb.client.IdUtil
- ifEventIsMissing() - Method in record class com.opencqrs.esdb.client.Option.FromLatestEvent
-
Returns the value of the
ifEventIsMissing
record component. - ImmediateEventPublisher - Interface in com.opencqrs.framework.persistence
-
Interface specifying operations for immediate, atomic event publication.
- IN_MEMORY - Enum constant in enum class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties.Type
-
In-memory caching is used.
- IN_MEMORY - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress.Tracker
-
Progress is tracked in-memory.
- index() - Method in record class com.opencqrs.framework.reflection.AutowiredParameter
-
Returns the value of the
index
record component. - initialInterval() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns the value of the
initialInterval
record component. - InMemoryProgressTracker - Class in com.opencqrs.framework.eventhandler.progress
-
ProgressTracker
implementation using an in-memoryMap
. - InMemoryProgressTracker() - Constructor for class com.opencqrs.framework.eventhandler.progress.InMemoryProgressTracker
- instance() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheValue
-
Returns the value of the
instance
record component. - instanceClass() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheKey
-
Returns the value of the
instanceClass
record component. - instanceClass() - Method in record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Returns the value of the
instanceClass
record component. - instanceClass() - Method in record class com.opencqrs.framework.command.StateRebuildingHandlerDefinition
-
Returns the value of the
instanceClass
record component. - InterruptedException(String) - Constructor for exception class com.opencqrs.esdb.client.ClientException.InterruptedException
- InterruptedException(String, Throwable) - Constructor for exception class com.opencqrs.esdb.client.ClientException.InterruptedException
- InvalidUsageException(String) - Constructor for exception class com.opencqrs.esdb.client.ClientException.InvalidUsageException
- isAutoStartup() - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- isRunning() - Method in interface com.opencqrs.framework.eventhandler.EventHandlingProcessorLifecycleController
-
States whether the associated
EventHandlingProcessor
is currently EventHandlingProcessor.run() running. - isRunning() - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
J
- JacksonEventDataMarshaller - Class in com.opencqrs.framework.serialization
-
EventDataMarshaller
implementation that uses a configurableObjectMapper
for marshalling. - JacksonEventDataMarshaller(ObjectMapper) - Constructor for class com.opencqrs.framework.serialization.JacksonEventDataMarshaller
- JacksonEventDataMarshallerAutoConfiguration - Class in com.opencqrs.framework.serialization
-
Auto-configuration for
JacksonEventDataMarshaller
. - JacksonEventDataMarshallerAutoConfiguration() - Constructor for class com.opencqrs.framework.serialization.JacksonEventDataMarshallerAutoConfiguration
- JacksonMarshaller - Class in com.opencqrs.esdb.client.jackson
-
ObjectMapper
basedMarshaller
implementation. - JacksonMarshaller(ObjectMapper) - Constructor for class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- JacksonMarshallerAutoConfiguration - Class in com.opencqrs.esdb.client
-
Auto-configuration
forJacksonMarshaller
. - JacksonMarshallerAutoConfiguration() - Constructor for class com.opencqrs.esdb.client.JacksonMarshallerAutoConfiguration
- JDBC - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress.Tracker
-
Progress is tracked using a JDBC data-source.
- JdbcProgressTracker - Class in com.opencqrs.framework.eventhandler.progress
-
ProgressTracker
implementation using SpringJdbcOperations
andTransactionOperations
to persistProgress
. - JdbcProgressTracker(DataSource, PlatformTransactionManager) - Constructor for class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
K
- KEEP_IF_PRESENT - Enum constant in enum class com.opencqrs.framework.metadata.PropagationMode
-
Specifies that meta-data will be propagated from source to destination, but meta-data keys already present within the destination will not be overridden.
- keys() - Method in record class com.opencqrs.framework.metadata.MetaDataPropagationProperties
-
Returns the value of the
keys
record component.
L
- LEADER_ELECTION - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle.Controller
-
Life-cycle is controlled by a
LockRegistryLeaderInitiator
bean using an underlyingLockRegistry
. - LeaderElectionLifecycleConfiguration() - Constructor for class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration
- lifeCycle() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Returns the value of the
lifeCycle
record component. - LifeCycle(Boolean, EventHandlingProperties.ProcessorSettings.LifeCycle.Controller, String, String, Long) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Creates an instance of a
LifeCycle
record class. - line() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Returns the value of the
line
record component. - LOCAL - Enum constant in enum class com.opencqrs.framework.command.SourcingMode
-
Events will be fetched for the
Command.getSubject()
non-recursively. - lockRegistry() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration.Registration
-
Returns the value of the
lockRegistry
record component. - lockRegistry() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Returns the value of the
lockRegistry
record component. - LowerBoundExclusive(String) - Constructor for record class com.opencqrs.esdb.client.Option.LowerBoundExclusive
-
Creates an instance of a
LowerBoundExclusive
record class. - LowerBoundInclusive(String) - Constructor for record class com.opencqrs.esdb.client.Option.LowerBoundInclusive
-
Creates an instance of a
LowerBoundInclusive
record class. - LruInMemoryStateRebuildingCache - Class in com.opencqrs.framework.command.cache
-
StateRebuildingCache
implementation backed by asynchronized
LinkedHashMap
with configurable maximum capacity and LRU semantics. - LruInMemoryStateRebuildingCache(int) - Constructor for class com.opencqrs.framework.command.cache.LruInMemoryStateRebuildingCache
-
Configures this with a maximum capacity.
M
- Marshaller - Interface in com.opencqrs.esdb.client
-
Interface specifying operations for HTTP request/response marshalling.
- Marshaller.QueryResponseElement - Interface in com.opencqrs.esdb.client
-
Sealed interface representing a deserialized ND-JSON response line transformed via
Marshaller.fromQueryResponseLine(String)
. - Marshaller.QueryResponseElement.Error - Record Class in com.opencqrs.esdb.client
-
Represents an
error
returned from the event store, typically caused by an invalid query or missing data in the result set. - Marshaller.QueryResponseElement.Row - Record Class in com.opencqrs.esdb.client
-
Represents a
row
returned from the event store, which may be processed by the deferredBiConsumer
. - Marshaller.ResponseElement - Interface in com.opencqrs.esdb.client
-
Sealed interface representing a deserialized ND-JSON response line transformed via
Marshaller.fromReadOrObserveResponseLine(String)
. - Marshaller.ResponseElement.Heartbeat - Record Class in com.opencqrs.esdb.client
-
Represents a heart beat returned from the event store to ensure the underlying HTTP connection is kept alive.
- marshallingError(ClientException.MarshallingException, String) - Method in interface com.opencqrs.esdb.client.eventql.ErrorHandler
-
Signals a marshalling error for result rows successfully received from the underlying event store that could not be properly deserialized or transformed to the desired target type by means of the requested
RowHandler
. - MarshallingException(String) - Constructor for exception class com.opencqrs.esdb.client.ClientException.MarshallingException
- MarshallingException(Throwable) - Constructor for exception class com.opencqrs.esdb.client.ClientException.MarshallingException
- maxAttempts() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns the value of the
maxAttempts
record component. - maxElapsedTime() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns the value of the
maxElapsedTime
record component. - maxInterval() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns the value of the
maxInterval
record component. - metaData() - Method in record class com.opencqrs.framework.persistence.CapturedEvent
-
Returns the value of the
metaData
record component. - metaData() - Method in record class com.opencqrs.framework.serialization.EventData
-
Returns the value of the
metaData
record component. - metaData() - Method in record class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult
-
Returns the value of the
metaData
record component. - metaData(Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Asserts that the captured event meta-data is equal to the expected one.
- metaData(Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given.GivenEvent
-
Specifies the event meta-data passed to appropriate
StateRebuildingHandler
variants. - MetaDataAndPayloadResult(String, Map<String, ?>, Map<String, ?>) - Constructor for record class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult
-
Creates an instance of a
MetaDataAndPayloadResult
record class. - MetaDataPropagationProperties - Record Class in com.opencqrs.framework.metadata
- MetaDataPropagationProperties(PropagationMode, Set<String>) - Constructor for record class com.opencqrs.framework.metadata.MetaDataPropagationProperties
-
Creates an instance of a
MetaDataPropagationProperties
record class. - metaDataSatisfying(Consumer<Map<String, ?>>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Verifies that the captured event meta-data asserts successfully using the given custom assertion.
- method - Variable in class com.opencqrs.framework.reflection.AutowiredParameterResolver
- mode() - Method in record class com.opencqrs.framework.metadata.MetaDataPropagationProperties
-
Returns the value of the
mode
record component. - multiplier() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns the value of the
multiplier
record component.
N
- next() - Method in interface com.opencqrs.framework.eventhandler.BackOff.Execution
-
Yields the number of milliseconds to back off.
- NO_SEQUENCE - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing.Resolution
-
(Partitioned) instances process events without any pre-defined sequence.
- NoEventSequenceResolver - Class in com.opencqrs.framework.eventhandler.partitioning
-
EventSequenceResolver.ForRawEvent
implementation to be used if no event sequencing is required, i.e. - NoEventSequenceResolver() - Constructor for class com.opencqrs.framework.eventhandler.partitioning.NoEventSequenceResolver
- NoEventUpcaster - Class in com.opencqrs.framework.upcaster
- NoEventUpcaster(String) - Constructor for class com.opencqrs.framework.upcaster.NoEventUpcaster
- noMetaData() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Verifies that no (aka empty) meta-data was published for the captured event.
- None() - Constructor for record class com.opencqrs.framework.eventhandler.progress.Progress.None
-
Creates an instance of a
None
record class. - NONE - Enum constant in enum class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties.Type
-
No caching is used.
- NONE - Enum constant in enum class com.opencqrs.framework.command.Command.SubjectCondition
-
No condition checks apply to the given subject.
- NONE - Enum constant in enum class com.opencqrs.framework.command.SourcingMode
-
No events will be fetched for the
Command.getSubject()
. - NONE - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry.Policy
-
No back-off.
- NONE - Enum constant in enum class com.opencqrs.framework.metadata.PropagationMode
-
Specifies that no meta-data keys (and values) will be propagated from source to destination.
- NonTransientException(String) - Constructor for exception class com.opencqrs.framework.CqrsFrameworkException.NonTransientException
- NonTransientException(String, Throwable) - Constructor for exception class com.opencqrs.framework.CqrsFrameworkException.NonTransientException
- NoStateRebuildingCache - Class in com.opencqrs.framework.command.cache
-
StateRebuildingCache
implementation that does not cache anything. - NoStateRebuildingCache() - Constructor for class com.opencqrs.framework.command.cache.NoStateRebuildingCache
- NoTransactionOperationsAdapter - Class in com.opencqrs.framework.transaction
-
Implementation of
TransactionOperationsAdapter
used if Spring TX is not available on the class-path orEventHandling
methods have not been annotated usingTransactional
. - NoTransactionOperationsAdapter() - Constructor for class com.opencqrs.framework.transaction.NoTransactionOperationsAdapter
O
- observe(String, Set<Option>, Consumer<Event>) - Method in class com.opencqrs.esdb.client.EsdbClient
-
Streams existing
Event
s from the underlying event store, waiting for any new events to be published. - on(I, E) - Method in interface com.opencqrs.framework.command.StateRebuildingHandler.FromObject
-
Applies the given event to the given instance (state).
- on(I, E, Event) - Method in interface com.opencqrs.framework.command.StateRebuildingHandler.FromObjectAndRawEvent
-
Applies the given event and optional raw event to the given instance (state).
- on(I, E, Map<String, ?>) - Method in interface com.opencqrs.framework.command.StateRebuildingHandler.FromObjectAndMetaData
-
Applies the given event and its meta-data to the given instance (state).
- on(I, E, Map<String, ?>, String) - Method in interface com.opencqrs.framework.command.StateRebuildingHandler.FromObjectAndMetaDataAndSubject
-
Applies the given event, its meta-data, and subject to the given instance (state).
- on(I, E, Map<String, ?>, String, Event) - Method in interface com.opencqrs.framework.command.StateRebuildingHandler.FromObjectAndMetaDataAndSubjectAndRawEvent
-
Applies the given event, its meta-data, and subject to the given instance (state).
- openCqrsClassNameEventTypeResolver() - Method in class com.opencqrs.framework.types.ClassNameEventTypeResolverAutoConfiguration
- openCqrsCommandHandlingAnnotatedMethodBeanRegistration() - Static method in class com.opencqrs.framework.command.CommandHandlingAnnotationProcessingAutoConfiguration
- openCqrsCommandRouter(EventReader, ImmediateEventPublisher, List<CommandHandlerDefinition>, List<StateRebuildingHandlerDefinition>, CommandHandlingCacheProperties, MetaDataPropagationProperties, ApplicationContext) - Method in class com.opencqrs.framework.command.CommandRouterAutoConfiguration
- openCqrsEventHandlingAnnotatedMethodBeanRegistration() - Static method in class com.opencqrs.framework.eventhandler.EventHandlingAnnotationProcessingAutoConfiguration
- openCqrsEventHandlingProcessorContext(ApplicationContext, EventHandlingProperties, List<EventHandlerDefinition>) - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- openCqrsEventRepository(EsdbClient, EventSource, EventTypeResolver, EventDataMarshaller, EventUpcasters) - Method in class com.opencqrs.framework.persistence.EventPersistenceAutoConfiguration
- openCqrsEventSource(Environment) - Method in class com.opencqrs.framework.persistence.EventPersistenceAutoConfiguration
- openCqrsEventUpcasterChain(List<EventUpcaster>) - Method in class com.opencqrs.framework.upcaster.EventUpcasterAutoConfiguration
- openCqrsInMemoryProgressTracker() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- openCqrsJacksonEventSerializer(ObjectMapper) - Method in class com.opencqrs.framework.serialization.JacksonEventDataMarshallerAutoConfiguration
- openCqrsLeaderElectionEventHandlingProcessorLifecycleControllerRegistration(LockRegistry) - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration
- openCqrsLruInMemoryStateRebuildingCache(CommandHandlingCacheProperties) - Method in class com.opencqrs.framework.command.CommandRouterAutoConfiguration
- openCqrsNoEventSequenceResolver() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- openCqrsNoStateRebuildingCache() - Method in class com.opencqrs.framework.command.CommandRouterAutoConfiguration
- openCqrsPerSecondLevelSubjectEventSequenceResolver() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- openCqrsPerSubjectEventSequenceResolver() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- openCqrsSmartLifecycleEventHandlingProcessorLifecycleControllerRegistration() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration
- openCqrsStateRebuildingAnnotatedMethodBeanRegistration() - Static method in class com.opencqrs.framework.command.StateRebuildingAnnotationProcessingAutoConfiguration
- Option - Interface in com.opencqrs.esdb.client
-
Sealed interface for options used by
EsdbClient
to read or observe events from the underlying event store. - Option.FromLatestEvent - Record Class in com.opencqrs.esdb.client
-
Specifies that the list of events is optimized by omitting any event prior to the latest event available for the subject specified as part of
this
. - Option.FromLatestEvent.IfEventIsMissing - Enum Class in com.opencqrs.esdb.client
-
Specifies the fall-back fetch strategy.
- Option.LowerBoundExclusive - Record Class in com.opencqrs.esdb.client
-
Specifies the lowest exclusive event id to fetch from.
- Option.LowerBoundInclusive - Record Class in com.opencqrs.esdb.client
-
Specifies the lowest inclusive event id to fetch from.
- Option.Order - Record Class in com.opencqrs.esdb.client
-
Encapsulates the type of ordering of the fetched events.
- Option.Order.Type - Enum Class in com.opencqrs.esdb.client
-
Specifies the event order.
- Option.Recursive - Record Class in com.opencqrs.esdb.client
-
Specifies that events shall be fetched recursively, that is including the requested subject (events) and its hierarchical subject (events).
- Option.UpperBoundExclusive - Record Class in com.opencqrs.esdb.client
-
Specifies the highest exclusive event id to fetch to.
- Option.UpperBoundInclusive - Record Class in com.opencqrs.esdb.client
-
Specifies the highest inclusive event id to fetch to.
- Order(Option.Order.Type) - Constructor for record class com.opencqrs.esdb.client.Option.Order
-
Creates an instance of a
Order
record class. - OVERRIDE_IF_PRESENT - Enum constant in enum class com.opencqrs.framework.metadata.PropagationMode
-
Specifies that meta-data will be propagated from source to destination, overriding any meta-data keys present in both source and destination.
P
- parameter() - Method in record class com.opencqrs.framework.reflection.AutowiredParameter
-
Returns the value of the
parameter
record component. - PartitionKeyResolver - Interface in com.opencqrs.framework.eventhandler.partitioning
-
Interface for implementations able to derive a consistently derive a numeric partition key from an event sequence identifier.
- partitions() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Returns the value of the
partitions
record component. - pass - Enum constant in enum class com.opencqrs.esdb.client.Health.Status
- payload() - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Error
-
Returns the value of the
payload
record component. - payload() - Method in record class com.opencqrs.framework.serialization.EventData
-
Returns the value of the
payload
record component. - payload() - Method in record class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult
-
Returns the value of the
payload
record component. - payload(E) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Asserts that the captured event payload is equal to the expected one.
- payload(E) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given.GivenEvent
-
Specifies the event payload passed any of the
StateRebuildingHandler
variants. - payloadExtracting(Function<E, R>, R) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Asserts that the captured event's payload property from the given extractor function is equal to the expected one.
- payloadSatisfying(Consumer<E>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Verifies that the captured event payload asserts successfully using the given custom assertion.
- payloadType(Class<?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Asserts that the captured event payload Class.isAssignableFrom(Class) is assignable to} the expected type
- PER_SECOND_LEVEL_SUBJECT - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing.Resolution
-
(Partitioned) instances process events in-order per second-level subject, i.e.
- PER_SUBJECT - Enum constant in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing.Resolution
-
(Partitioned) instances process events in-order per (same) subject.
- PerConfigurableLevelSubjectEventSequenceResolver - Class in com.opencqrs.framework.eventhandler.partitioning
-
EventSequenceResolver.ForRawEvent
implementation which reduced theEvent.subject()
path and reduces it to a configurable level, i.e. - PerConfigurableLevelSubjectEventSequenceResolver(int) - Constructor for class com.opencqrs.framework.eventhandler.partitioning.PerConfigurableLevelSubjectEventSequenceResolver
- PerSubjectEventSequenceResolver - Class in com.opencqrs.framework.eventhandler.partitioning
-
EventSequenceResolver.ForRawEvent
implementation which usesEvent.subject()
as the event sequence identifier. - PerSubjectEventSequenceResolver() - Constructor for class com.opencqrs.framework.eventhandler.partitioning.PerSubjectEventSequenceResolver
- ping() - Method in class com.opencqrs.esdb.client.EsdbClient
-
Pings the configured event store, ensuring the server is running
- policy() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns the value of the
policy
record component. - Precondition - Interface in com.opencqrs.esdb.client
-
Sealed interface for preconditions used for
event publication
to ensure consistency within the underlying event store. - Precondition.SubjectIsOnEventId - Record Class in com.opencqrs.esdb.client
-
A precondition stating the given subject must have been updated by the given event id.
- Precondition.SubjectIsPristine - Record Class in com.opencqrs.esdb.client
-
A precondition stating the given subject must not yet exist within the event store.
- preconditions() - Method in record class com.opencqrs.framework.persistence.CapturedEvent
-
Returns the value of the
preconditions
record component. - PreconfiguredAssignableClassEventTypeResolver - Class in com.opencqrs.framework.types
-
EventTypeResolver
implementation that can be pre-configured using a specific mapping between event types and Java classes. - PreconfiguredAssignableClassEventTypeResolver(Map<String, Class<?>>) - Constructor for class com.opencqrs.framework.types.PreconfiguredAssignableClassEventTypeResolver
- predecessorHash() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
predecessorHash
record component. - PRISTINE - Enum constant in enum class com.opencqrs.framework.command.Command.SubjectCondition
-
Assures that the given subject does not exist, that is no
Event
was sourced with that specificEvent.subject()
, in spite of any recursive subjects. - proceed(String, long, Supplier<Progress>) - Method in class com.opencqrs.framework.eventhandler.progress.InMemoryProgressTracker
- proceed(String, long, Supplier<Progress>) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- proceed(String, long, Supplier<Progress>) - Method in interface com.opencqrs.framework.eventhandler.progress.ProgressTracker
- ProcessorSettings(EventHandlingProperties.ProcessorSettings.Fetch, EventHandlingProperties.ProcessorSettings.LifeCycle, EventHandlingProperties.ProcessorSettings.Progress, EventHandlingProperties.ProcessorSettings.Sequencing, EventHandlingProperties.ProcessorSettings.Retry) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Creates an instance of a
ProcessorSettings
record class. - progress() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Returns the value of the
progress
record component. - Progress - Interface in com.opencqrs.framework.eventhandler.progress
-
Sealed interface for subclasses representing the progress of event handling the event stream for a processing group.
- Progress(EventHandlingProperties.ProcessorSettings.Progress.Tracker, String) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress
-
Creates an instance of a
Progress
record class. - Progress.None - Record Class in com.opencqrs.framework.eventhandler.progress
-
States no progress for the event processing group is known.
- Progress.Success - Record Class in com.opencqrs.framework.eventhandler.progress
-
Represents the last
Event.id()
that has been successfully processed by the event processing group. - ProgressTracker - Interface in com.opencqrs.framework.eventhandler.progress
-
Interface specifying operations for tracking progress of event processing groups.
- propagateMetaData(Map<String, ?>, Map<String, ?>, PropagationMode) - Static method in class com.opencqrs.framework.metadata.PropagationUtil
- PropagationMode - Enum Class in com.opencqrs.framework.metadata
-
Specifies how meta-data is going to be propagated from source (for instance command meta-data) to destination (for instance published event meta-data).
- PropagationUtil - Class in com.opencqrs.framework.metadata
-
Util class for meta-data propagation.
- PropagationUtil() - Constructor for class com.opencqrs.framework.metadata.PropagationUtil
- publish(E) - Method in interface com.opencqrs.framework.command.CommandEventPublisher
-
Publishes an event to the subject specified by
Command.getSubject()
and applies it to any assignableStateRebuildingHandler
s participating in the command execution. - publish(E, Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandEventCapturer
- publish(E, Map<String, ?>) - Method in interface com.opencqrs.framework.command.CommandEventPublisher
-
Publishes an event and its meta-data to the subject specified by
Command.getSubject()
and applies it to any assignableStateRebuildingHandler
s participating in the command execution. - publish(String, E) - Method in interface com.opencqrs.framework.persistence.EventPublisher
-
Publishes the given event onto the given subject.
- publish(String, E) - Method in interface com.opencqrs.framework.persistence.ImmediateEventPublisher
-
Publishes the given event onto the given subject.
- publish(String, E, Map<String, ?>) - Method in interface com.opencqrs.framework.persistence.EventPublisher
-
Publishes the given event and its meta-data onto the given subject.
- publish(String, E, Map<String, ?>, List<Precondition>) - Method in class com.opencqrs.framework.persistence.EventCapturer
- publish(String, E, Map<String, ?>, List<Precondition>) - Method in interface com.opencqrs.framework.persistence.EventPublisher
-
Publishes the given event and its meta-data onto the given subject with preconditions.
- publish(String, E, Map<String, ?>, List<Precondition>) - Method in interface com.opencqrs.framework.persistence.ImmediateEventPublisher
-
Publishes the given event including its meta-data onto the given subject with preconditions.
- publish(Consumer<EventPublisher>) - Method in interface com.opencqrs.framework.persistence.ImmediateEventPublisher
-
Atomically publishes all events captured from the given
EventPublisher
consumer. - publish(Consumer<EventPublisher>, List<Precondition>) - Method in class com.opencqrs.framework.persistence.EventRepository
- publish(Consumer<EventPublisher>, List<Precondition>) - Method in interface com.opencqrs.framework.persistence.ImmediateEventPublisher
-
Atomically publishes all events captured from the given
EventPublisher
consumer together with the additional preconditions. - publish(List<CapturedEvent>, List<Precondition>) - Method in class com.opencqrs.framework.persistence.EventRepository
- publish(List<CapturedEvent>, List<Precondition>) - Method in interface com.opencqrs.framework.persistence.ImmediateEventPublisher
-
Atomically publishes the given events together with the additional preconditions.
- publishRelative(String, E) - Method in interface com.opencqrs.framework.command.CommandEventPublisher
-
Publishes an event to the subject specified by
Command.getSubject()
appended with the specified suffix and applies it to any assignableStateRebuildingHandler
s participating in the command execution. - publishRelative(String, E, Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandEventCapturer
- publishRelative(String, E, Map<String, ?>) - Method in interface com.opencqrs.framework.command.CommandEventPublisher
-
Publishes an event and its meta-data to the subject specified by
Command.getSubject()
appended with the specified suffix and applies it to any assignableStateRebuildingHandler
s participating in the command execution.
Q
- query(String, RowHandler, ErrorHandler) - Method in class com.opencqrs.esdb.client.EsdbClient
-
Queries the underlying event store using EventQL.
- queryProcessingError(QueryProcessingError) - Method in interface com.opencqrs.esdb.client.eventql.ErrorHandler
-
Signals a query processing error received from the underlying event store, while processing a row for the result set.
- QueryProcessingError - Record Class in com.opencqrs.esdb.client.eventql
-
Encapsulates a query processing error caused by
EsdbClient.query(String, RowHandler, ErrorHandler)
. - QueryProcessingError(String, QueryProcessingError.Token, QueryProcessingError.Token) - Constructor for record class com.opencqrs.esdb.client.eventql.QueryProcessingError
-
Creates an instance of a
QueryProcessingError
record class. - QueryProcessingError.Token - Record Class in com.opencqrs.esdb.client.eventql
-
Encapsulates a token describing the error position within a malformed or unprocessable query.
R
- read(String, Set<Option>) - Method in class com.opencqrs.esdb.client.EsdbClient
-
Reads existing
Event
s from the underlying event store. - read(String, Set<Option>, Consumer<Event>) - Method in class com.opencqrs.esdb.client.EsdbClient
-
Reads existing
Event
s from the underlying event store. - READ_EVERYTHING - Enum constant in enum class com.opencqrs.esdb.client.Option.FromLatestEvent.IfEventIsMissing
-
Specifies that all events shall be fetched for the actual subject.
- READ_NOTHING - Enum constant in enum class com.opencqrs.esdb.client.Option.FromLatestEvent.IfEventIsMissing
-
Specifies that no events shall be fetched for the actual subject.
- readAsObject(String, Set<Option>) - Method in interface com.opencqrs.framework.persistence.EventReader
-
Retrieves a list of upcasted and converted Java event objects matching the given subject and options.
- readRaw(String, Set<Option>) - Method in interface com.opencqrs.framework.persistence.EventReader
-
Retrieves a list of raw
Event
s matching the given subject and options. - readUpcasted(String, Set<Option>) - Method in interface com.opencqrs.framework.persistence.EventReader
-
Retrieves a list of upcasted
Event
s matching the given subject and options. - recursive() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Fetch
-
Returns the value of the
recursive
record component. - Recursive() - Constructor for record class com.opencqrs.esdb.client.Option.Recursive
-
Creates an instance of a
Recursive
record class. - RECURSIVE - Enum constant in enum class com.opencqrs.framework.command.SourcingMode
-
Events will be fetched for the
Command.getSubject()
recursively. - ref() - Method in record class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties
-
Returns the value of the
ref
record component. - registerLifecycleBean(BeanDefinitionRegistry, String, EventHandlingProperties.ProcessorSettings) - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration.Registration
- registerLifecycleBean(BeanDefinitionRegistry, String, EventHandlingProperties.ProcessorSettings) - Method in interface com.opencqrs.framework.eventhandler.EventHandlingProcessorLifecycleRegistration
-
Implementations are expected to register an
EventHandlingProcessorLifecycleController
within the givenBeanDefinitionRegistry
, if needed. - Registration(LockRegistry) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration.Registration
-
Creates an instance of a
Registration
record class. - request(EsdbClient, Consumer<Event>) - Method in interface com.opencqrs.framework.persistence.EventReader.ClientRequestor
-
Encapsulates an
EsdbClient
call to fetch rawEvent
s passed to the given consumer. - resolution() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing
-
Returns the value of the
resolution
record component. - resolve(String) - Method in class com.opencqrs.framework.eventhandler.partitioning.DefaultPartitionKeyResolver
- resolve(String) - Method in interface com.opencqrs.framework.eventhandler.partitioning.PartitionKeyResolver
-
Deterministically resolves a partition number for the given sequence identifier.
- resolveIncludingAutowiredParameters(Map<Integer, Object>) - Method in class com.opencqrs.framework.reflection.AutowiredParameterResolver
-
Resolves the configured
AutowiredParameter
s, merges them with the given parameter positions and returns them in order. - resolverRef() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing
-
Returns the value of the
resolverRef
record component. - Result(String, Map<String, ?>) - Constructor for record class com.opencqrs.framework.upcaster.EventUpcaster.Result
-
Creates an instance of a
Result
record class. - retry() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Returns the value of the
retry
record component. - Retry(EventHandlingProperties.ProcessorSettings.Retry.Policy, Duration, Duration, Duration, Double, Integer) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Creates an instance of a
Retry
record class. - Row(BiConsumer<RowHandler, ErrorHandler>) - Constructor for record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Row
-
Creates an instance of a
Row
record class. - RowHandler - Interface in com.opencqrs.esdb.client.eventql
-
Sealed base interface for handlers capable of processing query result rows.
- RowHandler.AsEvent - Interface in com.opencqrs.esdb.client.eventql
-
FunctionalInterface
to be implemented for consuming query result rows asEvent
. - RowHandler.AsMap - Interface in com.opencqrs.esdb.client.eventql
-
FunctionalInterface
to be implemented for consuming query result rows as JSON maps. - RowHandler.AsObject<T> - Interface in com.opencqrs.esdb.client.eventql
-
Interface to be implemented for consuming query result rows as JSON objects.
- RowHandler.AsScalar<T> - Interface in com.opencqrs.esdb.client.eventql
-
FunctionalInterface
to be implemented for consuming query result rows as scalar data types. - run() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessor
-
Enters the event processing loop, running infinitely unless interrupted or
CqrsFrameworkException.NonTransientException
is thrown.
S
- send(Command) - Method in class com.opencqrs.framework.command.CommandRouter
-
Sends the given command with empty meta-data to the appropriate
CommandHandler
for execution. - send(Command, Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandRouter
-
Sends the given command and meta-data to the appropriate
CommandHandler
for execution. - sequence() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Returns the value of the
sequence
record component. - sequenceIdFor(Event) - Method in interface com.opencqrs.framework.eventhandler.partitioning.EventSequenceResolver.ForRawEvent
-
Determines the sequence identifier from a raw
Event
. - sequenceIdFor(Event) - Method in class com.opencqrs.framework.eventhandler.partitioning.NoEventSequenceResolver
- sequenceIdFor(Event) - Method in class com.opencqrs.framework.eventhandler.partitioning.PerConfigurableLevelSubjectEventSequenceResolver
- sequenceIdFor(Event) - Method in class com.opencqrs.framework.eventhandler.partitioning.PerSubjectEventSequenceResolver
- sequenceIdFor(E, Map<String, ?>) - Method in interface com.opencqrs.framework.eventhandler.partitioning.EventSequenceResolver.ForObjectAndMetaDataAndRawEvent
-
Determines the sequence identifier from an upcasted and deserialized
Event
. - Sequencing(EventHandlingProperties.ProcessorSettings.Sequencing.Resolution, String) - Constructor for record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing
-
Creates an instance of a
Sequencing
record class. - serialize(EventData<E>) - Method in interface com.opencqrs.framework.serialization.EventDataMarshaller
- serialize(EventData<E>) - Method in class com.opencqrs.framework.serialization.JacksonEventDataMarshaller
- server() - Method in record class com.opencqrs.esdb.client.EsdbProperties
-
Returns the value of the
server
record component. - Server(URI, String) - Constructor for record class com.opencqrs.esdb.client.EsdbProperties.Server
-
Creates an instance of a
Server
record class. - setApplicationContext(ApplicationContext) - Method in class com.opencqrs.framework.reflection.AutowiredParameterResolver
- setBeanClassLoader(ClassLoader) - Method in class com.opencqrs.framework.types.ClassNameEventTypeResolverAutoConfiguration
- setCheckDatabaseOnStart(boolean) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
-
Configures, if the SQL database should be checked on startup, in order to be sure the tables have been created.
- setCountAllQuery(String) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
-
Configures the SQL {code SELECT} statement used to check the database on start-up.
- setFindQuery(String) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- setInsertQuery(String) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
-
Configures the SQL
INSERT
statement to insert a newProgress
duringJdbcProgressTracker.proceed(String, long, Supplier)
. - setProceedTransactionally(boolean) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
-
Configures whether the execution passed to
JdbcProgressTracker.proceed(String, long, Supplier)
will be executed within the same transaction asthis
. - setTablePrefix(String) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
-
Configures the SQL table prefix.
- setUpdateQuery(String) - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
-
Configures the SQL
UPDATE
statement to update an existingProgress
duringJdbcProgressTracker.proceed(String, long, Supplier)
. - skipEvents(int) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Expect
-
Skips the given number of next events for upcoming assertions.
- source() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
source
record component. - source() - Method in record class com.opencqrs.esdb.client.EventCandidate
-
Returns the value of the
source
record component. - source() - Method in record class com.opencqrs.framework.persistence.EventSource
-
Returns the value of the
source
record component. - sourcedSubjectIds() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheValue
-
Returns the value of the
sourcedSubjectIds
record component. - sourcingMode() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheKey
-
Returns the value of the
sourcingMode
record component. - sourcingMode() - Method in record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Returns the value of the
sourcingMode
record component. - sourcingMode() - Element in annotation interface com.opencqrs.framework.command.CommandHandling
-
The
SourcingMode
for theCommandHandlerDefinition
. - SourcingMode - Enum Class in com.opencqrs.framework.command
-
The type of sourcing affecting which events will be sourced for
CommandHandler
s. - specVersion() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
specVersion
record component. - SpringTransactionOperationsAdapter - Class in com.opencqrs.framework.transaction
-
TransactionOperationsAdapter
implementation that uses aTransactionOperations
delegate for transactional execution of anEventHandling
annotated method according to the suppliedTransactional
configuration. - SpringTransactionOperationsAdapter(PlatformTransactionManager, TransactionAttributeSource, Method, Class<?>) - Constructor for class com.opencqrs.framework.transaction.SpringTransactionOperationsAdapter
- standard() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties
-
Returns the value of the
standard
record component. - start() - Method in interface com.opencqrs.framework.eventhandler.BackOff
-
Starts a back off
BackOff.Execution
. - start() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessor
- start() - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- startToken() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError
-
Returns the value of the
startToken
record component. - StateRebuilding - Annotation Interface in com.opencqrs.framework.command
-
Annotation to be used in favor of defining
StateRebuildingHandlerDefinition
Bean
s. - StateRebuildingAnnotationProcessingAutoConfiguration - Class in com.opencqrs.framework.command
-
Auto-configuration for
StateRebuildingHandlerDefinition
s defined viaStateRebuilding
annotated bean methods. - StateRebuildingAnnotationProcessingAutoConfiguration() - Constructor for class com.opencqrs.framework.command.StateRebuildingAnnotationProcessingAutoConfiguration
- StateRebuildingCache - Interface in com.opencqrs.framework.command.cache
-
Interface specifying operations to cache event-sourced instance state to reduce the number of fetched events prior to executing a
CommandHandler
. - StateRebuildingCache.CacheKey<I> - Record Class in com.opencqrs.framework.command.cache
-
Represents the cache key, whose
equality
determines, whichStateRebuildingCache.CacheValue
to fetch. - StateRebuildingCache.CacheValue<I> - Record Class in com.opencqrs.framework.command.cache
-
Represents the cache value.
- StateRebuildingHandler<I,
E> - Interface in com.opencqrs.framework.command -
Sealed base interface for inherited
FunctionalInterface
variants encapsulating the event-sourcing logic needed to reconstruct instance state from an event stream. - StateRebuildingHandler.FromObject<I,
E> - Interface in com.opencqrs.framework.command -
FunctionalInterface
to be implemented, if only the Java event is needed to reconstruct the instance state. - StateRebuildingHandler.FromObjectAndMetaData<I,
E> - Interface in com.opencqrs.framework.command -
FunctionalInterface
to be implemented, if the Java event and its meta-data is needed to reconstruct the instance state. - StateRebuildingHandler.FromObjectAndMetaDataAndSubject<I,
E> - Interface in com.opencqrs.framework.command -
FunctionalInterface
to be implemented, if the Java event, its meta-data, and subject is needed to reconstruct the instance state. - StateRebuildingHandler.FromObjectAndMetaDataAndSubjectAndRawEvent<I,
E> - Interface in com.opencqrs.framework.command -
FunctionalInterface
to be implemented, if the Java event, its meta-data, subject, and optional raw event is needed to reconstruct the instance state. - StateRebuildingHandler.FromObjectAndRawEvent<I,
E> - Interface in com.opencqrs.framework.command -
FunctionalInterface
to be implemented, if the Java event and the rawEvent
is needed to reconstruct the instance state. - StateRebuildingHandlerDefinition<I,
E> - Record Class in com.opencqrs.framework.command -
StateRebuildingHandler
definition suitable for event-sourcing an instance prior tocommand handling
. - StateRebuildingHandlerDefinition(Class<I>, Class<E>, StateRebuildingHandler<I, E>) - Constructor for record class com.opencqrs.framework.command.StateRebuildingHandlerDefinition
-
Creates an instance of a
StateRebuildingHandlerDefinition
record class. - status() - Method in record class com.opencqrs.esdb.client.Health
-
Returns the value of the
status
record component. - stop() - Method in class com.opencqrs.framework.eventhandler.EventHandlingProcessor
- stop() - Method in class com.opencqrs.framework.eventhandler.progress.JdbcProgressTracker
- subject() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
subject
record component. - subject() - Method in record class com.opencqrs.esdb.client.EventCandidate
-
Returns the value of the
subject
record component. - subject() - Method in record class com.opencqrs.esdb.client.Option.FromLatestEvent
-
Returns the value of the
subject
record component. - subject() - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsOnEventId
-
Returns the value of the
subject
record component. - subject() - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsPristine
-
Returns the value of the
subject
record component. - subject() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheKey
-
Returns the value of the
subject
record component. - subject() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Fetch
-
Returns the value of the
subject
record component. - subject() - Method in record class com.opencqrs.framework.persistence.CapturedEvent
-
Returns the value of the
subject
record component. - subject(String) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Asserts that the captured event subject is equal to the expected one.
- subject(String) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given.GivenEvent
-
Specifies the
Event.subject()
to be used. - SubjectIsOnEventId(String, String) - Constructor for record class com.opencqrs.esdb.client.Precondition.SubjectIsOnEventId
-
Creates an instance of a
SubjectIsOnEventId
record class. - SubjectIsPristine(String) - Constructor for record class com.opencqrs.esdb.client.Precondition.SubjectIsPristine
-
Creates an instance of a
SubjectIsPristine
record class. - subjectSatisfying(Consumer<String>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.EventAsserter
-
Verifies that the captured event subject asserts successfully using the given custom assertion.
- Success(String) - Constructor for record class com.opencqrs.framework.eventhandler.progress.Progress.Success
-
Creates an instance of a
Success
record class.
T
- text() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Returns the value of the
text
record component. - time() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
time
record component. - time(Instant) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given.GivenEvent
-
Specifies the
Event.time()
to be used. - Token(Integer, Integer, String, String) - Constructor for record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Creates an instance of a
Token
record class. - toQueryRequest(String) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- toQueryRequest(String) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient
to transform the given parameters into a valid HTTP request body to be sent to the event store for query operations. - toReadOrObserveEventsRequest(String, Set<Option>) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- toReadOrObserveEventsRequest(String, Set<Option>) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient
to transform the given parameters into a valid HTTP request body toe be sent to the event store for read or observe operations. - toString() - Method in record class com.opencqrs.esdb.client.EsdbProperties.Server
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.EsdbProperties
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Event
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.EventCandidate
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Health
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Error
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Marshaller.QueryResponseElement.Row
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Marshaller.ResponseElement.Heartbeat
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Option.FromLatestEvent
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Option.LowerBoundExclusive
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Option.LowerBoundInclusive
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Option.Order
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Option.Recursive
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Option.UpperBoundExclusive
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Option.UpperBoundInclusive
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsOnEventId
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.esdb.client.Precondition.SubjectIsPristine
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheKey
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.command.cache.StateRebuildingCache.CacheValue
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.command.CommandHandlerDefinition
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.command.StateRebuildingHandlerDefinition
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlerDefinition
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProcessorAutoConfiguration.LeaderElectionLifecycleConfiguration.Registration
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Fetch
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.progress.Progress.None
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.eventhandler.progress.Progress.Success
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.metadata.MetaDataPropagationProperties
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.persistence.CapturedEvent
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.persistence.EventSource
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.reflection.AutowiredParameter
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.serialization.EventData
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult
-
Returns a string representation of this record class.
- toString() - Method in record class com.opencqrs.framework.upcaster.EventUpcaster.Result
-
Returns a string representation of this record class.
- toWriteEventsRequest(List<EventCandidate>, List<Precondition>) - Method in class com.opencqrs.esdb.client.jackson.JacksonMarshaller
- toWriteEventsRequest(List<EventCandidate>, List<Precondition>) - Method in interface com.opencqrs.esdb.client.Marshaller
-
Used by
EsdbClient.write(List, List)
to transform the givenEventCandidate
s andPrecondition
s to a valid HTTP request body to be sent to the event store. - trackerRef() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress
-
Returns the value of the
trackerRef
record component. - tracking() - Method in record class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress
-
Returns the value of the
tracking
record component. - TransactionOperationsAdapter - Interface in com.opencqrs.framework.transaction
-
Internal interface encapsulating
Transactional
method execution. - TransientException(String) - Constructor for exception class com.opencqrs.framework.CqrsFrameworkException.TransientException
- TransientException(String, Throwable) - Constructor for exception class com.opencqrs.framework.CqrsFrameworkException.TransientException
- TransportException(String) - Constructor for exception class com.opencqrs.esdb.client.ClientException.TransportException
- TransportException(String, Throwable) - Constructor for exception class com.opencqrs.esdb.client.ClientException.TransportException
- type() - Method in record class com.opencqrs.esdb.client.Event
-
Returns the value of the
type
record component. - type() - Method in record class com.opencqrs.esdb.client.EventCandidate
-
Returns the value of the
type
record component. - type() - Method in record class com.opencqrs.esdb.client.eventql.QueryProcessingError.Token
-
Returns the value of the
type
record component. - type() - Method in interface com.opencqrs.esdb.client.eventql.RowHandler.AsObject
- type() - Method in record class com.opencqrs.esdb.client.Option.FromLatestEvent
-
Returns the value of the
type
record component. - type() - Method in record class com.opencqrs.esdb.client.Option.Order
-
Returns the value of the
type
record component. - type() - Method in record class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties
-
Returns the value of the
type
record component. - type() - Method in record class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster.MetaDataAndPayloadResult
-
Returns the value of the
type
record component. - type() - Method in record class com.opencqrs.framework.upcaster.EventUpcaster.Result
-
Returns the value of the
type
record component. - TypeChangingEventUpcaster - Class in com.opencqrs.framework.upcaster
-
EventUpcaster
implementation that changes theEvent.type()
to a new type if it matches the configured source type. - TypeChangingEventUpcaster(String, String) - Constructor for class com.opencqrs.framework.upcaster.TypeChangingEventUpcaster
U
- upcast(Event) - Method in class com.opencqrs.framework.upcaster.AbstractEventDataMarshallingEventUpcaster
- upcast(Event) - Method in interface com.opencqrs.framework.upcaster.EventUpcaster
-
Upcasts the given event to a stream of
EventUpcaster.Result
s. - upcast(Event) - Method in class com.opencqrs.framework.upcaster.EventUpcasters
-
If necessary upcasts the given
Event
using all configuredEventUpcaster
s repeatedly, as long as one of them is capable of upcasting the event. - upcast(Event) - Method in class com.opencqrs.framework.upcaster.NoEventUpcaster
- upcast(Event) - Method in class com.opencqrs.framework.upcaster.TypeChangingEventUpcaster
- upcast(BiConsumer<EventReader.UpcastedCallback, Event>) - Method in interface com.opencqrs.framework.persistence.EventReader.RawCallback
-
Upcasts the encapsulated raw
Event
and maps resulting event stream to the given consumer. - UpperBoundExclusive(String) - Constructor for record class com.opencqrs.esdb.client.Option.UpperBoundExclusive
-
Creates an instance of a
UpperBoundExclusive
record class. - UpperBoundInclusive(String) - Constructor for record class com.opencqrs.esdb.client.Option.UpperBoundInclusive
-
Creates an instance of a
UpperBoundInclusive
record class. - uri() - Method in record class com.opencqrs.esdb.client.EsdbProperties.Server
-
Returns the value of the
uri
record component. - using(CommandHandlerDefinition<I, C, R>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Builder
-
Initializes the
CommandHandlingTestFixture
using the givenCommandHandlerDefinition
. - using(Class<I>, CommandHandler<I, C, R>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Builder
-
Initializes the
CommandHandlingTestFixture
using the givenCommandHandler
. - usingCommandSubject() - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
- usingSubject(String) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Specifies the
Event.subject()
to be used for subsequent calls toCommandHandlingTestFixture.Given.andGiven(Object...)
. - usingSubject(String) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Specifies the
Event.subject()
to be used for subsequent calls toCommandHandlingTestFixture.Given.andGiven(Object...)
.
V
- value() - Element in annotation interface com.opencqrs.framework.eventhandler.EventHandling
-
Alias for
EventHandling.group()
. - valueOf(String) - Static method in enum class com.opencqrs.esdb.client.Health.Status
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.esdb.client.Option.FromLatestEvent.IfEventIsMissing
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.esdb.client.Option.Order.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.command.Command.SubjectCondition
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.command.SourcingMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle.Controller
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress.Tracker
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry.Policy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing.Resolution
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.opencqrs.framework.metadata.PropagationMode
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.opencqrs.esdb.client.Health.Status
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.esdb.client.Option.FromLatestEvent.IfEventIsMissing
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.esdb.client.Option.Order.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.command.cache.CommandHandlingCacheProperties.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.command.Command.SubjectCondition
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.command.SourcingMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.LifeCycle.Controller
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Progress.Tracker
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Retry.Policy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.eventhandler.EventHandlingProperties.ProcessorSettings.Sequencing.Resolution
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.opencqrs.framework.metadata.PropagationMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
W
- warn - Enum constant in enum class com.opencqrs.esdb.client.Health.Status
- when(C) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Executes the CommandHandlingTestFixture.Builder.using(Class, CommandHandler) configured}
CommandHandler
using the previously initialized instance state. - when(C, Map<String, ?>) - Method in class com.opencqrs.framework.command.CommandHandlingTestFixture.Given
-
Executes the CommandHandlingTestFixture.Builder.using(Class, CommandHandler) configured}
CommandHandler
using the previously initialized instance state. - withStateRebuildingHandlerDefinitions(StateRebuildingHandlerDefinition<I, ?>...) - Static method in class com.opencqrs.framework.command.CommandHandlingTestFixture
-
Creates a
CommandHandlingTestFixture.Builder
instance for the givenStateRebuildingHandlerDefinition
s. - write(List<EventCandidate>, List<Precondition>) - Method in class com.opencqrs.esdb.client.EsdbClient
-
Publishes the given
EventCandidate
s to the underlying event store.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form