Index

A B C D E F G H I J K L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

abort(int) - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
abort(Session) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
AbstractClient - Class in io.fluxcapacitor.javaclient.configuration.client
Abstract base implementation of the Client interface, providing shared logic and lifecycle management for both local (in-memory) and remote (WebSocket-based) Flux clients.
AbstractClient() - Constructor for class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
 
AbstractConverter<I,O> - Class in io.fluxcapacitor.common.serialization
An abstract base class for converting data of type I to type O.
AbstractConverter() - Constructor for class io.fluxcapacitor.common.serialization.AbstractConverter
 
AbstractSerializer<I> - Class in io.fluxcapacitor.javaclient.common.serialization
Abstract base implementation of the Serializer interface.
AbstractSerializer(Collection<?>, Converter<byte[], I>, String) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Constructs a new serializer with the provided caster candidates and converter.
AbstractUserProvider - Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
Abstract base class for implementing UserProviders that resolve user identities via a metadata key.
AbstractUserProvider(Class<? extends User>) - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.authentication.AbstractUserProvider
Constructs an AbstractUserProvider using the default metadata key AbstractUserProvider.DEFAULT_USER_KEY.
AbstractWebsocketClient - Class in io.fluxcapacitor.javaclient.common.websocket
Abstract base class for all WebSocket-based clients in the Flux Capacitor Java client.
AbstractWebsocketClient(WebSocketContainer, URI, WebSocketClient, boolean, Duration, ObjectMapper, int) - Constructor for class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
Constructs a WebSocket client with fine-grained control over connection setup.
AbstractWebsocketClient(URI, WebSocketClient, boolean) - Constructor for class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
Creates a WebSocket client using the given endpoint URI, client implementation, and a flag to allow metrics.
AbstractWebsocketClient(URI, WebSocketClient, boolean, int) - Constructor for class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
Creates a WebSocket client with multiple parallel sessions using default settings.
AbstractWebsocketClient.PingRegistration - Class in io.fluxcapacitor.javaclient.common.websocket
 
AbstractWebsocketClient.WebSocketRequest - Class in io.fluxcapacitor.javaclient.common.websocket
 
accept() - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer0
 
accept(MessageType, String, List<SerializedMessage>) - Method in interface io.fluxcapacitor.javaclient.configuration.client.ClientDispatchMonitor
Called when a batch of messages is dispatched by the client.
accept(CacheEviction) - Method in class io.fluxcapacitor.javaclient.persisting.caching.CacheEvictionsLogger
Publishes the given cache eviction event to the configured metrics gateway.
accept(Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer1
 
accept(Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer2
 
accept(Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer3
 
accept(Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer4
 
accept(Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer5
 
accept(Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer6
 
accept(Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer7
 
accept(Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer8
 
accept(Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer9
 
accept(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Consumer10
 
accept(List<SerializedMessage>) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
accept(List<T>) - Method in interface io.fluxcapacitor.common.Backlog.BatchConsumer
 
accept(T) - Method in interface io.fluxcapacitor.common.ThrowingConsumer
Performs this operation on the given argument.
accept(T, U) - Method in interface io.fluxcapacitor.common.ThrowingBiConsumer
Performs this operation on the given arguments.
acceptCompression() - Method in class io.fluxcapacitor.javaclient.web.WebResponseCompressingInterceptor
Checks whether the current request accepts GZIP compression.
add(Collection<? extends T>) - Method in class io.fluxcapacitor.common.Backlog
Adds a collection of values to the backlog.
add(T...) - Method in class io.fluxcapacitor.common.Backlog
Adds values to the backlog.
addBatchInterceptor(BatchInterceptor, MessageType...) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
addBatchInterceptor(BatchInterceptor, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Registers a BatchInterceptor that applies to the given message types.
addConsumerConfiguration(ConsumerConfiguration, MessageType...) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
addConsumerConfiguration(ConsumerConfiguration, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a specific consumer configuration for one or more message types.
addDispatchInterceptor(DispatchInterceptor, boolean, MessageType...) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
addDispatchInterceptor(DispatchInterceptor, boolean, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a DispatchInterceptor for specified message types with optional priority.
addDispatchInterceptor(DispatchInterceptor, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a DispatchInterceptor that modifies or monitors message dispatch.
addHandlerDecorator(HandlerDecorator, boolean, MessageType...) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
addHandlerDecorator(HandlerDecorator, boolean, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a HandlerDecorator with control over priority.
addHandlerDecorator(HandlerDecorator, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a HandlerDecorator for the given message types.
addHandlerInterceptor(HandlerInterceptor, boolean, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a HandlerInterceptor with specified priority.
addHandlerInterceptor(HandlerInterceptor, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a HandlerInterceptor for given message types.
addIfAbsent(Object, Object) - Method in class io.fluxcapacitor.common.api.Metadata
Adds the specified key-value pair to the metadata if the key is not already present.
addIfAbsent(Map<?, ?>) - Method in class io.fluxcapacitor.common.api.Metadata
Adds all entries from the specified map to the current Metadata, ignoring keys that already exist.
addMetadata(Metadata) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Adds metadata to the index operation, merging with any previously set metadata.
addMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.common.Message
Returns a new message with the combined metadata.
addMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new schedule with additional metadata.
addMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
addMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
addMetadata(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Adds a single metadata key-value pair.
addMetadata(Object...) - Method in class io.fluxcapacitor.javaclient.common.Message
Adds multiple metadata entries.
addMetadata(Object...) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new schedule with multiple metadata entries added.
addMetadata(Object...) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
addMetadata(Object...) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
addMetadata(String, Object) - Method in class io.fluxcapacitor.javaclient.common.Message
Adds a single metadata entry.
addMetadata(String, Object) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new schedule with a single metadata entry added.
addMetadata(String, Object) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
addMetadata(String, Object) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
addMetadata(Map<String, ?>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Adds multiple metadata entries from a map.
addMetadata(Map<String, ?>) - Method in class io.fluxcapacitor.javaclient.common.Message
Adds metadata from a given map.
addMetadata(Map<String, ?>) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new schedule with all values from the given metadata map added.
addMetadata(Map<String, ?>) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
addMetadata(Map<String, ?>) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
addParameterResolver(ParameterResolver<? super DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
addParameterResolver(ParameterResolver<? super DeserializingMessage>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Registers a ParameterResolver to support injection of method arguments in handlers.
addPropertySource(PropertySource) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Adds a PropertySource to the configuration chain.
addToMetadata(Metadata, User) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Adds user-related metadata to a message, overwriting existing values if present.
addToMetadata(Metadata, User, boolean) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AbstractUserProvider
Adds a User to the metadata using the configured key.
addToMetadata(Metadata, User, boolean) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
addToMetadata(Metadata, User, boolean) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
 
addToMetadata(Metadata, User, boolean) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Adds user-related metadata to a message.
addUser(User) - Method in class io.fluxcapacitor.javaclient.common.Message
Attaches a user object to the metadata using the configured UserProvider.
addUser(User) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new schedule with a User added to the metadata using the configured UserProvider.
addUser(User) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
addUser(User) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
AdhocDispatchInterceptor - Class in io.fluxcapacitor.javaclient.publishing
A DispatchInterceptor that enables thread-local, dynamically scoped interceptors during message dispatch.
AdhocDispatchInterceptor() - Constructor for class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
 
adjustMaxSize(Tracker, int) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
Advanced Configuration - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Section
Advanced Use Case: Building a dynamic dead-letter queue - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Section
afterHandler() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Determines if the legality check should be performed immediately (the default), or when the current handler is done, i.e.: after @Apply and just before the aggregate updates are committed.
afterRetry(Throwable) - Method in class io.fluxcapacitor.common.RetryStatus
Produces a new RetryStatus based on this one, incrementing the retry count and updating the exception.
aggregate(String...) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch.DefaultGroupSearch
 
aggregate(String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.GroupSearch
Performs aggregation over the given fields for each group.
aggregate(String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Returns field statistics for one or more fields.
Aggregate - Annotation Interface in io.fluxcapacitor.javaclient.modeling
Marks a class as the root of an aggregate in the domain model.
AGGREGATE_ID_METADATA_KEY - Static variable in interface io.fluxcapacitor.javaclient.modeling.Entity
A constant key used for identifying the aggregate ID in metadata of events.
AGGREGATE_SN_METADATA_KEY - Static variable in interface io.fluxcapacitor.javaclient.modeling.Entity
A constant key used for identifying the sequence number of an applied event in metadata.
AGGREGATE_TYPE_METADATA_KEY - Static variable in interface io.fluxcapacitor.javaclient.modeling.Entity
A constant key used for identifying the aggregate type in metadata of events.
AggregateEventStream<T> - Class in io.fluxcapacitor.javaclient.persisting.eventsourcing
A wrapper around a stream of aggregate events, enriched with metadata such as the aggregate ID and the last known sequence number.
AggregateEventStream() - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
aggregateRepository() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns a client to assist with event sourcing.
aggregateRepository(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
AggregateRepository - Interface in io.fluxcapacitor.javaclient.persisting.repository
Repository interface for loading, managing, and repairing aggregates in Flux Capacitor.
AggregateRoot<T> - Interface in io.fluxcapacitor.javaclient.modeling
Represents the root of an aggregate in a domain model.
aggregateSelector(Class<?>) - Static method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
Utility predicate to match aggregates of a given root type.
ALGORITHM - Static variable in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
Alias - Annotation Interface in io.fluxcapacitor.javaclient.modeling
Annotation used on properties of an entity value that provide an alternative identifier to find the entity.
aliases() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
aliases() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves a collection of aliases associated with this entity.
aliases() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
aliases() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
aliases() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
aliveCheck() - Element in annotation interface io.fluxcapacitor.javaclient.web.SocketEndpoint
Configures the WebSocket session keep-alive mechanism (ping/pong).
all(Constraint...) - Static method in class io.fluxcapacitor.common.api.search.constraints.AllConstraint
Creates an AllConstraint from the given array of constraints.
all(Constraint...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Combines multiple constraints using a logical AND.
all(Collection<Constraint>) - Static method in class io.fluxcapacitor.common.api.search.constraints.AllConstraint
Creates an AllConstraint from the given collection of constraints.
AllConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A composite constraint that requires all inner constraints to match.
AllConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.AllConstraint
 
allEntities() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves a stream of all entities, including the current entity and all nested entities.
allMatch(Predicate<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleCommand
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleCustom
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleError
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleEvent
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleMessage
Optional list of payload types that are allowed for handler methods using this annotation.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleMetrics
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleNotification
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleQuery
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleResult
Restricts which payload types this handler may be invoked for.
allowedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleSchedule
Restricts which payload types this handler may be invoked for.
allowExternalMessages() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.LocalHandler
If true, this handler may also receive **externally published messages** (i.e. from other application instances).
alreadyFiltered(HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
 
always() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Returns whether the message matched by this handler should always be applied to any stored handlers.
ALWAYS - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublication
Always publish and/or store the applied update, even if it does not change the entity.
ALWAYS_HANDLE - Static variable in interface io.fluxcapacitor.common.handling.HandlerFilter
 
ancestors() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves a list of the ancestor entities for the current entity.
ancestorValue(Class<A>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the value of the first ancestor entity in the hierarchy that matches the specified type.
and(Constraint) - Method in interface io.fluxcapacitor.common.api.search.Constraint
Combines this constraint with another using logical AND.
and(HandlerFilter) - Method in interface io.fluxcapacitor.common.handling.HandlerFilter
Combines this filter with another using logical AND.
and(MessageFilter<? super M>) - Method in interface io.fluxcapacitor.common.handling.MessageFilter
Combines this filter with another using logical AND.
and(ThrowingPredicate<? super T>) - Method in interface io.fluxcapacitor.common.ThrowingPredicate
Returns a composed predicate that represents a short-circuiting logical AND of this predicate and another.
andFinally(HandlerInvoker) - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Composes this invoker with another to be invoked in a finally block.
andThen(ThrowingBiConsumer<? super T, ? super U>) - Method in interface io.fluxcapacitor.common.ThrowingBiConsumer
Returns a composed ThrowingBiConsumer that performs, in sequence, this operation followed by the after operation.
andThen(ThrowingConsumer<? super T>) - Method in interface io.fluxcapacitor.common.ThrowingConsumer
Returns a composed consumer that performs, in sequence, this operation followed by the after operation.
andThen(ThrowingFunction<? super R, ? extends V>) - Method in interface io.fluxcapacitor.common.ThrowingBiFunction
Returns a composed function that first applies this function to its input, and then applies the after function to the result.
andThen(ThrowingFunction<? super R, ? extends V>) - Method in interface io.fluxcapacitor.common.ThrowingFunction
Returns a composed function that first applies this function to its input, and then applies the after function to the result.
andThen(PropertySource) - Method in interface io.fluxcapacitor.common.application.PropertySource
Combines this property source with another, returning the first non-null value found between the two.
andThen(CorrelationDataProvider) - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Chains this provider with another, returning a composed provider that merges the metadata from both.
andThen(DispatchInterceptor) - Method in interface io.fluxcapacitor.javaclient.publishing.DispatchInterceptor
Chains this interceptor with another.
andThen(BatchInterceptor) - Method in interface io.fluxcapacitor.javaclient.tracking.BatchInterceptor
Composes this interceptor with another, returning a new interceptor that applies both in sequence.
andThen(UserProvider) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
andThen(UserProvider) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Combines this provider with another.
andThen(HandlerDecorator) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerDecorator
Chains this decorator with another, producing a composite decorator.
andThen(HandlerRegistry) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
Creates a composite registry that invokes both this and the given registry.
AnnotatedAggregateRepository(Class<T>) - Constructor for class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository.AnnotatedAggregateRepository
 
AnnotatedCaster<T> - Class in io.fluxcapacitor.javaclient.common.serialization.casting
Represents a dynamically discovered casting method (annotated with Upcast or Downcast) that is bound to a specific data revision and type.
AnnotatedCaster(Method, CastParameters, Function<SerializedObject<T>, Stream<SerializedObject<T>>>) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.casting.AnnotatedCaster
Creates a new AnnotatedCaster.
AnnotatedEntityHolder - Class in io.fluxcapacitor.javaclient.modeling
Helper class for Entity instances that manage nested entity relationships annotated with @Member.
any(Constraint...) - Static method in class io.fluxcapacitor.common.api.search.constraints.AnyConstraint
Creates an AnyConstraint from the given array of constraints.
any(Constraint...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Combines multiple constraints using a logical OR.
any(Collection<Constraint>) - Static method in class io.fluxcapacitor.common.api.search.constraints.AnyConstraint
Creates an AnyConstraint from the given collection of constraints.
ANY - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Matches any HTTP method (wildcard).
AnyConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A composite constraint that requires at least one inner constraint to match.
AnyConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.AnyConstraint
 
anyExist(String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Constrains the search to documents that have any of the given paths.
anyMatch(Predicate<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
append(ILoggingEvent) - Method in class io.fluxcapacitor.javaclient.common.logging.FluxCapacitorLogbackAppender
Processes log events of level WARN or higher.
append(SerializedMessage...) - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Appends the given messages to the store.
append(SerializedMessage...) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
append(Guarantee, SerializedMessage...) - Method in interface io.fluxcapacitor.javaclient.publishing.client.GatewayClient
Append the given messages to the gateway, applying the given delivery Guarantee.
append(Guarantee, SerializedMessage...) - Method in class io.fluxcapacitor.javaclient.publishing.client.WebsocketGatewayClient
 
append(Guarantee, SerializedMessage...) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
append(List<SerializedMessage>) - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Appends a list of messages to the store.
append(List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.CollectionMessageStore
 
append(List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
append(List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
Append - Class in io.fluxcapacitor.common.api.publishing
Command to publish messages to a specific log in Flux (e.g., commands, events, metrics, etc.).
Append() - Constructor for class io.fluxcapacitor.common.api.publishing.Append
 
Append.Metric - Class in io.fluxcapacitor.common.api.publishing
Metric payload used for internal monitoring and logging.
AppendEvents - Class in io.fluxcapacitor.common.api.eventsourcing
Command used to append one or more event batches to the event store.
AppendEvents() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.AppendEvents
 
AppendEvents.Metric - Class in io.fluxcapacitor.common.api.eventsourcing
Compact metric representation of an AppendEvents command.
ApplicationEnvironmentPropertiesSource - Class in io.fluxcapacitor.common.application
A PropertySource that loads environment-specific properties from an application-<env>.properties file on the classpath.
ApplicationEnvironmentPropertiesSource() - Constructor for class io.fluxcapacitor.common.application.ApplicationEnvironmentPropertiesSource
Constructs an ApplicationEnvironmentPropertiesSource based on the resolved environment.
ApplicationEnvironmentPropertiesSource(String) - Constructor for class io.fluxcapacitor.common.application.ApplicationEnvironmentPropertiesSource
Constructs an ApplicationEnvironmentPropertiesSource using the specified environment name.
applicationId() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the application ID under which this client instance is registered.
applicationId() - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
applicationId() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
applicationInstance - Static variable in interface io.fluxcapacitor.javaclient.FluxCapacitor
Flux Capacitor instance set by the current application.
ApplicationProperties - Class in io.fluxcapacitor.javaclient.configuration
Central utility for resolving configuration properties within a Flux application.
ApplicationProperties() - Constructor for class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
 
ApplicationPropertiesSource - Class in io.fluxcapacitor.common.application
A PropertySource implementation that loads properties from an application.properties file located on the classpath.
ApplicationPropertiesSource() - Constructor for class io.fluxcapacitor.common.application.ApplicationPropertiesSource
Constructs a new ApplicationPropertiesSource by loading the application.properties file from the classpath.
AppliedEvent - Class in io.fluxcapacitor.javaclient.modeling
Represents an event that has been applied to an aggregate along with its intended publication strategy.
AppliedEvent() - Constructor for class io.fluxcapacitor.javaclient.modeling.AppliedEvent
 
apply() - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function0
 
apply(MessageBatch, Tracker) - Method in interface io.fluxcapacitor.javaclient.tracking.MappingBatchInterceptor
Applies a transformation to the given MessageBatch, optionally modifying its contents or structure.
apply(ThrowingFunction<FluxCapacitor, R>) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Applies the given function with this Flux Capacitor set as current threadlocal instance.
apply(Message) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies the given message to the entity.
apply(Message) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
apply(Message) - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
apply(Message) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
apply(Message) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
apply(Message) - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
apply(Message) - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
apply(Message, boolean) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
apply(DeserializingMessage) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies the given deserializing message to the entity.
apply(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableAggregateRoot
 
apply(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
apply(Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function1
 
apply(Object) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Processes the given event and applies the corresponding logic based on its type.
apply(Object...) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies the given events to reconstruct or update the entity's state.
apply(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies an event and associated metadata to produce a resulting entity.
apply(Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function2
 
apply(Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function3
 
apply(Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function4
 
apply(Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function5
 
apply(Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function6
 
apply(Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function7
 
apply(Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function8
 
apply(Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function9
 
apply(Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface io.fluxcapacitor.common.reflection.DefaultMemberInvoker._Function10
 
apply(Collection<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies a collection of events to the current entity, returning an updated entity.
apply(Callable<T>) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.User
Executes a callable task with this user set as the current thread-local user.
apply(Function<DeserializingMessage, T>) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
apply(K) - Method in class io.fluxcapacitor.common.DefaultMemoizingFunction
 
apply(T) - Method in interface io.fluxcapacitor.common.ThrowingFunction
Applies this function to the given argument.
apply(T, U) - Method in class io.fluxcapacitor.common.DefaultMemoizingBiFunction
 
apply(T, U) - Method in interface io.fluxcapacitor.common.ThrowingBiFunction
Applies this function to the given arguments.
Apply - Annotation Interface in io.fluxcapacitor.javaclient.persisting.eventsourcing
Indicates that a method or constructor applies an update to an entity, or creates or deletes an entity.
applying - Static variable in interface io.fluxcapacitor.javaclient.modeling.Entity
 
applyInvoker(DeserializingMessage, Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.EntityHelper
Returns an invoker that can apply the given event to the provided entity.
applyInvoker(DeserializingMessage, Entity<?>, boolean) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
Finds a handler method annotated with @Apply and wraps it to preserve apply context flags.
applyInvoker(DeserializingMessage, Entity<?>, boolean) - Method in interface io.fluxcapacitor.javaclient.modeling.EntityHelper
Returns an invoker for applying the event to the entity, optionally checking nested entities.
as(Class<V>) - Method in class io.fluxcapacitor.javaclient.web.ParameterValue
Converts the underlying value to the specified target type.
AS_INTERMEDIATE - Enum constant in enum class io.fluxcapacitor.javaclient.common.serialization.UnknownTypeStrategy
 
asBytes(Object) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to a JSON byte array.
asCallable(ThrowingRunnable) - Static method in class io.fluxcapacitor.common.ObjectUtils
Converts a ThrowingRunnable into a Callable<Object> that returns null.
asCallable(Runnable) - Static method in class io.fluxcapacitor.common.ObjectUtils
Converts a standard Runnable into a Callable<Object> that returns null.
asClass(Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
asConstraint(Map<Object, String>) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultHandlerRepository
 
asConsumer(ThrowingConsumer<T>) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
asEntity(T) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns an Entity containing given value.
asEntity(T) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Wrap an existing aggregate instance into an Entity, initializing tracking and identity information.
asEntity(T) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
asEntity(T) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository
 
asFacets(Metadata) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
asFunction(ThrowingFunction<T, R>) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
asHeaderMap(Map<String, List<String>>) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Converts the input map into a case-insensitive header map.
asHttpRequest(SerializedMessage, URI, WebRequestSettings) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
asIdentifier(String, String) - Static method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
asInstance(Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
asIntegerOrString(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Attempts to convert a numeric string to an Integer, falling back to the original string otherwise.
asIntermediateValue(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Converts an object into its intermediate form (e.g., JsonNode) used for revision downcasting.
asIntermediateValue(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Converts the given object into a JsonNode for use in revision downcasting.
asInvoker(Member) - Static method in class io.fluxcapacitor.common.reflection.DefaultMemberInvoker
 
asInvoker(Member, boolean) - Static method in class io.fluxcapacitor.common.reflection.DefaultMemberInvoker
 
asJson(Object) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to a JSON string.
asKotlinFunction(Executable) - Static method in class io.fluxcapacitor.common.reflection.KotlinReflectionUtils
 
asKotlinParameter(Parameter) - Static method in class io.fluxcapacitor.common.reflection.KotlinReflectionUtils
 
asList(Map<Long, String>, Serializer) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
asMessage(Object) - Static method in class io.fluxcapacitor.javaclient.common.Message
Converts any object into a Message.
asMetadata(int, Map<String, List<String>>) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
Constructs a Metadata object containing the provided status code and headers.
asPredicate() - Method in interface io.fluxcapacitor.common.ThrowingPredicate
Converts this ThrowingPredicate into a standard Predicate.
asPrettyJson(Object) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to a formatted JSON string.
asPrimitive(Object) - Static method in class io.fluxcapacitor.common.SearchUtils
Converts any non-primitive value to its string form.
asProperties(String) - Static method in class io.fluxcapacitor.common.ObjectUtils
Parses Java Properties from a string.
asRunnable(ThrowingRunnable) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
asRunnable(Callable<?>) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
asSerializedMessage(SerializedDocument) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
assertAndApply(Object) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Verifies that the provided update is legal given the current state of the aggregate and on success applies it to the aggregate.
assertAndApply(Object) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
assertAndApply(Object) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
assertAndApply(Object...) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies a number of updates to the current entity after performing necessary legality assertions.
assertAndApply(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Verifies that the provided update is legal given the current state of the aggregate and on success applies it to the aggregate.
assertAndApply(Collection<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies a collection of updates sequentially to the current entity after asserting each is legal, and returns the resulting entity.
assertAuthorized(Class<?>, User) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Verifies whether the given user is authorized to issue the given payload, based on roles declared via annotations on the payload's class or package.
assertAuthorized(Class<?>, Executable, User) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Checks if the given user is authorized to invoke the given method on the given target.
assertAuthorized(String, User, ValidationUtils.RequiredRole[]) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
 
assertLegal(Object) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Verifies that the provided update is legal given the current state of the aggregate.
assertLegal(Object) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
assertLegal(Object) - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
assertLegal(Object) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
assertLegal(Object) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
assertLegal(Object) - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
assertLegal(Object) - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
assertLegal(Object, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
Performs a validation check using @AssertLegal handlers for the provided payload.
assertLegal(Object, Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.EntityHelper
Validates whether the given value results in a legal state transition for the specified entity.
AssertLegal - Annotation Interface in io.fluxcapacitor.javaclient.modeling
Annotation to mark methods or fields that assert whether a command or query is legal, given the current state of an aggregate.
assertValid(Object, Validator, Class<?>...) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Asserts that the object is valid using the given Validator and validation groups.
assertValid(Object, Class<?>...) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Asserts that the given object is valid, using the default Validator.
assertValid(T, Class<?>...) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.validation.Validator
Validates the given object and throws a ValidationException if it is invalid.
Association - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Declares how a message should be routed to a stateful handler instance (typically annotated with Stateful).
Association behavior with deferred commits - Search tag in io.fluxcapacitor.javaclient.tracking.handling.Stateful.commitInBatch()
Section
associations(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
 
associations(Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Determines the set of new associations (relationships) that are present in the current entity but not in the provided previous entity.
AssociationValue() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler.AssociationValue
 
asStream(Object) - Static method in class io.fluxcapacitor.common.ObjectUtils
Converts an object into a stream.
asString(Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Converts a Type to a readable string name.
asString(Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Returns a canonical string name for the given type.
asSupplier(Callable<T>) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
asWebResponse(Throwable) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
asWebResponse(HttpResponse<byte[]>) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
atLeast(Object, String) - Static method in class io.fluxcapacitor.common.api.search.constraints.BetweenConstraint
Creates a constraint that matches values in the given path that are greater than or equal to min.
atLeast(Number, String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds a lower-bound constraint for a field.
attach() - Static method in class io.fluxcapacitor.javaclient.common.logging.FluxCapacitorLogbackAppender
Attaches this appender to the root logger in the Logback logging context.
AuthenticatingInterceptor - Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
 
AuthenticatingInterceptor() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.authentication.AuthenticatingInterceptor
 
Authorization - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Section
Auto-Indexing - Search tag in exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Section
Automatic Error Reporting - Search tag in interface io.fluxcapacitor.javaclient.publishing.ErrorGateway
Section
Automatic Invocation Wrapping - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.Invocation
Section
Automatic Start - Search tag in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Section
autoStart() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Returns true if this periodic schedule should be automatically started if it's not already active.
available() - Method in class io.fluxcapacitor.common.LazyInputStream
 
awaitTermination(long, TimeUnit) - Method in class io.fluxcapacitor.common.DirectExecutorService
 

B

Backlog<T> - Class in io.fluxcapacitor.common
A thread-safe batching queue that asynchronously flushes its content to a consumer in configurable batch sizes.
Backlog(ThrowingFunction<List<T>, CompletableFuture<?>>) - Constructor for class io.fluxcapacitor.common.Backlog
 
Backlog(ThrowingFunction<List<T>, CompletableFuture<?>>, int) - Constructor for class io.fluxcapacitor.common.Backlog
 
Backlog(ThrowingFunction<List<T>, CompletableFuture<?>>, int, ErrorHandler<List<T>>) - Constructor for class io.fluxcapacitor.common.Backlog
 
Backlog.BatchConsumer<T> - Interface in io.fluxcapacitor.common
A function that consumes a batch of items and returns a future that completes when processing is done.
Basic Example - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Section
Batch-Aware Behavior - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
Section
BatchingHandlerRepository - Class in io.fluxcapacitor.javaclient.modeling
A batching wrapper for HandlerRepository that delays persistence operations until the end of the current message batch.
BatchingHandlerRepository() - Constructor for class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
BatchingHandlerRepository.Update - Class in io.fluxcapacitor.javaclient.modeling
Represents a buffered update to a handler instance (either index or delete).
BatchInterceptor - Interface in io.fluxcapacitor.javaclient.tracking
Intercepts and decorates batch-level message handling for a Tracker.
batchInterceptors() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Interceptors applied at the batch level across all messages in a poll cycle.
BatchProcessingException - Exception Class in io.fluxcapacitor.javaclient.tracking
Exception thrown during message batch processing to intentionally halt tracking after a specific message.
BatchProcessingException() - Constructor for exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Constructs the exception using the index of the currently handled message, if available.
BatchProcessingException(Long) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Constructs the exception with a specified message index.
BatchProcessingException(String) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Constructs the exception with a message and automatically determines the current message index.
BatchProcessingException(String, Long) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Constructs the exception with a message and a specified message index.
BatchProcessingException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Constructs the exception with a message, cause, and automatically determined message index.
BatchProcessingException(String, Throwable, Long) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Constructs the exception with a message, cause, and message index.
before(Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters documents with timestamps strictly before the given end time.
before(Instant, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
before(Instant, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters documents with timestamps before the given time.
beforeLast(Duration) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters out documents older than the given duration.
beforeShutdown(Runnable) - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
 
beforeShutdown(Runnable) - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Registers a shutdown hook that will be called before this client shuts down.
beforeShutdown(Runnable) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
beforeShutdown(Runnable) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Register a task to run before this Flux Capacitor instance is closed.
Behavior - Search tag in class io.fluxcapacitor.common.api.keyvalue.DeleteValue
Section
Behavior - Search tag in class io.fluxcapacitor.common.api.keyvalue.GetValue
Section
Behavior - Search tag in class io.fluxcapacitor.javaclient.publishing.routing.MessageRoutingInterceptor
Section
Behavior - Search tag in class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
Section
Behavior - Search tag in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
Section
Behavior - Search tag in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
Section
Behavior - Search tag in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
Section
Behavior - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.MutableHandler
Section
Behavior - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.errorreporting.ErrorReportingInterceptor
Section
below(Object, String) - Static method in class io.fluxcapacitor.common.api.search.constraints.BetweenConstraint
Creates a constraint that matches values in the given path that are less than maxExclusive.
below(Number, String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds an upper-bound constraint for a field.
between(Number, Number, String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds a numeric range constraint.
between(Object, Object, String) - Static method in class io.fluxcapacitor.common.api.search.constraints.BetweenConstraint
Creates a constraint that matches values in the given path that are greater than or equal to min and less than max.
BetweenConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A Constraint that filters documents based on whether a value in a specific path lies between two bounds.
BetweenConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.BetweenConstraint
 
body(Object) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
BOOLEAN - Enum constant in enum class io.fluxcapacitor.common.search.Document.EntryType
Represents boolean values: true or false.
BooleanResult - Class in io.fluxcapacitor.common.api
A generic response containing a boolean value, typically used to indicate success/failure.
BooleanResult() - Constructor for class io.fluxcapacitor.common.api.BooleanResult
 
BROTLI - Enum constant in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
 
build() - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
build() - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
build(Client) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
build(Client) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Builds the FluxCapacitor instance using the provided low-level Client.
builder() - Static method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
builder() - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Creates a new WebRequest.Builder instance for constructing a WebRequest.
builder() - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
Creates a new WebResponse.Builder instance for constructing WebResponse objects.
Builder() - Constructor for class io.fluxcapacitor.common.api.search.SearchQuery.Builder
 
Builder() - Constructor for class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
Builder(Metadata) - Constructor for class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
Builder(WebRequest) - Constructor for class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
Builder(WebResponse) - Constructor for class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
buildHandler(Object, HandlerConfiguration<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
buildUrl(WebSocketClient.ClientConfig, String) - Static method in class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
Constructs a base URL for a given service path, including query parameters derived from the given client config.
Built-in Implementations - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
Section
bulkUpdate(Collection<? extends BulkUpdate>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Applies a batch of document updates, using Guarantee.STORED.
bulkUpdate(Collection<? extends BulkUpdate>, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
bulkUpdate(Collection<? extends BulkUpdate>, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Applies a batch of document updates, using given Guarantee.
bulkUpdate(Collection<DocumentUpdate>, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
bulkUpdate(Collection<DocumentUpdate>, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Performs a batch update on a set of documents.
bulkUpdate(Collection<DocumentUpdate>, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
BulkUpdate - Interface in io.fluxcapacitor.common.api.search
Represents a single operation in a bulk document update.
BulkUpdate.Type - Enum Class in io.fluxcapacitor.common.api.search
Supported bulk operation types.
BulkUpdateDocuments - Class in io.fluxcapacitor.common.api.search
Command to perform a batch update of documents in the search/document store.
BulkUpdateDocuments() - Constructor for class io.fluxcapacitor.common.api.search.BulkUpdateDocuments
 
BulkUpdateDocuments.Metric - Class in io.fluxcapacitor.common.api.search
Metric representation for monitoring or observability.
ByteRange(long, long) - Constructor for record class io.fluxcapacitor.javaclient.web.StaticFileHandler.ByteRange
Creates an instance of a ByteRange record class.
bytes() - Method in class io.fluxcapacitor.common.api.search.SerializedDocument
Returns the number of bytes in the serialized representation of the document.

C

1. Creating a new entity from an @Apply method inside the update class - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Section
cache() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Default cache used for internal stateful optimizations (e.g. handler state, snapshots).
cache() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the cache used by the client to cache aggregates etc.
Cache - Interface in io.fluxcapacitor.javaclient.persisting.caching
A generic cache interface for storing and managing objects identified by unique keys.
cached() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Whether the aggregate should be cached after updates (enabled by default).
CacheEviction - Class in io.fluxcapacitor.javaclient.persisting.caching
Represents an eviction from a Cache.
CacheEviction() - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.CacheEviction
 
CacheEviction.Reason - Enum Class in io.fluxcapacitor.javaclient.persisting.caching
Indicates the cause for a cache entry eviction.
CacheEvictionEvent - Class in io.fluxcapacitor.javaclient.persisting.caching
Represents an eviction event from a Cache.
CacheEvictionEvent() - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.CacheEvictionEvent
 
CacheEvictionsLogger - Class in io.fluxcapacitor.javaclient.persisting.caching
Logs and publishes cache eviction events as metrics.
CacheEvictionsLogger() - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.CacheEvictionsLogger
 
cacheNewMessages(List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
CachingAggregateRepository - Class in io.fluxcapacitor.javaclient.persisting.repository
A wrapper around a delegate AggregateRepository that ensures cached aggregates stay in sync with the event log.
CachingAggregateRepository() - Constructor for class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
cachingDepth() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Controls how many versions of the aggregate should be retained in the cache.
CachingTrackingClient - Class in io.fluxcapacitor.javaclient.tracking.client
A TrackingClient implementation that wraps another client (typically a WebsocketTrackingClient) and caches recent messages in memory to reduce redundant round trips to the Flux platform.
CachingTrackingClient(WebsocketTrackingClient) - Constructor for class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
call(Callable<?>) - Static method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Wraps a Callable in a HandlerInvoker.
call(Callable<T>) - Static method in class io.fluxcapacitor.common.ObjectUtils
Calls the given callable, forcibly rethrowing exceptions.
cancel() - Method in interface io.fluxcapacitor.common.Registration
Cancels the resource or subscription associated with this registration.
cancel() - Method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
 
cancelAndDisconnect() - Method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
 
CancelPeriodic - Exception Class in io.fluxcapacitor.javaclient.scheduling
Exception used to cancel a periodic schedule from a schedule handler.
CancelPeriodic() - Constructor for exception class io.fluxcapacitor.javaclient.scheduling.CancelPeriodic
 
cancelSchedule(String) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Cancels the schedule with given scheduleId.
cancelSchedule(String) - Method in interface io.fluxcapacitor.javaclient.scheduling.client.SchedulingClient
Cancel a scheduled message using Guarantee.SENT as the default guarantee.
cancelSchedule(String) - Method in class io.fluxcapacitor.javaclient.scheduling.DefaultMessageScheduler
 
cancelSchedule(String) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Cancel a previously scheduled message or command by ID.
cancelSchedule(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
cancelSchedule(String, Guarantee) - Method in interface io.fluxcapacitor.javaclient.scheduling.client.SchedulingClient
Cancel a scheduled message using the provided delivery guarantee.
cancelSchedule(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.scheduling.client.WebsocketSchedulingClient
 
CancelSchedule - Class in io.fluxcapacitor.common.api.scheduling
Command to cancel a previously scheduled message using its CancelSchedule.scheduleId.
CancelSchedule() - Constructor for class io.fluxcapacitor.common.api.scheduling.CancelSchedule
 
canDeserialize(Data<byte[]>) - Method in enum class io.fluxcapacitor.common.search.DefaultDocumentSerializer
Checks whether the given Data object is in a format that this serializer can deserialize.
canHandle(SerializedMessage, int[]) - Method in interface io.fluxcapacitor.common.tracking.Tracker
Checks if the given message can be handled by this tracker based on segment range and type filtering.
canHandle(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
 
canHandle(DeserializingMessage, String) - Method in class io.fluxcapacitor.javaclient.tracking.Tracker
When the consumer is configured with ignoreSegment=true, segment filtering is performed client-side.
canHandle(M) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
canHandle(M) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.ObjectHandlerMatcher
 
canHandle(M) - Method in interface io.fluxcapacitor.common.handling.HandlerMatcher
Returns whether the given message can be handled by a handler instance of type T.
canTrackerHandle(DeserializingMessage, String) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
 
Capabilities - Search tag in class io.fluxcapacitor.common.handling.HandlerInspector
Section
cast(Stream<? extends I>) - Method in interface io.fluxcapacitor.javaclient.common.serialization.casting.Caster
Casts the given stream of input values to the output format using the default transformation rules.
cast(Stream<? extends I>, Integer) - Method in interface io.fluxcapacitor.javaclient.common.serialization.casting.Caster
Casts the given stream of input values to the output format, optionally considering a target revision.
cast(Stream<? extends S>, Integer) - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
cast(S) - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.AnnotatedCaster
Applies the casting logic to the given serialized object if its type and revision match this caster’s parameters.
Cast - Annotation Interface in io.fluxcapacitor.javaclient.common.serialization.casting
Meta-annotation that indicates a method performs a revision-based type transformation.
Caster<I,O> - Interface in io.fluxcapacitor.javaclient.common.serialization.casting
Functional interface representing a transformation from one stream of values to another, possibly adjusting for version compatibility or format changes.
CasterChain<I,O> - Interface in io.fluxcapacitor.javaclient.common.serialization.casting
A composite Caster that supports registration of multiple casting strategies.
CastInspector - Class in io.fluxcapacitor.javaclient.common.serialization.casting
Internal utility for inspecting and instantiating caster methods based on annotations such as Upcast or Downcast.
CastInspector() - Constructor for class io.fluxcapacitor.javaclient.common.serialization.casting.CastInspector
 
CastParameters - Class in io.fluxcapacitor.javaclient.common.serialization.casting
Represents metadata that uniquely identifies a version of a serialized data type, along with an optional delta indicating how the revision should change after casting.
CastParameters() - Constructor for class io.fluxcapacitor.javaclient.common.serialization.casting.CastParameters
 
catchUpIfNeeded() - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
ChaCha20Poly1305Encryption - Class in io.fluxcapacitor.common.encryption
Implementation of Encryption using the ChaCha20-Poly1305 authenticated encryption algorithm.
ChaCha20Poly1305Encryption() - Constructor for class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
ChaCha20Poly1305Encryption(String) - Constructor for class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
checkLegality(Object, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
Returns an exception if the value is illegal for the current entity, or Optional.empty() if legal.
checkLegality(Object, Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.EntityHelper
Checks if the given value would be considered legal for the specified entity.
checkPathBeforeEntry() - Method in class io.fluxcapacitor.common.api.search.constraints.BetweenConstraint
 
checkPathBeforeEntry() - Method in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
Determines whether path filtering should be performed before evaluating entry-level match criteria.
checkpointPeriod() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Sets the event checkpointing frequency for intermediate aggregate states.
checkValidity(Object, Validator, Class<?>...) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Checks whether the provided object is valid using the given Validator and validation groups.
checkValidity(Object, Class<?>...) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Checks whether the provided object is valid, using the default Validator and validation groups.
checkValidity(T, Class<?>...) - Method in class io.fluxcapacitor.javaclient.tracking.handling.validation.Jsr380Validator
 
checkValidity(T, Class<?>...) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.validation.Validator
Validates the given object and returns an optional ValidationException if the object is invalid.
Child Entities - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Section
chunked() - Method in interface io.fluxcapacitor.common.api.HasMetadata
Determines if the data associated with this metadata is "chunked".
claimSegment(Tracker) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
claimSegment(Tracker, PositionStore) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
claimSegment(Tracker, PositionStore) - Method in interface io.fluxcapacitor.common.tracking.TrackingStrategy
Claims one or more message segments for the given tracker.
claimSegment(String, Long, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
claimSegment(String, Long, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
claimSegment(String, Long, ConsumerConfiguration) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Claims a processing segment for the given tracker.
claimSegment(String, Long, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
ClaimSegment - Class in io.fluxcapacitor.common.api.tracking
A request to claim a message segment for consumption in client-controlled tracking mode.
ClaimSegment(Read) - Constructor for class io.fluxcapacitor.common.api.tracking.ClaimSegment
 
ClaimSegment(MessageType, String, String, long, boolean, String, boolean, Long, Long) - Constructor for class io.fluxcapacitor.common.api.tracking.ClaimSegment
 
ClaimSegmentResult - Class in io.fluxcapacitor.common.api.tracking
Result of a ClaimSegment request.
ClaimSegmentResult() - Constructor for class io.fluxcapacitor.common.api.tracking.ClaimSegmentResult
 
ClaimSegmentResult.Metric - Class in io.fluxcapacitor.common.api.tracking
Lightweight metric representation of a ClaimSegmentResult, used for telemetry.
classExists(String) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
classForName(String) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
classForName(String, Class<?>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
classpathPrefix - Static variable in class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
cleanUpOnClose(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
 
clear() - Method in class io.fluxcapacitor.common.DefaultMemoizingBiFunction
 
clear() - Method in class io.fluxcapacitor.common.DefaultMemoizingFunction
 
clear() - Method in class io.fluxcapacitor.common.DefaultMemoizingSupplier
 
clear() - Method in interface io.fluxcapacitor.common.MemoizingBiFunction
Clears all cached values.
clear() - Method in interface io.fluxcapacitor.common.MemoizingFunction
Removes all cached values from this function.
clear() - Method in interface io.fluxcapacitor.common.MemoizingSupplier
Clears the cached value, forcing the next call to recompute.
clear() - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Removes all entries from the cache.
clear() - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
clear() - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
clear() - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
clear() - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
clearHeader(String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
clearHeader(String) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
clearHeaders() - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
client() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the low level client used by this FluxCapacitor instance to interface with the Flux Capacitor service.
Client - Interface in io.fluxcapacitor.javaclient.configuration.client
Defines the low-level client contract used by FluxCapacitorBuilder to construct a FluxCapacitor instance.
ClientConfig() - Constructor for class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient.ClientConfig
 
clientControlledIndex() - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
clientControlledIndex() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
clientControlledIndex() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
If true, the consumer will not rely on Flux's internal tracking index.
ClientDispatchMonitor - Interface in io.fluxcapacitor.javaclient.configuration.client
Functional interface for monitoring the dispatch of messages by a Client.
ClientEvent - Interface in io.fluxcapacitor.common.api
Base interface for client lifecycle events such as ConnectEvent and DisconnectEvent.
clientId() - Method in record class io.fluxcapacitor.proxy.WebsocketEndpoint.SessionContext
Returns the value of the clientId record component.
Client Implementations - Search tag in interface io.fluxcapacitor.javaclient.configuration.client.Client
Section
ClientMessage() - Constructor for class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint.ClientMessage
 
ClientUtils - Class in io.fluxcapacitor.javaclient.common
Utility class offering client-side support functions for working with Flux Capacitor.
ClientUtils() - Constructor for class io.fluxcapacitor.javaclient.common.ClientUtils
 
clock() - Method in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
clock() - Method in interface io.fluxcapacitor.common.TaskScheduler
Returns the clock associated with this scheduler.
clock() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
clock() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Provides a central clock used throughout the system for timestamps and scheduling.
clock() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the clock used by Flux Capacitor to generate timestamps.
clone(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Creates a deep copy of the object.
clone(Object) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Creates a deep copy of the given object using serialization.
clone(Object) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
close() - Method in class io.fluxcapacitor.common.LazyInputStream
 
close() - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
close() - Method in class io.fluxcapacitor.common.tracking.InMemoryPositionStore
 
close() - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Default no-op close method.
close() - Method in interface io.fluxcapacitor.common.tracking.PositionStore
Closes any underlying resources held by the store.
close() - Method in interface io.fluxcapacitor.common.tracking.TrackingStrategy
Closes the tracking strategy and releases any underlying resources.
close() - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
close() - Method in class io.fluxcapacitor.javaclient.common.websocket.SessionPool
 
close() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Closes this Flux Capacitor instance gracefully.
close() - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Closes the cache and releases all associated resources.
close() - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
close() - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
close() - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
close() - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
close() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
close() - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Closes the client and releases any open resources or connections.
close() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.LocalEventStoreClient
 
close() - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.InMemoryKeyValueStore
 
close() - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.client.KeyValueClient
 
close() - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
close() - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Closes any underlying resources.
close() - Method in interface io.fluxcapacitor.javaclient.publishing.client.GatewayClient
Closes this gateway client, releasing any associated resources (e.g. network connections or background tasks).
close() - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Shuts down the command gateway.
close() - Method in class io.fluxcapacitor.javaclient.publishing.DefaultGenericGateway
 
close() - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
 
close() - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Closes this gateway and releases any underlying resources.
close() - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Gracefully shuts down this gateway and releases any held resources.
close() - Method in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
Releases all resources associated with this handler.
close() - Method in interface io.fluxcapacitor.javaclient.publishing.WebRequestGateway
Gracefully shuts down the gateway and releases any associated resources.
close() - Method in class io.fluxcapacitor.javaclient.scheduling.client.LocalSchedulingClient
 
close() - Method in interface io.fluxcapacitor.javaclient.scheduling.client.SchedulingClient
Closes this client and releases any underlying resources or tracking registrations.
close() - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
close() - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
close() - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
close() - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Closes any open resources associated with this client.
close() - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
close() - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
Shuts down all started trackers and waits briefly for asynchronous results (e.g. command responses) to complete.
close() - Method in interface io.fluxcapacitor.javaclient.tracking.Tracking
Closes the tracking process, releasing any resources held by it.
close() - Method in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
close() - Method in class io.fluxcapacitor.javaclient.web.OutputStreamCapturer
 
close() - Method in class io.fluxcapacitor.javaclient.web.PartialFileInputStream
 
close() - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Closes the WebSocket session using the default closing behavior.
close() - Method in class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
close() - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
close(boolean) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
close(boolean) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
close(boolean) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Closes this Flux Capacitor instance gracefully.
close(int) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Closes the WebSocket session using the specified close reason and a default guarantee of Guarantee.NONE.
close(int, Guarantee) - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
close(int, Guarantee) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Closes the WebSocket session with the specified close reason and delivery guarantee.
close(Guarantee) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Closes the WebSocket session with the specified guarantee for handling pending operations.
closeOnError(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
 
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
collect(Collector<? super T, A, R>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
collection() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Name of the collection to index the aggregate into.
collection() - Element in annotation interface io.fluxcapacitor.javaclient.persisting.search.Searchable
The name of the collection where instances of this class should be indexed.
collection() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Name of the collection in which the stateful handler instance will be stored.
collection(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Sets the collection into which the document should be indexed.
CollectionMessageStore - Class in io.fluxcapacitor.javaclient.persisting.search.client
A MessageStore implementation backed by a collection in an InMemorySearchStore.
CollectionMessageStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.search.client.CollectionMessageStore
 
Combining multiple registrations - Search tag in interface io.fluxcapacitor.common.Registration
Section
Command - Class in io.fluxcapacitor.common.api
Base class for commands sent to the Flux platform.
Command() - Constructor for class io.fluxcapacitor.common.api.Command
 
COMMAND - Enum constant in enum class io.fluxcapacitor.common.MessageType
A request to perform an action or change state.
commandGateway() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway for command messages.
commandGateway(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
CommandGateway - Interface in io.fluxcapacitor.javaclient.publishing
Gateway interface for publishing command messages in Flux Capacitor.
commit() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Commits the current state of the entity, persisting any changes made to it.
commit() - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
commit() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
commit() - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
commit() - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
commit() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
commit() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
commit(Entity<?>, List<AppliedEvent>, Entity<?>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository.AnnotatedAggregateRepository
 
commitInBatch() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Whether changes to the aggregate should be committed at the end of a message batch (enabled by default).
commitInBatch() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Determines whether the state changes to this handler should be committed at the end of the current message batch (if applicable), or immediately after the message that triggered the change (default behavior).
Commit Lifecycle - Search tag in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
Section
Common Usage - Search tag in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
Section
Common Use Cases: - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor
Section
comparator - Static variable in class io.fluxcapacitor.common.api.search.SortableEntry
Comparator used to lexicographically compare entries based on SortableEntry.name and SortableEntry.value.
comparator - Static variable in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
comparator - Static variable in interface io.fluxcapacitor.common.tracking.Tracker
Default comparator based on consumer name and tracker ID.
compareTo(FacetEntry) - Method in class io.fluxcapacitor.common.api.search.FacetEntry
Sorts facet entries by name, then by value.
compareTo(SortableEntry) - Method in class io.fluxcapacitor.common.api.search.SortableEntry
 
compareTo(Document.Entry) - Method in class io.fluxcapacitor.common.search.Document.Entry
Compares this entry with the specified entry for order.
compareTo(Tracker) - Method in interface io.fluxcapacitor.common.tracking.Tracker
Compares trackers based on consumer and tracker IDs for stable sorting.
CompleteMessageEvent - Class in io.fluxcapacitor.javaclient.tracking.metrics
 
CompleteMessageEvent() - Constructor for class io.fluxcapacitor.javaclient.tracking.metrics.CompleteMessageEvent
 
completeResults(long, Throwable) - Method in class io.fluxcapacitor.common.Backlog
 
Components - Search tag in class io.fluxcapacitor.common.search.Document
Section
Composability - Search tag in interface io.fluxcapacitor.common.api.search.Constraint
Section
compose(ThrowingFunction<? super V, ? extends T>) - Method in interface io.fluxcapacitor.common.ThrowingFunction
Returns a composed function that first applies the before function to its input, and then applies this function to the result.
compose(Function<? super K1, ? extends K>) - Method in interface io.fluxcapacitor.common.MemoizingFunction
Composes this memoizing function with another function.
compose(Function<? super K1, Map.Entry<? extends T, ? extends U>>) - Method in interface io.fluxcapacitor.common.MemoizingBiFunction
Creates a MemoizingFunction by composing this memoizing bi-function with an input transformation.
Composing Registries - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
Section
Composition - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerDecorator
Section
compress(byte[]) - Static method in class io.fluxcapacitor.common.serialization.compression.CompressionUtils
Compresses the given byte array using CompressionAlgorithm.LZ4 by default.
compress(byte[], CompressionAlgorithm) - Static method in class io.fluxcapacitor.common.serialization.compression.CompressionUtils
Compresses the given byte array using the specified compression algorithm.
compress(SerializedMessage) - Method in class io.fluxcapacitor.javaclient.web.WebResponseCompressingInterceptor
Applies GZIP compression to the response payload and updates the metadata to indicate the Content-Encoding used.
CompressionAlgorithm - Enum Class in io.fluxcapacitor.common.serialization.compression
Enumeration of supported compression algorithms used for serializing and deserializing byte data.
CompressionUtils - Class in io.fluxcapacitor.common.serialization.compression
Utility class for compressing and decompressing byte arrays using common compression algorithms.
CompressionUtils() - Constructor for class io.fluxcapacitor.common.serialization.compression.CompressionUtils
 
compute(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Computes and stores a new value for the given id using the provided function.
compute(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
Returns a synchronized computation that adds, removes, or updates a cache entry.
compute(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
compute(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
compute(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
compute(Stream<Document>, List<String>, List<String>) - Static method in class io.fluxcapacitor.common.api.search.DocumentStats
Computes document statistics from a stream of documents.
computeAliases() - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
computeClassForSpecificity() - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
computeContextIfAbsent(Class<T>, Function<DeserializingMessage, ? extends T>) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
computeEntities() - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
computeEntryMatcher() - Method in class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
 
computeForBatch(K, BiFunction<? super K, ? super V, ? extends V>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
computeForBatchIfAbsent(K, Function<? super K, ? extends V>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
computeId(Object) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler.StatefulHandlerInvoker
 
computeIfAbsent(Object, Function<? super Object, T>) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
If a value is not already associated with the given id, computes and stores one using the given function.
computeIfAbsent(Object, Function<? super Object, T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
computeIfAbsent(Object, Function<? super Object, T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
computeIfAbsent(Object, Function<? super Object, T>) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
computeIfAbsent(Object, Function<? super Object, T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
computeIfPresent(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
If a value is already associated with the given id, computes a new value using the provided function and replaces the old one.
computeIfPresent(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
computeIfPresent(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
computeIfPresent(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
computeIfPresent(Object, BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
computeMessageFilter() - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
computeParameterResolver(Parameter) - Method in class io.fluxcapacitor.javaclient.configuration.spring.SpringBeanParameterResolver
 
computePathFilter() - Method in class io.fluxcapacitor.common.api.search.SearchDocuments
Computes a path-level filter based on the SearchDocuments.pathFilters list.
computeRoutingKey() - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Computes the default routing key for this message.
computeSegment(String) - Static method in class io.fluxcapacitor.common.ConsistentHashing
Computes the segment for a given routing key using the default hash function and the default maximum segment size.
computeSegment(String, int) - Static method in class io.fluxcapacitor.common.ConsistentHashing
Computes the segment for a given routing key and maximum number of segments, using the default hash function.
computeSegment(String, Function<String, Integer>, int) - Static method in class io.fluxcapacitor.common.ConsistentHashing
Computes the segment using a custom hash function and max segment size.
concat(Stream<? extends T>...) - Static method in class io.fluxcapacitor.common.ObjectUtils
Concatenates multiple streams into a single flat stream.
concatenateUrlParts(String...) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Concatenates multiple segments of a URL, ensuring that: Double slashes in schemes like https:// are preserved Duplicate slashes between path segments are removed Null or empty segments are skipped
Condition() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnBean.Condition
 
Condition() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingBean.Condition
 
Condition() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingProperty.Condition
 
Condition() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnProperty.Condition
 
ConditionalOnBean - Annotation Interface in io.fluxcapacitor.javaclient.configuration.spring
Conditional that only matches when a bean of the specified type is present in the application context.
ConditionalOnBean.Condition - Class in io.fluxcapacitor.javaclient.configuration.spring
 
ConditionalOnMissingBean - Annotation Interface in io.fluxcapacitor.javaclient.configuration.spring
Conditional that only matches when a bean of the specified type is not present in the context.
ConditionalOnMissingBean.Condition - Class in io.fluxcapacitor.javaclient.configuration.spring
 
ConditionalOnMissingProperty - Annotation Interface in io.fluxcapacitor.javaclient.configuration.spring
Conditional that only matches when the specified property is either unset or blank.
ConditionalOnMissingProperty.Condition - Class in io.fluxcapacitor.javaclient.configuration.spring
 
ConditionalOnProperty - Annotation Interface in io.fluxcapacitor.javaclient.configuration.spring
Conditional that only matches when a specific property is set and matches a given pattern.
ConditionalOnProperty.Condition - Class in io.fluxcapacitor.javaclient.configuration.spring
 
configuration() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the FluxCapacitorConfiguration of this FluxCapacitor instance.
Configuration - Search tag in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
Section
configurations(Collection<Class<?>>) - Static method in class io.fluxcapacitor.javaclient.tracking.ConsumerConfiguration
Returns a stream of ConsumerConfigurations by inspecting the given handler classes and their packages.
configureDefaultConsumer(MessageType, UnaryOperator<ConsumerConfiguration>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
configureDefaultConsumer(MessageType, UnaryOperator<ConsumerConfiguration>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Update the default consumer configuration for the specified message type.
ConnectEvent - Class in io.fluxcapacitor.common.api
A platform-generated event that indicates a client has successfully connected to the Flux platform.
ConnectEvent() - Constructor for class io.fluxcapacitor.common.api.ConnectEvent
 
ConsistentHashing - Class in io.fluxcapacitor.common
Utility class for computing segment assignments using consistent hashing.
ConsistentHashing() - Constructor for class io.fluxcapacitor.common.ConsistentHashing
 
ConsoleError - Class in io.fluxcapacitor.javaclient.common.logging
A marker message type published to the Flux error gateway for error-level log entries.
ConsoleError() - Constructor for class io.fluxcapacitor.javaclient.common.logging.ConsoleError
 
ConsoleWarning - Class in io.fluxcapacitor.javaclient.common.logging
A marker message type published to the Flux error gateway for warning-level log entries.
ConsoleWarning() - Constructor for class io.fluxcapacitor.javaclient.common.logging.ConsoleWarning
 
constraint(Constraint...) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
constraint(Constraint...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds one or more custom constraints to the search using a logical AND.
Constraint - Interface in io.fluxcapacitor.common.api.search
Base interface for defining filter conditions (constraints) used in document search queries.
consumer() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Restricts the trigger to messages sent by specific consumer(s).
Consumer - Annotation Interface in io.fluxcapacitor.javaclient.tracking
Declares a Consumer within a Flux application.
ConsumerConfiguration - Class in io.fluxcapacitor.javaclient.tracking
Configuration class that defines how a message consumer behaves during message tracking and handler invocation.
ConsumerConfiguration() - Constructor for class io.fluxcapacitor.javaclient.tracking.ConsumerConfiguration
 
ConsumerEndpoint - Class in io.fluxcapacitor.testserver.websocket
 
ConsumerEndpoint(MessageStore, MessageType) - Constructor for class io.fluxcapacitor.testserver.websocket.ConsumerEndpoint
 
contains() - Element in annotation interface io.fluxcapacitor.common.serialization.RegisterType
Optional filters to determine which types should be registered based on name matching.
contains(Metadata) - Method in class io.fluxcapacitor.common.api.Metadata
Checks whether the current metadata contains all entries of the specified metadata.
contains(Tracker) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Checks if the tracker is part of this cluster.
contains(Object, Object) - Method in class io.fluxcapacitor.common.api.Metadata
Determines if the specified key-value pair exists within the data structure.
contains(String, boolean, boolean, boolean, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.ContainsConstraint
Create a constraint that optionally splits the input phrase into individual terms and combines the resulting constraints using AllConstraint.
contains(String, boolean, boolean, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.ContainsConstraint
Create a constraint that allows prefix and/or postfix matching of a given phrase.
contains(String, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.ContainsConstraint
Create a basic ContainsConstraint that checks if the given phrase exists anywhere in the entry, using default full-word matching (i.e., neither prefix nor postfix logic).
containsAnyKey(Object...) - Method in class io.fluxcapacitor.common.api.Metadata
Checks if the given keys are present in the internal entries.
ContainsConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A constraint that matches document entries containing the specified phrase, with optional wildcard-like flexibility.
ContainsConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.ContainsConstraint
 
containsKey(Object) - Method in class io.fluxcapacitor.common.api.Metadata
Checks if the specified key is present in the entries map.
containsKey(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Checks whether the cache contains an entry for the given id.
containsKey(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
containsKey(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
containsKey(Object) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
containsKey(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
containsProperty(String) - Method in interface io.fluxcapacitor.common.application.PropertySource
Checks if a property is defined.
containsProperty(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Returns true if a property with the given name exists.
containsUser(Metadata) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AbstractUserProvider
Returns true if the metadata contains a user entry under the configured key.
containsUser(Metadata) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
containsUser(Metadata) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
 
containsUser(Metadata) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Checks if the given metadata contains user information that can be resolved by this provider.
ContentFilter - Interface in io.fluxcapacitor.javaclient.common.serialization
Represents an interface for filtering content before it is passed to a specified viewer.
contentType(String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
contentType(String) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
continueOnError() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Returns true if the schedule should continue after an error.
convert(I) - Method in class io.fluxcapacitor.common.serialization.AbstractConverter
 
convert(Data<byte[]>) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
convert(Data<I>) - Method in class io.fluxcapacitor.common.serialization.AbstractConverter
 
convert(Data<I>) - Method in interface io.fluxcapacitor.common.serialization.Converter
Converts the given Data from input type I to output type O.
convert(Value, Class) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext.DefaultConverter
 
convert(Object, Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Converts the given object to the specified target type.
convert(Object, Type) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Converts a given object to another type using the serializer's object mapping rules.
convert(Object, Type) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
convert(Function<Stream<T>, Stream<O>>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
Transforms the underlying stream of events using a given stream converter function.
convertAnnotation(Annotation, Class<? extends T>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
Converter<I,O> - Interface in io.fluxcapacitor.common.serialization
Interface for converting Data objects from one format or representation to another.
convertFormat(Data<byte[]>) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
convertFormat(Data<I>) - Method in interface io.fluxcapacitor.common.serialization.Converter
Optionally converts the structure or format (e.g.: application/json) of the input data without modifying its core content.
convertIfKotlinClass(Object) - Static method in class io.fluxcapacitor.common.reflection.KotlinReflectionUtils
 
ConvertingRouter() - Constructor for class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext.ConvertingRouter
 
ConvertingSerializedObject(SerializedObject<I>, Converter<I, O>) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain.ConvertingSerializedObject
Constructs a ConvertingSerializedObject with deferred conversion.
convertValue(Object, TypeReference<T>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to an object of the given type.
convertValue(Object, Class<? extends T>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to an object of the given class.
convertValue(Object, Type) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to an object of the given type which may be a ParameterizedType or Class.
convertValue(Object, Function<TypeFactory, JavaType>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to an object of the given type.
cookie(HttpCookie) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
cookie(HttpCookie) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
COOKIE - Enum constant in enum class io.fluxcapacitor.javaclient.web.WebParameterSource
Cookies sent in the request
CookieParam - Annotation Interface in io.fluxcapacitor.javaclient.web
Injects the value of an HTTP cookie into a handler method parameter.
copy() - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultIndexOperation
 
copy() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Creates a deep copy of this operation, preserving all configured values.
copyFields(V, V) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
copyOf(Properties) - Static method in class io.fluxcapacitor.common.ObjectUtils
Creates a deep copy of a Properties instance.
Core Responsibilities - Search tag in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
Section
CorrelatingInterceptor - Class in io.fluxcapacitor.javaclient.publishing.correlation
A DispatchInterceptor that enriches outgoing messages with correlation metadata, enabling full traceability across message flows within Flux Capacitor.
CorrelatingInterceptor() - Constructor for class io.fluxcapacitor.javaclient.publishing.correlation.CorrelatingInterceptor
 
correlationDataProvider() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Returns the provider responsible for adding correlation data to outgoing messages.
correlationDataProvider() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the provider of correlation data for published messages.
CorrelationDataProvider - Interface in io.fluxcapacitor.javaclient.publishing.correlation
Strategy interface for extracting correlation metadata from the current context.
count() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
count() - Method in interface io.fluxcapacitor.javaclient.persisting.search.GroupSearch
Counts the number of documents in each group.
count() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Returns the number of matching documents.
counter - Static variable in class io.fluxcapacitor.javaclient.web.SocketRequest
Counter used to generate unique request IDs for new socket requests.
create(Object, Class<?>, List<ParameterResolver<? super DeserializingMessage>>, HandlerConfiguration<DeserializingMessage>) - Static method in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
 
create(Object, List<ParameterResolver<? super DeserializingMessage>>, HandlerConfiguration<DeserializingMessage>) - Static method in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
 
create(Collection<?>, Converter<BEFORE, INTERNAL>, boolean) - Static method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
create(Collection<?>, Class<T>, boolean) - Static method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
createAuditTrail(CreateAuditTrail) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
createAuditTrail(CreateAuditTrail) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Configures Flux to use a search collection as a searchable audit trail.
createAuditTrail(CreateAuditTrail) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
createAuditTrail(Object, Duration) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
createAuditTrail(Object, Duration) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Configures Flux to use a search collection as a searchable audit trail with the given retention time.
CreateAuditTrail - Class in io.fluxcapacitor.common.api.search
Command to configure to use a search collection as a searchable audit trail.
CreateAuditTrail() - Constructor for class io.fluxcapacitor.common.api.search.CreateAuditTrail
 
createComparator(SearchDocuments) - Static method in class io.fluxcapacitor.common.search.Document
Constructs a Comparator to sort documents based on the sorting options in SearchDocuments.
createConsumer(ConsumerConfiguration, List<Handler<DeserializingMessage>>) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
createDefault() - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.Jsr380Validator
 
createDefaultHandler(Object, Function<DeserializingMessage, ?>, HandlerConfiguration<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
createDowncaster(Collection<?>, Class<T>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
createEventStoreClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Subclasses must implement this method to return a EventStoreClient.
createEventStoreClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
createEventStoreClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
createGatewayClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Subclasses must implement this method to return a GatewayClient for the given message type and topic.
createGatewayClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
createGatewayClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
createHandler(Object, HandlerFilter, List<HandlerInterceptor>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
createHandler(Object, HandlerFilter, List<HandlerInterceptor>) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerFactory
Attempts to create a message handler for the given target object.
createHandler(Object, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.handling.HandlerInspector
Creates a Handler for the given target object and annotation type.
createHandler(Object, Class<? extends Annotation>, List<ParameterResolver<? super M>>) - Static method in class io.fluxcapacitor.common.handling.HandlerInspector
Creates a Handler backed by a target supplier and parameter resolvers.
createHandler(Object, List<ParameterResolver<? super M>>, HandlerConfiguration<? super M>) - Static method in class io.fluxcapacitor.common.handling.HandlerInspector
Creates a Handler backed by a target supplier and parameter resolvers.
createHandler(Function<M, ?>, Class<?>, List<ParameterResolver<? super M>>, HandlerConfiguration<? super M>) - Static method in class io.fluxcapacitor.common.handling.HandlerInspector
Creates a Handler backed by a target supplier and parameter resolvers.
createHandlerMatcher(Object, HandlerConfiguration<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
createKeyValueClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Subclasses must implement this method to return a KeyValueClient.
createKeyValueClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
createKeyValueClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
createRequest(SerializedMessage) - Method in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
createRequestGateway(Client, MessageType, String, RequestHandler, Map<MessageType, DispatchInterceptor>, Map<MessageType, HandlerDecorator>, List<ParameterResolver<? super DeserializingMessage>>, Function<Class<?>, HandlerRepository>, RepositoryProvider, ResponseMapper) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
createSchedulingClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Subclasses must implement this method to return a SchedulingClient.
createSchedulingClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
createSchedulingClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
createSearchClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Subclasses must implement this method to return a SearchClient.
createSearchClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
createSearchClient() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
createSummarizer(JacksonInverter) - Static method in class io.fluxcapacitor.common.search.JacksonInverter
 
createTasks(RequestBatch<?>, Session) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
createTrackingClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Subclasses must implement this method to return a TrackingClient for the given message type and topic.
createTrackingClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
createTrackingClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
createUpcaster(Collection<?>, Converter<BEFORE, INTERNAL>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
createUpcaster(Collection<?>, Class<T>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
createWebRequest(HttpServerExchange, byte[]) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
createWebsocketDeploymentInfo() - Static method in class io.fluxcapacitor.testserver.websocket.WebsocketDeploymentUtils
 
createWebsocketHandler() - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
cron() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Define a unix-like cron expression.
CronExpression - Class in io.fluxcapacitor.javaclient.scheduling
This provides cron support for java8 using java-time.
current - Static variable in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.User
Thread-local reference to the current user.
current - Static variable in class io.fluxcapacitor.javaclient.tracking.Tracker
Thread-local variable that holds the current tracker instance.
current() - Static method in class io.fluxcapacitor.javaclient.tracking.Tracker
Returns the current tracker instance, if any.
currentClock() - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Gets the clock of the current FluxCapacitor instance (obtained via FluxCapacitor.getOptionally()).
currentCorrelationData() - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Gets the current correlation data, which by default depends on the current Client, Tracker and DeserializingMessage
currentIdentityProvider() - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Fetches the configured identity provider used for both functional and technical IDs.
currentTime() - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Gets the time according to the current FluxCapacitor clock (obtained via FluxCapacitor.currentClock()).
CurrentUserParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
Resolves handler method parameters of type User.
CurrentUserParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.authentication.CurrentUserParameterResolver
 
CUSTOM - Enum constant in enum class io.fluxcapacitor.common.MessageType
A message from a custom message topic.
Custom configuration - Search tag in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Section
customConsumerConfigurations() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Provides custom consumer configurations per message type.
customGateway(String) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
customGateway(String) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway for given custom message topic.
Custom Implementations - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.validation.Validator
Section
Customization - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
Section
customize(FluxCapacitorBuilder) - Method in interface io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorCustomizer
 
customParameterResolvers() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Returns additional resolvers for injecting parameters into message handler methods.
⚠️ Caution: Limited Use Case - Search tag in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
Section

D

3. Deleting an entity - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Section
4. Defining apply methods inside the entity class - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Section
data() - Method in class io.fluxcapacitor.common.api.Data
Returns this instance (for SerializedObject compatibility).
data() - Method in class io.fluxcapacitor.common.api.SerializedMessage
 
data() - Method in interface io.fluxcapacitor.common.api.SerializedObject
Returns the serialized payload held by this object.
data() - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain.ConvertingSerializedObject
 
Data<T> - Class in io.fluxcapacitor.common.api
A generic container for holding a value along with serialization metadata such as type, revision, and format.
Data(Supplier<T>, String, int, String) - Constructor for class io.fluxcapacitor.common.api.Data
Constructs a Data instance with a Supplier to support lazy access.
Data(T, String, int) - Constructor for class io.fluxcapacitor.common.api.Data
Constructs a Data instance without a specific format (defaults to JSON).
Data(T, String, int, String) - Constructor for class io.fluxcapacitor.common.api.Data
Constructs a Data instance with a fixed value and full metadata.
DataProtectionInterceptor - Class in io.fluxcapacitor.javaclient.publishing.dataprotection
A DispatchInterceptor and HandlerInterceptor that supports secure transmission of sensitive data fields by removing them from the payload before dispatch and restoring them during handling.
DataProtectionInterceptor() - Constructor for class io.fluxcapacitor.javaclient.publishing.dataprotection.DataProtectionInterceptor
 
declaresField(Class<?>, String) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
decompose() - Method in interface io.fluxcapacitor.common.api.search.Constraint
Returns a version of this constraint with all composite constraints decomposed into their atomic elements.
decompress(byte[]) - Static method in class io.fluxcapacitor.common.serialization.compression.CompressionUtils
Decompresses the given byte array using CompressionAlgorithm.LZ4 by default.
decompress(byte[], CompressionAlgorithm) - Static method in class io.fluxcapacitor.common.serialization.compression.CompressionUtils
Decompresses the given byte array using the specified algorithm.
Decorator Chaining - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
Section
decrypt(String) - Method in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
decrypt(String) - Method in class io.fluxcapacitor.common.encryption.DefaultEncryption
 
decrypt(String) - Method in interface io.fluxcapacitor.common.encryption.Encryption
Decrypts the given encrypted value.
decrypt(String) - Method in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
 
DecryptingPropertySource - Class in io.fluxcapacitor.common.application
A PropertySource decorator that transparently decrypts encrypted property values.
DecryptingPropertySource(PropertySource) - Constructor for class io.fluxcapacitor.common.application.DecryptingPropertySource
Constructs a DecryptingPropertySource using a delegate and automatically resolves the encryption key from system or environment variables.
DecryptingPropertySource(PropertySource, Encryption) - Constructor for class io.fluxcapacitor.common.application.DecryptingPropertySource
Constructs a DecryptingPropertySource using an explicit Encryption strategy.
DecryptingPropertySource(PropertySource, String) - Constructor for class io.fluxcapacitor.common.application.DecryptingPropertySource
Constructs a DecryptingPropertySource using the given encryption key.
decryptValue(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Decrypts the given encrypted value using the configured Encryption strategy.
deduplicate(List<T>) - Static method in class io.fluxcapacitor.common.ObjectUtils
Deduplicates elements in the list, preserving the last occurrence.
deduplicate(List<T>, Function<T, ?>) - Static method in class io.fluxcapacitor.common.ObjectUtils
Deduplicates elements using a key extractor, preserving the last occurrence.
deduplicate(List<T>, Function<T, ?>, boolean) - Static method in class io.fluxcapacitor.common.ObjectUtils
Deduplicates elements using a key extractor, optionally keeping the first occurrence.
DEFAULT - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublication
Inherit the publication behavior from the parent context.
DEFAULT - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublicationStrategy
Inherit the strategy from the enclosing aggregate or global default.
DEFAULT - Static variable in interface io.fluxcapacitor.javaclient.common.serialization.MessageFormatter
The default formatter that returns the simple name of the payload class if deserialized, or the raw type string if not.
DEFAULT_PRIORITY - Static variable in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
 
DEFAULT_USER_KEY - Static variable in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AbstractUserProvider
Default key used in Metadata to store User objects.
DefaultAggregateRepository - Class in io.fluxcapacitor.javaclient.persisting.repository
Default implementation of the AggregateRepository interface.
DefaultAggregateRepository() - Constructor for class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository
 
DefaultAggregateRepository.AnnotatedAggregateRepository<T> - Class in io.fluxcapacitor.javaclient.persisting.repository
Aggregate-type-specific delegate used internally by DefaultAggregateRepository.
DefaultCache - Class in io.fluxcapacitor.javaclient.persisting.caching
Default implementation of the Cache interface using key-level synchronized access and soft references for value storage.
DefaultCache() - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
Constructs a cache with a default maximum size of 1,000,000 entries and no expiration.
DefaultCache(int) - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
Constructs a cache with a specified max size and no expiration.
DefaultCache(int, Duration) - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
Constructs a cache with specified size and expiration.
DefaultCache(int, Executor, Duration) - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
Constructs a cache with specified size, executor for eviction notifications and expiration.
DefaultCache(int, Executor, Duration, Duration, boolean) - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
Constructs a cache with full configuration of size, eviction executor, expiration delay, and expiration check frequency.
DefaultCache.CacheReference - Interface in io.fluxcapacitor.javaclient.persisting.caching
 
DefaultCache.HardCacheReference - Class in io.fluxcapacitor.javaclient.persisting.caching
 
DefaultCache.SoftCacheReference - Class in io.fluxcapacitor.javaclient.persisting.caching
 
DefaultCasterChain<T,S> - Class in io.fluxcapacitor.javaclient.common.serialization.casting
Default implementation of the CasterChain interface used for managing and applying casting operations— typically upcasting or downcasting—on SerializedObject instances.
DefaultCasterChain(Collection<?>, Class<T>, boolean) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
DefaultCasterChain.ConvertingSerializedObject<I,O> - Class in io.fluxcapacitor.javaclient.common.serialization.casting
A SerializedObject wrapper that applies a Converter to translate data from one format to another.
DefaultCasterChain.DataRevision - Class in io.fluxcapacitor.javaclient.common.serialization.casting
Represents a unique combination of serialized object type and revision, used as a key in the caster registry.
defaultclock - Static variable in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
DefaultCommandGateway - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the CommandGateway interface.
DefaultCommandGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultCommandGateway
 
defaultConsumerConfigurations() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Provides the default consumer configuration per message type.
DefaultConverter() - Constructor for class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext.DefaultConverter
 
DefaultCorrelationDataProvider - Enum Class in io.fluxcapacitor.javaclient.publishing.correlation
Default implementation of the CorrelationDataProvider interface.
defaultDelay - Static variable in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
DefaultDocumentSerializer - Enum Class in io.fluxcapacitor.common.search
Default serializer for Document instances in the Flux platform.
DefaultDocumentStore - Class in io.fluxcapacitor.javaclient.persisting.search
 
DefaultDocumentStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
DefaultDocumentStore.DefaultSearch - Class in io.fluxcapacitor.javaclient.persisting.search
 
DefaultDocumentStore.DefaultSearch.DefaultGroupSearch - Class in io.fluxcapacitor.javaclient.persisting.search
 
DefaultEncryption - Class in io.fluxcapacitor.common.encryption
Default implementation of the Encryption interface used in the Flux platform.
DefaultEncryption() - Constructor for class io.fluxcapacitor.common.encryption.DefaultEncryption
 
DefaultEntityHelper - Class in io.fluxcapacitor.javaclient.modeling
The DefaultEntityHelper provides the default implementation of the EntityHelper interface.
DefaultEntityHelper(List<ParameterResolver<? super DeserializingMessage>>, boolean) - Constructor for class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
Creates a new helper using the given parameter resolvers and configuration.
DefaultEntityHelper.DeserializingMessageWithEntity - Class in io.fluxcapacitor.javaclient.modeling
Decorates a DeserializingMessage with an associated entity.
DefaultEntityHelper.MessageWithEntity - Class in io.fluxcapacitor.javaclient.modeling
Wraps a message and its corresponding entity for use in interception or handler invocation.
DefaultErrorGateway - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the ErrorGateway interface.
DefaultErrorGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultErrorGateway
 
DefaultEventGateway - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the EventGateway interface.
DefaultEventGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultEventGateway
 
DefaultEventStore - Class in io.fluxcapacitor.javaclient.persisting.eventsourcing
Default implementation of the EventStore interface, providing mechanisms to store and retrieve events associated with aggregate instances.
DefaultEventStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultEventStore
 
defaultFetchSize - Static variable in interface io.fluxcapacitor.javaclient.persisting.search.Search
The default number of records to fetch in a single batch during search operations.
DefaultFluxCapacitor - Class in io.fluxcapacitor.javaclient.configuration
 
DefaultFluxCapacitor() - Constructor for class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
DefaultFluxCapacitor.Builder - Class in io.fluxcapacitor.javaclient.configuration
 
DefaultGenericGateway - Class in io.fluxcapacitor.javaclient.publishing
 
DefaultGenericGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultGenericGateway
 
DefaultGroupSearch() - Constructor for class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch.DefaultGroupSearch
 
DefaultHandler<M> - Class in io.fluxcapacitor.common.handling
Default implementation of the Handler interface.
DefaultHandler() - Constructor for class io.fluxcapacitor.common.handling.DefaultHandler
 
DefaultHandlerFactory - Class in io.fluxcapacitor.javaclient.tracking.handling
Default implementation of the HandlerFactory for creating message handlers based on reflection.
DefaultHandlerFactory(MessageType, HandlerDecorator, List<ParameterResolver<? super DeserializingMessage>>, Function<Class<?>, HandlerRepository>, RepositoryProvider) - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
DefaultHandlerRepository - Class in io.fluxcapacitor.javaclient.modeling
Default implementation of HandlerRepository, backed by a DocumentStore.
DefaultHandlerRepository(DocumentStore, String, Class<?>, Stateful) - Constructor for class io.fluxcapacitor.javaclient.modeling.DefaultHandlerRepository
 
defaultIdentityProvider - Static variable in interface io.fluxcapacitor.javaclient.common.IdentityProvider
The default identity provider, resolved using ServiceLoader, or falling back to UuidFactory.
Default Implementation - Search tag in interface io.fluxcapacitor.javaclient.common.serialization.MessageFormatter
Section
DefaultIndexOperation - Class in io.fluxcapacitor.javaclient.persisting.search
Default implementation of the IndexOperation interface.
DefaultIndexOperation(DocumentStore, Object) - Constructor for class io.fluxcapacitor.javaclient.persisting.search.DefaultIndexOperation
Constructs a new DefaultIndexOperation instance for managing document indexing.
DefaultKeyValueStore - Class in io.fluxcapacitor.javaclient.persisting.keyvalue
The default implementation of the KeyValueStore interface that provides operations for storing, retrieving, and deleting key-value pairs using a KeyValueClient and a Serializer.
DefaultKeyValueStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.keyvalue.DefaultKeyValueStore
 
DefaultMemberInvoker - Class in io.fluxcapacitor.common.reflection
Default implementation of MemberInvoker using high-performance method handle-based invocation.
DefaultMemberInvoker._Consumer0 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer1 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer10 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer2 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer3 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer4 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer5 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer6 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer7 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer8 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Consumer9 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function0 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function1 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function10 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function2 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function3 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function4 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function5 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function6 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function7 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function8 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemberInvoker._Function9 - Interface in io.fluxcapacitor.common.reflection
 
DefaultMemoizingBiFunction<T,U,R> - Class in io.fluxcapacitor.common
A default implementation of the MemoizingBiFunction interface that memoizes (caches) results of a BiFunction based on a pair of input arguments.
DefaultMemoizingBiFunction(BiFunction<T, U, R>) - Constructor for class io.fluxcapacitor.common.DefaultMemoizingBiFunction
 
DefaultMemoizingBiFunction(BiFunction<T, U, R>, Duration, Clock) - Constructor for class io.fluxcapacitor.common.DefaultMemoizingBiFunction
 
DefaultMemoizingFunction<K,V> - Class in io.fluxcapacitor.common
A default implementation of the MemoizingFunction interface that provides caching functionality for computed function results.
DefaultMemoizingFunction(Function<K, V>) - Constructor for class io.fluxcapacitor.common.DefaultMemoizingFunction
 
DefaultMemoizingSupplier<T> - Class in io.fluxcapacitor.common
A default implementation of the MemoizingSupplier interface that memoizes (caches) the result of a computation performed by a supplied Supplier.
DefaultMemoizingSupplier(Supplier<T>) - Constructor for class io.fluxcapacitor.common.DefaultMemoizingSupplier
 
DefaultMemoizingSupplier(Supplier<T>, Duration, Clock) - Constructor for class io.fluxcapacitor.common.DefaultMemoizingSupplier
 
DefaultMessageScheduler - Class in io.fluxcapacitor.javaclient.scheduling
Default implementation of the MessageScheduler interface.
DefaultMessageScheduler() - Constructor for class io.fluxcapacitor.javaclient.scheduling.DefaultMessageScheduler
 
DefaultMetricsGateway - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the MetricsGateway interface.
DefaultMetricsGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultMetricsGateway
 
DefaultMetricsLog - Class in io.fluxcapacitor.testserver.metrics
 
DefaultMetricsLog(MessageStore) - Constructor for class io.fluxcapacitor.testserver.metrics.DefaultMetricsLog
 
DefaultMetricsLog(MessageStore, ExecutorService) - Constructor for class io.fluxcapacitor.testserver.metrics.DefaultMetricsLog
 
defaultObjectMapper - Static variable in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Default JsonMapper instance used for JSON serialization and deserialization.
defaultObjectMapper - Static variable in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
DefaultPropertySource - Class in io.fluxcapacitor.common.application
A layered PropertySource implementation used as the default source for resolving application properties in a Flux application.
DefaultPropertySource() - Constructor for class io.fluxcapacitor.common.application.DefaultPropertySource
 
DefaultQueryGateway - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the QueryGateway interface.
DefaultQueryGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultQueryGateway
 
DefaultRepositoryProvider - Class in io.fluxcapacitor.javaclient.tracking.handling
A default implementation of the RepositoryProvider interface that uses a ConcurrentHashMap for each repository.
DefaultRepositoryProvider() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.DefaultRepositoryProvider
 
DefaultRequestHandler - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the RequestHandler interface.
DefaultRequestHandler(Client, MessageType) - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
Constructs a DefaultRequestHandler with the specified client and message type, and a default timeout of 200 seconds.
DefaultRequestHandler.ResponseCallback - Record Class in io.fluxcapacitor.javaclient.publishing
Encapsulates a callback mechanism to handle both intermediate and final responses when processing requests.
defaultResponseMapper() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Default response mapper used for converting handler return values into generic responses.
DefaultResponseMapper - Class in io.fluxcapacitor.javaclient.tracking.handling
A default implementation of the ResponseMapper interface that simply wraps the response in a Message
DefaultResponseMapper() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.DefaultResponseMapper
 
DefaultResultGateway - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the ResultGateway interface for sending response messages.
DefaultResultGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultResultGateway
 
Defaults - Search tag in class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
Section
DefaultSearch() - Constructor for class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
defaultSearchParameters - Static variable in class io.fluxcapacitor.javaclient.modeling.SearchParameters
Default instance with searchable=true, and no collection/timestamp configuration.
defaultSettings - Static variable in interface io.fluxcapacitor.javaclient.publishing.WebRequestGateway
Default request settings used when none are specified explicitly.
defaultSettings - Static variable in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
DefaultSnapshotStore - Class in io.fluxcapacitor.javaclient.persisting.eventsourcing
Default implementation of the SnapshotStore interface, responsible for managing snapshots of aggregate roots in an event-sourced system.
DefaultSnapshotStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultSnapshotStore
 
DefaultSocketSession - Class in io.fluxcapacitor.javaclient.web
Default implementation of a SocketSession for managing Flux WebSocket sessions.
DefaultSocketSession() - Constructor for class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
DefaultTracker - Class in io.fluxcapacitor.javaclient.tracking.client
A tracker keeps reading messages until it is stopped (generally only when the application is shut down).
DefaultTracking - Class in io.fluxcapacitor.javaclient.tracking
Default implementation of the Tracking interface that coordinates message tracking for a specific MessageType.
DefaultTracking() - Constructor for class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
DefaultTrackingStrategy - Class in io.fluxcapacitor.common.tracking
Streaming strategy that allows multiple clients to concurrently consume a message stream.
DefaultTrackingStrategy(MessageStore) - Constructor for class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
DefaultTrackingStrategy(MessageStore, TaskScheduler) - Constructor for class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
DefaultTrackingStrategy(MessageStore, TaskScheduler, int) - Constructor for class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
DefaultTrackingStrategy.WaitingTracker - Class in io.fluxcapacitor.common.tracking
 
DefaultTypeRegistry - Class in io.fluxcapacitor.common.serialization
 
DefaultTypeRegistry() - Constructor for class io.fluxcapacitor.common.serialization.DefaultTypeRegistry
 
DefaultTypeRegistry(List<String>) - Constructor for class io.fluxcapacitor.common.serialization.DefaultTypeRegistry
 
defaultUserProvider - Static variable in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Default UserProvider discovered via ServiceLoader.
defaultValidator - Static variable in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Returns the default Validator used for message validation.
DefaultWebRequestContext - Class in io.fluxcapacitor.javaclient.web
Default implementation of WebRequestContext that adapts a DeserializingMessage of type MessageType.WEBREQUEST to a Jooby-compatible Context.
DefaultWebRequestContext.ConvertingRouter - Class in io.fluxcapacitor.javaclient.web
 
DefaultWebRequestContext.DefaultConverter - Class in io.fluxcapacitor.javaclient.web
 
DefaultWebRequestContext.Wrapper<T> - Class in io.fluxcapacitor.javaclient.web
 
DefaultWebRequestGateway - Class in io.fluxcapacitor.javaclient.publishing
Default implementation of the WebRequestGateway interface that delegates requests to a configured GenericGateway.
DefaultWebRequestGateway() - Constructor for class io.fluxcapacitor.javaclient.publishing.DefaultWebRequestGateway
 
DefaultWebResponseMapper - Class in io.fluxcapacitor.javaclient.web
Default implementation of WebResponseMapper that converts handler return values into WebResponse objects.
DefaultWebResponseMapper() - Constructor for class io.fluxcapacitor.javaclient.web.DefaultWebResponseMapper
 
defaultWebSocketContainer - Static variable in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
DefaultWebSocketContainerProvider - Class in io.fluxcapacitor.javaclient.common.websocket
The default ContainerProvider used to create and manage websocket sessions with Flux Platform.
DefaultWebSocketContainerProvider() - Constructor for class io.fluxcapacitor.javaclient.common.websocket.DefaultWebSocketContainerProvider
 
defaultWriterBuilder() - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Creates a preconfigured builder for a JsonMapper for writing/serializing objects to JSON.
delay() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Returns the schedule delay in Periodic.timeUnit() units.
delayAfterError() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Returns the schedule delay in Periodic.timeUnit() units after handling of the last schedule gave rise to an exception.
delegate - Variable in class io.fluxcapacitor.common.handling.Handler.DelegatingHandler
 
delegate - Variable in class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
delegate - Variable in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
delegate - Variable in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
DelegatingClock - Class in io.fluxcapacitor.common
A concrete implementation of a Clock that delegates its method calls to another Clock instance, allowing runtime manipulation of the delegated clock.
DelegatingClock() - Constructor for class io.fluxcapacitor.common.DelegatingClock
 
DelegatingEntity<T> - Class in io.fluxcapacitor.javaclient.modeling
A base implementation of Entity that forwards all method calls to a delegated Entity instance.
DelegatingEntity(Entity<T>) - Constructor for class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
DelegatingHandler() - Constructor for class io.fluxcapacitor.common.handling.Handler.DelegatingHandler
 
DelegatingHandlerInvoker() - Constructor for class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
DelegatingUserProvider - Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
An extendable UserProvider that delegates to another UserProvider.
DelegatingUserProvider() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
delete - Enum constant in enum class io.fluxcapacitor.common.api.search.BulkUpdate.Type
 
delete() - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
delete() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Deletes all matching documents in the current search.
delete(SearchQuery, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
delete(SearchQuery, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Deletes documents matching a given query.
delete(SearchQuery, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
delete(Object) - Method in class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
delete(Object) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultHandlerRepository
 
delete(Object) - Method in interface io.fluxcapacitor.javaclient.modeling.HandlerRepository
Removes the handler instance identified by the given ID from the repository.
delete(Object) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository.AnnotatedAggregateRepository
 
delete(String) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.DefaultKeyValueStore
 
delete(String) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.KeyValueStore
Removes the value associated with the given key.
delete(String) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Creates a new WebRequest.Builder instance for constructing a DELETE request to given url.
delete(String, String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
delete(String, String, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Deletes a document by its unique id and collection name.
delete(String, String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
DELETE - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
deleteAggregate(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Deletes the persisted state for an aggregate, including its events or document and relationships.
deleteAggregate(Object) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
deleteAggregate(Object) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository
 
deleteCollection(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Deletes a search collection if it exists.
deleteCollection(Object) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
deleteCollection(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Deletes an entire collection of documents.
deleteCollection(String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Deletes an entire document collection and all its contents.
deleteCollection(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
deleteCollection(String, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Deletes an entire document collection and all its contents.
deleteCollection(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
DeleteCollection - Class in io.fluxcapacitor.common.api.search
Command to delete an entire search collection, removing all documents within it.
DeleteCollection() - Constructor for class io.fluxcapacitor.common.api.search.DeleteCollection
 
deleteDocument(Object, Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Deletes the document with given id in given collection if it exists.
deleteDocument(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
deleteDocument(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Deletes a document from the collection.
DeleteDocument - Class in io.fluxcapacitor.common.api.search.bulkupdate
A bulk update operation that deletes a document from a given collection using its ID.
DeleteDocument() - Constructor for class io.fluxcapacitor.common.api.search.bulkupdate.DeleteDocument
 
DeleteDocumentById - Class in io.fluxcapacitor.common.api.search
Command to delete a single document from the search store by its collection and ID.
DeleteDocumentById() - Constructor for class io.fluxcapacitor.common.api.search.DeleteDocumentById
 
DeleteDocuments - Class in io.fluxcapacitor.common.api.search
Command to delete documents from the search store based on a search query.
DeleteDocuments() - Constructor for class io.fluxcapacitor.common.api.search.DeleteDocuments
 
deleteEvents(String) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Deletes all events for a specific aggregate.
deleteEvents(String, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Deletes all events for a specific aggregate with a given delivery guarantee.
deleteEvents(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
deleteEvents(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Sends a delete command for the event stream of the specified aggregate.
DeleteEvents - Class in io.fluxcapacitor.common.api.eventsourcing
Command to permanently delete all events associated with a specific aggregate ID.
DeleteEvents() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.DeleteEvents
 
deleteSnapshot(Object) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultSnapshotStore
 
deleteSnapshot(Object) - Method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoOpSnapshotStore
 
deleteSnapshot(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.SnapshotStore
Deletes the snapshot for the specified aggregate ID.
deleteValue(String) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.client.KeyValueClient
Deletes the value associated with the given key.
deleteValue(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.InMemoryKeyValueStore
 
deleteValue(String, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.client.KeyValueClient
Deletes the value associated with the given key.
deleteValue(String, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.WebsocketKeyValueClient
 
DeleteValue - Class in io.fluxcapacitor.common.api.keyvalue
Command to delete a value from the legacy key-value store by key.
DeleteValue() - Constructor for class io.fluxcapacitor.common.api.keyvalue.DeleteValue
 
Deleting a stateful handler - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Section
deploy(Function<String, Endpoint>, String, PathHandler) - Static method in class io.fluxcapacitor.testserver.websocket.WebsocketDeploymentUtils
 
deployFromSession(MemoizingFunction<Session, Endpoint>, String, PathHandler) - Static method in class io.fluxcapacitor.testserver.websocket.WebsocketDeploymentUtils
 
depth() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Calculates the depth level of the current entity in the aggregate.
DeserializationException - Exception Class in io.fluxcapacitor.javaclient.common.serialization
Thrown to indicate that a problem occurred during the deserialization of data.
DeserializationException() - Constructor for exception class io.fluxcapacitor.javaclient.common.serialization.DeserializationException
 
DeserializationException(String) - Constructor for exception class io.fluxcapacitor.javaclient.common.serialization.DeserializationException
 
DeserializationException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.common.serialization.DeserializationException
 
deserialize(byte) - Static method in enum class io.fluxcapacitor.common.search.Document.EntryType
Deserializes a byte into an Document.EntryType enum instance.
deserialize(Data<byte[]>) - Method in enum class io.fluxcapacitor.common.search.DefaultDocumentSerializer
Deserializes a Data blob containing a compressed, binary Document.
deserialize(SerializedObject<byte[]>) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Upcasts and deserializes the given Data object to an object of type T.
deserialize(SerializedObject<byte[]>, Class<T>) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Upcasts and deserializes the given Data object to an object of type T.
deserialize(Type) - Method in class io.fluxcapacitor.javaclient.web.SocketResponse
Deserializes the SocketResponse.result JSON node into an object of the given type.
deserialize(Stream<I>, UnknownTypeStrategy) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Upcasts and deserializes a stream of serialized objects.
deserialize(Stream<I>, UnknownTypeStrategy) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
deserialize(Stream<S>, UnknownTypeStrategy) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Deserializes a stream of SerializedObject values into deserialized objects.
deserializeDocument() - Method in class io.fluxcapacitor.common.api.search.SerializedDocument
Returns the deserialized document view.
deserializeMessage(SerializedMessage, MessageType) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Deserializes a single SerializedMessage into a DeserializingMessage.
deserializeMessages(Stream<SerializedMessage>, MessageType) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Deserializes a stream of SerializedMessage into DeserializingMessage instances with the specified MessageType.
deserializeMessages(Stream<SerializedMessage>, MessageType, UnknownTypeStrategy) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Deserializes a stream of SerializedMessage into DeserializingMessage instances with the specified MessageType.
deserializeMessages(Stream<SerializedMessage>, MessageType, String) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Deserializes a stream of SerializedMessage into DeserializingMessage instances with the specified MessageType.
deserializeMessages(Stream<SerializedMessage>, MessageType, String, UnknownTypeStrategy) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Deserializes a stream of SerializedMessage into DeserializingMessage instances with the specified MessageType.
deserializeOtherFormat(SerializedObject<byte[]>) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Handles deserialization of objects in formats other than the current default (e.g., fallback string deserialization).
deserializeRequest(Session, byte[]) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
deserializeUnknownType(SerializedObject<?>) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Hook for handling deserialization of unknown types.
deserializeUnknownType(SerializedObject<?>) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Fallback handler for deserialization of unknown types.
DeserializingMessage - Class in io.fluxcapacitor.javaclient.common.serialization
Wrapper for a Message that supports lazy deserialization, context caching, type adaptation, and batch-level execution utilities.
DeserializingMessage(SerializedMessage, Function<Type, Object>, MessageType, String, Serializer) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
DeserializingMessage(Message, MessageType, Serializer) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
DeserializingMessage(Message, MessageType, String, Serializer) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
DeserializingMessage(DeserializingMessage) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
DeserializingMessage(DeserializingObject<byte[], SerializedMessage>, MessageType, String, Serializer) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
DeserializingMessage.MessageSpliterator - Class in io.fluxcapacitor.javaclient.common.serialization
 
DeserializingMessageParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling
Resolves handler method parameters of type DeserializingMessage.
DeserializingMessageParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.DeserializingMessageParameterResolver
 
DeserializingMessageWithEntity(DeserializingMessage, Entity<?>) - Constructor for class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper.DeserializingMessageWithEntity
 
DeserializingObject<T,S> - Class in io.fluxcapacitor.javaclient.common.serialization
A wrapper around a SerializedObject that supports lazy deserialization of its payload.
DeserializingObject(S, Function<Type, Object>) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Creates a new DeserializingObject with the given serialized representation and deserializer function.
Design Notes - Search tag in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
Section
detach() - Static method in class io.fluxcapacitor.javaclient.common.logging.FluxCapacitorLogbackAppender
Detaches any active instances of this appender from the root logger.
detach(Route.Handler) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
determineCollection(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Resolves a given collection specifier to a collection name, using ClientUtils.determineSearchCollection(java.lang.Object).
determineCommonAncestors(Collection<?>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
determineSearchCollection(Object) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Determines the collection name used for document indexing and search based on the annotated handler or document type.
determinesSpecificity() - Method in interface io.fluxcapacitor.common.handling.ParameterResolver
Indicates whether this resolver contributes to determining handler method specificity when multiple handler candidates are available.
determinesSpecificity() - Method in class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
Indicates that this resolver contributes to disambiguating handler methods when multiple handlers are present in the same target class.
determinesSpecificity() - Method in class io.fluxcapacitor.javaclient.tracking.handling.PayloadParameterResolver
Indicates that this resolver contributes to disambiguating handler methods when multiple handlers are present in the same target class.
DirectExecutorService - Class in io.fluxcapacitor.common
A simple implementation of AbstractExecutorService that executes tasks directly in the calling thread without using any worker threads.
DirectExecutorService() - Constructor for class io.fluxcapacitor.common.DirectExecutorService
 
disableAdhocDispatchInterceptor() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableAdhocDispatchInterceptor() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables support for dynamically injected dispatch interceptors.
disableAutomaticAggregateCaching() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableAutomaticAggregateCaching() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables automatic caching of aggregates.
disableCacheEvictionMetrics() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableCacheEvictionMetrics() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables metrics related to cache eviction.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleCommand
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleCustom
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleDocument
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleError
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleEvent
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleMetrics
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleNotification
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleQuery
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleResult
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleSchedule
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleDelete
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleGet
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleHead
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleOptions
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePatch
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePost
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePut
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketClose
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketHandshake
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketMessage
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketOpen
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketPong
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleTrace
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleWeb
If true, disables this handler during discovery.
disabled() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleWebResponse
If true, disables this handler during discovery.
DISABLED - Static variable in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Special expression that can be used to disable automatic periodic scheduling if passed to Periodic.cron().
disableDataProtection() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableDataProtection() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables security filtering based on @FilterContent.
disableErrorReporting() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableErrorReporting() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables automatic error reporting (e.g., via ErrorGateway).
disableJsonIgnore(ObjectMapper) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Disables any Jackson @JsonIgnore behavior on the specified ObjectMapper.
disableMessageCorrelation() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableMessageCorrelation() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables automatic message correlation.
DisableMetrics - Class in io.fluxcapacitor.javaclient.tracking.metrics
Interceptor that disables the dispatch of outbound MessageType.METRICS messages.
DisableMetrics() - Constructor for class io.fluxcapacitor.javaclient.tracking.metrics.DisableMetrics
 
disablePayloadValidation() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disablePayloadValidation() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables payload validation.
disableScheduledCommandHandler() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableScheduledCommandHandler() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Prevents installation of the default scheduled command handler.
disableShutdownHook() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableShutdownHook() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Prevents registration of a shutdown hook.
disableTrackingMetrics() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableTrackingMetrics() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables tracking of processing metrics.
disableWebResponseCompression() - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
disableWebResponseCompression() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Disables compression for web responses.
Disabling All Adhoc Interceptors - Search tag in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Section
DisconnectEvent - Class in io.fluxcapacitor.common.api
A platform-generated event that indicates a client has disconnected from the Flux platform.
DisconnectEvent() - Constructor for class io.fluxcapacitor.common.api.DisconnectEvent
 
disconnectTracker(String, String, boolean) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Disconnects the specified tracker from its segment and optionally sends an empty final batch.
disconnectTracker(String, String, boolean, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
disconnectTracker(String, String, boolean, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
disconnectTracker(String, String, boolean, Guarantee) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Disconnects the specified tracker from its segment with the specified delivery guarantee.
disconnectTracker(String, String, boolean, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
DisconnectTracker - Class in io.fluxcapacitor.common.api.tracking
Command used to explicitly disconnect a tracker from the Flux platform and release any claimed message segments.
DisconnectTracker() - Constructor for class io.fluxcapacitor.common.api.tracking.DisconnectTracker
 
disconnectTrackers(Predicate<Tracker>, boolean) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
disconnectTrackers(Predicate<Tracker>, boolean) - Method in interface io.fluxcapacitor.common.tracking.TrackingStrategy
Disconnects trackers that match the provided filter.
dispatch(Runnable) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
dispatch(Executor, Runnable) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
DispatchInterceptor - Interface in io.fluxcapacitor.javaclient.publishing
Mechanism that enables modification, monitoring, or conditional suppression of messages before they are dispatched to local handlers or published to the Flux platform.
dissociations(Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Identifies and returns the set of relationships that are dissociated when compared to the relationships of the given previous entity.
distinct() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
distinctByKey(Function<? super T, ?>) - Static method in class io.fluxcapacitor.common.ObjectUtils
Returns a predicate that filters out duplicates based on a key extractor.
doBuild(Map<MessageType, ? extends Tracking>, Function<String, ? extends GenericGateway>, CommandGateway, QueryGateway, EventGateway, ResultGateway, ErrorGateway, MetricsGateway, WebRequestGateway, AggregateRepository, SnapshotStore, EventStore, KeyValueStore, DocumentStore, MessageScheduler, UserProvider, Cache, Serializer, CorrelationDataProvider, IdentityProvider, PropertySource, DelegatingClock, TaskScheduler, Client, ThrowingRunnable) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
doClone(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Hook to clone a deserialized object.
doClone(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Performs a field-level clone by copying values from the original object into a new instance of the same type.
doConvert(Object, Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Converts a deserialized object to the desired target type.
doConvert(Object, Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Converts an object into another type using Jackson’s ObjectMapper.
Document - Class in io.fluxcapacitor.common.search
Represents a structured, searchable, and indexable document within a Flux Capacitor collection.
Document() - Constructor for class io.fluxcapacitor.common.search.Document
 
DOCUMENT - Enum constant in enum class io.fluxcapacitor.common.MessageType
A message containing an updated search document from a given collection.
DOCUMENT_FORMAT - Static variable in class io.fluxcapacitor.common.api.Data
Custom format identifier for document data used in SerializedDocument.
Document.Entry - Class in io.fluxcapacitor.common.search
Represents a typed field value within a document (e.g. text, number, boolean).
Document.EntryType - Enum Class in io.fluxcapacitor.common.search
Enumerates the supported types of values that can appear in a Document entry.
Document.Path - Class in io.fluxcapacitor.common.search
Represents a navigable field access path for a Document entry.
documentClass() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleDocument
Optional class of the documents to handle.
documentExists(HasDocument) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
documentExists(HasDocument) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Checks whether a document with the given criteria exists.
documentExists(HasDocument) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
DocumentHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator.DocumentHandler
 
DocumentHandlerDecorator - Class in io.fluxcapacitor.javaclient.tracking.handling
A HandlerDecorator that intercepts handler methods annotated with HandleDocument and synchronizes their return values with a DocumentStore.
DocumentHandlerDecorator() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator
 
DocumentHandlerDecorator.DocumentHandler - Class in io.fluxcapacitor.javaclient.tracking.handling
 
DocumentHandlerDecorator.DocumentHandler.DocumentHandlerInvoker - Class in io.fluxcapacitor.javaclient.tracking.handling
 
DocumentHandlerInvoker(HandlerInvoker, String, DeserializingMessage) - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator.DocumentHandler.DocumentHandlerInvoker
 
documentSerializer() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Returns the serializer used to store and retrieve documents in the DocumentStore.
DocumentSerializer - Interface in io.fluxcapacitor.javaclient.persisting.search
Interface for converting domain objects to and from SerializedDocument instances for indexing and searching.
DocumentStats - Class in io.fluxcapacitor.common.api.search
Represents aggregate statistics for a group of documents, including values for specified fields.
DocumentStats() - Constructor for class io.fluxcapacitor.common.api.search.DocumentStats
 
DocumentStats.FieldStats - Class in io.fluxcapacitor.common.api.search
Statistical summary for a single document field.
documentStore() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns a client for the document search service offered by Flux Capacitor.
documentStore(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
DocumentStore - Interface in io.fluxcapacitor.javaclient.persisting.search
Interface for storing, updating, and querying documents in the Flux Capacitor platform.
DocumentStoreException - Exception Class in io.fluxcapacitor.javaclient.persisting.search
This class represents an exception that is thrown by the DocumentStore when a document store operation fails.
DocumentStoreException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.persisting.search.DocumentStoreException
 
Document Tracking Semantics - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleDocument
Section
DocumentUpdate - Class in io.fluxcapacitor.common.api.search
Represents a single low-level document update operation to be applied to a search collection.
DocumentUpdate() - Constructor for class io.fluxcapacitor.common.api.search.DocumentUpdate
 
doDeserialize(Data<?>, String) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Core method to deserialize the given Data with an explicit type hint.
doDeserialize(Data<?>, String) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Deserializes a Data instance into an object of the given type using the Jackson object mapper.
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class io.fluxcapacitor.proxy.WebsocketFilter
 
doSendResult(Session, RequestResult) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
doSerialize(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Hook for serializing the object to bytes using the primary format.
doSerialize(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Serializes the object to a JSON byte array.
downcast(Data<?>, int) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Downcasts an object already in Data form.
downcast(Data<?>, int) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Downcasts a Data object to the specified revision level.
downcast(Data<?>, int) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Downcasts a Data object to the specified revision level.
downcast(Data<?>, int) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
downcast(Object, int) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Downcasts a deserialized object to the desired revision number.
downcast(Object, int) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Downcasts the given object to a previous revision.
downcast(Object, int) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Downcasts the given object to a previous revision.
downcast(Object, int) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
Downcast - Annotation Interface in io.fluxcapacitor.javaclient.common.serialization.casting
Declares a method that transforms an object from a newer revision to an older one.
DropProtectedData - Annotation Interface in io.fluxcapacitor.javaclient.publishing.dataprotection
Indicates that a message handler method or constructor is the final usage point for protected data.
dropWhile(Predicate<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
durationUnit() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer

E

3. Expand a bulk update into individual operations - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.InterceptApply
Section
empty() - Static method in class io.fluxcapacitor.common.api.Metadata
Creates an empty instance of the Metadata class with no entries.
EMPTY_ARRAY - Enum constant in enum class io.fluxcapacitor.common.search.Document.EntryType
Represents empty arrays (e.g., []).
EMPTY_OBJECT - Enum constant in enum class io.fluxcapacitor.common.search.Document.EntryType
Represents empty objects (e.g., {}).
EMPTY_PATH - Static variable in class io.fluxcapacitor.common.search.Document.Path
Singleton instance representing an empty path.
emptyHeaderMap() - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Returns a new case-insensitive header map, with keys compared ignoring case.
emptyRange - Static variable in class io.fluxcapacitor.common.tracking.TrackerCluster
Shared constant representing an empty segment range.
emptyReturnMessage() - Method in class io.fluxcapacitor.javaclient.publishing.DefaultGenericGateway
 
enableHandshake(Handler<DeserializingMessage>, List<WebPattern>) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
 
encoding - Variable in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
 
encrypt(String) - Method in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
encrypt(String) - Method in class io.fluxcapacitor.common.encryption.DefaultEncryption
 
encrypt(String) - Method in interface io.fluxcapacitor.common.encryption.Encryption
Encrypts the given plain-text value using the configured encryption algorithm and key.
encrypt(String) - Method in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
 
Encryption - Interface in io.fluxcapacitor.common.encryption
Defines a contract for encrypting and decrypting sensitive values within the system.
encryptValue(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Encrypts the given value using the configured Encryption strategy.
end() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Returns the configured end timestamp for this operation.
end() - Method in record class io.fluxcapacitor.javaclient.web.StaticFileHandler.ByteRange
Returns the value of the end record component.
end(Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Sets the end time for the document (e.g., used in range queries or versioning).
endPath() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Optional path to extract an end timestamp for search indexing.
endPath() - Element in annotation interface io.fluxcapacitor.javaclient.persisting.search.Searchable
A path expression used to extract an optional end timestamp from the object.
endPath() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Optional path to extract an end timestamp for search indexing.
ensureAccessible(T) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
ensureMessageSegment(SerializedMessage) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
ensureStarted() - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
 
ensureStarted() - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
entities() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
entities() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves child entities of this entity.
entities() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
entities() - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
entities() - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
entities() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
Entity<T> - Interface in io.fluxcapacitor.javaclient.modeling
Represents an entity that encapsulates domain behavior and state.
EntityHelper - Interface in io.fluxcapacitor.javaclient.modeling
Strategy interface for handling domain entity operations such as applying updates, validating state transitions, and intercepting updates.
EntityId - Annotation Interface in io.fluxcapacitor.javaclient.modeling
Marks a property (field or getter) as the unique identifier of an entity within an aggregate structure.
EntityParameterResolver - Class in io.fluxcapacitor.javaclient.modeling
Resolves handler method parameters that reference an Entity or the entity's value.
EntityParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
 
Entry<T> - Interface in io.fluxcapacitor.javaclient.common
Represents a key-value pair with a string-based identifier.
Entry() - Constructor for class io.fluxcapacitor.common.search.Document.Entry
 
entrySet() - Method in class io.fluxcapacitor.common.api.Metadata
Returns a set view of the mappings contained in this metadata object.
EnvironmentVariablesSource - Enum Class in io.fluxcapacitor.common.application
A PropertySource that resolves property values from system environment variables.
equals(Object) - Method in class io.fluxcapacitor.common.api.Data
 
equals(Object) - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
equals(Object) - Method in class io.fluxcapacitor.common.tracking.WebSocketTracker
 
equals(Object) - Method in class io.fluxcapacitor.javaclient.modeling.Id
 
equals(Object) - Method in record class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler.ResponseCallback
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in record class io.fluxcapacitor.javaclient.web.StaticFileHandler.ByteRange
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in record class io.fluxcapacitor.proxy.WebsocketEndpoint.SessionContext
Indicates whether some other object is "equal to" this one.
error(long, String) - Static method in class io.fluxcapacitor.javaclient.web.SocketResponse
Creates a SocketResponse representing a failed request.
ERROR - Enum constant in enum class io.fluxcapacitor.common.MessageType
A handler failure in response to a request message or generic system failure.
errorGateway() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway for any error messages published while handling a command or query.
errorGateway(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
ErrorGateway - Interface in io.fluxcapacitor.javaclient.publishing
Gateway interface for reporting errors during message handling.
errorHandler() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Error handler invoked when a message processing error occurs.
ErrorHandler<T> - Interface in io.fluxcapacitor.common
Functional interface for handling errors during tasks.
ErrorHandler - Interface in io.fluxcapacitor.javaclient.tracking
An interface to handle errors encountered during message tracking and processing, with the ability to retry operations.
Error Handling - Search tag in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Section
Error Handling - Search tag in class io.fluxcapacitor.common.api.ResultBatch
Section
ErrorReportingInterceptor - Class in io.fluxcapacitor.javaclient.tracking.handling.errorreporting
HandlerInterceptor that reports exceptions to the configured ErrorGateway.
ErrorReportingInterceptor() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.errorreporting.ErrorReportingInterceptor
 
ErrorResult - Class in io.fluxcapacitor.common.api
A generic error response returned when a request could not be completed successfully.
ErrorResult() - Constructor for class io.fluxcapacitor.common.api.ErrorResult
 
escapeFieldName(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Escapes slashes and quotes in field names for safe indexing.
EVENT - Enum constant in enum class io.fluxcapacitor.common.MessageType
A record of something that occurred.
EventBatch - Class in io.fluxcapacitor.common.api.eventsourcing
Represents a batch of serialized events for a specific aggregate.
EventBatch() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.EventBatch
 
EventBatch.Metric - Class in io.fluxcapacitor.common.api.eventsourcing
A compact metric representation of an EventBatch, used in AppendEvents.Metric.
eventGateway() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the message gateway for application events.
eventGateway(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
EventGateway - Interface in io.fluxcapacitor.javaclient.publishing
Gateway for publishing event messages to Flux Capacitor.
eventPublication() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Controls whether updates that don’t change the aggregate result in events.
eventPublication() - Element in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Controls whether the update should result in a published update, depending on whether the entity was actually modified.
EventPublication - Enum Class in io.fluxcapacitor.javaclient.modeling
Controls whether an applied update should result in event publication.
EventPublicationStrategy - Enum Class in io.fluxcapacitor.javaclient.modeling
Strategy for controlling how applied updates (typically from @Apply methods) are handled in terms of storage and publication.
eventSourced() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Whether the aggregate should use event sourcing (enabled by default).
eventSourceModel(Entity<T>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository.AnnotatedAggregateRepository
 
EventSourcingEndpoint - Class in io.fluxcapacitor.testserver.websocket
 
EventSourcingEndpoint() - Constructor for class io.fluxcapacitor.testserver.websocket.EventSourcingEndpoint
 
EventSourcingException - Exception Class in io.fluxcapacitor.javaclient.persisting.eventsourcing
Thrown when an event sourcing operation fails.
EventSourcingException(String) - Constructor for exception class io.fluxcapacitor.javaclient.persisting.eventsourcing.EventSourcingException
Constructs a new EventSourcingException with the specified detail message.
EventSourcingException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.persisting.eventsourcing.EventSourcingException
Constructs a new EventSourcingException with the specified detail message and cause.
eventSourcingPath() - Static method in class io.fluxcapacitor.common.ServicePathBuilder
Returns the service path for the event sourcing subsystem.
eventSourcingUrl(WebSocketClient.ClientConfig) - Static method in class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
Constructs the URL for accessing the event sourcing stream.
eventStore() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the store for aggregate events.
EventStore - Interface in io.fluxcapacitor.javaclient.persisting.eventsourcing
High-level abstraction for accessing and storing domain events in an event-sourced system.
EventStoreClient - Interface in io.fluxcapacitor.javaclient.persisting.eventsourcing.client
Low-level client interface for interacting with the event store in Flux Capacitor.
Example - Search tag in annotation interface io.fluxcapacitor.common.serialization.Revision
Section
Example - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
Example - Search tag in annotation interface io.fluxcapacitor.javaclient.publishing.dataprotection.DropProtectedData
Section
Example - Search tag in annotation interface io.fluxcapacitor.javaclient.publishing.dataprotection.ProtectData
Section
Example - Search tag in class io.fluxcapacitor.common.api.eventsourcing.GetEvents
Section
Example - Search tag in class io.fluxcapacitor.javaclient.publishing.correlation.CorrelatingInterceptor
Section
Example - Search tag in class io.fluxcapacitor.javaclient.publishing.dataprotection.DataProtectionInterceptor
Section
Example - Search tag in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
Section
Example - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
Section
Example - Search tag in class io.fluxcapacitor.javaclient.web.WebParameterProcessor
Section
Example - Search tag in exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Section
Example - Search tag in interface io.fluxcapacitor.common.api.HasId
Section
Example - Search tag in interface io.fluxcapacitor.common.serialization.TypeRegistry
Section
Example - Search tag in interface io.fluxcapacitor.javaclient.configuration.client.ClientDispatchMonitor
Section
Example - Search tag in interface io.fluxcapacitor.javaclient.tracking.BatchInterceptor
Section
Example - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.Request
Section
Example - Search tag in io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage.getOptionally()
Section
Example: - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Section
Example: - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleEvent
Section
Example: - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleNotification
Section
Example: - Search tag in annotation interface io.fluxcapacitor.javaclient.web.CookieParam
Section
Example: - Search tag in annotation interface io.fluxcapacitor.javaclient.web.HeaderParam
Section
Example: - Search tag in annotation interface io.fluxcapacitor.javaclient.web.PathParam
Section
Example: - Search tag in annotation interface io.fluxcapacitor.javaclient.web.QueryParam
Section
Example: - Search tag in class io.fluxcapacitor.common.application.ApplicationEnvironmentPropertiesSource
Section
Example: - Search tag in class io.fluxcapacitor.common.application.SystemPropertiesSource
Section
Example: - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerDecorator
Section
Example: - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor
Section
Example: Associating by field - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Section
Example: Dynamic continuation using payload return - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleSchedule
Section
Example: Fast local query handling - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.LocalHandler
Section
Example: Handling a result with access to the triggering command - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Section
Example: Method-level association - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Section
Example: Preventing admin users from handling a message - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.ForbidsAnyRole
Section
Example: Retrying failed commands using a consumer-specific trigger - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Section
Example: Return a delay for the next schedule - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleSchedule
Section
Example: Schedule Every 5 Minutes - Search tag in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Section
Example: Validate entity does exist - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
Example: Validate entity does not exist yet - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
Example: Weekly Schedule via Cron - Search tag in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Section
Example (on handler method): - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresAnyRole
Section
Example (on payload class): - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresAnyRole
Section
Example application.properties: - Search tag in class io.fluxcapacitor.common.application.ApplicationPropertiesSource
Section
Example Output - Search tag in class io.fluxcapacitor.javaclient.common.UuidFactory
Section
Examples - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Section
Examples - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.InterceptApply
Section
Examples - Search tag in annotation interface io.fluxcapacitor.javaclient.web.Path
Section
Examples - Search tag in class io.fluxcapacitor.common.ServicePathBuilder
Section
Examples - Search tag in class io.fluxcapacitor.common.api.search.constraints.BetweenConstraint
Section
Examples - Search tag in class io.fluxcapacitor.common.api.search.constraints.ExistsConstraint
Section
Examples - Search tag in class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
Section
Examples - Search tag in class io.fluxcapacitor.common.search.Document.Path
Section
Examples - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Section
Examples - Search tag in interface io.fluxcapacitor.common.api.JsonType
Section
Examples: - Search tag in annotation interface io.fluxcapacitor.javaclient.web.FormParam
Section
Example usage - Search tag in enum class io.fluxcapacitor.common.application.EnvironmentVariablesSource
Section
Example usage - Search tag in interface io.fluxcapacitor.common.Monitored
Section
Example Usage - Search tag in class io.fluxcapacitor.common.serialization.JsonUtils
Section
Example Usage - Search tag in class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
Section
Example Usage - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator
Section
Example Usage - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.PayloadFilter
Section
Example Usage - Search tag in class io.fluxcapacitor.javaclient.tracking.metrics.DisableMetrics
Section
Example Usage - Search tag in class io.fluxcapacitor.javaclient.web.WebRequest
Section
Example Usage - Search tag in interface io.fluxcapacitor.javaclient.common.IdentityProvider
Section
Example Usage - Search tag in interface io.fluxcapacitor.javaclient.tracking.MappingBatchInterceptor
Section
Example Use Cases - Search tag in class io.fluxcapacitor.common.api.search.SortableEntry
Section
Exception Behavior - Search tag in class io.fluxcapacitor.common.api.ErrorResult
Section
exclude(String...) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
exclude(String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Excludes specific fields from the returned documents.
excludedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Returns payload classes for which this association is active.
excludeMetadata() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Returns whether metadata properties of messages should be checked for possible association with a stored handler.
exclusive() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Determines whether handlers assigned to this consumer are excluded from other consumers.
execute(ThrowingConsumer<FluxCapacitor>) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Executes the given task with this Flux Capacitor set as current threadlocal instance.
execute(Runnable) - Method in class io.fluxcapacitor.common.DirectExecutorService
 
executeExpiredTasks() - Method in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
executeExpiredTasks() - Method in interface io.fluxcapacitor.common.TaskScheduler
Executes any scheduled tasks that are due according to the scheduler's current time.
executeExpiredTasksAsync() - Method in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
executeRequest(HttpRequest) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
Execution timing - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
exists(String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.ExistsConstraint
Creates a constraint that checks for the presence of any of the given paths.
ExistsConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A Constraint that checks whether one or more paths exist in a document.
ExistsConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.ExistsConstraint
 
expectResult() - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker
 
expectResult() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
expectResult() - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Indicates whether the handler method has a return value.
expectResult() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.SimpleInvoker
 
expiry - Enum constant in enum class io.fluxcapacitor.javaclient.persisting.caching.CacheEviction.Reason
The entry expired due to time-based eviction policy.
Extensibility - Search tag in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
Section
extension - Variable in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
 
External source integration - Search tag in class io.fluxcapacitor.common.api.tracking.ClaimSegment
Section
extractBeanClass(BeanDefinition) - Method in class io.fluxcapacitor.javaclient.configuration.spring.TrackSelfPostProcessor
Extracts the target class from the scanned BeanDefinition.
extractPathParameters(String) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Extracts all named path parameters from the given path.

F

Facet - Annotation Interface in io.fluxcapacitor.common.search
Marker annotation on fields and methods that indicates that a property is to be used as facet when indexing a document for search.
FacetConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A constraint that matches documents containing a specific FacetEntry.
FacetConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.FacetConstraint
 
FacetEntry - Class in io.fluxcapacitor.common.api.search
Represents a single facet field-value pair within a document.
FacetEntry() - Constructor for class io.fluxcapacitor.common.api.search.FacetEntry
 
facetStats() - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
facetStats() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Returns facet statistics for the current search.
FacetStats - Class in io.fluxcapacitor.common.api.search
Represents the count of documents matching a specific facet value.
FacetStats() - Constructor for class io.fluxcapacitor.common.api.search.FacetStats
 
FAIL - Enum constant in enum class io.fluxcapacitor.javaclient.common.serialization.UnknownTypeStrategy
 
fallbackFile() - Element in annotation interface io.fluxcapacitor.javaclient.web.ServeStatic
Optional fallback file to serve if a requested resource is not found.
Fallback pattern with multiple handlers - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.ForbidsAnyRole
Section
Fallback to ANY Method - Search tag in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
Section
Fallback to Flux Platform - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
Section
fallsInRange(int, int[]) - Static method in class io.fluxcapacitor.common.ConsistentHashing
Checks if a given segment index falls within a specified segment range.
fallsInRange(String, int[]) - Static method in class io.fluxcapacitor.common.ConsistentHashing
Checks if the segment computed from the routing key falls within the specified segment range.
fallsInRange(String, int[], int) - Static method in class io.fluxcapacitor.common.ConsistentHashing
Same as ConsistentHashing.fallsInRange(String, int[]), but uses a custom max segment size.
Features - Search tag in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
Section
Features - Search tag in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
Section
Features - Search tag in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
Section
fetch(int) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
fetch(int) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches up to the given number of matching documents and deserializes them to the stored type.
fetch(int, Class<T>) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
fetch(int, Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches up to the given number of documents and deserializes them to the specified type.
fetch(GetDocument) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
fetch(GetDocument) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Fetches a single serialized document matching the given request.
fetch(GetDocument) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
fetch(Long) - Method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
 
fetchAll() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches all matching documents and deserializes each to its stored type.
fetchAll(Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches all matching documents and deserializes them to the specified type.
fetchDocument(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
fetchDocument(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Fetches a document by ID and deserializes it into the stored type.
fetchDocument(Object, Object, Class<T>) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
fetchDocument(Object, Object, Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Fetches a document by ID and deserializes it into the provided type.
fetchFacetStats(SearchQuery) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
fetchFacetStats(SearchQuery) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Retrieves facet statistics (i.e., value counts) for a given query.
fetchFacetStats(SearchQuery) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
fetchFirst() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches the first matching document if available and deserializes it to the stored type.
fetchFirst(Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches the first matching document if available and deserializes it as an optional value of the specified type.
fetchFirstOrNull() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches the first matching document if available and deserializes it to the stored type.
fetchFirstOrNull(Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Fetches the first matching document if available and deserializes it to the specified type.
fetchHistogram(int, int) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
fetchHistogram(int, int) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Computes a histogram for the timestamp distribution of matching documents.
fetchHistogram(GetSearchHistogram) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
fetchHistogram(GetSearchHistogram) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Fetches a histogram (bucketed time-series view) for documents matching the query.
fetchHistogram(GetSearchHistogram) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
fetchHitStream(Integer, Class<T>) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
fetchHitStream(Integer, Class<T>, int) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
fetchStatistics(SearchQuery, List<String>, List<String>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
fetchStatistics(SearchQuery, List<String>, List<String>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Retrieves search statistics (counts, averages, etc.) over matching documents.
fetchStatistics(SearchQuery, List<String>, List<String>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
Fields - Search tag in class io.fluxcapacitor.common.api.keyvalue.StoreValues
Section
Fields - Search tag in class io.fluxcapacitor.common.api.search.SearchQuery
Section
Fields: - Search tag in class io.fluxcapacitor.javaclient.modeling.SearchParameters
Section
FieldStats(List<Document>, String) - Constructor for class io.fluxcapacitor.common.api.search.DocumentStats.FieldStats
Constructs a FieldStats instance by scanning all numeric entries for a given path.
File Inheritance via @extends - Search tag in class io.fluxcapacitor.common.serialization.JsonUtils
Section
filePrefix - Static variable in class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
FileUtils - Class in io.fluxcapacitor.common
Utility class for reading and writing files and classpath resources.
FileUtils() - Constructor for class io.fluxcapacitor.common.FileUtils
 
filter(Predicate<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
filter(List<SerializedMessage>, int[], Position, Tracker) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
filterContent(T, User) - Method in interface io.fluxcapacitor.javaclient.common.serialization.ContentFilter
Filters the given value based on the current viewer (user) context.
filterContent(T, User) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter
 
filterContent(T, User) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Modify given value before it's passed to the given viewer.
filterContent(T, User) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
FilterContent - Annotation Interface in io.fluxcapacitor.javaclient.common.serialization
Declares that a method should be invoked to filter the visibility of an object for a specific User.
Filtering Options - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Section
FilteringSerializer() - Constructor for class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter.FilteringSerializer
 
Filtering using #contains() - Search tag in annotation interface io.fluxcapacitor.common.serialization.RegisterType
Section
filterMessage(HasMessage, Trigger) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
 
filterMessage(HasMessage, Parameter) - Method in class io.fluxcapacitor.javaclient.tracking.handling.PayloadParameterResolver
 
filterMessage(HasMessage, Parameter) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
Applies additional filtering logic based on the Trigger annotation on the parameter.
filterMessage(HasMessage, Parameter) - Method in class io.fluxcapacitor.javaclient.web.WebPayloadParameterResolver
 
filterMessage(M, Parameter) - Method in interface io.fluxcapacitor.common.handling.ParameterResolver
Determines whether a given message should be passed to a handler method based on this parameter's characteristics.
filterMessages(Collection<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
filterMessages(Collection<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
filterMessages(List<SerializedMessage>, int[], Position, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
filterMessageTarget() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
If true, only messages explicitly targeted at this application instance will be processed.
filterPaths(Predicate<Document.Path>) - Method in class io.fluxcapacitor.common.search.Document
Filters document entries by a Document.Path predicate.
FINAL_CHUNK - Static variable in interface io.fluxcapacitor.common.api.HasMetadata
 
finalCallback() - Method in record class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler.ResponseCallback
Returns the value of the finalCallback record component.
findAlternativeBacklog(Session) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
findAny() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
findByAssociation(Map<Object, String>) - Method in class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
findByAssociation(Map<Object, String>) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultHandlerRepository
 
findByAssociation(Map<Object, String>) - Method in interface io.fluxcapacitor.javaclient.modeling.HandlerRepository
Finds all handler instances that match the given set of associations.
findFirst() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
first - Variable in class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
firstDeadline(Periodic, Instant) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
flatMap(Function<? super T, ? extends Stream<? extends R>>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
flatMapToDouble(Function<? super T, ? extends DoubleStream>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
flatMapToInt(Function<? super T, ? extends IntStream>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
flatMapToLong(Function<? super T, ? extends LongStream>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
flowRegulator() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Regulates message flow and backpressure behavior.
FlowRegulator - Interface in io.fluxcapacitor.javaclient.tracking
Interface for controlling flow regulation in a consumer.
flush() - Method in class io.fluxcapacitor.javaclient.web.OutputStreamCapturer
 
flush(boolean) - Method in class io.fluxcapacitor.javaclient.web.OutputStreamCapturer
 
flushUpdates(Map<Object, BatchingHandlerRepository.Update>) - Method in class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
fluxCapacitor(FluxCapacitorBuilder, List<FluxCapacitorCustomizer>) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Constructs the FluxCapacitor instance if no FluxCapacitor bean exists, preferring a user-provided Client or falling back to either a WebSocketClient or LocalClient depending on presence of configuration properties.
FluxCapacitor - Interface in io.fluxcapacitor.javaclient
High-level entry point for all interactions with the Flux Capacitor platform.
fluxCapacitorBuilder(Serializer, Optional<UserProvider>, Optional<Cache>, Optional<WebResponseMapper>, Environment) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Provides a default FluxCapacitorBuilder, configured using Spring-provided components such as UserProvider, Cache, and WebResponseMapper.
FluxCapacitorBuilder - Interface in io.fluxcapacitor.javaclient.configuration
Builder interface for constructing a FluxCapacitor instance.
FluxCapacitorConfiguration - Interface in io.fluxcapacitor.javaclient.configuration
Central configuration interface for a Flux Capacitor client instance.
FluxCapacitorCustomizer - Interface in io.fluxcapacitor.javaclient.configuration.spring
Callback interface that can be implemented by Spring beans to customize the FluxCapacitorBuilder before it is used to build the main FluxCapacitor instance.
FluxCapacitorInterceptor - Class in io.fluxcapacitor.javaclient.tracking
A BatchInterceptor that ensures the correct FluxCapacitor instance is bound to the current thread for the duration of a MessageBatch.
FluxCapacitorInterceptor() - Constructor for class io.fluxcapacitor.javaclient.tracking.FluxCapacitorInterceptor
 
FluxCapacitorLogbackAppender - Class in io.fluxcapacitor.javaclient.common.logging
A Logback-compatible appender that automatically publishes warning and error-level log events to the Flux Capacitor platform.
FluxCapacitorLogbackAppender() - Constructor for class io.fluxcapacitor.javaclient.common.logging.FluxCapacitorLogbackAppender
 
FluxCapacitorSpringConfig - Class in io.fluxcapacitor.javaclient.configuration.spring
Spring configuration class for automatically wiring and initializing common Flux Capacitor components in a Spring application context.
FluxCapacitorSpringConfig(ApplicationContext) - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Stores a reference to the Spring context and prepares for handler detection.
FluxPrototype - Class in io.fluxcapacitor.javaclient.configuration.spring
Wrapper class representing a prototype-scoped Spring handler type within Flux Capacitor.
FluxPrototype() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.FluxPrototype
 
forAsyncConsumer(ThrowingFunction<List<T>, CompletableFuture<?>>) - Static method in class io.fluxcapacitor.common.Backlog
Creates a backlog for an asynchronous consumer with default max batch size and default logging error handler.
forAsyncConsumer(ThrowingFunction<List<T>, CompletableFuture<?>>, int) - Static method in class io.fluxcapacitor.common.Backlog
Creates a backlog for an asynchronous consumer with custom max batch size and default logging error handler.
forAsyncConsumer(ThrowingFunction<List<T>, CompletableFuture<?>>, int, ErrorHandler<List<T>>) - Static method in class io.fluxcapacitor.common.Backlog
Creates a backlog for an asynchronous consumer with custom max batch size and error handler.
ForbidsAnyRole - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling.authentication
Indicates that a handler method, class, package, or payload should not be invoked or processed if the current user has any of the specified roles.
forbidsUser() - Method in record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Returns the value of the forbidsUser record component.
ForbidsUser - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling.authentication
Indicates that a handler method, class, package, or payload should not be invoked or processed if a user is currently authenticated.
forceThrow(Throwable) - Static method in class io.fluxcapacitor.common.ObjectUtils
Forces the given throwable to be thrown.
forConsumer(ThrowingConsumer<List<T>>) - Static method in class io.fluxcapacitor.common.Backlog
Creates a new backlog for a synchronous consumer and default batch size and default logging error handler.
forConsumer(ThrowingConsumer<List<T>>, int) - Static method in class io.fluxcapacitor.common.Backlog
Creates a backlog with custom max batch size and default logging error handler.
forConsumer(ThrowingConsumer<List<T>>, int, ErrorHandler<List<T>>) - Static method in class io.fluxcapacitor.common.Backlog
Creates a backlog with custom max batch size and error handler.
forEach(Consumer<? super R>) - Method in class io.fluxcapacitor.common.DefaultMemoizingBiFunction
 
forEach(Consumer<? super R>) - Method in interface io.fluxcapacitor.common.MemoizingBiFunction
Applies the given consumer to all currently cached values.
forEach(Consumer<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
forEach(Consumer<? super V>) - Method in class io.fluxcapacitor.common.DefaultMemoizingFunction
 
forEach(Consumer<? super V>) - Method in interface io.fluxcapacitor.common.MemoizingFunction
Applies the given consumer to all currently cached values.
forEachOrdered(Consumer<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
ForeverRetryingErrorHandler - Class in io.fluxcapacitor.javaclient.tracking
A specialized RetryingErrorHandler that retries failed operations indefinitely until they succeed.
ForeverRetryingErrorHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.ForeverRetryingErrorHandler
Constructs a ForeverRetryingErrorHandler with a default 10-second delay between attempts, retrying non-functional errors and logging both functional and technical failures.
ForeverRetryingErrorHandler(Duration, Predicate<Throwable>, boolean, Function<Throwable, ?>) - Constructor for class io.fluxcapacitor.javaclient.tracking.ForeverRetryingErrorHandler
Constructs a ForeverRetryingErrorHandler with custom delay, error filtering, logging, and error mapping.
FORM - Enum constant in enum class io.fluxcapacitor.javaclient.web.WebParameterSource
Form fields (application/x-www-form-urlencoded or multipart/form-data)
format(ConstraintViolation<?>, boolean) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.Jsr380Validator
 
format(Collection<? extends ConstraintViolation<?>>, boolean) - Method in class io.fluxcapacitor.javaclient.tracking.handling.validation.Jsr380Validator
 
formatSortable(Object) - Static method in class io.fluxcapacitor.common.api.search.SortableEntry
Formats the given object into a sortable string depending on its type.
formatType(SerializedMessage) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
formatType(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.HandlerMonitor
 
FormParam - Annotation Interface in io.fluxcapacitor.javaclient.web
Injects an individual form field or a complete form object into a handler method parameter.
forTargetClass(Class<?>) - Static method in class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
forwardingWebConsumer() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Internal web consumer that can forward incoming WebRequest messages to a local HTTP server.
ForwardingWebConsumer - Class in io.fluxcapacitor.javaclient.web
A specialized, opt-in {web request consumer that forwards incoming MessageType.WEBREQUEST messages to a locally running HTTP server.
ForwardingWebConsumer(LocalServerConfig, ConsumerConfiguration) - Constructor for class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
ForwardProxyConsumer - Class in io.fluxcapacitor.proxy
 
ForwardProxyConsumer() - Constructor for class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
forwardWebRequestsToLocalServer(int) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Forwards incoming MessageType.WEBREQUEST messages to a locally running HTTP server on the specified port.
forwardWebRequestsToLocalServer(LocalServerConfig, UnaryOperator<ConsumerConfiguration>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
forwardWebRequestsToLocalServer(LocalServerConfig, UnaryOperator<ConsumerConfiguration>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Configures forwarding of MessageType.WEBREQUEST messages to a local HTTP server using the specified LocalServerConfig and custom consumer configuration.
from(Entity<T>, EntityHelper, Serializer, EventStore) - Static method in class io.fluxcapacitor.javaclient.modeling.ImmutableAggregateRoot
 
from(ImmutableAggregateRoot<T>) - Static method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
fromData(Data<byte[]>, Supplier<Document>) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
fromDocument(SerializedDocument) - Static method in class io.fluxcapacitor.common.api.search.bulkupdate.IndexDocument
Creates a bulk index operation from a SerializedDocument.
fromDocument(SerializedDocument) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
 
fromDocument(SerializedDocument) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentSerializer
Deserializes the payload of the given document into a Java object using the type information contained in the document.
fromDocument(SerializedDocument) - Static method in class io.fluxcapacitor.javaclient.persisting.search.SearchHit
Constructs a SearchHit instance from a raw SerializedDocument.
fromDocument(SerializedDocument, Class<T>) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
 
fromDocument(SerializedDocument, Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentSerializer
Deserializes the payload of the given document into an instance of the specified type.
fromEncryptionKey(String) - Static method in class io.fluxcapacitor.common.encryption.DefaultEncryption
 
fromFile(Class<?>, String) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the reference point into an object.
fromFile(Class<?>, String, JavaType) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the reference point into an object of the provided type.
fromFile(Class<?>, String, Class<T>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the reference point into an object of the provided type.
fromFile(Class<?>, String, Function<TypeFactory, JavaType>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the referencePoint into an object of the type specified by the provided type function.
fromFile(String) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the calling class.
fromFile(String...) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes JSON files located relative to the calling class.
fromFile(String, JavaType) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the calling class to an object of the specified type.
fromFile(String, Class<T>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the calling class to an object of the specified type.
fromFile(String, Function<TypeFactory, JavaType>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the calling class into an object of the type specified by the provided type function.
fromFileAs(String) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the calling class and casts it to type JsonUtils.
fromFileWith(String, Map<String, Object>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Loads and deserializes a JSON file located relative to the calling class, applies property replacements, and returns the resulting object.
fromJson(byte[]) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Deserializes a JSON byte array and casts the result to type JsonUtils.
fromJson(byte[], JavaType) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Deserializes a JSON byte array into an instance of the specified type.
fromJson(byte[], Class<T>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Deserializes a JSON byte array into an instance of the specified class type.
fromJson(byte[], Type) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts a JSON string to an object of the given type, which may be a ParameterizedType or Class.
fromJson(byte[], Function<TypeFactory, JavaType>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Deserializes a JSON byte array into an object of the type specified by the provided type function.
fromJson(String) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
 
fromJson(String, JavaType) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts a JSON string to an object of the given type.
fromJson(String, Class<T>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts a JSON string to an object of the given class type.
fromJson(String, Type) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts a JSON string to an object of the given type, which may be a ParameterizedType or Class.
fromJson(String, Function<TypeFactory, JavaType>) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Deserializes a JSON string into an object of the type specified by the provided type function.
fromMessage(HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AbstractUserProvider
Extracts a User from the metadata of a message.
fromMessage(HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
fromMessage(HasMessage) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
 
fromMessage(HasMessage) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Extracts the User from a given HasMessage instance.
fromValue(T) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository.AnnotatedAggregateRepository
 
FULL_SEGMENT - Static variable in class io.fluxcapacitor.common.api.tracking.Position
 
FunctionalException - Exception Class in io.fluxcapacitor.javaclient.common.exception
Base class for user-facing exceptions that are intended to be serialized and transferred across system boundaries (e.g., back to a calling client or frontend application).
FunctionalException() - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.FunctionalException
 
FunctionalException(String) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.FunctionalException
 
FunctionalException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.FunctionalException
 
FunctionalException(String, Throwable, boolean, boolean) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.FunctionalException
 
FunctionalException(Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.FunctionalException
 

G

GatewayClient - Interface in io.fluxcapacitor.javaclient.publishing.client
Low-level interface for sending SerializedMessages to a gateway (e.g. commands, events, queries).
GatewayException - Exception Class in io.fluxcapacitor.javaclient.publishing
 
GatewayException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.publishing.GatewayException
 
gatewayPath(MessageType) - Static method in class io.fluxcapacitor.common.ServicePathBuilder
Returns the gateway path used to publish messages of the given MessageType.
gatewayUrl(MessageType, String, WebSocketClient.ClientConfig) - Static method in class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
Builds the URL to send messages to a gateway endpoint for the specified message type and topic.
generalBatchInterceptors() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Interceptors applied to message batches during tracking and dispatch.
generateId() - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Generates a functional ID using the current IdentityProvider.
generateId(Class<T>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Generates a strongly typed ID of given idClass using the current IdentityProvider.
generateNewEncryptionKey() - Static method in class io.fluxcapacitor.common.encryption.DefaultEncryption
Generates a new encryption key using the default encryption mechanism.
GenericGateway - Interface in io.fluxcapacitor.javaclient.publishing
A generic message gateway for publication of messages in Flux Capacitor.
GenericTypeResolver - Class in io.fluxcapacitor.common.reflection
Utility class for resolving generic type information in class hierarchies.
GenericTypeResolver() - Constructor for class io.fluxcapacitor.common.reflection.GenericTypeResolver
 
get() - Method in class io.fluxcapacitor.common.DefaultMemoizingSupplier
 
get() - Method in class io.fluxcapacitor.javaclient.common.websocket.SessionPool
 
get() - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the Flux Capacitor instance bound to the current thread or else set by the current application.
get() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
get() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the current instance of the entity.
get() - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
get() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
get() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
get() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
get() - Method in interface io.fluxcapacitor.javaclient.persisting.caching.DefaultCache.CacheReference
 
get() - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache.HardCacheReference
 
get(int) - Method in class io.fluxcapacitor.javaclient.common.websocket.SessionPool
 
get(Object) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves the value associated with the given key from the entries map.
get(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Retrieves the value associated with the given id, or null if not found.
get(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
get(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
get(Object) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
get(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
get(Object, TypeReference<T>) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves a value associated with the given key, deserializes it to the specified type, and returns it.
get(Object, Class<T>) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves the value associated with the given key and attempts to deserialize it into the specified type.
get(String) - Method in class io.fluxcapacitor.common.api.search.Group
Returns the value associated with the given path in this group.
get(String) - Method in class io.fluxcapacitor.common.application.DecryptingPropertySource
Returns the decrypted value of the given property name.
get(String) - Method in class io.fluxcapacitor.common.application.DefaultPropertySource
 
get(String) - Method in enum class io.fluxcapacitor.common.application.EnvironmentVariablesSource
Retrieves the value of the given property name from the system environment.
get(String) - Method in class io.fluxcapacitor.common.application.JavaPropertiesSource
Retrieves the value for the given property name.
get(String) - Method in enum class io.fluxcapacitor.common.application.NoOpPropertySource
Always returns null for any requested property name.
get(String) - Method in interface io.fluxcapacitor.common.application.PropertySource
Retrieves the value of a property by name.
get(String) - Method in class io.fluxcapacitor.common.application.SimplePropertySource
Retrieves the value associated with the given property name from the internal map.
get(String) - Method in class io.fluxcapacitor.javaclient.common.websocket.SessionPool
 
get(String) - Method in class io.fluxcapacitor.javaclient.configuration.spring.SpringPropertySource
 
get(String) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.DefaultKeyValueStore
 
get(String) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.KeyValueStore
Retrieves the value associated with the given key.
get(String) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Creates a new WebRequest.Builder instance for constructing a GET request to given url.
get(String, String) - Method in interface io.fluxcapacitor.common.application.PropertySource
Returns the property value, or the given default if not present.
GET - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
getActiveAggregatesFor(Object) - Static method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
getActiveUser() - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
getActiveUser() - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Returns the currently active user, typically injected by the current context.
getAdhocInterceptor(MessageType) - Static method in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Returns the current thread-local ad hoc interceptor for the given MessageType, if present.
getAggregateId(HasMetadata) - Static method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the aggregate ID from the metadata of the given message.
getAggregateIds(GetAggregateIds) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Gets aggregate IDs based on a GetAggregateIds request.
getAggregateIds(GetAggregateIds) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
getAggregateIds(GetAggregateIds) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Retrieves a map of aggregate IDs associated with a given entity, using a GetAggregateIds request.
GetAggregateIds - Class in io.fluxcapacitor.common.api.modeling
Request to retrieve all aggregate identifiers associated with a given entity ID.
GetAggregateIds() - Constructor for class io.fluxcapacitor.common.api.modeling.GetAggregateIds
 
GetAggregateIdsResult - Class in io.fluxcapacitor.common.api.modeling
Response to a GetAggregateIds request, returning a mapping of aggregate IDs to types.
GetAggregateIdsResult() - Constructor for class io.fluxcapacitor.common.api.modeling.GetAggregateIdsResult
 
getAggregatesFor(Object) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository
 
getAggregatesFor(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Returns a map of aggregate IDs and their types that are associated with a given entity ID.
getAggregatesFor(Object) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
getAggregatesFor(String) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Gets a map of aggregate IDs that reference a given entity ID.
getAggregateType(HasMetadata) - Static method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the aggregate type from the metadata of the given message.
getAlgorithm() - Method in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
getAlgorithm() - Method in class io.fluxcapacitor.common.encryption.DefaultEncryption
 
getAlgorithm() - Method in interface io.fluxcapacitor.common.encryption.Encryption
Returns the name or identifier of the encryption algorithm used.
getAlgorithm() - Method in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
 
getAll() - Method in class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
getAll() - Method in class io.fluxcapacitor.javaclient.modeling.DefaultHandlerRepository
 
getAll() - Method in interface io.fluxcapacitor.javaclient.modeling.HandlerRepository
Retrieves all currently stored handler instances.
getAllMethods(Class<?>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedFields(Class<?>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedFields(Object, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedMethods(Class<?>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedMethods(Object, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedProperties(Class<?>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedProperty(Class<?>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedProperty(Object, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedPropertyValue(Object, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotatedPropertyValues(Object, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotation(AnnotatedElement, Class<A>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotation(Executable) - Method in class io.fluxcapacitor.common.handling.HandlerConfiguration
Retrieves the configured method annotation on the given method, if present.
getAnnotationAs(Annotation, Class<? extends Annotation>, Class<? extends T>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotationAs(Class<?>, Class<? extends Annotation>, Class<T>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getAnnotationAs(AnnotatedElement, Class<? extends Annotation>, Class<? extends T>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getApplicationIdKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the key used to identify the application ID in correlation metadata.
getBatch(int[], Position, int) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
getBatch(Tracker, PositionStore) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
getBatch(Tracker, PositionStore) - Method in interface io.fluxcapacitor.common.tracking.TrackingStrategy
Requests a new batch of messages for the given tracker.
getBatch(Long, int) - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Retrieves a batch of messages starting from the given lastIndex (exclusive).
getBatch(Long, int) - Method in class io.fluxcapacitor.testserver.scheduling.TestServerScheduleStore
 
getBatch(Long, int, boolean) - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Retrieves a batch of messages starting from the given minIndex.
getBatch(Long, int, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.CollectionMessageStore
 
getBatch(Long, int, boolean) - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
getBatch(Long, int, boolean) - Method in class io.fluxcapacitor.testserver.scheduling.TestServerScheduleStore
 
getBatchResource(Object) - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getBatchResourceOrDefault(Object, V) - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getBean(Class<T>) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
getBefore() - Method in class io.fluxcapacitor.common.api.search.SearchQuery
 
getBodyPublisher(SerializedMessage) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
getBoolean(String) - Method in interface io.fluxcapacitor.common.application.PropertySource
Returns the value of the property as a boolean.
getBoolean(String, boolean) - Method in interface io.fluxcapacitor.common.application.PropertySource
Returns the value of the property as a boolean, falling back to a default if not present.
getBooleanProperty(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Resolves a boolean property by key, returning false if not present.
getBooleanProperty(String, boolean) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Resolves a boolean property by key, returning a default if the property is not present.
getBytes() - Method in class io.fluxcapacitor.common.api.eventsourcing.EventBatch
Calculates the total number of bytes in the data across all messages within the batch.
getBytes() - Method in class io.fluxcapacitor.common.api.SerializedMessage
Returns the length of bytes in the serialized payload.
getBytes() - Method in class io.fluxcapacitor.common.api.tracking.MessageBatch
Calculates the total number of bytes in the data across all messages within the batch.
getBytes(ByteBuffer) - Static method in class io.fluxcapacitor.common.ObjectUtils
Extracts the byte array from a ByteBuffer.
getCallerClass() - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getCanonicalType(Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Computes the canonical string representation of a Type.
getCasters(Class<? extends Annotation>, Collection<?>, Class<T>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.casting.CastInspector
Discovers all caster methods annotated with the given annotation (typically Upcast or Downcast) in the provided candidates, and wraps them as AnnotatedCaster instances.
getClient() - Method in interface io.fluxcapacitor.common.api.ClientEvent
 
getClientCertificates() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getClientId() - Method in interface io.fluxcapacitor.common.api.ClientEvent
 
getClientId() - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
getClientId() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
getClientId(Session) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
getClientIdKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the key representing the client identifier in the correlation metadata.
getClientName(Session) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
getClientNameKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the key associated with the client's name from the correlation metadata.
getCollection() - Method in interface io.fluxcapacitor.common.api.search.BulkUpdate
The name of the collection to which this document belongs.
getCollectionElementType(AccessibleObject) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getCollectionElementType(Type) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getCompressionAlgorithm(Session) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
getConfigurationPhase() - Method in class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnBean.Condition
 
getConsumer(HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
 
getConsumerKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the consumer key used to identify the consumer of a message.
getConsumerName() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
getContainer() - Method in class io.fluxcapacitor.javaclient.common.websocket.DefaultWebSocketContainerProvider
 
getContent(Class<?>, String) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
 
getContent(URI) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
 
getContentType() - Method in class io.fluxcapacitor.javaclient.web.WebRequest
Returns the content type of the request (based on Content-Type header).
getContentType() - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves the value of the "Content-Type" header from the HTTP response.
getContext(Session) - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
getCookie(Metadata, String) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Retrieves the first cookie with the given name from the provided Metadata object.
getCookie(String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
Finds a cookie by name.
getCookieParameter(String) - Method in interface io.fluxcapacitor.javaclient.web.WebRequestContext
Retrieves a parameter value from the cookie source using the specified parameter name.
getCookies() - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves a list of cookies from the response's "Set-Cookie" headers.
getCorrelationData() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Returns correlation metadata based on the current message being handled (if any).
getCorrelationData(SerializedMessage) - Method in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
getCorrelationData(DeserializingMessage) - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Returns correlation metadata derived from the current deserializing message.
getCorrelationData(Client, SerializedMessage, MessageType) - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Returns correlation metadata derived from a serialized message and optional context.
getCorrelationIdKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Returns the key used for identifying the correlation ID within the metadata.
getCurrent() - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
Returns the current DeserializingMessage being processed in this thread, or null if none is set.
getCurrent() - Static method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.User
Returns the user currently associated with the executing thread.
getCurrent() - Static method in class io.fluxcapacitor.javaclient.tracking.handling.Invocation
Returns the current Invocation bound to this thread, or null if none exists.
getCurrentWebRequestContext() - Static method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
Returns the current DefaultWebRequestContext from the active DeserializingMessage, or null if no such message is available or it is not a MessageType.WEBREQUEST.
getDeadline() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
getDeadline() - Method in interface io.fluxcapacitor.javaclient.persisting.caching.DefaultCache.CacheReference
 
getDeadline() - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
The time at which this scheduled message should be delivered.
getDefaultConsumerConfiguration(MessageType) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
getDelayKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the key used to identify the delay metadata within correlation data.
getDocument() - Method in class io.fluxcapacitor.common.api.search.SerializedDocument
Returns the serialized representation of the document.
getDocument(Object, Class<T>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Gets the document with given id in given collection type, returning the value.
getDocument(Object, Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Gets the document with given id in given collection, returning the value in the type that it was stored.
getDocument(Object, Object, Class<T>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Gets the document with given id in given collection, converting the matching document to a value with given type.
GetDocument - Class in io.fluxcapacitor.common.api.search
Request to fetch a single document from the search store by ID and collection.
GetDocument() - Constructor for class io.fluxcapacitor.common.api.search.GetDocument
 
GetDocumentResult - Class in io.fluxcapacitor.common.api.search
Result returned in response to a GetDocument request.
GetDocumentResult() - Constructor for class io.fluxcapacitor.common.api.search.GetDocumentResult
 
GetDocumentResult.Metric - Class in io.fluxcapacitor.common.api.search
Lightweight structure for representing GetDocumentResult in Flux metrics logs.
GetDocumentStats - Class in io.fluxcapacitor.common.api.search
Request to compute statistics on documents that match a given SearchQuery.
GetDocumentStats() - Constructor for class io.fluxcapacitor.common.api.search.GetDocumentStats
 
GetDocumentStatsResult - Class in io.fluxcapacitor.common.api.search
Response to a GetDocumentStats request.
GetDocumentStatsResult() - Constructor for class io.fluxcapacitor.common.api.search.GetDocumentStatsResult
 
GetDocumentStatsResult.Metric - Class in io.fluxcapacitor.common.api.search
Compact summary of the result, used for internal monitoring purposes.
getEnclosingClass(AccessibleObject) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getEncryption() - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Returns the currently active Encryption instance.
getEncryptionKey() - Method in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
getEncryptionKey() - Method in class io.fluxcapacitor.common.encryption.DefaultEncryption
 
getEncryptionKey() - Method in interface io.fluxcapacitor.common.encryption.Encryption
Returns the encryption key used by this implementation.
getEncryptionKey() - Method in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
 
getEnd() - Method in class io.fluxcapacitor.common.api.search.SerializedDocument
Returns the adjusted end timestamp.
getEnd() - Method in class io.fluxcapacitor.common.search.Document
 
getEntities(Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.AnnotatedEntityHolder
Returns the set of ImmutableEntity instances that are defined at the member location within the specified parent entity.
getEntity() - Method in interface io.fluxcapacitor.javaclient.modeling.HasEntity
Retrieves the associated Entity of the object.
getEntity(Object) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves an entity based on the provided entity ID.
getEntityHolder(Class<?>, AccessibleObject, EntityHelper, Serializer) - Static method in class io.fluxcapacitor.javaclient.modeling.AnnotatedEntityHolder
Retrieves or creates a cached AnnotatedEntityHolder at the given member location.
getEntries() - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves a map of entries where the keys and values are strings.
getEntryAtPath(String) - Method in class io.fluxcapacitor.common.search.Document
Retrieves the first matching Document.Entry for a given query path.
getEntryType(JsonToken) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
getEnvironment() - Static method in class io.fluxcapacitor.common.application.ApplicationEnvironmentPropertiesSource
Attempts to resolve the active environment using environment variables or system properties.
getEvents(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.EventStore
Retrieves the full event stream for an aggregate starting from the beginning.
getEvents(Object, long) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.EventStore
Retrieves the event stream for an aggregate starting after the specified sequence number.
getEvents(Object, long, int) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.EventStore
Retrieves the event stream for an aggregate starting after a given sequence number, with a maximum limit.
getEvents(Object, long, int, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultEventStore
 
getEvents(Object, long, int, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.EventStore
Retrieves the event stream for an aggregate with full control over behavior.
getEvents(String) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Retrieves the full event stream for a given aggregate.
getEvents(String, long) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Retrieves the event stream for an aggregate starting after the given sequence number.
getEvents(String, long, int) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Retrieves the event stream for an aggregate with control over size and offset.
getEvents(String, long, int) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
getEvents(String, long, int) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Retrieves events for a specific aggregate starting after a given sequence number, optionally limiting the result size.
GetEvents - Class in io.fluxcapacitor.common.api.eventsourcing
A request to fetch stored events for a specific aggregate in an event-sourced system.
GetEvents() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.GetEvents
 
GetEventsResult - Class in io.fluxcapacitor.common.api.eventsourcing
Response to a GetEvents request, returning a batch of events for an aggregate.
GetEventsResult() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.GetEventsResult
 
GetEventsResult.Metric - Class in io.fluxcapacitor.common.api.eventsourcing
Lightweight metric representation of a GetEventsResult used for monitoring.
getEventStoreClient() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the EventStoreClient associated with this client for querying event logs.
getFacets(Object) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
getFacets(Object, Metadata) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
getFacets(AccessibleObject, Object) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
GetFacetStats - Class in io.fluxcapacitor.common.api.search
Request to retrieve aggregated counts for all facet fields across documents matching the given SearchQuery.
GetFacetStats() - Constructor for class io.fluxcapacitor.common.api.search.GetFacetStats
 
GetFacetStatsResult - Class in io.fluxcapacitor.common.api.search
Result returned for a GetFacetStats request.
GetFacetStatsResult() - Constructor for class io.fluxcapacitor.common.api.search.GetFacetStatsResult
 
GetFacetStatsResult.Metric - Class in io.fluxcapacitor.common.api.search
Lightweight summary of the facet statistics result, used for internal metric tracking.
getField(Class<?>, String) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getFieldAnnotation(Field, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getFieldValue(String, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getFile(Class<?>, String) - Static method in class io.fluxcapacitor.common.FileUtils
Gets a file from a classpath location using a reference class.
getFirstTypeArgument(Type) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getFormat() - Method in class io.fluxcapacitor.common.api.Data
Returns the effective format for the data, defaulting to Data.JSON_FORMAT if format is null or "json".
getFormParameter(String) - Method in interface io.fluxcapacitor.javaclient.web.WebRequestContext
Retrieves the value of a form parameter from the web request context.
getFutureSchedules(Serializer) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
getGatewayClient(MessageType) - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns a GatewayClient for the given message type using the default topic (typically null).
getGatewayClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Returns the memoized GatewayClient for the given message type and topic.
getGatewayClient(MessageType, String) - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns a GatewayClient for the given message type and topic.
getGenericPropertyType(AccessibleObject) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getGenericType(Class<?>, Class<?>) - Static method in class io.fluxcapacitor.common.reflection.GenericTypeResolver
 
getGenericType(Class<?>, Class<?>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getGlobMatcher(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Converts a standard POSIX Shell globbing pattern into a regular expression pattern.
getGuarantee() - Method in class io.fluxcapacitor.common.api.Command
Indicates the delivery guarantee required for this command.
getGuarantee() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValueIfAbsent
 
getGuarantee() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValuesAndWait
Deprecated.
 
getGuarantee() - Method in class io.fluxcapacitor.common.api.publishing.Append
 
getHandlerAnnotation(MessageType) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
getHandlerPath(Class<?>, Object, Executable) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Computes the complete @Path value for the given handler.
getHeader(Metadata, String) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Retrieves the first header value for the given name from the provided Metadata object.
getHeader(Metadata, String) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Retrieves the first header value for the given name from the provided Metadata object.
getHeader(String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
Returns a single header value, or null if not present.
getHeader(String) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves the value of the first occurrence of the specified header name.
getHeaderParameter(String) - Method in interface io.fluxcapacitor.javaclient.web.WebRequestContext
Retrieves the value of a parameter from the HTTP request headers by its name.
getHeaders() - Method in class io.fluxcapacitor.javaclient.web.WebRequest
The HTTP headers as a case-sensitive map.
getHeaders() - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Returns all HTTP headers associated with the current response.
getHeaders(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Retrieves a case-insensitive map of headers from the provided Metadata object.
getHeaders(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves a case-insensitive map of headers from the provided Metadata object.
getHeaders(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Retrieves a case-insensitive map of headers from the provided Metadata object.
getHeaders(String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
Returns all values for the specified header.
getHeaders(String) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves the list of header values associated with the given header name.
getId() - Method in interface io.fluxcapacitor.common.api.HasId
Returns the stringified identifier of this object.
getId() - Method in interface io.fluxcapacitor.common.api.search.BulkUpdate
The unique identifier of the document within the collection.
getId() - Method in interface io.fluxcapacitor.javaclient.common.Entry
Returns the identifier of the entry.
getId() - Method in class io.fluxcapacitor.javaclient.modeling.Id
 
getId() - Method in interface io.fluxcapacitor.javaclient.persisting.caching.DefaultCache.CacheReference
 
getIfActive(Object) - Static method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
getIndex() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getIndex(int) - Method in class io.fluxcapacitor.common.api.tracking.Position
 
getIntegerProperty(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Resolves an integer property by key, or null if not found.
getIntegerProperty(String, Integer) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Resolves an integer property by key, or returns the given default value if not found.
getInterceptInvoker(DefaultEntityHelper.MessageWithEntity) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
Recursively resolves the best-matching interceptor method, including nested members.
getInvocationKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the key associated with the invocation context within the correlation metadata.
getInvoker(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator.DocumentHandler
 
getInvoker(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor.InterceptedHandler
 
getInvoker(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
 
getInvoker(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler
 
getInvoker(DeserializingMessage, Handler<DeserializingMessage>, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
getInvoker(Object, DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
 
getInvoker(Object, M) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
getInvoker(Object, M) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.ObjectHandlerMatcher
 
getInvoker(M) - Method in class io.fluxcapacitor.common.handling.DefaultHandler
 
getInvoker(M) - Method in interface io.fluxcapacitor.common.handling.Handler
Returns a HandlerInvoker capable of processing the given message, if available.
getInvoker(M) - Method in class io.fluxcapacitor.javaclient.tracking.handling.MutableHandler
 
getInvoker(T, M) - Method in interface io.fluxcapacitor.common.handling.HandlerMatcher
Attempts to resolve a HandlerInvoker for the given target instance and message.
getJavaType(String) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Resolves a canonical JavaType for the given string-based type name.
getKeyValueClient() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the KeyValueClient for key-value store interactions.
getLastCheckpoint() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
getLastSequenceNumber() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
Returns the last known sequence number from the event stream, if available.
getLastTrackerIndex() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
getLatestAggregateId(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Returns the most recently created aggregate ID associated with a given entity ID, if any.
getLeastSpecificAllowedClass(Executable, Class<? extends Annotation>) - Method in interface io.fluxcapacitor.common.handling.MessageFilter
Provides the least specific class type that is allowed to match this filter for a given method and annotation.
getLeastSpecificAllowedClass(Executable, Class<? extends Annotation>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.PayloadFilter
 
getLocalHandlerAnnotation(HandlerInvoker) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Retrieves the LocalHandler annotation associated with a given handler, from its method, its declaring class, or ancestral package, if present.
getLocalHandlerAnnotation(Class<?>, Executable) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Retrieves the LocalHandler annotation associated with a given method, its declaring class, or ancestral package, if present.
getLocalHandlers(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
Returns the full list of handlers that should be used to process the given message.
getMatchingEntity(Object, Parameter) - Method in class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
Attempts to retrieve an Entity instance matching the given method parameter.
getMatchingEntries(Predicate<Document.Path>) - Method in class io.fluxcapacitor.common.search.Document
Retrieves a stream of entries that match the provided path predicate.
getMaxSize() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
getMechanism() - Method in class io.fluxcapacitor.common.serialization.GlobalTypeIdResolver
 
getMember() - Method in interface io.fluxcapacitor.common.reflection.MemberInvoker
 
getMemberAnnotation(Class<?>, String, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getMessage(long) - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
getMessageBatch(ConsumerConfiguration, long, ClaimSegmentResult) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
getMessageId() - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Returns the unique ID of the underlying message.
getMessageId() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getMessageStore() - Method in interface io.fluxcapacitor.common.tracking.HasMessageStore
Returns the associated MessageStore instance.
getMessageStore() - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Returns the current instance as the MessageStore.
getMessageStore() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.LocalEventStoreClient
 
getMessageStore() - Method in class io.fluxcapacitor.javaclient.scheduling.client.LocalSchedulingClient
 
getMessageType() - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
getMessageType() - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Returns the MessageType (e.g., COMMAND, EVENT, QUERY) associated with this tracking client.
getMetadata() - Method in interface io.fluxcapacitor.common.api.HasMetadata
Returns the Metadata associated with this object.
getMetadata() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getMetadata() - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper.MessageWithEntity
 
getMethod() - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker
 
getMethod() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
getMethod() - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
The Executable representing the handler method (can be a static or instance Method or Constructor).
getMethod() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.SimpleInvoker
 
getMethod() - Method in class io.fluxcapacitor.javaclient.web.WebRequest
The HTTP or WebSocket method (e.g.
getMethod(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Extracts the HTTP or WebSocket method (e.g., "GET", "POST", "WS_OPEN") from the provided Metadata object.
getMethod(Class<?>, String) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getMethodAnnotation() - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker
 
getMethodAnnotation() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
getMethodAnnotation() - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Retrieves a specific annotation from the handler method, if present.
getMethodAnnotation() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.SimpleInvoker
 
getMethodAnnotation(Executable, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getMethodAnnotations(Executable, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getMethodOverrideHierarchy(Method) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getName() - Method in class io.fluxcapacitor.javaclient.tracking.Tracker
Returns the name of the consumer associated with this tracker.
getName(AccessibleObject) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getObjectFunction() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Returns the memoized deserialization function used to deserialize the payload.
getOptionally() - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
Returns the current DeserializingMessage being processed in this thread, if available.
getOptionally() - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the FluxCapacitor client bound to the current thread or else set by the current application as Optional.
getOptionally(Object) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves the value associated with the provided key, if it exists, wrapped in an Optional.
getOptionally(Object, TypeReference<T>) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves an object associated with the given key, deserializes it to the specified type, and returns it wrapped in an Optional.
getOptionally(Object, Class<T>) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves an object associated with the given key, attempts to deserialize it to the specified type, and returns it wrapped in an Optional.
getOrCreateSocketSession(HasMessage) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
 
getOrDefault(Object, String) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves the value mapped to the specified key in the entries map.
getOrDefault(Object, T) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Retrieves the value associated with the given id, or returns the specified default if not present.
getOriginalRevision() - Method in class io.fluxcapacitor.common.api.SerializedMessage
Returns the original revision of the payload object.
getOrThrow(Object, Supplier<? extends X>) - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves the value associated with the specified key or throws an exception provided by the given error supplier if the key does not exist or has a null value.
getOutputType() - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
getOutputType() - Method in class io.fluxcapacitor.common.serialization.AbstractConverter
 
getOutputType() - Method in interface io.fluxcapacitor.common.serialization.Converter
 
getPackageAndParentPackages(Package) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getPackageAnnotation(Package, Class<A>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getPackageAnnotations(Package) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getPackageAnnotations(Package, boolean) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getParameter(String) - Method in interface io.fluxcapacitor.javaclient.web.WebRequestContext
Retrieves the value of a parameter from the web request.
getParameter(String, WebParameterSource...) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getParameter(String, WebParameterSource...) - Method in interface io.fluxcapacitor.javaclient.web.WebRequestContext
Retrieves the value of a specified parameter from the given sources in a web request.
getParameterIndex(Parameter) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getParameterName(Parameter) - Method in class io.fluxcapacitor.common.reflection.ParameterRegistry
Retrieves the name of a specific method parameter.
getParameterNames(Executable) - Method in class io.fluxcapacitor.common.reflection.ParameterRegistry
Retrieves the parameter names for a given method.
getParameterOverrideHierarchy(Parameter) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getPath() - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler.AssociationValue
 
getPath() - Method in class io.fluxcapacitor.javaclient.web.WebRequest
The request path including query parameters (e.g.
getPathParameter(String) - Method in interface io.fluxcapacitor.javaclient.web.WebRequestContext
Retrieves the value of a parameter from the path section of the web request.
getPaths() - Method in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
Retrieves a list of paths associated with this constraint.
getPayload() - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Retrieves the message payload, deserializing if necessary, cast to the expected type.
getPayload() - Method in class io.fluxcapacitor.javaclient.common.Message
Returns the strongly typed payload of the message.
getPayload() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getPayload() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Returns the deserialized payload using the default target type (Object.class).
getPayload() - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper.MessageWithEntity
 
getPayload() - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves the decoded payload from the response and casts it to the specified type.
getPayloadAs(Type) - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Retrieves the message payload, deserializing if necessary and optionally converted to the given type.
getPayloadAs(Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getPayloadAs(Type) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Returns the deserialized payload using the specified target Type.
getPayloadAs(Type) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
Deserializes the payload into a given type, using JSON if content type is application/json.
getPayloadAs(Type) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves the payload and converts it to the specified type.
getPayloadClass() - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Returns the runtime class of the payload object, or Void.class if the payload is null.
getPayloadClass() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getPayloadClass() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Attempts to resolve the declared payload class using ReflectionUtils.classForName(String) and throws an exception if the class cannot be found.
getPosition(String) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
getPosition(String) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
getPosition(String) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Returns the current committed tracking position for the given consumer.
getPosition(String) - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
GetPosition - Class in io.fluxcapacitor.common.api.tracking
Query to retrieve the current tracked Position for a given consumer and MessageType.
GetPosition() - Constructor for class io.fluxcapacitor.common.api.tracking.GetPosition
 
GetPositionResult - Class in io.fluxcapacitor.common.api.tracking
Response to a GetPosition request, containing the current tracked position for a specific consumer and MessageType.
GetPositionResult() - Constructor for class io.fluxcapacitor.common.api.tracking.GetPositionResult
 
getPriority(Annotation) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
getProcessingDuration(Tracker) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Returns how long the given tracker has been active.
getProjectId(Session) - Static method in class io.fluxcapacitor.testserver.websocket.WebsocketDeploymentUtils
 
getProjectId(Session) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
getProperty(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Returns the raw string property for the given key, or null if not found.
getProperty(String, String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Returns the string property value for the given key, or the specified default if not found.
getPropertyAnnotation(String, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getPropertyName(AccessibleObject) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getPropertyPath(ConstraintViolation<?>, boolean) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.Jsr380Validator
 
getPropertyType(AccessibleObject) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getProtocol() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getPurgeDelay() - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
getPurgeDelay() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
getQueryParameter(String) - Method in interface io.fluxcapacitor.javaclient.web.WebRequestContext
Retrieves the value of a query parameter from the web request.
getRelationships(GetRelationships) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Gets relationships based on a GetRelationships request.
getRelationships(GetRelationships) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
getRelationships(GetRelationships) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Retrieves all relationships for a given entity, using a GetRelationships request.
getRelationships(String) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Gets relationships for the given entity.
GetRelationships - Class in io.fluxcapacitor.common.api.modeling
Request to retrieve all aggregate relationships for a given entity ID.
GetRelationships() - Constructor for class io.fluxcapacitor.common.api.modeling.GetRelationships
 
GetRelationshipsResult - Class in io.fluxcapacitor.common.api.modeling
Response to a GetRelationships request, containing all known relationships for a given entity ID.
GetRelationshipsResult() - Constructor for class io.fluxcapacitor.common.api.modeling.GetRelationshipsResult
 
getRepository(Class<T>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultRepositoryProvider
 
getRepository(Class<T>) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.RepositoryProvider
Returns a repository (typically a shared, type-scoped map) for the given class type.
getRequestId() - Method in interface io.fluxcapacitor.common.api.RequestResult
The requestId of the original Request this result corresponds to.
getRequiredRoles(Collection<? extends Annotation>) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
 
getResetHeadersOnError() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getResourceBaseUri(String) - Static method in class io.fluxcapacitor.common.FileUtils
Retrieves the base URI of a given resource path.
getResourceBaseUri(String, ClassLoader) - Static method in class io.fluxcapacitor.common.FileUtils
Retrieves the base URI of a given resource path.
getResponseCode() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getResponseHeader(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getResponseLength() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getResponseType() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getResult() - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain.ConvertingSerializedObject
Returns the final SerializedObject after conversion.
getRevision() - Method in class io.fluxcapacitor.common.api.SerializedMessage
 
getRevision() - Method in interface io.fluxcapacitor.common.api.SerializedObject
Returns the revision of the serialized object.
getRevision() - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain.ConvertingSerializedObject
 
getRevision() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Returns the revision number of the serialized payload, if available.
getRevisionNumber(Object) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Extracts the revision number from the Revision annotation on the given object’s class.
getRootAnnotation(Class<?>) - Static method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
Returns the cached or default @Aggregate annotation for a given type.
getRouter() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getRoutingKey(String) - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Attempts to resolve the routing key from the given property name.
getRoutingKey(String, boolean) - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Attempts to resolve the routing key from the specified property name.
getSchedule(String) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
getSchedule(String) - Method in interface io.fluxcapacitor.javaclient.scheduling.client.SchedulingClient
Retrieves the serialized schedule associated with the given ID.
getSchedule(String) - Method in class io.fluxcapacitor.javaclient.scheduling.client.WebsocketSchedulingClient
 
getSchedule(String) - Method in class io.fluxcapacitor.javaclient.scheduling.DefaultMessageScheduler
 
getSchedule(String) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Look up an existing schedule.
GetSchedule - Class in io.fluxcapacitor.common.api.scheduling
Request to retrieve a scheduled message by its GetSchedule.scheduleId.
GetSchedule() - Constructor for class io.fluxcapacitor.common.api.scheduling.GetSchedule
 
getScheduleId() - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Unique identifier for this scheduled message.
GetScheduleResult - Class in io.fluxcapacitor.common.api.scheduling
Response to a GetSchedule request, containing the matching SerializedSchedule, if found.
GetScheduleResult() - Constructor for class io.fluxcapacitor.common.api.scheduling.GetScheduleResult
 
GetScheduleResult.Metric - Class in io.fluxcapacitor.common.api.scheduling
Metric payload used for internal monitoring and logging.
getSchedulingClient() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the SchedulingClient used to interact with the Flux scheduling subsystem.
getScheme() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
getSearchClient() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the SearchClient that provides access to document and search APIs.
GetSearchHistogram - Class in io.fluxcapacitor.common.api.search
Request to compute a time-based histogram over documents that match a given query.
GetSearchHistogram() - Constructor for class io.fluxcapacitor.common.api.search.GetSearchHistogram
 
GetSearchHistogramResult - Class in io.fluxcapacitor.common.api.search
Result of a GetSearchHistogram request.
GetSearchHistogramResult() - Constructor for class io.fluxcapacitor.common.api.search.GetSearchHistogramResult
 
getSearchParameters(Class<?>) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Returns the effective SearchParameters for the given type, using the Searchable annotation.
getSegment(Tracker) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Returns the segment range assigned to the tracker.
getSequenceNumber(HasMetadata) - Static method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the sequence number from the metadata of the given message.
getSerializedObject() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getSerializer() - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Retrieves the serializer used for document operations within the document store.
getSettings(SerializedMessage) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
getSimpleName(Class<?>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getSimpleName(Package) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getSimpleName(String) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getSize() - Method in class io.fluxcapacitor.common.api.eventsourcing.EventBatch
Returns the number of events in this batch.
getSize() - Method in class io.fluxcapacitor.common.api.publishing.Append
 
getSize() - Method in class io.fluxcapacitor.common.api.search.BulkUpdateDocuments
 
getSize() - Method in class io.fluxcapacitor.common.api.search.IndexDocuments
 
getSize() - Method in class io.fluxcapacitor.common.api.tracking.MessageBatch
Returns the number of messages contained in this batch.
getSnapshot(Object) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultSnapshotStore
 
getSnapshot(Object) - Method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoOpSnapshotStore
 
getSnapshot(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.SnapshotStore
Retrieves the most recent snapshot for a given aggregate ID, if available.
getSocketSessionId(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Retrieves the WebSocket session ID from the provided metadata, or null if it is missing.
getSortableEntries(Object) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
getSortableEntries(AccessibleObject, Object) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
getSortableEntries(Predicate<Document.Path>) - Method in class io.fluxcapacitor.common.search.Document
Retrieves a stream of SortableEntry objects from the document's indexes that match the provided path predicate.
getSortables(Object) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
getSource() - Method in interface io.fluxcapacitor.javaclient.common.serialization.casting.HasSource
Returns the original source object this instance was derived from.
getStatus() - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Returns the HTTP status code associated with the current response.
getStatusCode(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
Retrieves the status code from the provided metadata.
getSupportedSourceVersion() - Method in class io.fluxcapacitor.common.serialization.TypeRegistryProcessor
 
getSupportedSourceVersion() - Method in class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
 
getSupportedSourceVersion() - Method in class io.fluxcapacitor.javaclient.web.WebParameterProcessor
 
getSystemUser() - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
getSystemUser() - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
 
getSystemUser() - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Returns the User representing the system (non-human) identity.
getTargetClass() - Method in class io.fluxcapacitor.common.handling.DefaultHandler
 
getTargetClass() - Method in class io.fluxcapacitor.common.handling.Handler.DelegatingHandler
 
getTargetClass() - Method in interface io.fluxcapacitor.common.handling.Handler
Returns the class of the handler's target object.
getTargetClass() - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker
 
getTargetClass() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
getTargetClass() - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
The target class that contains the handler method.
getTargetClass() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.SimpleInvoker
 
getTargetClass() - Method in class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator.DocumentHandler
 
getTargetClass() - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor.InterceptedHandler
 
getTimestamp() - Method in interface io.fluxcapacitor.common.api.ClientEvent
 
getTimestamp() - Method in interface io.fluxcapacitor.common.api.RequestResult
The timestamp (in epoch milliseconds) when this result was generated.
getTimestamp() - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Returns the timestamp at which the message was created or published.
getTimestamp() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getTopic() - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
getTopic() - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Returns the topic associated with this tracking client.
getTopic(HandleDocument, Executable) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Extracts the topic associated with a given HandleDocument annotation or Executable.
getTopics(MessageType, Object) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Extracts all topics associated with the given handler object and message type.
getTopics(MessageType, Collection<Class<?>>) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Extracts all topics from HandleDocument or HandleCustom annotated methods for the given classes.
getTraceEntries() - Method in class io.fluxcapacitor.common.api.Metadata
Retrieves a map containing only the entries from the metadata whose keys start with the prefix "$trace.".
getTraceIdKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Returns the key used to identify the trace ID in correlation metadata.
getTrackerId() - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
getTrackerId() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
getTrackerKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the key representing the tracker component in correlation metadata.
getTrackers() - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Returns an unmodifiable view of the current set of trackers.
getTrackingClient(MessageType) - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns a TrackingClient for the given message type using the default topic.
getTrackingClient(MessageType, String) - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
 
getTrackingClient(MessageType, String) - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns a TrackingClient for the given message type and topic.
getTriggerClass(HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
 
getTriggerKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Retrieves the trigger key used to identify the triggering context for correlation metadata.
getTriggerMessage(long, Class<?>, MessageType) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
 
getTriggerMessageType(HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
 
getTriggerTypeKey() - Method in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Returns the key associated with the trigger type in the correlation data.
getType() - Method in class io.fluxcapacitor.common.api.search.bulkupdate.DeleteDocument
 
getType() - Method in interface io.fluxcapacitor.common.api.search.BulkUpdate
Indicates the operation type: index, indexIfNotExists, or delete.
getType() - Method in class io.fluxcapacitor.common.api.search.bulkupdate.IndexDocument
 
getType() - Method in class io.fluxcapacitor.common.api.search.bulkupdate.IndexDocumentIfNotExists
 
getType() - Method in class io.fluxcapacitor.common.api.SerializedMessage
 
getType() - Method in interface io.fluxcapacitor.common.api.SerializedObject
Returns the type identifier for the serialized payload.
getType() - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain.ConvertingSerializedObject
 
getType() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
getType() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Returns the declared type of the payload (e.g., fully qualified class name), or null if unknown.
getType(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Determines the full type signature of the given object.
getTypeAnnotation(Class<?>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getTypeAnnotations(Class<?>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getTypeArgument(Type, int) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getTypeArguments(Type) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getTypeFilter() - Method in interface io.fluxcapacitor.common.tracking.Tracker
Returns a predicate for filtering messages based on their type (class name).
getTypeName(String) - Method in class io.fluxcapacitor.common.serialization.DefaultTypeRegistry
 
getTypeName(String) - Method in enum class io.fluxcapacitor.common.serialization.NoOpTypeRegistry
 
getTypeName(String) - Method in interface io.fluxcapacitor.common.serialization.TypeRegistry
Returns the fully qualified class name associated with the given alias or type key.
getTypeString(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Resolves the effective string representation of an object's type, including generic parameters if applicable.
getUrl(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Extracts the request path from the provided Metadata object.
getUserById(Object) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
getUserById(Object) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
 
getUserById(Object) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Retrieves a User by their unique ID.
getValue() - Method in class io.fluxcapacitor.common.api.Data
Returns the deserialized value.
getValue() - Method in interface io.fluxcapacitor.javaclient.common.Entry
Returns the value associated with this entry.
getValue() - Method in class io.fluxcapacitor.javaclient.persisting.search.SearchHit
Returns the actual value of the hit, deserialized or computed via the internal valueSupplier.
getValue(AccessibleObject, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getValue(AccessibleObject, Object, boolean) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
getValue(String) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.InMemoryKeyValueStore
 
getValue(String) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.client.KeyValueClient
Returns the Data object associated with the given key.
getValue(String) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.WebsocketKeyValueClient
 
GetValue - Class in io.fluxcapacitor.common.api.keyvalue
Request to retrieve a value from the legacy key-value store.
GetValue() - Constructor for class io.fluxcapacitor.common.api.keyvalue.GetValue
 
GetValueResult - Class in io.fluxcapacitor.common.api.keyvalue
Response to a GetValue request, returning the value associated with the given key.
GetValueResult() - Constructor for class io.fluxcapacitor.common.api.keyvalue.GetValueResult
 
GetValueResult.Metric - Class in io.fluxcapacitor.common.api.keyvalue
 
getWebPatterns() - Method in class io.fluxcapacitor.javaclient.web.WebParameters
Expands this configuration into a stream of WebPattern instances.
getWebPatterns(Class<?>, Object, Executable) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Returns all WebPattern instances declared on the given method in the given target class.
getWebPatterns(String) - Method in class io.fluxcapacitor.javaclient.web.WebParameters
Expands this configuration into a stream of WebPattern instances.
getWebRequestContext(DeserializingMessage) - Static method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
Creates or retrieves a DefaultWebRequestContext from the given DeserializingMessage.
getZone() - Method in class io.fluxcapacitor.common.DelegatingClock
 
GlobalTypeIdResolver - Class in io.fluxcapacitor.common.serialization
 
GlobalTypeIdResolver() - Constructor for class io.fluxcapacitor.common.serialization.GlobalTypeIdResolver
 
Group - Class in io.fluxcapacitor.common.api.search
Represents a group key for aggregating documents in DocumentStats.
Group(Map<String, String>) - Constructor for class io.fluxcapacitor.common.api.search.Group
 
groupBy(String...) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
groupBy(String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Groups search results by field(s) and supports aggregations.
GroupSearch - Interface in io.fluxcapacitor.javaclient.persisting.search
Represents a grouped search query in the Flux Capacitor search framework.
Guarantee - Enum Class in io.fluxcapacitor.common
Represents a delivery or completion guarantee for messages or state changes in Flux Capacitor.
GZIP - Enum constant in enum class io.fluxcapacitor.common.serialization.compression.CompressionAlgorithm
GZIP compression using standard Java APIs.
GZIP - Enum constant in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
 
GZIP Support - Search tag in class io.fluxcapacitor.common.serialization.compression.CompressionUtils
Section

H

handle(StoreValues) - Method in class io.fluxcapacitor.testserver.websocket.KeyValueEndPoint
 
handle(GetSearchHistogram) - Method in class io.fluxcapacitor.testserver.websocket.SearchEndpoint
 
handle(SearchDocuments) - Method in class io.fluxcapacitor.testserver.websocket.SearchEndpoint
 
handle(SerializedMessage, URI, WebRequestSettings) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
handle(DeserializingMessage) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
Attempts to handle the given message using local handlers.
handle(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
handle(DeserializingMessage) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.NoOpHandlerRegistry
 
handle(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
 
handle(DeserializingMessage, HandlerInvoker, Handler<DeserializingMessage>, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
handle(Entity<?>, List<AppliedEvent>, Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot.CommitHandler
 
handle(ContextRefreshedEvent) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Registers all discovered Spring beans as Flux Capacitor handlers once the application context is refreshed.
Handle - Annotation Interface in io.fluxcapacitor.testserver.websocket
 
handleBatch(Stream<DeserializingMessage>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
HandleCommand - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for command messages (MessageType.COMMAND).
HandleCustom - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for messages from a custom message topic.
HandleCustomFilter - Class in io.fluxcapacitor.javaclient.tracking.handling
A MessageFilter implementation that filters DeserializingMessage instances based on a custom topic defined in the HandleCustom annotation on handler methods.
HandleCustomFilter() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.HandleCustomFilter
 
HandleDelete - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP DELETE requests for the specified path(s).
handleDisconnects(List<SerializedMessage>) - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
HandleDocument - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for document messages within a search collection.
HandleDocumentFilter - Class in io.fluxcapacitor.javaclient.tracking.handling
A MessageFilter that routes DeserializingMessage instances to methods annotated with HandleDocument, based on the message's topic.
HandleDocumentFilter() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.HandleDocumentFilter
 
handleError(Throwable, String, Runnable) - Method in interface io.fluxcapacitor.javaclient.tracking.ErrorHandler
Handles an error encountered during message processing and provides an option to retry the operation.
handleError(Throwable, String, Callable<?>) - Method in interface io.fluxcapacitor.javaclient.tracking.ErrorHandler
Handles an error encountered during message processing and provides an option to retry the operation.
handleError(Throwable, String, Callable<?>) - Method in class io.fluxcapacitor.javaclient.tracking.LoggingErrorHandler
Logs the given error and allows tracking to continue.
handleError(Throwable, String, Callable<?>) - Method in class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Handles the error by retrying the operation if allowed, or propagating/logging based on configuration.
handleError(Throwable, String, Callable<?>) - Method in class io.fluxcapacitor.javaclient.tracking.SilentErrorHandler
Handles the given error by optionally logging it and then returning it without retry or propagation.
handleError(Throwable, String, Callable<?>) - Method in class io.fluxcapacitor.javaclient.tracking.ThrowingErrorHandler
Handles the given error by optionally logging it and then throwing it to halt message tracking.
handleError(Throwable, T) - Method in interface io.fluxcapacitor.common.ErrorHandler
Handles the given Throwable in the context of the provided value.
HandleError - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for error messages (MessageType.ERROR).
HandleEvent - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as an event handler for incoming messages of type MessageType.EVENT.
handleEvents(List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
handleExceptionalResult(Throwable, DeserializingMessage, Instant, Periodic) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
HandleGet - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP GET requests for the specified path(s).
HandleHead - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP HEAD requests for the specified path(s).
handleLocally(Schedule) - Method in class io.fluxcapacitor.javaclient.scheduling.DefaultMessageScheduler
 
handleMessage(Session, JsonType) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
HandleMessage - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Meta-annotation used to declare that an annotation marks a method as a message handler for a specific MessageType.
HandleMessageEvent - Class in io.fluxcapacitor.javaclient.tracking.metrics
 
HandleMessageEvent() - Constructor for class io.fluxcapacitor.javaclient.tracking.metrics.HandleMessageEvent
 
HandleMetrics - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for internal metrics events (MessageType.METRICS).
HandleNotification - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for notification messages (MessageType.NOTIFICATION).
HandleOptions - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP OPTIONS requests for the specified path(s).
HandlePatch - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP PATCH requests for the specified path(s).
HandlePost - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP POST requests for the specified path(s).
HandlePut - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP PUT requests for the specified path(s).
HandleQuery - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for query messages (MessageType.QUERY).
Handler<M> - Interface in io.fluxcapacitor.common.handling
Represents a container for a message handler and the mechanism to resolve a HandlerInvoker for a given message.
Handler.DelegatingHandler<M> - Class in io.fluxcapacitor.common.handling
Abstract base class for Handler implementations that delegate to another handler.
Handler Activation - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Section
Handler Architecture - Search tag in interface io.fluxcapacitor.common.handling.Handler
Section
HandlerConfiguration<M> - Class in io.fluxcapacitor.common.handling
Configuration object used to define how message handler methods are selected and filtered for a given message type.
HandlerConfiguration() - Constructor for class io.fluxcapacitor.common.handling.HandlerConfiguration
 
HandlerDecorator - Interface in io.fluxcapacitor.javaclient.tracking.handling
Functional interface for decorating Handler instances that process DeserializingMessage objects.
HandlerDecorator.MergedDecorator - Class in io.fluxcapacitor.javaclient.tracking.handling
A composite decorator that merges two decorators into one.
handleRequest(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
 
handleRequest(HttpServerExchange) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
handleResponse(SerializedMessage, WebRequest, HttpServerExchange) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
handleResult(RequestResult, String) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
handleResult(Object) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler.StatefulHandlerInvoker
 
handleResult(Object, DeserializingMessage, Instant, Periodic) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
HandleResult - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for result messages (MessageType.RESULT).
handleResultMessages(List<SerializedMessage>) - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
handleResults(List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
 
HandlerFactory - Interface in io.fluxcapacitor.javaclient.tracking.handling
Factory interface for creating Handler instances that process DeserializingMessages.
HandlerFilter - Interface in io.fluxcapacitor.common.handling
Represents a predicate used to determine whether a given method should be considered a valid message handler.
HandlerInspector - Class in io.fluxcapacitor.common.handling
Utility for inspecting and constructing handler components from annotated methods.
HandlerInspector() - Constructor for class io.fluxcapacitor.common.handling.HandlerInspector
 
HandlerInspector.MethodHandlerMatcher<M> - Class in io.fluxcapacitor.common.handling
A matcher that encapsulates metadata and resolution logic for a single handler method or constructor.
HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker - Class in io.fluxcapacitor.common.handling
 
HandlerInspector.ObjectHandlerMatcher<M> - Class in io.fluxcapacitor.common.handling
A composite HandlerMatcher that delegates to a list of individual matchers.
HandlerInterceptor - Interface in io.fluxcapacitor.javaclient.tracking.handling
Intercepts individual message handling operations, enabling cross-cutting behavior around handler invocation.
HandlerInterceptor.InterceptedHandler - Class in io.fluxcapacitor.javaclient.tracking.handling
Implementation of Handler that delegates to another handler and applies a HandlerInterceptor.
handlerInterceptors() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Interceptors applied to individual handler method invocations.
HandlerInvoker - Interface in io.fluxcapacitor.common.handling
Represents an invocable handler method.
HandlerInvoker.DelegatingHandlerInvoker - Class in io.fluxcapacitor.common.handling
A HandlerInvoker that delegates all behavior to another instance.
HandlerInvoker.SimpleInvoker - Class in io.fluxcapacitor.common.handling
A simple invoker backed by a Callable, typically used for test utilities or framework-internal logic.
HandlerMatcher<T,M> - Interface in io.fluxcapacitor.common.handling
Defines the logic to determine whether a given target object can handle a message, and how to invoke it.
HandlerMonitor - Class in io.fluxcapacitor.javaclient.tracking.metrics
 
HandlerMonitor() - Constructor for class io.fluxcapacitor.javaclient.tracking.metrics.HandlerMonitor
 
HandlerRegistry - Interface in io.fluxcapacitor.javaclient.tracking.handling
Interface for registering and invoking local message handlers.
HandlerRegistry.MergedHandlerRegistry - Class in io.fluxcapacitor.javaclient.tracking.handling
Combines two HandlerRegistry instances into one.
HandlerRegistry.NoOpHandlerRegistry - Enum Class in io.fluxcapacitor.javaclient.tracking.handling
A no-op handler registry that performs no registration or dispatch.
HandlerRepository - Interface in io.fluxcapacitor.javaclient.modeling
Repository interface for storing and retrieving @Stateful handler instances.
handlerRepositorySupplier(Supplier<DocumentStore>, DocumentSerializer) - Static method in class io.fluxcapacitor.javaclient.modeling.DefaultHandlerRepository
Returns a factory function that creates a HandlerRepository for a given handler type.
Handler requiring an authenticated user - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresUser
Section
Handler Resolution Process - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
Section
HandleSchedule - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a method or constructor as a handler for scheduled messages (MessageType.SCHEDULE).
HandleSocketClose - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles a WebSocket connection close event.
HandleSocketHandshake - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles a WebSocket handshake request, invoked when a client first attempts to connect using a specialised GET request.
HandleSocketMessage - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles an incoming WebSocket message.
HandleSocketOpen - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles the opening of a WebSocket connection (after handshake).
HandleSocketPong - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles a PONG WebSocket frame, typically sent in response to a PING.
HandleTrace - Annotation Interface in io.fluxcapacitor.javaclient.web
Handles incoming HTTP TRACE requests for the specified path(s).
handleUpdate(UnaryOperator<Entity<T>>) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
HandleWeb - Annotation Interface in io.fluxcapacitor.javaclient.web
Marks a method or meta-annotation as a handler for incoming web requests (MessageType.WEBREQUEST).
HandleWebResponse - Annotation Interface in io.fluxcapacitor.javaclient.web
Marks a method as a handler for MessageType.WEBRESPONSE messages.
Handling - Search tag in class io.fluxcapacitor.common.api.scheduling.Schedule
Section
Handling Strategies - Search tag in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
Section
HardCacheReference() - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache.HardCacheReference
 
has(Class<? extends Annotation>, Method) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
has(Class<? extends Annotation>, Parameter) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
hasCasterMethods(Class<?>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.casting.CastInspector
Returns true if the given class contains any method annotated with Cast.
hasDocument(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
hasDocument(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Checks if a document exists in the specified collection.
HasDocument - Class in io.fluxcapacitor.common.api.search
A request to check whether a document exists in a given collection.
HasDocument() - Constructor for class io.fluxcapacitor.common.api.search.HasDocument
 
HasEntity - Interface in io.fluxcapacitor.javaclient.modeling
Represents an object, typically a message used for invocation, that has an associated Entity.
hasExpired(Clock) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.DefaultCache.CacheReference
 
hasHandlerMethods(Class<?>, HandlerConfiguration<?>) - Static method in class io.fluxcapacitor.common.handling.HandlerInspector
Returns whether the given class contains at least one method or constructor that matches the handler configuration.
hashCode() - Method in class io.fluxcapacitor.common.api.Data
 
hashCode() - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
hashCode() - Method in class io.fluxcapacitor.common.tracking.WebSocketTracker
 
hashCode() - Method in class io.fluxcapacitor.javaclient.modeling.Id
 
hashCode() - Method in record class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler.ResponseCallback
Returns a hash code value for this object.
hashCode() - Method in record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Returns a hash code value for this object.
hashCode() - Method in record class io.fluxcapacitor.javaclient.web.StaticFileHandler.ByteRange
Returns a hash code value for this object.
hashCode() - Method in record class io.fluxcapacitor.proxy.WebsocketEndpoint.SessionContext
Returns a hash code value for this object.
HasId - Interface in io.fluxcapacitor.common.api
Interface for exposing a string-based representation of an object's identifier.
hasLocalHandlers() - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
hasLocalHandlers() - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.NoOpHandlerRegistry
 
hasLocalHandlers() - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HasLocalHandlers
Indicates whether any local handlers are currently registered for this gateway.
hasLocalHandlers() - Method in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
 
HasLocalHandlers - Interface in io.fluxcapacitor.javaclient.tracking.handling
Base interface for gateways that support registering local message handlers.
HasMessage - Interface in io.fluxcapacitor.javaclient.common
Interface for objects that expose a backing Message instance.
HasMessageStore - Interface in io.fluxcapacitor.common.tracking
Interface for components that expose a MessageStore.
HasMetadata - Interface in io.fluxcapacitor.common.api
Marker interface for objects that carry associated Metadata.
hasMissedDeadline() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
hasPassedDeadline() - Method in class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
 
hasPathConstraint() - Method in interface io.fluxcapacitor.common.api.search.Constraint
Indicates whether this constraint targets specific paths in the document.
hasPathConstraint() - Method in class io.fluxcapacitor.common.api.search.constraints.AllConstraint
 
hasPathConstraint() - Method in class io.fluxcapacitor.common.api.search.constraints.AnyConstraint
 
hasPathConstraint() - Method in class io.fluxcapacitor.common.api.search.constraints.FacetConstraint
This constraint does not apply to specific document paths, so this always returns false.
hasPathConstraint() - Method in class io.fluxcapacitor.common.api.search.constraints.NotConstraint
 
hasPathConstraint() - Method in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
 
hasPathConstraint() - Method in class io.fluxcapacitor.common.api.search.NoOpConstraint
Always returns false, as this constraint is not tied to any document path.
hasPathParameter(String) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Checks if the given path contains a named path parameter.
hasProperty(String, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
hasRole(String) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.User
Indicates whether this user has the specified role.
hasSchedule(String) - Method in interface io.fluxcapacitor.javaclient.scheduling.client.SchedulingClient
Checks whether a schedule with the given ID currently exists.
hasSequenceNumber(HasMetadata) - Static method in interface io.fluxcapacitor.javaclient.modeling.Entity
Determines whether the given message contains a sequence number in its metadata.
HasSource<T> - Interface in io.fluxcapacitor.javaclient.common.serialization.casting
Marker interface for wrapper objects that retain a reference to their originating source.
HEAD - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
header(String, String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
header(String, String) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
header(String, String, boolean) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
header(String, Collection<String>) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
HEADER - Enum constant in enum class io.fluxcapacitor.javaclient.web.WebParameterSource
HTTP request headers
headerIfAbsent(String, String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
HeaderParam - Annotation Interface in io.fluxcapacitor.javaclient.web
Injects an HTTP request header into a handler method parameter.
headers() - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
headers() - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
headers(Map<String, List<String>>) - Method in class io.fluxcapacitor.javaclient.web.WebRequest.Builder
 
headers(Map<String, List<String>>) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
headersKey - Static variable in class io.fluxcapacitor.javaclient.web.WebRequest
 
headersKey - Static variable in class io.fluxcapacitor.javaclient.web.WebResponse
 
HIGHEST_PRIORITY - Static variable in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
 
highestEventIndex() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the highest event index associated with the aggregate.
highPrioDispatchInterceptors() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Dispatch interceptors applied before low-priority interceptors.
highPrioHandlerDecorators() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Decorators applied to handlers before low-priority decorators.
How it works - Search tag in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter
Section
How It Works - Search tag in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
Section
How It Works - Search tag in class io.fluxcapacitor.javaclient.web.WebParameterProcessor
Section
HTTP_1_1 - Enum constant in enum class io.fluxcapacitor.javaclient.web.HttpVersion
 
HTTP_2 - Enum constant in enum class io.fluxcapacitor.javaclient.web.HttpVersion
 
HttpRequestMethod - Interface in io.fluxcapacitor.javaclient.web
Defines constants for standard and extended HTTP request methods used by Flux Capacitor's web handling system.
HttpVersion - Enum Class in io.fluxcapacitor.javaclient.web
Enumerates supported HTTP protocol versions for web requests and responses handled through the Flux platform.

I

id() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the unique identifier of this client instance.
id() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
id() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
id() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the unique identifier of the entity.
id() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
id() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
id() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
id() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Returns the configured ID of the document.
id(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Sets the ID of the document to index.
Id<T> - Class in io.fluxcapacitor.javaclient.modeling
Object that represents the identifier of a specific entity.
Id(String, Class<T>, String, boolean) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct an id for an entity.
Id(String, String, boolean) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct an id for an entity.
Id(String) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct a case-sensitive id for an entity without prefix.
Id(String, boolean) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct an id for an entity without prefix.
Id(String, Class<T>) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct a case-sensitive id for an entity without prefix.
Id(String, Class<T>, boolean) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct an id for an entity without prefix.
Id(String, Class<T>, String) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct a case-sensitive id for an entity.
Id(String, String) - Constructor for class io.fluxcapacitor.javaclient.modeling.Id
Construct a case-sensitive id for an entity.
identifier - Static variable in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
identityFunction - Static variable in class io.fluxcapacitor.common.search.Document
 
identityProvider() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Returns the provider used to generate or resolve application-specific identities.
identityProvider() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the factory used by Flux Capacitor to generate identifiers.
IdentityProvider - Interface in io.fluxcapacitor.javaclient.common
Strategy interface for generating unique identifiers used throughout the Flux platform.
idFromValue(Object) - Method in class io.fluxcapacitor.common.serialization.GlobalTypeIdResolver
 
idFromValueAndType(Object, Class<?>) - Method in class io.fluxcapacitor.common.serialization.GlobalTypeIdResolver
 
idProperty() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
idProperty() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the name of the property that serves as the unique identifier for the entity.
idProperty() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
idProperty() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Member
Specifies the name of the identifier property on the nested entity, if different from the default detected one.
idProperty() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
idProperty() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
IF_MODIFIED - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublication
Only publish or store the update if the entity's state is actually modified by the application.
ifClass(Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
Determines and returns the Class of the provided object if it is either an instance of Class or a Kotlin class that can be converted using Kotlin reflection utilities.
ifNotExists() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Whether the operation is configured to only index if the document doesn't already exist.
ifNotExists(boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
If set to true, only index the document if it does not already exist.
ifPresent(UnaryOperator<Entity<T>>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Applies the specified action to this entity if it is present, returning the result of the action.
ifTrue(boolean) - Static method in class io.fluxcapacitor.common.ObjectUtils
Returns a consumer that runs the task only if check is true.
IGNORE - Enum constant in enum class io.fluxcapacitor.javaclient.common.serialization.UnknownTypeStrategy
 
ignoreEvent(ILoggingEvent) - Method in class io.fluxcapacitor.javaclient.common.logging.FluxCapacitorLogbackAppender
Determines whether the given log event should be ignored.
ignoreMarker - Static variable in class io.fluxcapacitor.javaclient.common.ClientUtils
A marker used to denote specific log entries that should be ignored or treated differently, typically to bypass error handling in logging frameworks.
ignoreSegment() - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
ignoreSegment() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
ignoreSegment() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
If true, this consumer will bypass the default segment-based sharding applied by the Flux platform and attempt to process all message segments.
ignoreSilently(Class<?>, User) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Determines whether a particular operation on a payload type should be ignored without raising an exception.
ignoreSilently(Class<?>, Executable, User) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Determines whether a specific method invocation on a target class by a given user should be ignored without raising an exception, based on the user's authorization.
ignoreUnknownEvents() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Whether to ignore unknown events during event sourcing (disabled by default).
IllegalCommandException - Exception Class in io.fluxcapacitor.javaclient.tracking.handling
Thrown to indicate that a command was rejected due to business logic violations.
IllegalCommandException(String) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.handling.IllegalCommandException
 
Immutability and parent updates - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.Member
Section
ImmutableAggregateRoot<T> - Class in io.fluxcapacitor.javaclient.modeling
Immutable representation of an AggregateRoot, extending ImmutableEntity with additional metadata for event sourcing.
ImmutableAggregateRoot() - Constructor for class io.fluxcapacitor.javaclient.modeling.ImmutableAggregateRoot
 
immutableCandidateExtensions() - Element in annotation interface io.fluxcapacitor.javaclient.web.ServeStatic
File extensions considered candidates for immutable caching when their filenames are fingerprinted.
ImmutableEntity<T> - Class in io.fluxcapacitor.javaclient.modeling
Immutable implementation of the Entity interface, representing a snapshot of a domain entity.
ImmutableEntity() - Constructor for class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
Important Notes - Search tag in class io.fluxcapacitor.common.api.eventsourcing.DeleteEvents
Section
includedClasses() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Returns payload classes for which this association can be used.
includedPayload(Object, StatefulHandler.AssociationValue) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
 
includeOnly(String...) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
includeOnly(String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Includes only the specified fields in the returned documents.
index - Enum constant in enum class io.fluxcapacitor.common.api.search.BulkUpdate.Type
 
index() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Executes the indexing operation with a default guarantee of Guarantee.STORED.
index(Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultIndexOperation
 
index(Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Executes the indexing operation with the provided guarantee.
index(Object, Object, Object, Instant, Instant, Metadata, Guarantee, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a document with the specified guarantees, metadata, and if-not-exists condition.
index(Object, Object, Object, Instant, Instant, Guarantee, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a document with the specified guarantees, metadata, and if-not-exists condition.
index(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes one or more objects using the default configuration.
index(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes one or more objects into the specified collection.
index(Object, Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a single object with an explicitly provided ID and collection.
index(Object, Object, Object, Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a single object at a specific timestamp.
index(Object, Object, Object, Instant, Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a single object with a specific start and end time.
index(Object, Object, Object, Instant, Instant, Metadata, Guarantee, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
index(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Index given object for search.
index(Object, Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Index given object for search.
index(Object, Object, Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Index given object for search.
index(Object, Object, Object, Instant) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Index given object for search.
index(Object, Object, Object, Instant, Instant) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Index given object for search.
index(Collection<?>, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects into a named collection.
index(Collection<?>, Object, String, String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects using property paths for ID and timestamps.
index(Collection<?>, Object, String, String, String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects using property paths for ID, start, and end timestamps.
index(Collection<?>, Object, String, String, String, Guarantee, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
index(Collection<?>, Object, String, String, String, Guarantee, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects using functional accessors for ID and time intervals.
index(Collection<? extends T>, Object, Function<? super T, ?>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects using a function to extract the object ID.
index(Collection<? extends T>, Object, Function<? super T, ?>, Function<? super T, Instant>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects using property paths for ID, start, and end timestamps.
index(Collection<? extends T>, Object, Function<? super T, ?>, Function<? super T, Instant>, Function<? super T, Instant>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects using property paths for ID, start, and end timestamps.
index(Collection<? extends T>, Object, Function<? super T, ?>, Function<? super T, Instant>, Function<? super T, Instant>, Guarantee, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
index(Collection<? extends T>, Object, Function<? super T, ?>, Function<? super T, Instant>, Function<? super T, Instant>, Guarantee, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a collection of objects using functional accessors for ID and time intervals.
index(Collection<? extends T>, Object, Function<? super T, String>, Function<? super T, Instant>, Function<? super T, Instant>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Index given objects for search.
index(List<SerializedDocument>, Guarantee, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
index(List<SerializedDocument>, Guarantee, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Indexes a list of serialized documents into the search engine.
index(List<SerializedDocument>, Guarantee, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
indexAndForget() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Executes the indexing operation with a Guarantee.NONE guarantee and does not wait for completion.
indexAndWait() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Executes the indexing operation with Guarantee.STORED and blocks until it is completed.
indexAndWait(Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Executes the indexing operation with the specified guarantee and blocks until it is completed.
IndexDocument - Class in io.fluxcapacitor.common.api.search.bulkupdate
A bulk update operation that indexes (inserts or replaces) a document in the store.
IndexDocument() - Constructor for class io.fluxcapacitor.common.api.search.bulkupdate.IndexDocument
 
IndexDocumentIfNotExists - Class in io.fluxcapacitor.common.api.search.bulkupdate
A bulk update operation that indexes a document only if it does not already exist in the store.
IndexDocumentIfNotExists() - Constructor for class io.fluxcapacitor.common.api.search.bulkupdate.IndexDocumentIfNotExists
 
IndexDocuments - Class in io.fluxcapacitor.common.api.search
Command used to index a collection of SerializedDocument instances in the search store.
IndexDocuments() - Constructor for class io.fluxcapacitor.common.api.search.IndexDocuments
 
IndexDocuments.Metric - Class in io.fluxcapacitor.common.api.search
 
indexForCurrentTime() - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Calculates an index based on the current timestamp from Flux Capacitor's internal clock.
indexFromMillis(long) - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Derives an index value from the given timestamp in milliseconds since the epoch by shifting it 16 bits to the left.
indexFromTimestamp(Instant) - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Computes an index based on the provided timestamp.
indexIfNotExists - Enum constant in enum class io.fluxcapacitor.common.api.search.BulkUpdate.Type
 
indexIfNotExists(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a document only if it is not already present in the index.
indexIfNotExists(Object, Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a document only if it is not already present in the index.
indexIfNotExists(Object, Object, Object, Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a document only if it is not already present in the index.
indexIfNotExists(Object, Object, Object, Instant, Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes a document only if it is not already present in the index.
indexIfNotExists(Collection<? extends T>, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes documents only if there are not already present in the index.
indexIfNotExists(Collection<? extends T>, Object, String, String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes documents only if there are not already present in the index.
indexIfNotExists(Collection<? extends T>, Object, String, String, String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes documents only if there are not already present in the index.
indexIfNotExists(Collection<? extends T>, Object, Function<? super T, ?>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes documents only if there are not already present in the index.
indexIfNotExists(Collection<? extends T>, Object, Function<? super T, ?>, Function<? super T, Instant>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes documents only if there are not already present in the index.
indexIfNotExists(Collection<? extends T>, Object, Function<? super T, ?>, Function<? super T, Instant>, Function<? super T, Instant>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Indexes documents only if there are not already present in the index.
IndexOperation - Interface in io.fluxcapacitor.javaclient.persisting.search
Builder-style interface for indexing documents into the DocumentStore.
IndexUtils - Class in io.fluxcapacitor.javaclient.tracking
Use 48 bits of the current time in milliseconds since epoch as the base of the index.
IndexUtils() - Constructor for class io.fluxcapacitor.javaclient.tracking.IndexUtils
 
init(ProcessingEnvironment) - Method in class io.fluxcapacitor.common.serialization.TypeRegistryProcessor
 
init(ProcessingEnvironment) - Method in class io.fluxcapacitor.javaclient.web.WebParameterProcessor
 
initialDelay() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Returns the initial schedule delay.
initializePeriodicSchedule(Class<?>, Periodic) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
Injection Behavior - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Section
inLast(Duration) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters documents within the last given duration (e.g., last 7 days).
InMemoryEventStore - Class in io.fluxcapacitor.javaclient.persisting.eventsourcing.client
An implementation of the EventStoreClient interface that provides an in-memory event storage solution.
InMemoryEventStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
InMemoryEventStore(Duration) - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
InMemoryKeyValueStore - Class in io.fluxcapacitor.javaclient.persisting.keyvalue.client
An in-memory implementation of the KeyValueClient interface.
InMemoryKeyValueStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.keyvalue.client.InMemoryKeyValueStore
 
InMemoryKeyValueStore(Map<String, Data<byte[]>>) - Constructor for class io.fluxcapacitor.javaclient.persisting.keyvalue.client.InMemoryKeyValueStore
 
InMemoryMessageStore - Class in io.fluxcapacitor.javaclient.tracking.client
An in-memory implementation of the MessageStore interface for storing SerializedMessages without external persistence.
InMemoryMessageStore(MessageType) - Constructor for class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
InMemoryPositionStore - Class in io.fluxcapacitor.common.tracking
 
InMemoryPositionStore() - Constructor for class io.fluxcapacitor.common.tracking.InMemoryPositionStore
 
InMemoryScheduleStore - Class in io.fluxcapacitor.javaclient.scheduling.client
An in-memory implementation of a scheduling store that allows the scheduling, retrieval, and management of scheduled messages.
InMemoryScheduleStore() - Constructor for class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
InMemoryScheduleStore(Duration) - Constructor for class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
InMemorySearchStore - Class in io.fluxcapacitor.javaclient.persisting.search.client
In-memory implementation of the SearchClient, intended for local testing and development.
InMemorySearchStore() - Constructor for class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
InMemoryTaskScheduler - Class in io.fluxcapacitor.common
An in-memory implementation of the TaskScheduler interface, enabling scheduling and execution of tasks in a virtualized time environment.
InMemoryTaskScheduler() - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(int) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(int, String) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(int, String, Clock) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(int, String, Clock, ExecutorService) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(int, Clock) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(String) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(String, Clock) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(String, Clock, ExecutorService) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler(Clock) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler
 
InMemoryTaskScheduler.Task - Class in io.fluxcapacitor.common
 
inPeriod(Instant, boolean, Instant, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
inPeriod(Instant, boolean, Instant, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters documents within a specified time range.
inPeriod(Instant, Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters documents within the given time range.
InputParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling
Resolves handler method parameters by simply injecting the input if the parameter type is assignable from the input type.
InputParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.InputParameterResolver
 
inspect(Class<?>, List<ParameterResolver<? super M>>, HandlerConfiguration<? super M>) - Static method in class io.fluxcapacitor.common.handling.HandlerInspector
Inspects the given class for methods matching the specified annotation and builds a HandlerMatcher.
inspect(Class<?>, List<ParameterResolver<? super M>>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.handling.HandlerInspector
Inspects the given class for methods matching the specified annotation and builds a HandlerMatcher.
instance - Static variable in class io.fluxcapacitor.common.api.search.NoOpConstraint
Singleton instance of the no-op constraint.
instance - Static variable in interface io.fluxcapacitor.javaclient.FluxCapacitor
Thread-local binding of the current FluxCapacitor instance.
INSTANCE - Enum constant in enum class io.fluxcapacitor.common.application.EnvironmentVariablesSource
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.common.application.NoOpPropertySource
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.common.search.DefaultDocumentSerializer
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.common.serialization.NoOpTypeRegistry
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoOpSnapshotStore
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoSnapshotTrigger
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.javaclient.publishing.correlation.DefaultCorrelationDataProvider
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
 
INSTANCE - Enum constant in enum class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.NoOpHandlerRegistry
 
instant() - Method in class io.fluxcapacitor.common.DelegatingClock
 
instantiateTarget() - Method in class io.fluxcapacitor.javaclient.tracking.handling.MutableHandler
 
Interaction with HandleSchedule - Search tag in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Section
intercept(Object, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
Intercepts the given value using @InterceptApply methods defined on the entity.
intercept(Object, Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.EntityHelper
Intercepts the given value before it is applied to an entity.
intercept(Consumer<MessageBatch>, Tracker) - Method in interface io.fluxcapacitor.javaclient.tracking.BatchInterceptor
Intercepts the given batch message consumer and returns a decorated version to be invoked by the tracker.
intercept(Consumer<MessageBatch>, Tracker) - Method in class io.fluxcapacitor.javaclient.tracking.FluxCapacitorInterceptor
 
intercept(Consumer<MessageBatch>, Tracker) - Method in interface io.fluxcapacitor.javaclient.tracking.MappingBatchInterceptor
Wraps the batch processing consumer with a transformation step that rewrites the batch before processing.
intercept(Consumer<MessageBatch>, Tracker) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.DisableMetrics
 
intercept(Consumer<MessageBatch>, Tracker) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.TrackerMonitor
 
intercept(Consumer<MessageBatch>, Tracker) - Method in class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
 
intercept(Function<BEFORE, ? extends I>, Function<? super O, AFTER>) - Method in interface io.fluxcapacitor.javaclient.common.serialization.casting.Caster
Creates a new Caster that applies preprocessing and postprocessing steps before and after the core cast.
intercept(Function<BEFORE, ? extends I>, Function<? super O, AFTER>) - Method in interface io.fluxcapacitor.javaclient.common.serialization.casting.CasterChain
Composes this caster chain with input and output interceptors.
InterceptApply - Annotation Interface in io.fluxcapacitor.javaclient.persisting.eventsourcing
Indicates that a method should intercept and potentially transform an update before it is applied to an entity.
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Intercepts a message before dispatch for the given message type and topic.
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.publishing.correlation.CorrelatingInterceptor
 
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.publishing.dataprotection.DataProtectionInterceptor
 
interceptDispatch(Message, MessageType, String) - Method in interface io.fluxcapacitor.javaclient.publishing.DispatchInterceptor
Intercepts the dispatch of a message before it is serialized and published or locally handled.
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.publishing.routing.MessageRoutingInterceptor
Returns the unmodified Message as this interceptor only modifies the serialized form.
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AuthenticatingInterceptor
 
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.web.WebResponseCompressingInterceptor
No-op for message interception.
interceptDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.web.WebsocketResponseInterceptor
Intercepts and conditionally modifies an outgoing message in the context of a WebSocket request.
interceptDispatch(Object, Metadata) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultResultGateway
 
InterceptedHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor.InterceptedHandler
 
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.publishing.dataprotection.DataProtectionInterceptor
 
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AuthenticatingInterceptor
 
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.handling.errorreporting.ErrorReportingInterceptor
 
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor
Intercepts the message handling logic.
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidatingInterceptor
 
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.DisableMetrics
 
interceptHandling(Function<DeserializingMessage, Object>, HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.HandlerMonitor
 
intermediateCallback() - Method in record class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler.ResponseCallback
Returns the value of the intermediateCallback record component.
Internal Mechanics - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
Section
Internals - Search tag in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
Section
Internal Use Only - Search tag in class io.fluxcapacitor.common.reflection.ParameterRegistry
Section
invert(byte[]) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
Inverter<T> - Interface in io.fluxcapacitor.common.search
Interface responsible for converting a domain object into a SerializedDocument for indexing, and vice versa—deserializing a byte[] representation into the original object type.
Invocation - Class in io.fluxcapacitor.javaclient.tracking.handling
Tracks the lifecycle and identity of a single message handler invocation.
Invocation() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.Invocation
 
invoke() - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Invokes the handler using the default result-combining strategy (returns the first result).
invoke(Object) - Method in interface io.fluxcapacitor.common.reflection.MemberInvoker
Invokes the member with no parameters.
invoke(Object, int, IntFunction<?>) - Method in class io.fluxcapacitor.common.reflection.DefaultMemberInvoker
 
invoke(Object, int, IntFunction<?>) - Method in interface io.fluxcapacitor.common.reflection.MemberInvoker
Invokes the member with the provided number of parameters using a parameter provider.
invoke(Object, Object) - Method in interface io.fluxcapacitor.common.reflection.MemberInvoker
Invokes the member with a single parameter.
invoke(Object, Object...) - Method in interface io.fluxcapacitor.common.reflection.MemberInvoker
Invokes the member with a variable number of parameters.
invoke(BiFunction<Object, Object, Object>) - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Invokes the handler and combines results using the given combiner function.
invoke(BiFunction<Object, Object, Object>) - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.SimpleInvoker
 
invoke(BiFunction<Object, Object, Object>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator.DocumentHandler.DocumentHandlerInvoker
 
invoke(BiFunction<Object, Object, Object>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler.StatefulHandlerInvoker
 
io.fluxcapacitor.common - package io.fluxcapacitor.common
 
io.fluxcapacitor.common.api - package io.fluxcapacitor.common.api
 
io.fluxcapacitor.common.api.eventsourcing - package io.fluxcapacitor.common.api.eventsourcing
 
io.fluxcapacitor.common.api.keyvalue - package io.fluxcapacitor.common.api.keyvalue
 
io.fluxcapacitor.common.api.modeling - package io.fluxcapacitor.common.api.modeling
 
io.fluxcapacitor.common.api.publishing - package io.fluxcapacitor.common.api.publishing
 
io.fluxcapacitor.common.api.scheduling - package io.fluxcapacitor.common.api.scheduling
 
io.fluxcapacitor.common.api.search - package io.fluxcapacitor.common.api.search
 
io.fluxcapacitor.common.api.search.bulkupdate - package io.fluxcapacitor.common.api.search.bulkupdate
 
io.fluxcapacitor.common.api.search.constraints - package io.fluxcapacitor.common.api.search.constraints
 
io.fluxcapacitor.common.api.tracking - package io.fluxcapacitor.common.api.tracking
 
io.fluxcapacitor.common.application - package io.fluxcapacitor.common.application
 
io.fluxcapacitor.common.encryption - package io.fluxcapacitor.common.encryption
 
io.fluxcapacitor.common.handling - package io.fluxcapacitor.common.handling
 
io.fluxcapacitor.common.reflection - package io.fluxcapacitor.common.reflection
 
io.fluxcapacitor.common.search - package io.fluxcapacitor.common.search
 
io.fluxcapacitor.common.serialization - package io.fluxcapacitor.common.serialization
 
io.fluxcapacitor.common.serialization.compression - package io.fluxcapacitor.common.serialization.compression
 
io.fluxcapacitor.common.tracking - package io.fluxcapacitor.common.tracking
 
io.fluxcapacitor.javaclient - package io.fluxcapacitor.javaclient
 
io.fluxcapacitor.javaclient.common - package io.fluxcapacitor.javaclient.common
 
io.fluxcapacitor.javaclient.common.exception - package io.fluxcapacitor.javaclient.common.exception
 
io.fluxcapacitor.javaclient.common.logging - package io.fluxcapacitor.javaclient.common.logging
 
io.fluxcapacitor.javaclient.common.serialization - package io.fluxcapacitor.javaclient.common.serialization
 
io.fluxcapacitor.javaclient.common.serialization.casting - package io.fluxcapacitor.javaclient.common.serialization.casting
 
io.fluxcapacitor.javaclient.common.serialization.jackson - package io.fluxcapacitor.javaclient.common.serialization.jackson
 
io.fluxcapacitor.javaclient.common.websocket - package io.fluxcapacitor.javaclient.common.websocket
 
io.fluxcapacitor.javaclient.configuration - package io.fluxcapacitor.javaclient.configuration
 
io.fluxcapacitor.javaclient.configuration.client - package io.fluxcapacitor.javaclient.configuration.client
 
io.fluxcapacitor.javaclient.configuration.spring - package io.fluxcapacitor.javaclient.configuration.spring
 
io.fluxcapacitor.javaclient.modeling - package io.fluxcapacitor.javaclient.modeling
 
io.fluxcapacitor.javaclient.persisting.caching - package io.fluxcapacitor.javaclient.persisting.caching
 
io.fluxcapacitor.javaclient.persisting.eventsourcing - package io.fluxcapacitor.javaclient.persisting.eventsourcing
 
io.fluxcapacitor.javaclient.persisting.eventsourcing.client - package io.fluxcapacitor.javaclient.persisting.eventsourcing.client
 
io.fluxcapacitor.javaclient.persisting.keyvalue - package io.fluxcapacitor.javaclient.persisting.keyvalue
 
io.fluxcapacitor.javaclient.persisting.keyvalue.client - package io.fluxcapacitor.javaclient.persisting.keyvalue.client
 
io.fluxcapacitor.javaclient.persisting.repository - package io.fluxcapacitor.javaclient.persisting.repository
 
io.fluxcapacitor.javaclient.persisting.search - package io.fluxcapacitor.javaclient.persisting.search
 
io.fluxcapacitor.javaclient.persisting.search.client - package io.fluxcapacitor.javaclient.persisting.search.client
 
io.fluxcapacitor.javaclient.publishing - package io.fluxcapacitor.javaclient.publishing
 
io.fluxcapacitor.javaclient.publishing.client - package io.fluxcapacitor.javaclient.publishing.client
 
io.fluxcapacitor.javaclient.publishing.correlation - package io.fluxcapacitor.javaclient.publishing.correlation
 
io.fluxcapacitor.javaclient.publishing.dataprotection - package io.fluxcapacitor.javaclient.publishing.dataprotection
 
io.fluxcapacitor.javaclient.publishing.routing - package io.fluxcapacitor.javaclient.publishing.routing
 
io.fluxcapacitor.javaclient.scheduling - package io.fluxcapacitor.javaclient.scheduling
 
io.fluxcapacitor.javaclient.scheduling.client - package io.fluxcapacitor.javaclient.scheduling.client
 
io.fluxcapacitor.javaclient.tracking - package io.fluxcapacitor.javaclient.tracking
 
io.fluxcapacitor.javaclient.tracking.client - package io.fluxcapacitor.javaclient.tracking.client
 
io.fluxcapacitor.javaclient.tracking.handling - package io.fluxcapacitor.javaclient.tracking.handling
 
io.fluxcapacitor.javaclient.tracking.handling.authentication - package io.fluxcapacitor.javaclient.tracking.handling.authentication
 
io.fluxcapacitor.javaclient.tracking.handling.errorreporting - package io.fluxcapacitor.javaclient.tracking.handling.errorreporting
 
io.fluxcapacitor.javaclient.tracking.handling.validation - package io.fluxcapacitor.javaclient.tracking.handling.validation
 
io.fluxcapacitor.javaclient.tracking.metrics - package io.fluxcapacitor.javaclient.tracking.metrics
 
io.fluxcapacitor.javaclient.web - package io.fluxcapacitor.javaclient.web
 
io.fluxcapacitor.javaclient.web.internal - package io.fluxcapacitor.javaclient.web.internal
 
io.fluxcapacitor.proxy - package io.fluxcapacitor.proxy
 
io.fluxcapacitor.testserver - package io.fluxcapacitor.testserver
 
io.fluxcapacitor.testserver.metrics - package io.fluxcapacitor.testserver.metrics
 
io.fluxcapacitor.testserver.scheduling - package io.fluxcapacitor.testserver.scheduling
 
io.fluxcapacitor.testserver.websocket - package io.fluxcapacitor.testserver.websocket
 
isActive(Tracker) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Checks if the tracker is currently marked as active.
isAnnotationPresent(Class<?>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
isAnnotationPresent(Parameter, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
isApplying() - Static method in interface io.fluxcapacitor.javaclient.modeling.Entity
Indicates whether any entity is currently being applied to in this thread.
isAssignable(Parameter, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
Returns true if the entity or any of its parents match the expected parameter type.
isCached() - Method in class io.fluxcapacitor.common.DefaultMemoizingSupplier
 
isCached() - Method in interface io.fluxcapacitor.common.MemoizingSupplier
Returns whether this supplier has already cached a value.
isCached(K) - Method in class io.fluxcapacitor.common.DefaultMemoizingFunction
 
isCached(K) - Method in interface io.fluxcapacitor.common.MemoizingFunction
Checks if the given key has a cached value.
isCached(T, U) - Method in class io.fluxcapacitor.common.DefaultMemoizingBiFunction
 
isCached(T, U) - Method in interface io.fluxcapacitor.common.MemoizingBiFunction
Returns true if the function has already cached a value for the given inputs.
isDeserialized() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
isDeserialized() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingObject
Returns true if the payload has already been deserialized using the default type.
isEmpty() - Method in class io.fluxcapacitor.common.api.eventsourcing.EventBatch
Returns true if the batch contains no events.
isEmpty() - Method in class io.fluxcapacitor.common.api.tracking.MessageBatch
Indicates whether this message batch is empty.
isEmpty() - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Returns true if no trackers are currently registered.
isEmpty() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Checks if the current entity instance is empty.
isEmpty() - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Returns whether the cache is empty.
isEmpty() - Method in class io.fluxcapacitor.javaclient.tracking.handling.MutableHandler
 
isEmpty(SerializerProvider, Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter.FilteringSerializer
Determines if the value should be considered empty, based on whether filtering returns null.
isEmptyRange(int[]) - Static method in class io.fluxcapacitor.common.ConsistentHashing
Checks whether the segment range is empty (i.e., start == end).
isEncrypted(String) - Method in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
 
isEncrypted(String) - Method in class io.fluxcapacitor.common.encryption.DefaultEncryption
 
isEncrypted(String) - Method in interface io.fluxcapacitor.common.encryption.Encryption
Returns true if the given value is considered encrypted by this implementation.
isEncrypted(String) - Method in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
 
isEncryptedWithKnownAlgorithm(String) - Method in class io.fluxcapacitor.common.encryption.DefaultEncryption
 
isEqual(Object) - Static method in interface io.fluxcapacitor.common.ThrowingPredicate
Returns a predicate that tests if two arguments are equal according to Objects.equals(Object, Object).
isFilterMessageTarget() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
isHandler(Class<?>) - Static method in class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
isHandler(Class<?>, HandlerConfiguration<?>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
 
isIgnoreMessageTarget() - Method in class io.fluxcapacitor.common.api.tracking.Read
 
isInIoThread() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
isInteger(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Checks whether the input string is a parseable integer.
isKnownType(String) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Checks whether a given serialized type is recognized on the classpath.
isKnownType(String) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Determines whether the given type is known to the Jackson type system.
isKotlinReflectionSupported() - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
isLeafValue(Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
isLegal(Object, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper
isLegal(Object, Entity<?>) - Method in interface io.fluxcapacitor.javaclient.modeling.EntityHelper
Returns whether the given value is considered legal for the specified entity.
isLoading() - Static method in interface io.fluxcapacitor.javaclient.modeling.Entity
Indicates whether any entity is currently being loaded in this thread.
isLocalHandler(HandlerInvoker, HasMessage) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Determines if the specified handler method handles messages locally.
isLocalSelfHandler(HandlerInvoker, HasMessage) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Returns whether the handler method should only handle messages from the same instance ("self").
isLongPath(String) - Static method in class io.fluxcapacitor.common.search.Document.Path
Determines whether a given path string qualifies as a "long path".
isMethodAnnotationPresent(Class<?>, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
isMissedDeadline(long) - Static method in class io.fluxcapacitor.common.TimingUtils
Returns whether the given deadline has passed using the system UTC clock.
isMissedDeadline(Clock, long) - Static method in class io.fluxcapacitor.common.TimingUtils
Returns whether the given deadline has passed using the specified Clock.
isNew(int[]) - Method in class io.fluxcapacitor.common.api.tracking.Position
 
isNewIndex(int, Long) - Method in class io.fluxcapacitor.common.api.tracking.Position
 
isNewMessage(SerializedMessage) - Method in class io.fluxcapacitor.common.api.tracking.Position
 
isNullable(Parameter) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
ISO_FULL - Static variable in class io.fluxcapacitor.common.SearchUtils
Date-time formatter used to serialize or deserialize full ISO-8601 instant values with millisecond precision.
isOpen() - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
isOpen() - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
isOpen() - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Determines whether the WebSocket session is currently open.
isOrHas(Annotation, Class<? extends Annotation>) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
isParallel() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
isPassive() - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker
 
isPassive() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
isPassive() - Method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Indicates whether this handler operates in passive mode (i.e., results will not be published).
isPassive() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.SimpleInvoker
 
isPassive(Annotation) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
isPresent() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Checks whether the entity is considered present.
isResponseStarted() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
isRestricted(String) - Method in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
isRoot() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Determines whether the current entity is the root entity in its hierarchical structure.
isSelfTracking(Class<?>, Executable) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Returns whether the specified method or its declaring class is marked with TrackSelf.
isShutdown() - Method in class io.fluxcapacitor.common.DirectExecutorService
 
isStatic(Executable) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
isTechnicalError(Throwable) - Static method in class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Determines if the error is a technical exception (not FunctionalException).
isTerminated() - Method in class io.fluxcapacitor.common.DirectExecutorService
 
isValid(Object, Validator, Class<?>...) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Returns true if the object is valid, using the given Validator and validation groups.
isValid(Object, Class<?>...) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Returns true if the given object is valid using the default Validator and validation groups.
isValid(Object, Class<?>...) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.validation.Validator
Checks whether the given object is valid according to the defined validation rules.
isWebsocket(String) - Static method in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Determines whether the given method string represents a WebSocket-specific method.
iterate(T, UnaryOperator<T>, Predicate<T>) - Static method in class io.fluxcapacitor.common.ObjectUtils
Creates a stream that stops once the break condition evaluates true.
iterator() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 

J

JacksonContentFilter - Class in io.fluxcapacitor.javaclient.common.serialization.jackson
A ContentFilter implementation that uses Jackson to filter content dynamically for a specific User.
JacksonContentFilter(ObjectMapper) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter
Creates a new content filter using the provided ObjectMapper.
JacksonContentFilter.FilteringSerializer - Class in io.fluxcapacitor.javaclient.common.serialization.jackson
Custom Jackson serializer that attempts to invoke a FilterContent handler method during serialization.
JacksonInverter - Class in io.fluxcapacitor.common.search
Implementation of Inverter that uses Jackson to invert an Object into a SerializedDocument and back into a JsonNode.
JacksonInverter() - Constructor for class io.fluxcapacitor.common.search.JacksonInverter
 
JacksonInverter(JsonMapper) - Constructor for class io.fluxcapacitor.common.search.JacksonInverter
 
JacksonSerializer - Class in io.fluxcapacitor.javaclient.common.serialization.jackson
A concrete Serializer implementation based on Jackson.
JacksonSerializer() - Constructor for class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Constructs a default JacksonSerializer with no up/downcasters.
JacksonSerializer(JsonMapper) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Constructs a JacksonSerializer with a specific JsonMapper instance.
JacksonSerializer(JsonMapper, Collection<?>) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Constructs a JacksonSerializer with an object mapper and up/downcaster candidates.
JacksonSerializer(JsonMapper, Collection<?>, JacksonInverter) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Full constructor with object mapper, caster candidates and custom document inverter.
JacksonSerializer(Collection<?>) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
Constructs a JacksonSerializer with the given up/downcaster candidates.
JavaPropertiesSource - Class in io.fluxcapacitor.common.application
Base class for PropertySource implementations backed by a Properties object.
JavaPropertiesSource(Properties) - Constructor for class io.fluxcapacitor.common.application.JavaPropertiesSource
Creates a new property source backed by the given Properties instance.
join(byte[]...) - Static method in class io.fluxcapacitor.common.ObjectUtils
Combines multiple byte arrays into a single byte array by concatenating their contents in the given order.
join(PropertySource...) - Static method in interface io.fluxcapacitor.common.application.PropertySource
Joins multiple PropertySource instances into a single one.
join(List<? extends HandlerInvoker>) - Static method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Joins a list of invokers into a single composite invoker.
join(List<BatchInterceptor>) - Static method in interface io.fluxcapacitor.javaclient.tracking.BatchInterceptor
Joins a list of interceptors into a single composite interceptor, applying them in sequence.
JSON_FORMAT - Static variable in class io.fluxcapacitor.common.api.Data
Standard media type for JSON data.
JsonType - Interface in io.fluxcapacitor.common.api
Marker interface for all low-level request and response types in the Flux protocol.
JsonUtils - Class in io.fluxcapacitor.common.serialization
Utility class for JSON serialization, deserialization, and file-based JSON resource loading.
JsonUtils() - Constructor for class io.fluxcapacitor.common.serialization.JsonUtils
 
Jsr380Validator - Class in io.fluxcapacitor.javaclient.tracking.handling.validation
This validator uses JSR 380 annotations.
Jsr380Validator() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.validation.Jsr380Validator
 

K

Key Characteristics: - Search tag in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
Section
Key Features - Search tag in class io.fluxcapacitor.common.Backlog
Section
Key Features - Search tag in class io.fluxcapacitor.common.ConsistentHashing
Section
Key Features - Search tag in class io.fluxcapacitor.common.api.Metadata
Section
Key Features - Search tag in class io.fluxcapacitor.common.api.SerializedMessage
Section
Key Features - Search tag in class io.fluxcapacitor.common.reflection.DefaultMemberInvoker
Section
Key Features - Search tag in class io.fluxcapacitor.common.reflection.ParameterRegistry
Section
Key Features - Search tag in class io.fluxcapacitor.common.serialization.JsonUtils
Section
Key Features - Search tag in class io.fluxcapacitor.javaclient.common.Message
Section
Key Features - Search tag in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
Section
Key Features - Search tag in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
Section
Key Features - Search tag in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
Section
Key Responsibilities - Search tag in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
Section
KeyValueClient - Interface in io.fluxcapacitor.javaclient.persisting.keyvalue.client
Represents a service to store and retrieve a piece of serialized data by key.
KeyValueEndPoint - Class in io.fluxcapacitor.testserver.websocket
 
KeyValueEndPoint() - Constructor for class io.fluxcapacitor.testserver.websocket.KeyValueEndPoint
 
KeyValuePair - Class in io.fluxcapacitor.common.api.keyvalue
Represents a single key-value entry in the legacy key-value store.
KeyValuePair() - Constructor for class io.fluxcapacitor.common.api.keyvalue.KeyValuePair
 
keyValuePath() - Static method in class io.fluxcapacitor.common.ServicePathBuilder
Returns the service path for the key-value store subsystem.
keyValueStore() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns a client for the key value service offered by Flux Capacitor.
keyValueStore(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
KeyValueStore - Interface in io.fluxcapacitor.javaclient.persisting.keyvalue
A simple interface for storing, retrieving, and removing key-value pairs.
KeyValueStoreException - Exception Class in io.fluxcapacitor.javaclient.persisting.keyvalue
Thrown when a key-value store operation fails.
KeyValueStoreException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.persisting.keyvalue.KeyValueStoreException
 
keyValueUrl(WebSocketClient.ClientConfig) - Static method in class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
Constructs the URL for accessing the distributed key-value store service.
KotlinReflectionUtils - Class in io.fluxcapacitor.common.reflection
Provides utilities for bridging Java reflection with Kotlin reflection.
KotlinReflectionUtils() - Constructor for class io.fluxcapacitor.common.reflection.KotlinReflectionUtils
 

L

lastChunk() - Method in interface io.fluxcapacitor.common.api.HasMetadata
Determines if the data associated with this metadata is the final part of the data.
lastEventId() - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
lastEventId() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
lastEventId() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the identifier of the last event applied to the entity hierarchy.
lastEventId() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
lastEventIndex() - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
lastEventIndex() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
lastEventIndex() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the index of the last event applied to this entity hierarchy.
lastEventIndex() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
lastMatch() - Method in class io.fluxcapacitor.common.api.search.SearchDocumentsResult
Returns the last document in the result list, or null if no matches were found.
LazyAggregateRoot<T> - Class in io.fluxcapacitor.javaclient.modeling
A lazily-loaded implementation of AggregateRoot that defers deserialization and event application until the entity value is explicitly accessed.
LazyAggregateRoot(ImmutableAggregateRoot<T>) - Constructor for class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
LazyId - Class in io.fluxcapacitor.javaclient.common
A lazily initialized identifier that serializes as a plain string.
LazyId() - Constructor for class io.fluxcapacitor.javaclient.common.LazyId
Constructs a new LazyId with a default ID supplier using FluxCapacitor::generateId.
LazyId(Object) - Constructor for class io.fluxcapacitor.javaclient.common.LazyId
Constructs a LazyId with a known ID value.
LazyId(Supplier<String>) - Constructor for class io.fluxcapacitor.javaclient.common.LazyId
Constructs a new LazyId with the specified supplier.
LazyInputStream - Class in io.fluxcapacitor.common
 
LazyInputStream(Supplier<? extends InputStream>) - Constructor for class io.fluxcapacitor.common.LazyInputStream
 
length() - Method in record class io.fluxcapacitor.javaclient.web.StaticFileHandler.ByteRange
 
letterOrNumber - Static variable in class io.fluxcapacitor.common.SearchUtils
A character class used in regex patterns that includes letters and digits.
Lifecycle - Search tag in class io.fluxcapacitor.javaclient.tracking.FluxCapacitorInterceptor
Section
Lifecycle Hooks - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.MutableHandler
Section
limit(long) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
load(Id<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Load an aggregate by a typed identifier.
load(Object, Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Load an aggregate by its identifier and type.
load(Object, Class<T>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
load(Object, Class<T>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository
 
load(Object) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository.AnnotatedAggregateRepository
 
load(Object, Supplier<Entity<T>>, boolean, EventPublication, EventPublicationStrategy, EntityHelper, Serializer, DispatchInterceptor, ModifiableAggregateRoot.CommitHandler) - Static method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
loadAggregate(Id<T>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the aggregate root of type <T> with given aggregateId.
loadAggregate(Object, Class<T>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the aggregate root of type <T> with given aggregateId.
loadAggregateFor(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the aggregate root that currently contains the entity with given entityId.
loadAggregateFor(Object, Class<?>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the aggregate root of type <T> that currently contains the entity with given entityId.
loadEntity(Id<T>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the entity with given id.
loadEntity(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the entity with given id.
loadEntityValue(Id<T>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the current entity value for given entity id.
loadEntityValue(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Loads the current entity value for given entity id.
loadFile(File) - Static method in class io.fluxcapacitor.common.FileUtils
Loads file contents from a File.
loadFile(File, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Loads file contents from a File using a specific charset.
loadFile(Class<?>, String) - Static method in class io.fluxcapacitor.common.FileUtils
Loads a classpath resource relative to a given reference class.
loadFile(Class<?>, String, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Loads a file from a classpath location using a reference class and charset.
loadFile(String) - Static method in class io.fluxcapacitor.common.FileUtils
Loads the contents of a file located relative to the calling class.
loadFile(String, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Loads a file with a specified charset, using the calling class as reference point.
loadFile(URI) - Static method in class io.fluxcapacitor.common.FileUtils
Loads file contents from a URI.
loadFile(URI, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Loads file contents from a URI using a specific charset.
loadFile(URL, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Loads file contents from a URL using a specific charset.
loadFor(Object, Class<?>) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Load the aggregate that owns the specified entity.
loadFor(Object, Class<?>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
loadFor(Object, Class<?>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository
 
loading - Static variable in interface io.fluxcapacitor.javaclient.modeling.Entity
 
Loading and Modifying Aggregates - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Section
loadProperties(String) - Static method in class io.fluxcapacitor.common.application.ApplicationEnvironmentPropertiesSource
Loads properties from an application-<env>.properties file if the environment name is present.
loadProperties(String) - Static method in class io.fluxcapacitor.common.FileUtils
Loads properties from the classpath, merging from all available matching resources.
loadSnapshot(Object) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository.AnnotatedAggregateRepository
 
LocalClient - Class in io.fluxcapacitor.javaclient.configuration.client
An in-memory Client implementation used for local development, testing, or isolated runtime environments where no connection to the Flux Platform is required.
LocalClient(Duration) - Constructor for class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
LocalDocumentHandlerRegistry - Class in io.fluxcapacitor.javaclient.persisting.search.client
A handler registry implementation intended for local testing and development that registers handlers for document updates in a specific collection.
LocalDocumentHandlerRegistry() - Constructor for class io.fluxcapacitor.javaclient.persisting.search.client.LocalDocumentHandlerRegistry
 
LocalEventStoreClient - Class in io.fluxcapacitor.javaclient.persisting.eventsourcing.client
A client implementation for managing and storing events in an in-memory event store.
LocalEventStoreClient(Duration) - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.LocalEventStoreClient
 
LocalHandler - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Marks a message handler method, class, or package as a **local handler**—one that is invoked immediately in the publishing thread rather than asynchronously through tracking.
localHandlerRegistry(MessageType, Map<MessageType, HandlerDecorator>, List<ParameterResolver<? super DeserializingMessage>>, Function<Class<?>, HandlerRepository>, RepositoryProvider) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
LocalHandlerRegistry - Class in io.fluxcapacitor.javaclient.tracking.handling
In-memory implementation of HandlerRegistry that manages and dispatches local message handlers — i.e., handlers that are invoked directly in the publishing thread without involving the Flux platform.
LocalHandlerRegistry() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
 
LocalSchedulingClient - Class in io.fluxcapacitor.javaclient.scheduling.client
A client implementation for managing scheduling operations using an in-memory schedule store.
LocalSchedulingClient(Duration) - Constructor for class io.fluxcapacitor.javaclient.scheduling.client.LocalSchedulingClient
 
LocalServerConfig - Class in io.fluxcapacitor.javaclient.web
Configuration for the local HTTP server used to handle WebRequest messages outside of Flux Capacitor's own web handling framework.
LocalServerConfig() - Constructor for class io.fluxcapacitor.javaclient.web.LocalServerConfig
 
LocalTrackingClient - Class in io.fluxcapacitor.javaclient.tracking.client
In-memory implementation of the TrackingClient and GatewayClient interfaces, designed for local-only or test-time usage.
LocalTrackingClient(MessageType, String, Duration) - Constructor for class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
LocalTrackingClient(MessageStore, MessageType) - Constructor for class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
LocalTrackingClient(MessageStore, MessageType, String) - Constructor for class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
logError(String, Throwable) - Method in class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Logs the error at the appropriate level based on its type.
logError(Throwable, String) - Method in class io.fluxcapacitor.javaclient.tracking.ThrowingErrorHandler
Logs the given error based on its type and logging configuration.
LoggingErrorHandler - Class in io.fluxcapacitor.javaclient.tracking
The default ErrorHandler implementation used by Flux Capacitor consumers.
LoggingErrorHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.LoggingErrorHandler
Constructs a LoggingErrorHandler that logs both technical and functional errors.
logMessage() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.LocalHandler
Whether messages handled locally should also be **logged and published** to the event bus or event store.
logMessage(HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
Determines whether a handler allows its message to be sent to the Flux platform.
logMetrics() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.LocalHandler
Whether handling metrics (such as HandleMessageEvent) should be logged for this handler if monitoring is enabled.
logMetrics(HandlerInvoker, HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.HandlerMonitor
 
lookAhead(String, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.LookAheadConstraint
Creates a LookAheadConstraint that matches any terms or phrases starting with the given input string.
lookAhead(String, String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds a full-text lookahead constraint using the specified phrase.
LookAheadConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A constraint that supports search-as-you-type functionality by matching terms or phrases that start with a given input string.
LookAheadConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.LookAheadConstraint
 
LOWEST_PRIORITY - Static variable in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
 
lowestIndexForSegment(int[]) - Method in class io.fluxcapacitor.common.api.tracking.Position
 
lowPrioDispatchInterceptors() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Dispatch interceptors applied after high-priority interceptors.
lowPrioHandlerDecorators() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Decorators applied to handlers after high-priority decorators.
LZ4 - Enum constant in enum class io.fluxcapacitor.common.serialization.compression.CompressionAlgorithm
Fast compression using the LZ4 codec.
LZ4 Support - Search tag in class io.fluxcapacitor.common.serialization.compression.CompressionUtils
Section

M

main(String[]) - Static method in class io.fluxcapacitor.proxy.ProxyServer
 
main(String[]) - Static method in class io.fluxcapacitor.testserver.TestServer
 
makeApplicationInstance() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Whether the application instance should be created automatically on first use.
makeApplicationInstance(boolean) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
makeApplicationInstance(boolean) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Marks the built instance as the global (application-level) FluxCapacitor.
manual - Enum constant in enum class io.fluxcapacitor.javaclient.persisting.caching.CacheEviction.Reason
The entry was manually evicted by application logic.
Manual Use Cases - Search tag in interface io.fluxcapacitor.javaclient.publishing.ErrorGateway
Section
map(ThrowingFunction<T, M>) - Method in class io.fluxcapacitor.common.api.Data
Transforms the value using a custom mapping function, while preserving serialization metadata.
map(Object) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultResponseMapper
 
map(Object) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.ResponseMapper
Maps the given response object to a Message.
map(Object) - Method in interface io.fluxcapacitor.javaclient.web.WebResponseMapper
Maps a generic response object to a WebResponse.
map(Object, Metadata) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DefaultResponseMapper
 
map(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.ResponseMapper
Maps the given response object and metadata to a Message.
map(Object, Metadata) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebResponseMapper
Maps a raw handler return value and associated metadata into a WebResponse.
map(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.web.WebResponseMapper
Maps a response and optional metadata into a WebResponse.
map(Function<? super T, ? extends R>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
map(Function<T, V>) - Method in class io.fluxcapacitor.javaclient.persisting.search.SearchHit
Transforms the hit’s value using the provided mapper function, producing a new SearchHit with the same metadata but with a new mapped value.
mapIfPresent(Function<Entity<T>, U>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Maps the entity to a new value if the entity is present.
mapMulti(BiConsumer<? super T, ? super Consumer<R>>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
mapMultiToDouble(BiConsumer<? super T, ? super DoubleConsumer>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
mapMultiToInt(BiConsumer<? super T, ? super IntConsumer>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
mapMultiToLong(BiConsumer<? super T, ? super LongConsumer>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
MappingBatchInterceptor - Interface in io.fluxcapacitor.javaclient.tracking
A BatchInterceptor specialization that transforms a MessageBatch before it is passed to the consumer for processing.
Mapping Rules - Search tag in class io.fluxcapacitor.javaclient.web.DefaultWebResponseMapper
Section
mapToDouble(ToDoubleFunction<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
mapToInt(ToIntFunction<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
mapToLong(ToLongFunction<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
mark(int) - Method in class io.fluxcapacitor.common.LazyInputStream
 
markSupported() - Method in class io.fluxcapacitor.common.LazyInputStream
 
match(Object, boolean, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
Creates a constraint that matches the given value across the specified paths, with an option to enforce strict string equality.
match(Object, boolean, String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds a match constraint, optionally enforcing strict equality.
match(Object, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
Creates a constraint that performs non-strict (normalized) matching of the provided value across the specified paths.
match(Object, String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds an equality match constraint for the given value across one or more paths.
MatchConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A constraint that matches indexed document values based on text equality or normalized phrase matching.
MatchConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
 
matches(SerializedDocument) - Method in class io.fluxcapacitor.common.api.search.SearchQuery
Checks if the given serialized document matches the query's constraints and collection filters.
matches(Document) - Method in interface io.fluxcapacitor.common.api.search.Constraint
Evaluates whether this constraint applies to the given document.
matches(Document) - Method in class io.fluxcapacitor.common.api.search.constraints.AllConstraint
 
matches(Document) - Method in class io.fluxcapacitor.common.api.search.constraints.AnyConstraint
 
matches(Document) - Method in class io.fluxcapacitor.common.api.search.constraints.FacetConstraint
 
matches(Document) - Method in class io.fluxcapacitor.common.api.search.constraints.LookAheadConstraint
Evaluates whether this constraint matches the given Document.
matches(Document) - Method in class io.fluxcapacitor.common.api.search.constraints.NotConstraint
 
matches(Document) - Method in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
 
matches(Document) - Method in class io.fluxcapacitor.common.api.search.constraints.QueryConstraint
Overrides Constraint.matches(Document) to evaluate a decomposed constraint tree.
matches(Document) - Method in class io.fluxcapacitor.common.api.search.NoOpConstraint
Always returns true, indicating that any document matches.
matches(Document.Entry) - Method in class io.fluxcapacitor.common.api.search.constraints.BetweenConstraint
 
matches(Document.Entry) - Method in class io.fluxcapacitor.common.api.search.constraints.ContainsConstraint
Checks whether a single document entry matches the constraint.
matches(Document.Entry) - Method in class io.fluxcapacitor.common.api.search.constraints.ExistsConstraint
 
matches(Document.Entry) - Method in class io.fluxcapacitor.common.api.search.constraints.LookAheadConstraint
Not supported for this constraint type, as this constraint relies on higher-level document decomposition.
matches(Document.Entry) - Method in class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
 
matches(Document.Entry) - Method in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
Evaluates whether the specified document entry satisfies the condition defined by this method's implementation.
matches(Document.Entry) - Method in class io.fluxcapacitor.common.api.search.constraints.QueryConstraint
Not supported directly on a single document entry.
matches(Parameter, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
Returns true if the entity or any of its parents match the expected parameter type.
matches(Parameter, Annotation, HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.PayloadParameterResolver
 
matches(Parameter, Annotation, HasMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
Checks if the given method parameter should be resolved by this resolver.
matches(Parameter, Annotation, HasMessage) - Method in class io.fluxcapacitor.javaclient.web.WebParamParameterResolver
Determines if this resolver is applicable to a given method parameter.
matches(Parameter, Annotation, HasMessage) - Method in class io.fluxcapacitor.javaclient.web.WebPayloadParameterResolver
Determines whether this resolver should be used for the given method parameter.
matches(Parameter, Annotation, HasMessage) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
Determines whether this resolver supports injecting a SocketSession for the given method parameter.
matches(Parameter, Annotation, Object) - Method in class io.fluxcapacitor.javaclient.configuration.spring.SpringBeanParameterResolver
 
matches(Parameter, Annotation, Object) - Method in class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
Determines whether the parameter can be resolved from the given input.
matches(Parameter, Annotation, Object) - Method in class io.fluxcapacitor.javaclient.tracking.handling.InputParameterResolver
 
matches(Parameter, Annotation, M) - Method in interface io.fluxcapacitor.common.handling.ParameterResolver
Indicates whether the resolved value is compatible with the declared parameter type.
matches(Parameter, Annotation, M) - Method in class io.fluxcapacitor.common.handling.TypedParameterResolver
Determines whether the given parameter is eligible to be resolved by this resolver.
matches(ConditionContext, AnnotatedTypeMetadata) - Method in class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnBean.Condition
 
matches(ConditionContext, AnnotatedTypeMetadata) - Method in class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingBean.Condition
 
matches(ConditionContext, AnnotatedTypeMetadata) - Method in class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingProperty.Condition
 
matches(ConditionContext, AnnotatedTypeMetadata) - Method in class io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnProperty.Condition
 
matchesAny(Collection<String>) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
matchFacet(FacetEntry) - Static method in class io.fluxcapacitor.common.api.search.constraints.FacetConstraint
Factory method to create a constraint that matches a single FacetEntry.
matchFacet(String, Object) - Static method in class io.fluxcapacitor.common.api.search.constraints.FacetConstraint
Factory method to create a constraint that matches documents with the given facet name and value.
matchFacet(String, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Matches the value of a named facet.
matchingMethods(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
 
matchingMethods(M) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
matchingMethods(M) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.ObjectHandlerMatcher
 
matchingMethods(M) - Method in interface io.fluxcapacitor.common.handling.HandlerMatcher
Returns a stream of methods from the target class that match the given message.
Matching Modes - Search tag in class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
Section
Matching Semantics - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Section
matchMetadata(String, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Matches a metadata key to a value.
max(Comparator<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
MAX_RESPONSE_SIZE - Static variable in class io.fluxcapacitor.javaclient.web.WebResponseGateway
 
MAX_SEGMENT - Static variable in class io.fluxcapacitor.common.api.tracking.Position
 
maxAgeSeconds() - Element in annotation interface io.fluxcapacitor.javaclient.web.ServeStatic
Default max-age (in seconds) for non-immutable static files.
maxFetchSize() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Maximum number of messages to fetch in a batch.
maxIndexExclusive() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Optional exclusive upper bound for message processing.
maxIndexFromMillis(long) - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Computes the maximum possible index for the given timestamp in milliseconds since the epoch.
maxTimeout() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
maxWaitDuration() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Maximum time to wait before fetching a new batch, when none are available.
Member - Annotation Interface in io.fluxcapacitor.javaclient.modeling
Indicates that the annotated field or getter represents a nested entity or collection of entities within an aggregate.
MemberInvoker - Interface in io.fluxcapacitor.common.reflection
Abstraction for invoking a Member (e.g.
memoize(BiFunction<T, U, R>) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
memoize(BiFunction<T, U, R>) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Memoizes the given bi-function using a default memoization strategy.
memoize(BiFunction<T, U, R>, Duration) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Memoizes the given bi-function using a time-based lifespan and Flux’s internal clock.
memoize(Function<K, V>) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
memoize(Function<K, V>) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Memoizes the given function using a default memoization strategy.
memoize(Function<K, V>, Duration) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Memoizes the given function using a time-based lifespan and Flux’s internal clock.
memoize(Supplier<T>) - Static method in class io.fluxcapacitor.common.ObjectUtils
 
memoize(Supplier<T>) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Memoizes the given supplier using a default memoization strategy.
memoize(Supplier<T>, Duration) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Memoizes the given supplier using a time-based lifespan and Flux’s internal clock.
MemoizingBiFunction<T,U,R> - Interface in io.fluxcapacitor.common
A BiFunction that memoizes (caches) its results based on a pair of input arguments.
MemoizingFunction<K,V> - Interface in io.fluxcapacitor.common
A Function that memoizes (caches) its results by key.
MemoizingSupplier<T> - Interface in io.fluxcapacitor.common
A Supplier that memoizes (caches) the result of a single computation.
memoryPressure - Enum constant in enum class io.fluxcapacitor.javaclient.persisting.caching.CacheEviction.Reason
The JVM experienced memory pressure and the cache purged entries to free up space.
merge(Position) - Method in class io.fluxcapacitor.common.api.tracking.Position
Merges two Position objects by taking the highest known index per segment.
merge(Registration) - Method in interface io.fluxcapacitor.common.Registration
Returns a new Registration that cancels both this and the given otherRegistration.
merge(Properties, Properties) - Static method in class io.fluxcapacitor.common.ObjectUtils
Merges two Properties instances into a new one.
merge(T, Object) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Merges a base object with a patch/update object, omitting null fields.
MergedDecorator() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.HandlerDecorator.MergedDecorator
 
MergedHandlerRegistry() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
Message - Class in io.fluxcapacitor.javaclient.common
Represents a unit of communication within the Flux platform, wrapping a payload and its metadata.
Message(Object) - Constructor for class io.fluxcapacitor.javaclient.common.Message
Constructs a message with the given payload and empty metadata.
Message(Object, Metadata) - Constructor for class io.fluxcapacitor.javaclient.common.Message
Constructs a message with the given payload and metadata.
Message(Object, Metadata, String, Instant) - Constructor for class io.fluxcapacitor.javaclient.common.Message
Full constructor for internal use and deserialization.
MessageBatch - Class in io.fluxcapacitor.common.api.tracking
Represents a batch of messages retrieved from the message store for a specific segment range.
MessageBatch() - Constructor for class io.fluxcapacitor.common.api.tracking.MessageBatch
 
MessageBatch.Metric - Class in io.fluxcapacitor.common.api.tracking
Compact summary of a MessageBatch, used for logging and performance tracking.
Message Expiration - Search tag in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
Section
MessageFilter<M> - Interface in io.fluxcapacitor.common.handling
Defines a predicate that determines whether a given message is applicable to a handler method.
messageFormatter - Static variable in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
The formatter used to produce a human-readable representation of this message, primarily for logging or debugging.
MessageFormatter - Interface in io.fluxcapacitor.javaclient.common.serialization
A functional interface for formatting DeserializingMessage instances into human-readable strings.
MessageParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling
Resolves handler method parameters of type Message.
MessageParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.MessageParameterResolver
 
messageRoutingInterceptor() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Special interceptor used to determine routing of dispatched messages (e.g. for multitenancy).
MessageRoutingInterceptor - Class in io.fluxcapacitor.javaclient.publishing.routing
A DispatchInterceptor that assigns a routing segment to messages prior to dispatch.
MessageRoutingInterceptor() - Constructor for class io.fluxcapacitor.javaclient.publishing.routing.MessageRoutingInterceptor
 
messageScheduler() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway to schedule messages.
MessageScheduler - Interface in io.fluxcapacitor.javaclient.scheduling
Interface for scheduling deferred or periodic execution of messages in the Flux Capacitor platform.
MessageSpliterator(Spliterator<DeserializingMessage>) - Constructor for class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage.MessageSpliterator
 
MessageStore - Interface in io.fluxcapacitor.common.tracking
A low-level store for serialized messages.
messageType() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Restricts the trigger by its MessageType.
MessageType - Enum Class in io.fluxcapacitor.common
Enumerates the types of messages recognized and routed by the Flux platform.
MessageWithEntity(Object, Entity<?>) - Constructor for class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper.MessageWithEntity
 
Meta-annotation usage (with enum roles): - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresAnyRole
Section
metadata() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Returns the configured metadata.
metadata() - Method in record class io.fluxcapacitor.proxy.WebsocketEndpoint.SessionContext
Returns the value of the metadata record component.
metadata(Metadata) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Replaces all metadata in this operation with the given metadata.
Metadata - Class in io.fluxcapacitor.common.api
Represents immutable metadata associated with a Message in the Flux platform.
METADATA_KEY - Static variable in class io.fluxcapacitor.javaclient.publishing.dataprotection.DataProtectionInterceptor
 
Metadata key - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AbstractUserProvider
Section
MetadataParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling
Resolves handler method parameters of type Metadata.
MetadataParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.MetadataParameterResolver
 
method() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleWeb
HTTP or WebSocket methods that this handler supports (e.g.
Method-based usage - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
MethodHandlerInvoker() - Constructor for class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker
 
MethodHandlerMatcher(Executable, Class<?>, List<ParameterResolver<? super M>>, HandlerConfiguration<? super M>) - Constructor for class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
methodIndex(Method, Class<?>) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
methodKey - Static variable in class io.fluxcapacitor.javaclient.web.WebRequest
 
methodMatcher(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
 
methodMatches(Class<?>, Executable) - Method in class io.fluxcapacitor.common.handling.HandlerConfiguration
Determines whether the given method is eligible to handle messages according to this configuration.
Metric() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.AppendEvents.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.EventBatch.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.eventsourcing.GetEventsResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.keyvalue.GetValueResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.keyvalue.StoreValueIfAbsent.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.keyvalue.StoreValues.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.keyvalue.StoreValuesAndWait.Metric
Deprecated.
 
Metric() - Constructor for class io.fluxcapacitor.common.api.publishing.Append.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.scheduling.GetScheduleResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.scheduling.Schedule.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.scheduling.SerializedSchedule.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.search.BulkUpdateDocuments.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.search.GetDocumentResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.search.GetDocumentStatsResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.search.GetFacetStatsResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.search.IndexDocuments.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.search.SearchDocumentsResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.tracking.ClaimSegmentResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.tracking.MessageBatch.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.tracking.ReadFromIndexResult.Metric
 
Metric() - Constructor for class io.fluxcapacitor.common.api.tracking.ReadResult.Metric
 
Metrics - Search tag in class io.fluxcapacitor.common.api.keyvalue.StoreValues
Section
METRICS - Enum constant in enum class io.fluxcapacitor.common.MessageType
Internal system event used for diagnostics and monitoring.
metricsDisabled(HandlerInvoker) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.HandlerMonitor
 
metricsGateway() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway for metrics events.
metricsGateway(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
MetricsGateway - Interface in io.fluxcapacitor.javaclient.publishing
Gateway interface for publishing metrics messages in Flux Capacitor.
MetricsLog - Interface in io.fluxcapacitor.testserver.metrics
 
Metrics Logging - Search tag in interface io.fluxcapacitor.common.api.JsonType
Section
metricsMetadata() - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
metricsMetadata() - Method in class io.fluxcapacitor.javaclient.publishing.client.WebsocketGatewayClient
 
metricsMetadata() - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
metricsSerializer - Static variable in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
millisFromIndex(long) - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Extracts the millisecond component from the given index value.
min(Comparator<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
minIndex() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Optional minimum message index from which this consumer should begin processing.
ModifiableAggregateRoot<T> - Class in io.fluxcapacitor.javaclient.modeling
A mutable, stateful AggregateRoot implementation that allows in-place updates and applies events with commit support for persisting the state and synchronizing it with the Flux platform.
ModifiableAggregateRoot(Entity<T>, boolean, EventPublication, EventPublicationStrategy, EntityHelper, Serializer, DispatchInterceptor, ModifiableAggregateRoot.CommitHandler) - Constructor for class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
ModifiableAggregateRoot.CommitHandler - Interface in io.fluxcapacitor.javaclient.modeling
 
ModifiableEntity<T> - Class in io.fluxcapacitor.javaclient.modeling
A mutable view on a nested entity within a ModifiableAggregateRoot.
ModifiableEntity(Entity<T>, ModifiableAggregateRoot<?>) - Constructor for class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
modifyEach(BiFunction<? super Object, ? super T, ? extends T>) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Applies the given modifier function to all values currently in the cache.
modifyEach(BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
modifyEach(BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
modifyEach(BiFunction<? super Object, ? super T, ? extends T>) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
modifyEach(BiFunction<? super Object, ? super T, ? extends T>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
modifySerializedMessage(SerializedMessage, Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Optionally modifies the serialized message before dispatch, delegating to any registered ad hoc interceptor for the current thread.
modifySerializedMessage(SerializedMessage, Message, MessageType, String) - Method in interface io.fluxcapacitor.javaclient.publishing.DispatchInterceptor
Allows modifications to the serialized representation of the message before it is actually published.
modifySerializedMessage(SerializedMessage, Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.publishing.routing.MessageRoutingInterceptor
Computes and sets the routing segment on the serialized message if not already present.
modifySerializedMessage(SerializedMessage, Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.web.WebResponseCompressingInterceptor
Compresses the given response message using GZIP if the request supports compression and the response meets compression criteria.
Modular Use - Search tag in class io.fluxcapacitor.common.reflection.ReflectionUtils
Section
monitorDispatch(Message, MessageType, String) - Method in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Optionally monitors a dispatched message using any registered ad hoc interceptor for the current thread.
monitorDispatch(Message, MessageType, String) - Method in interface io.fluxcapacitor.javaclient.publishing.DispatchInterceptor
Hook to observe the dispatch of a message.
monitorDispatch(ClientDispatchMonitor, MessageType...) - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
 
monitorDispatch(ClientDispatchMonitor, MessageType...) - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Registers a ClientDispatchMonitor to receive hooks and diagnostics when messages of the given MessageTypes are dispatched from this client.
Monitored<T> - Interface in io.fluxcapacitor.common
Represents a resource or component that can be monitored.
MultiClientEndpoint - Class in io.fluxcapacitor.testserver.websocket
 
MultiClientEndpoint() - Constructor for class io.fluxcapacitor.testserver.websocket.MultiClientEndpoint
 
Multiple Handler Matches - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Section
Murmur3 - Class in io.fluxcapacitor.common
The MurmurHash3 algorithm was created by Austin Appleby and placed in the public domain.
Murmur3() - Constructor for class io.fluxcapacitor.common.Murmur3
 
murmurhash3_x86_32(CharSequence) - Static method in class io.fluxcapacitor.common.Murmur3
Returns the MurmurHash3_x86_32 hash of the UTF-8 bytes of the String using seed of 0 without actually encoding the string to a temporary buffer.
murmurhash3_x86_32(CharSequence, int, int, int) - Static method in class io.fluxcapacitor.common.Murmur3
Returns the MurmurHash3_x86_32 hash of the UTF-8 bytes of the String without actually encoding the string to a temporary buffer.
MutableHandler<M> - Class in io.fluxcapacitor.javaclient.tracking.handling
A specialized Handler that maintains and mutates an internal delegate instance.
MutableHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.MutableHandler
 
mutexPrecursor - Static variable in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 

N

name() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the name of this client as defined in its configuration.
name() - Method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
name() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
name() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
The unique name of the consumer.
NamedCache - Class in io.fluxcapacitor.javaclient.persisting.caching
A Cache implementation that wraps a delegate cache and applies a transformation to each key (ID) before delegating operations to the underlying cache.
NamedCache() - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
negate() - Method in interface io.fluxcapacitor.common.handling.HandlerFilter
Inverts the current filter.
negate() - Method in interface io.fluxcapacitor.common.ThrowingPredicate
Returns a predicate that represents the logical negation of this predicate.
negotiate(String, Path) - Static method in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
 
NEVER - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublication
Never publish or store applied updates.
newInstance() - Static method in class io.fluxcapacitor.common.DirectExecutorService
 
newInstance() - Static method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
newInstance(WebSocketClient.ClientConfig) - Static method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
newInstance(Duration) - Static method in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
 
newNamedWorkStealingPool(int, String) - Static method in class io.fluxcapacitor.common.ObjectUtils
Creates a named ForkJoinPool with the given parallelism.
newObjectNode(Object...) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Constructs a new ObjectNode from alternating key-value arguments.
newPosition() - Static method in class io.fluxcapacitor.common.api.tracking.Position
Creates an empty position.
newThreadFactory(String) - Static method in class io.fluxcapacitor.common.ObjectUtils
Creates a new ThreadFactory with a named prefix.
newThreadName(String) - Static method in class io.fluxcapacitor.common.ObjectUtils
Generates a unique thread name with the given prefix.
newValidationException(Collection<? extends ConstraintViolation<?>>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.validation.Jsr380Validator
 
nextDeadline(Periodic, Instant) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
nextFunctionalId() - Method in interface io.fluxcapacitor.javaclient.common.IdentityProvider
Returns a new functional ID, suitable for user-visible or application-level tracking.
nextFunctionalId() - Method in class io.fluxcapacitor.javaclient.common.UuidFactory
Returns a new UUID string, optionally stripped of dashes.
nextIndex(Long) - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Generates the next unique index based on the current time or the last provided index.
nextLocalDateTimeAfter(LocalDateTime) - Method in class io.fluxcapacitor.javaclient.scheduling.CronExpression
 
nextTechnicalId() - Method in interface io.fluxcapacitor.javaclient.common.IdentityProvider
Returns a new technical ID, suitable for lower-level operations such as internal tracing.
nextTimeAfter(ZonedDateTime) - Method in class io.fluxcapacitor.javaclient.scheduling.CronExpression
 
nextTimeAfter(ZonedDateTime, long) - Method in class io.fluxcapacitor.javaclient.scheduling.CronExpression
 
nextTimeAfter(ZonedDateTime, ZonedDateTime) - Method in class io.fluxcapacitor.javaclient.scheduling.CronExpression
 
NONE - Enum constant in enum class io.fluxcapacitor.common.Guarantee
No delivery guarantee is enforced.
NONE - Enum constant in enum class io.fluxcapacitor.common.serialization.compression.CompressionAlgorithm
No compression.
NONE - Enum constant in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
 
noneMatch(Predicate<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
noOp - Static variable in interface io.fluxcapacitor.javaclient.publishing.DispatchInterceptor
No-op implementation of the DispatchInterceptor that returns the original message unchanged.
noOp - Static variable in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerDecorator
A no-op decorator that returns the original handler unmodified.
noOp() - Static method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Returns a no-op invoker that performs no action and returns null.
noOp() - Static method in interface io.fluxcapacitor.common.Registration
Returns a no-op Registration that does nothing on Registration.cancel().
noOp() - Static method in interface io.fluxcapacitor.javaclient.tracking.BatchInterceptor
Returns a no-op interceptor that does not alter the consumer behavior.
noOp() - Static method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
A no-op registry that does not register or invoke any handlers.
noOpBiPredicate() - Static method in class io.fluxcapacitor.common.ObjectUtils
Returns a bi-predicate that always evaluates to true.
NoOpCache - Enum Class in io.fluxcapacitor.javaclient.persisting.caching
 
NoOpConstraint - Class in io.fluxcapacitor.common.api.search
A Constraint implementation that matches all documents and imposes no filtering conditions.
NoOpConstraint() - Constructor for class io.fluxcapacitor.common.api.search.NoOpConstraint
 
NoOpEncryption - Enum Class in io.fluxcapacitor.common.encryption
A no-op implementation of the Encryption interface that performs no actual encryption or decryption.
NoOpEntity<T> - Class in io.fluxcapacitor.javaclient.modeling
A read-only, inert Entity wrapper used exclusively during the loading phase of aggregate state.
NoOpFlowRegulator - Class in io.fluxcapacitor.javaclient.tracking
A no-op implementation of the FlowRegulator interface that never requests a pause.
NoOpFlowRegulator() - Constructor for class io.fluxcapacitor.javaclient.tracking.NoOpFlowRegulator
 
NoOpMetricsLog - Class in io.fluxcapacitor.testserver.metrics
 
NoOpMetricsLog() - Constructor for class io.fluxcapacitor.testserver.metrics.NoOpMetricsLog
 
noOpPredicate() - Static method in class io.fluxcapacitor.common.ObjectUtils
Returns a predicate that always evaluates to true.
NoOpPropertySource - Enum Class in io.fluxcapacitor.common.application
A no-operation PropertySource implementation that never returns any property values.
No-op Registration - Search tag in interface io.fluxcapacitor.common.Registration
Section
NoOpSnapshotStore - Enum Class in io.fluxcapacitor.javaclient.persisting.eventsourcing
A SnapshotStore implementation that is used when snapshotting is explicitly disabled, such as when snapshotPeriod <= 0 is configured on an aggregate via Aggregate.
NoOpTypeRegistry - Enum Class in io.fluxcapacitor.common.serialization
 
NoOpUserProvider - Enum Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
 
normalize(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Normalizes a string to lowercase and removes diacritics and leading/trailing whitespace.
normalizeJson(byte[]) - Static method in class io.fluxcapacitor.common.SearchUtils
Normalizes all string values in a JSON byte array by stripping accents and lowercasing.
normalizePath(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Replaces unescaped dots in field paths with slashes.
NoSnapshotTrigger - Enum Class in io.fluxcapacitor.javaclient.persisting.eventsourcing
A SnapshotTrigger implementation that never triggers snapshot creation.
not(Constraint) - Static method in class io.fluxcapacitor.common.api.search.constraints.NotConstraint
Factory method to create a NotConstraint.
not(Constraint) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Negates a constraint using a logical NOT.
not(ThrowingPredicate<? super T>) - Static method in interface io.fluxcapacitor.common.ThrowingPredicate
Returns a predicate that is the negation of the supplied predicate.
NotConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A constraint that negates the result of another constraint.
NotConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.NotConstraint
 
Note: - Search tag in io.fluxcapacitor.javaclient.tracking.handling.Stateful.commitInBatch()
Section
Notes - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.ForbidsAnyRole
Section
Notes - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresUser
Section
Notes - Search tag in class io.fluxcapacitor.common.api.keyvalue.StoreValueIfAbsent
Section
Notes: - Search tag in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
Section
notFound(String) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
 
NOTIFICATION - Enum constant in enum class io.fluxcapacitor.common.MessageType
Same as events, but used in a fan-out strategy when a consumer is interested in events across all segments.
notifyMonitors() - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
notifyMonitors(String, List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
notifyMonitors(List<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
notModified(Map<String, String>) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
 
NoUserRequired - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling.authentication
This annotation allows a message handler or payload to be invoked even if the current user is not authenticated.
NULL - Enum constant in enum class io.fluxcapacitor.common.search.Document.EntryType
Represents explicitly null entries.
NullCollectionsAsEmptyModule - Class in io.fluxcapacitor.common.serialization
A custom Jackson module that configures deserialization behavior to treat null collections as empty collections.
NullCollectionsAsEmptyModule() - Constructor for class io.fluxcapacitor.common.serialization.NullCollectionsAsEmptyModule
 
NUMERIC - Enum constant in enum class io.fluxcapacitor.common.search.Document.EntryType
Represents numeric values including integers and decimals (e.g., 42, 3.14).

O

ObjectHandlerMatcher() - Constructor for class io.fluxcapacitor.common.handling.HandlerInspector.ObjectHandlerMatcher
 
objectMapper - Static variable in class io.fluxcapacitor.common.api.Metadata
 
ObjectUtils - Class in io.fluxcapacitor.common
Utility class for common object handling, memoization, concurrency, stream processing, and error handling.
ObjectUtils() - Constructor for class io.fluxcapacitor.common.ObjectUtils
 
Obtaining a Gateway - Search tag in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Section
of(Class<?>) - Static method in class io.fluxcapacitor.common.reflection.ParameterRegistry
Returns the registry instance for the specified class, loading and memoizing the generated _params class on first access.
of(Object...) - Static method in class io.fluxcapacitor.common.api.Metadata
Creates a new Metadata instance with the provided key-value pairs.
of(Object, Object) - Static method in class io.fluxcapacitor.common.api.Metadata
Creates a new Metadata instance with a single key-value pair.
of(String...) - Static method in class io.fluxcapacitor.common.api.search.Group
Creates a Group from an even-length list of alternating keys and values.
of(Map<?, ?>) - Static method in class io.fluxcapacitor.common.api.Metadata
Creates a new instance of Metadata populated with the given map.
offsetFromIndex(long) - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Calculates the offset from the given index by extracting the least significant 16 bits.
ok(Object, Map<String, String>) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
 
ok(ThrowingSupplier<? extends InputStream>, Map<String, String>) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
 
onAbort(DefaultSocketSession, int) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
 
onBatchCompletion(Throwable) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage.MessageSpliterator
 
onClose() - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
onClose(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
onClose(Session, CloseReason) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
onClose(Session, CloseReason) - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
onClose(Session, CloseReason) - Method in class io.fluxcapacitor.testserver.websocket.ConsumerEndpoint
 
onClose(Session, CloseReason) - Method in class io.fluxcapacitor.testserver.websocket.MultiClientEndpoint
 
onClose(Session, CloseReason) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
onClose(Runnable) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
onClusterUpdate(TrackerCluster) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
onComplete(Route.Complete) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
onDelete(Runnable) - Method in class io.fluxcapacitor.javaclient.tracking.handling.MutableHandler
 
onError(Session, Throwable) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
onError(Session, Throwable) - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
onError(Session, Throwable) - Method in class io.fluxcapacitor.testserver.websocket.MultiClientEndpoint
 
onError(Session, Throwable) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
onMessage(byte[], Session) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
onOpen(Session) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
onOpen(Session, EndpointConfig) - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
onOpen(Session, EndpointConfig) - Method in class io.fluxcapacitor.testserver.websocket.MultiClientEndpoint
 
onOpen(Session, EndpointConfig) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
onOpenOrMessage(SocketSession, DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
onPong(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
onPong(PongMessage, Session) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
onUpdate(List<SerializedMessage>) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
openStream(String, Long, int) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
Optional attributes - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.Member
Section
Optional Final Notification - Search tag in class io.fluxcapacitor.common.api.tracking.DisconnectTracker
Section
OPTIONS - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
or(Constraint) - Method in interface io.fluxcapacitor.common.api.search.Constraint
Combines this constraint with another using logical OR.
or(HandlerFilter) - Method in interface io.fluxcapacitor.common.handling.HandlerFilter
Combines this filter with another using logical OR.
or(Handler<M>) - Method in interface io.fluxcapacitor.common.handling.Handler
Creates a composite handler that executes the current handler and then delegates to the specified next handler if the current handler cannot handle the message or does not provide an invoker.
or(HandlerMatcher<T, M>) - Method in interface io.fluxcapacitor.common.handling.HandlerMatcher
Combines this HandlerMatcher with another HandlerMatcher to form a composite matcher.
or(ThrowingPredicate<? super T>) - Method in interface io.fluxcapacitor.common.ThrowingPredicate
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
Ordering - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
orThen(HandlerRegistry) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
Creates a fallback registry that only invokes the given registry if this one yields no result.
orTimeout(CompletableFuture<R>, Duration) - Method in interface io.fluxcapacitor.common.TaskScheduler
Sets a timeout for a CompletableFuture.
OutputStreamCapturer - Class in io.fluxcapacitor.javaclient.web
 
OutputStreamCapturer(int, BiConsumer<byte[], Boolean>) - Constructor for class io.fluxcapacitor.javaclient.web.OutputStreamCapturer
 

P

parallel() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
ParameterRegistry - Class in io.fluxcapacitor.common.reflection
Registry for accessing method parameter names at runtime in environments where Java reflection does not retain them (e.g.
ParameterRegistry() - Constructor for class io.fluxcapacitor.common.reflection.ParameterRegistry
 
ParameterResolver<M> - Interface in io.fluxcapacitor.common.handling
Mechanism to resolve method parameters in message handler methods (e.g. those annotated with HandleEvent, HandleCommand, etc.).
ParameterValue - Class in io.fluxcapacitor.javaclient.web
Wrapper around a Value representing a resolved parameter value in a web request.
ParameterValue() - Constructor for class io.fluxcapacitor.javaclient.web.ParameterValue
 
parent() - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
parent() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
parent() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the parent entity of the current entity.
parent() - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
parent() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
parent() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
parseCronExpression(String) - Static method in class io.fluxcapacitor.javaclient.scheduling.CronExpression
 
parseCronExpression(String, boolean) - Static method in class io.fluxcapacitor.javaclient.scheduling.CronExpression
 
parseObject(JsonParser, Map<Document.Entry, List<Document.Path>>, String) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
parseRequestCookieHeader(String) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Parses a Cookie request header string into a list of HttpCookie instances.
parseResponseCookieHeader(List<String>) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Parses a list of Set-Cookie header values into a list of HttpCookie instances.
partial(ThrowingSupplier<? extends InputStream>, Map<String, String>) - Static method in class io.fluxcapacitor.javaclient.web.WebResponse
 
PartialFileInputStream - Class in io.fluxcapacitor.javaclient.web
 
PartialFileInputStream(Path, long, long) - Constructor for class io.fluxcapacitor.javaclient.web.PartialFileInputStream
 
passive() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Indicates that this consumer should process messages without publishing result messages.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleCommand
If true, this handler is considered passive and will not emit a result message.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleCustom
If true, this handler is considered passive and will not emit a result message.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleQuery
If true, this handler is considered passive and will not emit a result message.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleDelete
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleGet
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleHead
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleOptions
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePatch
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePost
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePut
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketHandshake
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketMessage
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketOpen
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketPong
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleTrace
If true, the handler will not publish a response to the WebResponse log.
passive() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleWeb
If true, the handler will not publish a response to the WebResponse log.
patch(String) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Creates a new WebRequest.Builder instance for constructing a PATCH request to given url.
PATCH - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
path() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Returns path of the property to match on in the handler state.
Path - Annotation Interface in io.fluxcapacitor.javaclient.web
Declares a path prefix that contributes to the final URI of a web handler.
Path() - Constructor for class io.fluxcapacitor.common.search.Document.Path
 
PATH - Enum constant in enum class io.fluxcapacitor.javaclient.web.WebParameterSource
URI path parameters (e.g.
PathConstraint - Class in io.fluxcapacitor.common.api.search.constraints
Abstract base class for constraints that apply to specific paths in a Document.
PathConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.PathConstraint
 
Path Filtering - Search tag in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
Section
Path Handling - Search tag in class io.fluxcapacitor.common.api.search.constraints.MatchConstraint
Section
pathMap() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
PathParam - Annotation Interface in io.fluxcapacitor.javaclient.web
Injects a path variable from the URI into a handler method parameter.
pathPredicate(String) - Static method in class io.fluxcapacitor.common.search.Document.Path
Constructs a predicate to match Document.Path instances against the given glob-style path query.
pattern() - Element in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnProperty
 
pauseDuration() - Method in interface io.fluxcapacitor.javaclient.tracking.FlowRegulator
Optionally pause this consumer for a given amount of time.
pauseFetchIfNeeded() - Method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
 
PauseTrackerEvent - Class in io.fluxcapacitor.javaclient.tracking.metrics
 
PauseTrackerEvent() - Constructor for class io.fluxcapacitor.javaclient.tracking.metrics.PauseTrackerEvent
 
payload(Object) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
PayloadFilter - Class in io.fluxcapacitor.javaclient.tracking.handling
A MessageFilter used to restrict message handling based on the payload type.
PayloadFilter() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.PayloadFilter
 
PayloadParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling
Resolves handler method parameters by injecting the message payload.
PayloadParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.PayloadParameterResolver
 
Payload requiring an authenticated user - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresUser
Section
peek(Consumer<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
Performance consideration - Search tag in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
Section
Performance Considerations - Search tag in class io.fluxcapacitor.common.api.search.constraints.ContainsConstraint
Section
Performance Considerations - Search tag in class io.fluxcapacitor.common.api.search.constraints.QueryConstraint
Section
Performance Considerations - Search tag in class io.fluxcapacitor.common.reflection.ReflectionUtils
Section
performInvocation(Callable<V>) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.Invocation
Wraps the given Callable in an invocation context.
period(Instant, Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Sets the start and end time using a time range.
Periodic - Annotation Interface in io.fluxcapacitor.javaclient.scheduling
Declares a message (typically a Schedule) or its handler method as part of a periodic schedule.
PeriodicSnapshotTrigger - Class in io.fluxcapacitor.javaclient.persisting.eventsourcing
A SnapshotTrigger that triggers snapshot creation at fixed intervals based on the aggregate's sequence number.
PeriodicSnapshotTrigger(int) - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.PeriodicSnapshotTrigger
Constructs a periodic snapshot trigger with the given interval.
periodIndex(long) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.PeriodicSnapshotTrigger
 
Persistence - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Section
Persistence and Lifecycle - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
Section
pingDelay() - Element in annotation interface io.fluxcapacitor.javaclient.web.SocketEndpoint.AliveCheck
Interval between pings in SocketEndpoint.AliveCheck.timeUnit().
PingRegistration() - Constructor for class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient.PingRegistration
 
pingTimeout() - Element in annotation interface io.fluxcapacitor.javaclient.web.SocketEndpoint.AliveCheck
Time allowed to receive a pong after a ping.
playBackToCondition(Predicate<Entity<T>>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Plays back through older versions of this entity until a specified condition is met.
playBackToEvent(Long, String) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Finds a version of this entity matching the given eventIndex or eventId.
pollReferenceQueue() - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
position(Tracker, PositionStore, int[]) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
position(String) - Method in class io.fluxcapacitor.common.tracking.InMemoryPositionStore
 
position(String) - Method in interface io.fluxcapacitor.common.tracking.PositionStore
Retrieves the full multi-segment position for the given consumer.
Position - Class in io.fluxcapacitor.common.api.tracking
Represents the tracking state of a consumer, i.e. the last known indexes of consumed messages per segment.
Position(int[], long) - Constructor for class io.fluxcapacitor.common.api.tracking.Position
 
Position(long) - Constructor for class io.fluxcapacitor.common.api.tracking.Position
 
PositionStore - Interface in io.fluxcapacitor.common.tracking
Interface for storing and retrieving Position objects representing the last processed message indexes per segment for a given consumer.
possibleTargets(Object) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Determines the possible target entities for the given update.
post(String) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Creates a new WebRequest.Builder instance for constructing a POST request to given url.
POST - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
postfix() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Alias
Adds given string as a postfix to the alias (if the property value is non-null).
postProcessAfterInitialization(Object, String) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Captures beans post-initialization to inspect later for handler registration.
postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class io.fluxcapacitor.javaclient.configuration.spring.SocketEndpointPostProcessor
 
postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class io.fluxcapacitor.javaclient.configuration.spring.StatefulPostProcessor
No-op.
postProcessBeanDefinitionRegistry(BeanDefinitionRegistry) - Method in class io.fluxcapacitor.javaclient.configuration.spring.TrackSelfPostProcessor
No-op.
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class io.fluxcapacitor.javaclient.configuration.spring.SocketEndpointPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class io.fluxcapacitor.javaclient.configuration.spring.StatefulPostProcessor
Scans for beans annotated with Stateful, wraps each of them in a FluxPrototype, and registers them programmatically as Spring bean definitions.
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class io.fluxcapacitor.javaclient.configuration.spring.TrackSelfPostProcessor
Scans the classpath for components annotated with TrackSelf, based on ComponentScan metadata, and registers each of them as a FluxPrototype.
Preferred Alternatives - Search tag in class io.fluxcapacitor.common.api.tracking.ResetPosition
Section
prefix() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Alias
Adds given string as a prefix to the alias (if the property value is non-null).
prepareForSending(SerializedMessage, HttpServerExchange, int) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
prepareIndex(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Prepare given object for indexing for search.
prepareIndex(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Begins an index operation for the given object.
prepareInvoker(M) - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher
 
prepareRequest(SerializedMessage, Duration, Consumer<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
 
previous() - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
previous() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
previous() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the previous version of this entity.
previous() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
previous() - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
previous() - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
previous() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
previous() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
priority() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Determines the order of assertions if there are multiple annotated methods.
process(MessageBatch) - Method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
 
process(Set<? extends TypeElement>, RoundEnvironment) - Method in class io.fluxcapacitor.common.serialization.TypeRegistryProcessor
 
process(Set<? extends TypeElement>, RoundEnvironment) - Method in class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
 
process(Set<? extends TypeElement>, RoundEnvironment) - Method in class io.fluxcapacitor.javaclient.web.WebParameterProcessor
 
ProcessBatchEvent - Class in io.fluxcapacitor.javaclient.tracking.metrics
 
ProcessBatchEvent() - Constructor for class io.fluxcapacitor.javaclient.tracking.metrics.ProcessBatchEvent
 
processError(Throwable, DeserializingMessage, HandlerInvoker, Handler<DeserializingMessage>, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
processToken(JsonToken, Map<Document.Entry, List<Document.Path>>, String, JsonParser) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
ProducerEndpoint - Class in io.fluxcapacitor.testserver.websocket
 
ProducerEndpoint() - Constructor for class io.fluxcapacitor.testserver.websocket.ProducerEndpoint
 
Property-based usage - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
propertySource() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Provides access to configuration properties (typically loaded from the environment).
propertySource() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the PropertySource configured for this FluxCapacitor instance.
PropertySource - Interface in io.fluxcapacitor.common.application
Represents a source of configuration properties.
ProtectData - Annotation Interface in io.fluxcapacitor.javaclient.publishing.dataprotection
Marks a field within a message payload as containing sensitive information that should be protected.
ProxyRequestHandler - Class in io.fluxcapacitor.proxy
 
ProxyRequestHandler(Client) - Constructor for class io.fluxcapacitor.proxy.ProxyRequestHandler
 
ProxySerializer - Class in io.fluxcapacitor.proxy
 
ProxySerializer() - Constructor for class io.fluxcapacitor.proxy.ProxySerializer
 
ProxyServer - Class in io.fluxcapacitor.proxy
 
ProxyServer() - Constructor for class io.fluxcapacitor.proxy.ProxyServer
 
publicationStrategy() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Strategy that determines how applied updates are persisted and/or published.
publicationStrategy() - Element in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Controls how the applied update is stored and/or published.
Publication Strategy - Search tag in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
Section
publish(Guarantee, Object...) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultEventGateway
 
publish(Guarantee, Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.EventGateway
Publishes one or more event messages with a specific delivery guarantee.
publish(Message, Guarantee) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultEventGateway
 
publish(Message, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.EventGateway
Publishes the given Message to Flux Capacitor and/or local handlers.
publish(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.EventGateway
Publishes the given event object.
publish(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.MetricsGateway
Publishes a metrics message using default metadata and Guarantee.NONE.
publish(Object...) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultEventGateway
 
publish(Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.EventGateway
Publishes one or more event messages.
publish(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.EventGateway
Publishes an event with the specified payload and metadata.
publish(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.MetricsGateway
Publishes a metrics payload with the specified metadata and a Guarantee.NONE delivery guarantee.
publish(Object, Metadata, Guarantee) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultMetricsGateway
 
publish(Object, Metadata, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.MetricsGateway
Publishes a metrics message with the specified metadata and delivery guarantee.
PUBLISH_ONLY - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublicationStrategy
Publish the update to event handlers but do not store it in the event store.
publishEvent(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Publishes the given application event.
publishEvent(Object, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Publishes an event with given payload and metadata.
publishEvents(Object...) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Publishes given application events.
publishHandleMessageMetrics(SerializedMessage, boolean, Instant) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
publishMetrics(HandlerInvoker, DeserializingMessage, boolean, Instant, Object) - Method in class io.fluxcapacitor.javaclient.tracking.metrics.HandlerMonitor
 
publishMetrics(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Publishes a metrics event.
publishMetrics(Object, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Publishes a metrics event with given payload and metadata.
publishProcessBatchMetrics(Instant) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
purgeCeasedTrackers(Duration) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
purgeCeasedTrackers(Instant) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Removes trackers that have not sent activity after the given timestamp.
purgeExpiredMessages(Duration) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
purgeExpiredMessages(Duration) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
purgeExpiredMessages(Duration) - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
purgeTrackers(Predicate<Tracker>) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Removes all trackers that match the provided predicate.
Purpose - Search tag in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
Section
Purpose - Search tag in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
Section
put(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
put(Object, Object) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
put(Object, Object) - Method in class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
put(Object, Object) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultHandlerRepository
 
put(Object, Object) - Method in interface io.fluxcapacitor.javaclient.modeling.HandlerRepository
Persists or updates the handler instance identified by the given ID.
put(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Puts a value in the cache for the given id, overwriting any existing value.
put(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
put(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
put(String) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Creates a new WebRequest.Builder instance for constructing a PUT request to given url.
PUT - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
putIfAbsent(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
putIfAbsent(Object, Object) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
putIfAbsent(Object, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Associates the specified value with the given id only if no value is currently associated.
putIfAbsent(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
putIfAbsent(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
putValue(String, Data<byte[]>, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.InMemoryKeyValueStore
 
putValue(String, Data<byte[]>, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.client.KeyValueClient
Adds or replaces the given value in the key value store.
putValue(String, Data<byte[]>, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.WebsocketKeyValueClient
 
putValueIfAbsent(String, Data<byte[]>) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.InMemoryKeyValueStore
 
putValueIfAbsent(String, Data<byte[]>) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.client.KeyValueClient
Adds the given value in the key value store if the key is not already mapped to a value.
putValueIfAbsent(String, Data<byte[]>) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.client.WebsocketKeyValueClient
 

Q

query(Request<R>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given query and returns a future that will be completed with the query's result.
query(Request<R>, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a query with given payload and metadata and returns a future that will be completed with the query's result.
query(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given query and returns a future that will be completed with the query's result.
query(Object, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a query with given payload and metadata and returns a future that will be completed with the query's result.
query(String, boolean, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.QueryConstraint
Creates a QueryConstraint with optional lookahead behavior for terms.
query(String, String...) - Static method in class io.fluxcapacitor.common.api.search.constraints.QueryConstraint
Creates a QueryConstraint that parses and evaluates the given query string.
query(String, String...) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Adds a full-text search constraint for the given phrase.
QUERY - Enum constant in enum class io.fluxcapacitor.common.MessageType
A request for data or read-only information.
QUERY - Enum constant in enum class io.fluxcapacitor.javaclient.web.WebParameterSource
HTTP query string parameters (e.g. ?
queryAndWait(Request<R>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given query and returns the query's result.
queryAndWait(Request<R>, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a query with given payload and metadata and returns the query's result.
queryAndWait(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given query and returns the query's result.
queryAndWait(Object, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a query with given payload and metadata and returns the query's result.
QueryConstraint - Class in io.fluxcapacitor.common.api.search.constraints
A Constraint that parses a human-friendly query string into a structured tree of constraints.
QueryConstraint() - Constructor for class io.fluxcapacitor.common.api.search.constraints.QueryConstraint
 
queryGateway() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway for query messages.
queryGateway(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
QueryGateway - Interface in io.fluxcapacitor.javaclient.publishing
Gateway interface for dispatching queries and receiving responses in Flux Capacitor.
QueryParam - Annotation Interface in io.fluxcapacitor.javaclient.web
Injects an HTTP query parameter into a handler method parameter.

R

1. Rewrite a duplicate create into an update (inside the update class) - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.InterceptApply
Section
4. Recursive interception - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.InterceptApply
Section
read() - Method in class io.fluxcapacitor.common.LazyInputStream
 
read() - Method in class io.fluxcapacitor.javaclient.web.PartialFileInputStream
 
read(byte[]) - Method in class io.fluxcapacitor.common.LazyInputStream
 
read(byte[], int, int) - Method in class io.fluxcapacitor.common.LazyInputStream
 
read(byte[], int, int) - Method in class io.fluxcapacitor.javaclient.web.PartialFileInputStream
 
read(String, Long, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
read(String, Long, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
read(String, Long, ConsumerConfiguration) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Asynchronously reads the next available MessageBatch for a given tracker.
read(String, Long, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
Read - Class in io.fluxcapacitor.common.api.tracking
Command to read a batch of messages from the Flux platform for a given consumer and tracker.
Read() - Constructor for class io.fluxcapacitor.common.api.tracking.Read
 
readAndWait(String, Long, ConsumerConfiguration) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Reads the next available MessageBatch for the given tracker and blocks until messages are available.
reader - Static variable in class io.fluxcapacitor.common.serialization.JsonUtils
Preconfigured JsonMapper for reading/deserializing objects from JSON, including type handling.
readFromIndex(long, int) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
readFromIndex(long, int) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
readFromIndex(long, int) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Fetches messages starting from the given index up to the provided max size.
readFromIndex(long, int) - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
ReadFromIndex - Class in io.fluxcapacitor.common.api.tracking
Request to fetch a batch of messages from a given log starting from a given index.
ReadFromIndex() - Constructor for class io.fluxcapacitor.common.api.tracking.ReadFromIndex
 
ReadFromIndexResult - Class in io.fluxcapacitor.common.api.tracking
Result for a ReadFromIndex request.
ReadFromIndexResult() - Constructor for class io.fluxcapacitor.common.api.tracking.ReadFromIndexResult
 
ReadFromIndexResult.Metric - Class in io.fluxcapacitor.common.api.tracking
Metric representation of a ReadFromIndexResult, used for internal monitoring and analytics.
readProperty(String, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
ReadResult - Class in io.fluxcapacitor.common.api.tracking
Result returned in response to a Read request for a batch of messages.
ReadResult() - Constructor for class io.fluxcapacitor.common.api.tracking.ReadResult
 
ReadResult.Metric - Class in io.fluxcapacitor.common.api.tracking
Compact representation of the ReadResult used for monitoring.
readTree(byte[]) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Reads a JSON structure as a JsonNode tree from a JSON byte array.
readTree(InputStream) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Reads a JSON structure as a JsonNode tree from a JSON input stream.
readTree(String) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Reads a JSON structure as a JsonNode tree from a JSON string.
reduce(BinaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
reduce(T, BinaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
reduce(U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
ReflectionUtils - Class in io.fluxcapacitor.common.reflection
Utility class for high-performance reflection-based operations across the Flux platform.
ReflectionUtils() - Constructor for class io.fluxcapacitor.common.reflection.ReflectionUtils
 
register(Cache) - Method in class io.fluxcapacitor.javaclient.persisting.caching.CacheEvictionsLogger
Registers this logger as an eviction listener for the given Cache.
registerCasterCandidates(Object...) - Method in interface io.fluxcapacitor.javaclient.common.serialization.casting.CasterChain
Registers one or more objects that may contain casting logic (e.g. annotated methods or implementations).
registerCasterCandidates(Object...) - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
 
registerCasters(Object...) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Registers upcasters and downcasters in one step.
registerDowncasters(Object...) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Registers custom downcasters for transforming newer object states to older revisions.
registerDowncasters(Object...) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Registers one or more downcaster candidates.
registerDowncasters(Object...) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
registerEviction(DefaultCache.CacheReference, CacheEviction.Reason) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
registerEvictionListener(Consumer<CacheEviction>) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Registers a listener to be notified whenever a cache entry is evicted or removed.
registerEvictionListener(Consumer<CacheEviction>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
registerEvictionListener(Consumer<CacheEviction>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
registerEvictionListener(Consumer<CacheEviction>) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
registerEvictionListener(Consumer<CacheEviction>) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
registerHandler(Object) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
registerHandler(Object) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HasLocalHandlers
Registers the given handler object and includes only the methods that are annotated with a recognized handler annotation (e.g., @HandleCommand, @HandleQuery, etc.).
registerHandler(Object, HandlerFilter) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.LocalDocumentHandlerRegistry
 
registerHandler(Object, HandlerFilter) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
registerHandler(Object, HandlerFilter) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.NoOpHandlerRegistry
 
registerHandler(Object, HandlerFilter) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HasLocalHandlers
Registers a handler object, including only those methods that match the provided HandlerFilter.
registerHandler(Object, HandlerFilter) - Method in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
 
registerHandlers(Object...) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Registers given handlers and initiates message tracking (i.e. listening for messages).
registerHandlers(List<?>) - Method in interface io.fluxcapacitor.javaclient.configuration.spring.SpringHandlerRegistry
Registers the given list of handlers with the registry.
registerHandlers(List<?>) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Registers given handlers and initiates message tracking.
registerMetrics(ClientEvent) - Method in interface io.fluxcapacitor.testserver.metrics.MetricsLog
 
registerMetrics(ClientEvent) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
registerMetrics(ClientEvent, Metadata) - Method in class io.fluxcapacitor.testserver.metrics.DefaultMetricsLog
 
registerMetrics(ClientEvent, Metadata) - Method in interface io.fluxcapacitor.testserver.metrics.MetricsLog
 
registerMetrics(ClientEvent, Metadata) - Method in class io.fluxcapacitor.testserver.metrics.NoOpMetricsLog
 
registerMonitor(String, Consumer<List<SerializedMessage>>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
registerMonitor(BiConsumer<String, List<SerializedMessage>>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
registerMonitor(Consumer<List<SerializedMessage>>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.CollectionMessageStore
 
registerMonitor(Consumer<List<SerializedMessage>>) - Method in class io.fluxcapacitor.javaclient.publishing.client.WebsocketGatewayClient
 
registerMonitor(Consumer<List<SerializedMessage>>) - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
registerMonitor(Consumer<List<SerializedMessage>>) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
registerMonitor(Consumer<List<T>>) - Method in class io.fluxcapacitor.common.Backlog
Adds a monitor to observe flushed batches.
registerMonitor(Consumer<T>) - Method in interface io.fluxcapacitor.common.Monitored
Registers a monitor that will be notified when an activity of type T occurs.
RegisterType - Annotation Interface in io.fluxcapacitor.common.serialization
Annotation to register a class or package for inclusion in the TypeRegistry.
registerTypeCaster(String, String) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Registers a type mapping for upcasting old type names to new ones.
registerTypeCaster(String, String) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Registers a mapping from an old type identifier to a new one.
registerTypeCaster(String, String) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
registerUpcasters(Object...) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Registers custom upcasters for handling older serialized formats.
registerUpcasters(Object...) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Registers one or more upcaster candidates.
registerUpcasters(Object...) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
registerUserProvider(UserProvider) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
registerUserProvider(UserProvider) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Registers a user provider used for resolving and authenticating User instances.
registerValue(Document.EntryType, String, String, Map<Document.Entry, List<Document.Path>>) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
Registration - Interface in io.fluxcapacitor.common
Represents a handle for a cancellable registration, such as a subscription, listener, or callback.
Relationship - Class in io.fluxcapacitor.common.api.modeling
Describes a relationship between an entity and the aggregate that contains or owns it.
Relationship() - Constructor for class io.fluxcapacitor.common.api.modeling.Relationship
 
relationships() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the set of relationships between the aggregate root and all its entities.
relationshipsCache() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Dedicated cache used to store and lookup relationships between entities.
remove(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Removes the entry associated with the given id, if present.
remove(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
remove(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
remove(Object) - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
remove(Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
remove(K) - Method in class io.fluxcapacitor.common.DefaultMemoizingFunction
 
remove(K) - Method in interface io.fluxcapacitor.common.MemoizingFunction
Removes and returns the cached result for the given key, if present.
remove(T, U) - Method in class io.fluxcapacitor.common.DefaultMemoizingBiFunction
 
remove(T, U) - Method in interface io.fluxcapacitor.common.MemoizingBiFunction
Removes the cached result for the given input pair, if present.
removeExpiredReferences() - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
removeExpiredSchedules(Serializer) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
removeFromMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AbstractUserProvider
Removes the user entry from the metadata.
removeFromMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.DelegatingUserProvider
 
removeFromMetadata(Metadata) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
 
removeFromMetadata(Metadata) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.UserProvider
Removes any user-related metadata entries from the given Metadata.
removeOldMessages() - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
removeOutdatedValues(Collection<? extends Entry<?>>) - Method in class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
removeResponseHeader(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
removeResponseHeaders() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
repairRelationships(RepairRelationships) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Repairs entity relationships, e.g. by forcing re-evaluation of existing relationships.
repairRelationships(RepairRelationships) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
repairRelationships(RepairRelationships) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Sends a request to repair relationships for a specific entity.
repairRelationships(Entity<?>) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Repairs the internal relationship model for a loaded aggregate.
repairRelationships(Entity<?>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
repairRelationships(Entity<?>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.DefaultAggregateRepository
 
repairRelationships(Id<?>) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Repairs the relationships of the aggregate corresponding to the given typed ID.
repairRelationships(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.repository.AggregateRepository
Repairs the relationships of the aggregate with the given ID.
RepairRelationships - Class in io.fluxcapacitor.common.api.modeling
Command to repair or re-index the relationships for an existing aggregate.
RepairRelationships() - Constructor for class io.fluxcapacitor.common.api.modeling.RepairRelationships
 
replaceCache(Cache) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceCache(Cache) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the default cache implementation.
replaceCorrelationDataProvider(UnaryOperator<CorrelationDataProvider>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceCorrelationDataProvider(UnaryOperator<CorrelationDataProvider>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the CorrelationDataProvider used to attach correlation data to messages.
replaceDefaultResponseMapper(ResponseMapper) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceDefaultResponseMapper(ResponseMapper) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the default response mapper used for generic result mapping.
replaceDocumentSerializer(DocumentSerializer) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceDocumentSerializer(DocumentSerializer) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the document serializer for search indexing.
replaceIdentityProvider(UnaryOperator<IdentityProvider>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceIdentityProvider(UnaryOperator<IdentityProvider>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the identity provider used to generate message and entity identifiers.
replaceMessageRoutingInterceptor(DispatchInterceptor) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceMessageRoutingInterceptor(DispatchInterceptor) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the default routing interceptor used for message dispatch.
replacePathParameter(String, String, String) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Replaces named path parameter with provided value.
replacePropertySource(UnaryOperator<PropertySource>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replacePropertySource(UnaryOperator<PropertySource>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the existing property source.
replaceRelationshipsCache(UnaryOperator<Cache>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceRelationshipsCache(UnaryOperator<Cache>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the internal relationships cache with a new implementation.
replaceSerializer(Serializer) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceSerializer(Serializer) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the default serializer used for events, commands, snapshots, and documents.
replaceSnapshotSerializer(Serializer) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceSnapshotSerializer(Serializer) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Overrides the serializer used specifically for snapshot serialization.
replaceTaskScheduler(Function<Clock, TaskScheduler>) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceTaskScheduler(Function<Clock, TaskScheduler>) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the default TaskScheduler implementation.
replaceWebResponseMapper(WebResponseMapper) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
replaceWebResponseMapper(WebResponseMapper) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Replaces the WebResponseMapper used for handling web responses.
report(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.ErrorGateway
Reports an error using the provided object.
report(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.ErrorGateway
Reports an error with the given payload and metadata using the default Guarantee.NONE.
report(Object, Metadata, Guarantee) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultErrorGateway
 
report(Object, Metadata, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.ErrorGateway
Reports an error with the given payload, metadata, and delivery guarantee.
reportError(Throwable, HandlerInvoker, DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.tracking.handling.errorreporting.ErrorReportingInterceptor
 
reportResult(Object, HandlerInvoker, DeserializingMessage, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
RepositoryProvider - Interface in io.fluxcapacitor.javaclient.tracking.handling
Provides access to a singleton-style repository for a given class type.
Request - Class in io.fluxcapacitor.common.api
Base class for requests sent to the Flux platform.
Request<R> - Interface in io.fluxcapacitor.javaclient.tracking.handling
Marker interface for request messages (e.g., commands or queries) that expect a response of a specific type.
Request() - Constructor for class io.fluxcapacitor.common.api.Request
 
RequestAnnotationProcessor - Class in io.fluxcapacitor.javaclient.tracking.handling
Annotation processor that validates whether handler methods annotated with HandleCommand, HandleQuery or HandleCustom correctly match the response type declared by a Request payload.
RequestAnnotationProcessor() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
 
RequestBatch<T> - Class in io.fluxcapacitor.common.api
Represents a batch of requests to be sent to the Flux platform in a single network round-trip.
RequestBatch() - Constructor for class io.fluxcapacitor.common.api.RequestBatch
 
RequestHandler - Interface in io.fluxcapacitor.javaclient.publishing
Handles the lifecycle of request/response interactions in a Flux Capacitor client.
RequestResult - Interface in io.fluxcapacitor.common.api
Marker interface for responses to Request objects (including commands and queries).
require(String) - Method in interface io.fluxcapacitor.common.application.PropertySource
Retrieves the value of a property by name and throws if not present.
RequiredRole(String, boolean, boolean, boolean) - Constructor for record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Creates an instance of a RequiredRole record class.
requireProperty(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Returns the string property for the given key, throwing an IllegalStateException if not found.
RequiresAnyRole - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling.authentication
Declares role-based access control for message handlers or payload types.
requireSocketSessionId(Metadata) - Static method in class io.fluxcapacitor.javaclient.web.WebRequest
Retrieves the WebSocket session ID from the provided metadata or throws an exception if it is missing.
requiresUser() - Method in record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Returns the value of the requiresUser record component.
RequiresUser - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling.authentication
Indicates that a handler or message requires the presence of an authenticated user.
reschedule(Duration) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new Schedule with the same scheduleId and a new deadline offset by the given duration.
rescheduleNextDeadline(long) - Method in class io.fluxcapacitor.testserver.scheduling.TestServerScheduleStore
 
Rescheduling Behavior - Search tag in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Section
reset() - Method in class io.fluxcapacitor.common.LazyInputStream
 
resetPosition(String, long) - Method in class io.fluxcapacitor.common.tracking.InMemoryPositionStore
 
resetPosition(String, long) - Method in interface io.fluxcapacitor.common.tracking.PositionStore
Resets the position of the consumer for all segments to the given index.
resetPosition(String, long) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Resets the consumer's tracking position to a given index.
resetPosition(String, long, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
resetPosition(String, long, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
resetPosition(String, long, Guarantee) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Resets the consumer's tracking position to a given index with a specific delivery guarantee.
resetPosition(String, long, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
ResetPosition - Class in io.fluxcapacitor.common.api.tracking
Command to forcibly reset the tracked position for a given consumer and message type.
ResetPosition() - Constructor for class io.fluxcapacitor.common.api.tracking.ResetPosition
 
resolve(Parameter, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
Returns a Supplier that returns the entity if the entity or any of its parents match the expected parameter type.
resolve(Parameter, Annotation) - Method in interface io.fluxcapacitor.common.handling.ParameterResolver
Resolves a Parameter of a handler method into a value function based on the given message.
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.configuration.spring.SpringBeanParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.modeling.EntityParameterResolver
Provides a Supplier that returns the matching entity or its value for the given parameter.
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.CurrentUserParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.UserParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DeserializingMessageParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.InputParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.MessageParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.MetadataParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.PayloadParameterResolver
 
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
Resolves the value to inject into a parameter annotated with Trigger.
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.web.WebParamParameterResolver
Resolves the parameter value from a WebRequestContext using the metadata provided by a parameter annotation that is meta-annotated with WebParam.
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.web.WebPayloadParameterResolver
Resolves the value for the given method parameter by converting the message payload to the expected parameter type.
resolve(Parameter, Annotation) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
Resolves a SocketSession parameter from the current HasMessage context.
resourcePath() - Element in annotation interface io.fluxcapacitor.javaclient.web.ServeStatic
The base resource path from which to serve static files.
respond(Object, Metadata, String, Integer, Guarantee) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultResultGateway
 
respond(Object, Metadata, String, Integer, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.ResultGateway
Sends a response with the specified payload, metadata, target, request ID, and delivery guarantee.
respond(Object, Metadata, String, Integer, Guarantee) - Method in class io.fluxcapacitor.javaclient.web.WebResponseGateway
 
respond(Object, String, Integer) - Method in interface io.fluxcapacitor.javaclient.publishing.ResultGateway
Sends a response message with default metadata and Guarantee.NONE.
ResponseCallback(Consumer<SerializedMessage>, CompletableFuture<SerializedMessage>) - Constructor for record class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler.ResponseCallback
Creates an instance of a ResponseCallback record class.
ResponseMapper - Interface in io.fluxcapacitor.javaclient.tracking.handling
A strategy interface for converting arbitrary response objects into Message instances.
responseSender() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
responseStream() - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
responseType() - Method in interface io.fluxcapacitor.javaclient.tracking.handling.Request
Returns the expected response type associated with this request instance.
responseWriter(MediaType, Charset) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
Responsibilities - Search tag in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Section
Responsibilities - Search tag in interface io.fluxcapacitor.common.tracking.Tracker
Section
Responsibilities - Search tag in interface io.fluxcapacitor.common.tracking.TrackingStrategy
Section
Responsibilities - Search tag in interface io.fluxcapacitor.javaclient.common.HasMessage
Section
Responsibilities - Search tag in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Section
Responsibilities - Search tag in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Section
Responsibilities - Search tag in interface io.fluxcapacitor.javaclient.configuration.client.Client
Section
Responsibilities - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
Section
Responsibilities: - Search tag in class io.fluxcapacitor.javaclient.modeling.AnnotatedEntityHolder
Section
RESULT - Enum constant in enum class io.fluxcapacitor.common.MessageType
The result of handling a request (e.g. command, query).
ResultBatch - Class in io.fluxcapacitor.common.api
Represents a batch of results returned from the Flux platform in response to a RequestBatch.
ResultBatch() - Constructor for class io.fluxcapacitor.common.api.ResultBatch
 
resultGateway() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway for result messages sent by handlers of commands and queries.
resultGateway(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
ResultGateway - Interface in io.fluxcapacitor.javaclient.publishing
Gateway interface for sending result messages in response to a command or query.
Result Matching - Search tag in class io.fluxcapacitor.common.api.ResultBatch
Section
retainHeaders(String...) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Retains only the specified headers from the current WebResponse.
RetryConfiguration - Class in io.fluxcapacitor.common
Configuration for retry behavior when executing a task using TimingUtils.retryOnFailure(java.lang.Runnable, java.time.Duration).
RetryConfiguration() - Constructor for class io.fluxcapacitor.common.RetryConfiguration
 
RetryingErrorHandler - Class in io.fluxcapacitor.javaclient.tracking
An ErrorHandler implementation that retries failed operations a configurable number of times, with optional propagation or suppression of unrecoverable errors.
RetryingErrorHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Constructs a handler that retries on technical exceptions up to 5 times with a 2-second delay.
RetryingErrorHandler(boolean) - Constructor for class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Constructs a handler with default retry behavior and optional consumer stop behavior.
RetryingErrorHandler(int, Duration, Predicate<Throwable>, boolean, boolean) - Constructor for class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Constructs a handler with detailed retry configuration options.
RetryingErrorHandler(int, Duration, Predicate<Throwable>, boolean, boolean, Function<Throwable, ?>) - Constructor for class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Constructs a fully customized retrying handler with retry behavior and error mapping logic.
RetryingErrorHandler(Predicate<Throwable>) - Constructor for class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Constructs a handler with a custom error filter that allows message tracking to continue if the error persists after retries.
RetryingErrorHandler(Predicate<Throwable>, boolean) - Constructor for class io.fluxcapacitor.javaclient.tracking.RetryingErrorHandler
Constructs a handler with a custom error filter and optional consumer stop behavior.
retryOnFailure(Runnable, Duration) - Static method in class io.fluxcapacitor.common.TimingUtils
Retries a task indefinitely if it fails, using a fixed delay.
retryOnFailure(Runnable, Duration, Predicate<Throwable>) - Static method in class io.fluxcapacitor.common.TimingUtils
Retries a task indefinitely if it fails and matches the given exception predicate.
retryOnFailure(Callable<T>, RetryConfiguration) - Static method in class io.fluxcapacitor.common.TimingUtils
Retries a Callable task using a full RetryConfiguration.
retryOnFailure(Callable<T>, Duration) - Static method in class io.fluxcapacitor.common.TimingUtils
Retries a Callable task indefinitely with a fixed delay.
retryOnFailure(Callable<T>, Duration, Predicate<Throwable>) - Static method in class io.fluxcapacitor.common.TimingUtils
Retries a Callable task with a delay and a predicate to filter retryable exceptions.
retryOutstandingRequests(String) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
RetryStatus - Class in io.fluxcapacitor.common
Represents the current status of a retry operation.
RetryStatus() - Constructor for class io.fluxcapacitor.common.RetryStatus
 
Return behavior - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleSchedule
Section
Return value inspection - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.AssertLegal
Section
revision() - Element in annotation interface io.fluxcapacitor.javaclient.common.serialization.casting.Downcast
The revision number of the input object this method handles.
revision() - Element in annotation interface io.fluxcapacitor.javaclient.common.serialization.casting.Upcast
The revision number of the input type this method handles.
Revision - Annotation Interface in io.fluxcapacitor.common.serialization
Specifies the revision number of a persistable object, such as a message payload, document, or aggregate snapshot.
revisionDelta() - Element in annotation interface io.fluxcapacitor.javaclient.common.serialization.casting.Cast
The relative revision change this cast represents.
root() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the root entity in the hierarchy.
rootAnnotation() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the root-level annotation of the aggregate, if any.
rootValue - Static variable in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter.FilteringSerializer
 
router() - Static method in class io.fluxcapacitor.javaclient.web.internal.WebUtilsInternal
 
Routing - Search tag in class io.fluxcapacitor.common.api.eventsourcing.AppendEvents
Section
Routing - Search tag in class io.fluxcapacitor.common.api.keyvalue.StoreValues
Section
Routing example with aggregates and nested entities - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Section
routingKey() - Method in class io.fluxcapacitor.common.api.Command
Optionally specifies a routing key for this command, which may be used to partition work or apply consistent hashing when processed in the Flux platform.
routingKey() - Method in class io.fluxcapacitor.common.api.eventsourcing.AppendEvents
Returns the routing key used to partition the command, based on the first batch’s aggregate ID.
routingKey() - Method in class io.fluxcapacitor.common.api.eventsourcing.DeleteEvents
Returns the routing key used to partition or locate the event stream.
routingKey() - Method in class io.fluxcapacitor.common.api.keyvalue.DeleteValue
Routing key used by the Flux platform to shard or partition this command.
routingKey() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValueIfAbsent
 
routingKey() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValues
 
routingKey() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValuesAndWait
Deprecated.
 
routingKey() - Method in class io.fluxcapacitor.common.api.modeling.RepairRelationships
Routing key derived from the aggregate ID to ensure consistent processing.
routingKey() - Method in class io.fluxcapacitor.common.api.modeling.UpdateRelationships
Returns a routing key to optimize dispatching.
routingKey() - Method in class io.fluxcapacitor.common.api.publishing.Append
 
routingKey() - Method in class io.fluxcapacitor.common.api.scheduling.CancelSchedule
Returns the routing key used for this command.
routingKey() - Method in class io.fluxcapacitor.common.api.search.BulkUpdateDocuments
Uses the ID of the first update as the routing key for this command.
routingKey() - Method in class io.fluxcapacitor.common.api.search.CreateAuditTrail
Uses the collection name as routing key to ensure consistent configuration.
routingKey() - Method in class io.fluxcapacitor.common.api.search.DeleteCollection
Uses the collection name as the routing key for consistency and traceability.
routingKey() - Method in class io.fluxcapacitor.common.api.search.DeleteDocumentById
Uses the document ID as the routing key, ensuring consistency during deletion.
routingKey() - Method in class io.fluxcapacitor.common.api.search.IndexDocuments
 
routingKey() - Method in class io.fluxcapacitor.common.api.tracking.DisconnectTracker
 
routingKey() - Method in class io.fluxcapacitor.common.api.tracking.ResetPosition
Returns a routing key used for partitioning the reset command by consumer and message type.
routingKey() - Method in class io.fluxcapacitor.common.api.tracking.StorePosition
Returns a routing key based on the message type and consumer name.
RoutingKey - Annotation Interface in io.fluxcapacitor.javaclient.publishing.routing
Annotation used to identify the routing key of a message, which in turn is used to compute the message segment using consistent hashing.
Routing Logic - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
Section
Routing Logic - Search tag in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
Section
run() - Method in interface io.fluxcapacitor.common.ThrowingRunnable
Executes this runnable.
run() - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy.WaitingTracker
 
run() - Method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
 
run(ThrowingRunnable) - Static method in interface io.fluxcapacitor.common.handling.HandlerInvoker
Wraps a ThrowingRunnable in a HandlerInvoker.
run(ThrowingRunnable) - Static method in class io.fluxcapacitor.common.ObjectUtils
Executes the runnable, forcibly rethrowing exceptions as unchecked.
run(ThrowingRunnable) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.authentication.User
Executes a runnable task with this user set as the current thread-local user.
run(Consumer<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
runningConsumers - Variable in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
Runtime Expectations - Search tag in class io.fluxcapacitor.javaclient.tracking.FluxCapacitorInterceptor
Section
runWithAdhocInterceptor(Runnable, DispatchInterceptor, MessageType...) - Static method in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Executes the given Runnable while temporarily enabling the provided interceptor for the specified message types.
runWithAdhocInterceptor(Callable<T>, DispatchInterceptor, MessageType...) - Static method in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Executes the given Callable while temporarily enabling the provided interceptor for the specified message types.

S

2. Suppress a no-op update - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.InterceptApply
Section
safeResolve(URI, String) - Static method in class io.fluxcapacitor.common.FileUtils
Safely resolves a relative path against a base URI, including JAR URLs.
schedule(long, ThrowingRunnable) - Method in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
schedule(long, ThrowingRunnable) - Method in interface io.fluxcapacitor.common.TaskScheduler
Schedules a task to be executed at the given epoch millisecond timestamp.
schedule(SerializedSchedule...) - Method in interface io.fluxcapacitor.javaclient.scheduling.client.SchedulingClient
Schedule one or more serialized schedules using Guarantee.SENT as the default delivery guarantee.
schedule(Guarantee, SerializedSchedule...) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
schedule(Guarantee, SerializedSchedule...) - Method in interface io.fluxcapacitor.javaclient.scheduling.client.SchedulingClient
Schedule one or more serialized schedules with a specified Guarantee.
schedule(Guarantee, SerializedSchedule...) - Method in class io.fluxcapacitor.javaclient.scheduling.client.WebsocketSchedulingClient
 
schedule(Guarantee, SerializedSchedule...) - Method in class io.fluxcapacitor.testserver.scheduling.TestServerScheduleStore
 
schedule(Schedule) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedule a message object (of type Schedule) for execution, using the Guarantee.SENT guarantee.
schedule(Schedule) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message object (typically of type Schedule) for execution, using the Guarantee.SENT guarantee.
schedule(Schedule, boolean) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedule a message object (of type Schedule) for execution, using the Guarantee.SENT guarantee.
schedule(Schedule, boolean) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message, optionally skipping if already present, using the Guarantee.SENT guarantee.
schedule(Schedule, boolean, Guarantee) - Method in class io.fluxcapacitor.javaclient.scheduling.DefaultMessageScheduler
 
schedule(Schedule, boolean, Guarantee) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule the given Schedule object, optionally skipping if already present, using the specified guarantee.
schedule(Object, Metadata, String, Duration) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message with payload and metadata using a delay, using the Guarantee.SENT guarantee.
schedule(Object, Metadata, String, Instant) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message with payload and metadata, using the Guarantee.SENT guarantee.
schedule(Object, String, Duration) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a message with given scheduleId after given delay.
schedule(Object, String, Duration) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message with a custom ID using a delay.
schedule(Object, String, Instant) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a message with given scheduleId for the given timestamp.
schedule(Object, String, Instant) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message with the given ID and deadline, using the Guarantee.SENT guarantee.
schedule(Object, Duration) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a message after the given delay, returning the schedule's id.
schedule(Object, Duration) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message using a delay from the current time, using the Guarantee.SENT guarantee.
schedule(Object, Instant) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a message for the given timestamp, returning the schedule's id.
schedule(Object, Instant) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a message to be triggered at the given deadline, using the Guarantee.SENT guarantee.
schedule(Duration, ThrowingRunnable) - Method in interface io.fluxcapacitor.common.TaskScheduler
Schedules a task to be executed after a specified delay.
schedule(Instant, ThrowingRunnable) - Method in interface io.fluxcapacitor.common.TaskScheduler
Schedules a task to be executed at a specific timestamp.
Schedule - Class in io.fluxcapacitor.common.api.scheduling
Command to schedule a batch of messages for future delivery.
Schedule - Class in io.fluxcapacitor.javaclient.scheduling
Represents a scheduled message to be delivered at a specific future time.
Schedule() - Constructor for class io.fluxcapacitor.common.api.scheduling.Schedule
 
Schedule(Object, Metadata, String, Instant) - Constructor for class io.fluxcapacitor.javaclient.scheduling.Schedule
Full constructor specifying payload, metadata, scheduleId, and deadline.
Schedule(Object, Metadata, String, Instant, String, Instant) - Constructor for class io.fluxcapacitor.javaclient.scheduling.Schedule
Full constructor including message ID and timestamp.
Schedule(Object, String, Instant) - Constructor for class io.fluxcapacitor.javaclient.scheduling.Schedule
Creates a new scheduled message with a given scheduleId.
Schedule(Object, Instant) - Constructor for class io.fluxcapacitor.javaclient.scheduling.Schedule
Creates a new schedule using the current identity provider for the scheduleId and a future deadline.
SCHEDULE - Enum constant in enum class io.fluxcapacitor.common.MessageType
A scheduled message to be delivered at a specific time.
Schedule.Metric - Class in io.fluxcapacitor.common.api.scheduling
Lightweight metric representation of this Schedule command, used for monitoring purposes.
scheduleCommand(Schedule) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedule a command using the given scheduling settings, using the Guarantee.SENT guarantee.
scheduleCommand(Schedule) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command message using the given scheduling settings, using the Guarantee.SENT guarantee.
scheduleCommand(Schedule, boolean) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedule a command using the given scheduling settings if no other with same ID exists, using the Guarantee.SENT guarantee.
scheduleCommand(Schedule, boolean) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command using the given scheduling settings if no other with same ID exists, using the Guarantee.SENT guarantee.
scheduleCommand(Schedule, boolean, Guarantee) - Method in class io.fluxcapacitor.javaclient.scheduling.DefaultMessageScheduler
 
scheduleCommand(Schedule, boolean, Guarantee) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command using the given scheduling settings, using the provided Guarantee.
scheduleCommand(Object, Metadata, String, Duration) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command with metadata and delay, using the Guarantee.SENT guarantee.
scheduleCommand(Object, Metadata, String, Instant) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command message with attached metadata, using the Guarantee.SENT guarantee.
scheduleCommand(Object, String, Duration) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a command with given scheduleId after given delay.
scheduleCommand(Object, String, Duration) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command with the given ID and delay, using the Guarantee.SENT guarantee.
scheduleCommand(Object, String, Instant) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a command with given scheduleId for the given timestamp.
scheduleCommand(Object, String, Instant) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command using a specific deadline, using the Guarantee.SENT guarantee.
scheduleCommand(Object, Duration) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a command after given delay, returning the command schedule's id.
scheduleCommand(Object, Duration) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command to execute after given delay, using the Guarantee.SENT guarantee.
scheduleCommand(Object, Instant) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Schedules a command for the given timestamp, returning the command schedule's id.
scheduleCommand(Object, Instant) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a command message for future execution.
ScheduledCommand - Class in io.fluxcapacitor.javaclient.scheduling
Wrapper for a serialized command message scheduled for deferred execution.
ScheduledCommand() - Constructor for class io.fluxcapacitor.javaclient.scheduling.ScheduledCommand
 
ScheduledCommandHandler - Class in io.fluxcapacitor.javaclient.scheduling
Internal handler responsible for executing scheduled commands when they are due.
ScheduledCommandHandler() - Constructor for class io.fluxcapacitor.javaclient.scheduling.ScheduledCommandHandler
 
scheduleId() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Returns the id of the periodic schedule.
Schedule identity - Search tag in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Section
scheduleIdMetadataKey - Static variable in class io.fluxcapacitor.javaclient.scheduling.Schedule
Metadata key for the schedule identifier.
schedulePeriodic(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Starts a new periodic schedule, returning the schedule's id.
schedulePeriodic(Object) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a periodic message using the @Periodic annotation on its class, using the Guarantee.SENT guarantee.
schedulePeriodic(Object, String) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Starts a new periodic schedule using given schedule id.
schedulePeriodic(Object, String) - Method in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Schedule a periodic message using the given ID and the @Periodic annotation, using the Guarantee.SENT guarantee.
schedulePing(Session) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
scheduler(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
 
SchedulerException - Exception Class in io.fluxcapacitor.javaclient.scheduling
Exception thrown by a MessageScheduler when scheduling a message fails.
SchedulerException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.scheduling.SchedulerException
 
SchedulingClient - Interface in io.fluxcapacitor.javaclient.scheduling.client
A lower-level client interface for scheduling and cancelling deferred messages (i.e., schedules) in Flux Capacitor.
SchedulingEndpoint - Class in io.fluxcapacitor.testserver.websocket
 
SchedulingEndpoint() - Constructor for class io.fluxcapacitor.testserver.websocket.SchedulingEndpoint
 
schedulingInterceptor() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Interceptor applied to scheduled messages, such as time-based commands or events.
SchedulingInterceptor - Class in io.fluxcapacitor.javaclient.scheduling
Intercepts scheduled messages to handle periodic scheduling logic.
SchedulingInterceptor() - Constructor for class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
schedulingPath() - Static method in class io.fluxcapacitor.common.ServicePathBuilder
Returns the service path for the scheduling subsystem.
Scheduling semantics - Search tag in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Section
schedulingUrl(WebSocketClient.ClientConfig) - Static method in class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
Constructs the URL for accessing the time-based message scheduling service.
search(SearchDocuments, int) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
search(SearchDocuments, int) - Method in interface io.fluxcapacitor.javaclient.persisting.search.client.SearchClient
Executes a streaming search query using the given criteria and fetch size.
search(SearchDocuments, int) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
search(SearchQuery.Builder) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Search documents using given reusable query builder.
search(SearchQuery.Builder) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
search(SearchQuery.Builder) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Prepares a search query based on the specified SearchQuery.Builder.
search(Object) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentStore
Prepares a search query for one or more document collections.
search(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Search the given collection for documents.
search(Object, Object...) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Search the given collections for documents.
Search - Interface in io.fluxcapacitor.javaclient.persisting.search
Fluent interface for building and executing document search queries in Flux Capacitor.
searchable() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Whether the aggregate should be indexed in Flux’s document store (disabled by default).
searchable() - Element in annotation interface io.fluxcapacitor.javaclient.persisting.search.Searchable
Whether the annotated type should be included in search indexing.
Searchable - Annotation Interface in io.fluxcapacitor.javaclient.persisting.search
Indicates that instances of the annotated type should be indexed for search within Flux Capacitor.
Searchable value classes can be published using: - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.search.Searchable
Section
SearchClient - Interface in io.fluxcapacitor.javaclient.persisting.search.client
Low-level interface for interacting with a search and indexing service in Flux.
SearchDocuments - Class in io.fluxcapacitor.common.api.search
Request used to perform a search over documents indexed in the Flux search store.
SearchDocuments() - Constructor for class io.fluxcapacitor.common.api.search.SearchDocuments
 
SearchDocumentsResult - Class in io.fluxcapacitor.common.api.search
The result of a SearchDocuments request.
SearchDocumentsResult() - Constructor for class io.fluxcapacitor.common.api.search.SearchDocumentsResult
 
SearchDocumentsResult.Metric - Class in io.fluxcapacitor.common.api.search
Lightweight metric representation used for logging search result metadata.
SearchEndpoint - Class in io.fluxcapacitor.testserver.websocket
 
SearchEndpoint() - Constructor for class io.fluxcapacitor.testserver.websocket.SearchEndpoint
 
SearchExclude - Annotation Interface in io.fluxcapacitor.common.search
Marker annotation that indicates that a property is to be ignored when indexing a document for search.
SearchHistogram - Class in io.fluxcapacitor.common.api.search
Represents a histogram over a time range, typically returned by GetSearchHistogramResult.
SearchHistogram() - Constructor for class io.fluxcapacitor.common.api.search.SearchHistogram
 
SearchHit<T> - Class in io.fluxcapacitor.javaclient.persisting.search
Represents a single result returned by a Search query.
SearchHit() - Constructor for class io.fluxcapacitor.javaclient.persisting.search.SearchHit
 
searchIgnoreCache - Static variable in class io.fluxcapacitor.common.search.JacksonInverter
 
SearchInclude - Annotation Interface in io.fluxcapacitor.common.search
Marker annotation that indicates that a property is to be included when indexing a document for search.
Search Indexing - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Section
SearchParameters - Class in io.fluxcapacitor.javaclient.modeling
Represents configuration options extracted from the @Searchable annotation on a domain type.
SearchParameters() - Constructor for class io.fluxcapacitor.javaclient.modeling.SearchParameters
 
searchPath() - Static method in class io.fluxcapacitor.common.ServicePathBuilder
Returns the service path for the search/document store subsystem.
SearchQuery - Class in io.fluxcapacitor.common.api.search
A query for filtering documents in one or more search collections.
SearchQuery(List<String>, Instant, Instant, boolean, boolean, List<Constraint>) - Constructor for class io.fluxcapacitor.common.api.search.SearchQuery
 
SearchQuery.Builder - Class in io.fluxcapacitor.common.api.search
Builder class for constructing instances of SearchQuery.
Search-Specific Filtering - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.DefaultHandlerFactory
Section
searchUrl(WebSocketClient.ClientConfig) - Static method in class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
Constructs the URL for accessing the document and handler state search service.
SearchUtils - Class in io.fluxcapacitor.common
Utility class for search-related functionality such as term normalization, path transformation, glob pattern matching, and primitive value extraction.
SearchUtils() - Constructor for class io.fluxcapacitor.common.SearchUtils
 
second - Variable in class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
SegmentFilter - Class in io.fluxcapacitor.javaclient.tracking.handling
A MessageFilter that restricts handler invocation based on segment membership, using routing keys.
SegmentFilter() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.SegmentFilter
 
Segment Reassignment - Search tag in class io.fluxcapacitor.common.api.tracking.DisconnectTracker
Section
SelectiveCache - Class in io.fluxcapacitor.javaclient.persisting.caching
A Cache implementation that partitions values across two internal caches based on a provided Predicate.
SelectiveCache(Cache, Predicate<Object>) - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
Constructs a SelectiveCache with a default in-memory delegate cache.
Self-Handlers - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
Section
Semantics - Search tag in exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Section
send() - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient.WebSocketRequest
 
send(byte[]) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(Request) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
send(MessageBatch) - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
send(MessageBatch) - Method in interface io.fluxcapacitor.common.tracking.Tracker
Sends a batch of messages to this tracker.
send(MessageBatch) - Method in class io.fluxcapacitor.common.tracking.WebSocketTracker
 
send(Message) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a Message and returns a future that completes with its response payload.
send(Request<R>) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a typed request command and returns a future for the result.
send(Request<R>) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a Request message and returns a future with its typed response.
send(Request<R>) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends a typed Request query and returns a future representing the result.
send(Request<R>, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a typed request command with metadata and returns a future for the result.
send(Request<R>, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a Request with metadata and returns a future with its response.
send(Request<R>, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends a typed Request query with additional metadata and returns a future with the result.
send(WebRequest) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultWebRequestGateway
 
send(WebRequest) - Method in interface io.fluxcapacitor.javaclient.publishing.WebRequestGateway
Sends the given web request and returns a future that completes with the response.
send(DataBuffer) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(StatusCode) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(InputStream) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a command and returns a future for the result.
send(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message (raw object or Request) and returns a future with its response.
send(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends the given query asynchronously and returns a future representing the result.
send(Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends multiple commands and returns futures for their results.
send(Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends multiple messages and returns a list of futures with their payload responses.
send(Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends multiple queries asynchronously and returns a list of futures, one for each result.
send(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a command with metadata and returns a future for the result.
send(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message with custom metadata and returns a future with its response.
send(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends the given query along with metadata asynchronously and returns a future representing the result.
send(String, Charset) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(ByteBuffer) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(ByteBuffer[]) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(FileChannel) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
send(ReadableByteChannel) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
sendAndForget(Guarantee, Message...) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultGenericGateway
 
sendAndForget(Guarantee, Message...) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends multiple Message objects with a guarantee.
sendAndForget(Guarantee, WebRequest...) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultWebRequestGateway
 
sendAndForget(Guarantee, WebRequest...) - Method in interface io.fluxcapacitor.javaclient.publishing.WebRequestGateway
Sends one or more web requests without waiting for a response.
sendAndForget(Guarantee, Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends multiple commands with a delivery guarantee without waiting for results.
sendAndForget(Guarantee, Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends multiple messages asynchronously with a specified delivery guarantee.
sendAndForget(Message, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a Message asynchronously with a given guarantee.
sendAndForget(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a command without waiting for a result.
sendAndForget(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message asynchronously without waiting for a result or acknowledgement.
sendAndForget(Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends multiple commands without waiting for results.
sendAndForget(Object...) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends multiple messages asynchronously with Guarantee.NONE.
sendAndForget(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a command with metadata without waiting for a result.
sendAndForget(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message with custom payload and metadata asynchronously.
sendAndForget(Object, Metadata, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a command with metadata and delivery guarantee, without waiting for a result.
sendAndForget(Object, Metadata, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message with payload, metadata, and delivery guarantee asynchronously.
sendAndForgetCommand(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given command and doesn't wait for a result.
sendAndForgetCommand(Object, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a command with given payload and metadata and don't wait for a result.
sendAndForgetCommand(Object, Metadata, Guarantee) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a command with given payload and metadata and don't wait for a result.
sendAndForgetCommands(Object...) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given commands and doesn't wait for results.
sendAndWait(Request) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
sendAndWait(Message) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message and blocks for a result with a configurable timeout.
sendAndWait(Request<R>) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a typed request command and waits for the result.
sendAndWait(Request<R>) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a Request and blocks until a response is received.
sendAndWait(Request<R>) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends a typed Request query and waits for the result.
sendAndWait(Request<R>, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a typed request command with metadata and waits for the result.
sendAndWait(Request<R>, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a Request with metadata and blocks for a response.
sendAndWait(Request<R>, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends a typed Request query with metadata and waits for the result.
sendAndWait(WebRequest) - Method in interface io.fluxcapacitor.javaclient.publishing.WebRequestGateway
Sends the given web request and waits for the response synchronously using default request settings.
sendAndWait(WebRequest, WebRequestSettings) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultWebRequestGateway
 
sendAndWait(WebRequest, WebRequestSettings) - Method in interface io.fluxcapacitor.javaclient.publishing.WebRequestGateway
Sends the given web request and waits for the response synchronously using the specified request settings.
sendAndWait(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a command and waits for the result.
sendAndWait(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message and blocks until a response is received.
sendAndWait(Object) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends the given query and waits for the result, blocking the current thread.
sendAndWait(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a command with metadata and waits for the result.
sendAndWait(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a message with metadata and blocks for a response.
sendAndWait(Object, Metadata) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends the given query and metadata, then waits for the result.
sendCommand(Command) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
sendCommand(Request<R>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given command and returns a future that will be completed with the command's result.
sendCommand(Request<R>, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a command with given payload and metadata and returns a future that will be completed with the command's result.
sendCommand(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given command and returns a future that will be completed with the command's result.
sendCommand(Object, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a command with given payload and metadata and returns a future that will be completed with the command's result.
sendCommandAndWait(Request<R>) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given command and returns the command's result.
sendCommandAndWait(Request<R>, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a command with given payload and metadata and returns a future that will be completed with the command's result.
sendCommandAndWait(Object) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given command and returns the command's result.
sendCommandAndWait(Object, Metadata) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends a command with given payload and metadata and returns a future that will be completed with the command's result.
sendCommands(Object...) - Static method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Sends the given commands and returns a list of futures that will be completed with the commands' results.
sendEmptyBatch(MessageBatch) - Method in interface io.fluxcapacitor.common.tracking.Tracker
Sends an empty batch (typically used to signal idle or shutdown).
sendForMessage(Message) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends a fully-formed Message and returns a future for the result Message.
sendForMessage(Message) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends a single Message and returns a future that resolves to the complete Message response.
sendForMessage(Message) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends the given Message and returns a future representing the resulting message.
sendForMessages(Message...) - Method in interface io.fluxcapacitor.javaclient.publishing.CommandGateway
Sends multiple messages and returns futures for the result messages.
sendForMessages(Message...) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultGenericGateway
 
sendForMessages(Message...) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Sends multiple messages and returns futures for their full Message responses.
sendForMessages(Message...) - Method in interface io.fluxcapacitor.javaclient.publishing.QueryGateway
Sends multiple query Messages and returns a list of futures for the raw responses.
sendGatewayTimeout(HttpServerExchange) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
sendMessage(Object) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Sends a message over the WebSocket session with the specified value, using the Guarantee.NONE policy.
sendMessage(Object, Guarantee) - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
sendMessage(Object, Guarantee) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Sends a message over the WebSocket session with the specified delivery guarantee.
sendPing(Session) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
sendPing(Object) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Sends a WebSocket ping message with the given value.
sendPing(Object, Guarantee) - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
sendPing(Object, Guarantee) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Sends a ping message with the specified value to the WebSocket session.
sendPing(Duration, TaskScheduler) - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
sendRequest(SerializedMessage, Consumer<SerializedMessage>) - Method in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
Sends a single request and returns a future that completes when the corresponding response is received.
sendRequest(SerializedMessage, Consumer<SerializedMessage>, Duration) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
Sends a request and processes the response, combining intermediate responses (if any) with the final response data.
sendRequest(SerializedMessage, Consumer<SerializedMessage>, Duration) - Method in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
Sends a single request with a custom timeout and returns a future for the corresponding response.
sendRequest(SerializedMessage, Consumer<SerializedMessage>, Duration, Consumer<SerializedMessage>) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
 
sendRequest(SerializedMessage, Consumer<SerializedMessage>, Duration, Consumer<SerializedMessage>) - Method in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
 
sendRequest(SerializedMessage, Consumer<SerializedMessage>, Consumer<SerializedMessage>) - Method in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
 
sendRequest(Request<R>) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Sends a request and returns a CompletionStage representing the pending result.
sendRequest(Request<R>, Duration) - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
sendRequest(Request<R>, Duration) - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Sends a request over the WebSocket session with a specified timeout duration.
sendRequest(Session, String, byte[]) - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
sendRequests(List<SerializedMessage>, Consumer<List<SerializedMessage>>) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
 
sendRequests(List<SerializedMessage>, Consumer<List<SerializedMessage>>) - Method in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
Sends multiple requests and returns a list of futures for their corresponding responses.
sendRequests(List<SerializedMessage>, Consumer<List<SerializedMessage>>, Duration) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler
 
sendRequests(List<SerializedMessage>, Consumer<List<SerializedMessage>>, Duration) - Method in interface io.fluxcapacitor.javaclient.publishing.RequestHandler
Sends multiple requests with a custom timeout and returns a list of futures for their responses.
sendResponse(SerializedMessage, HttpServerExchange) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
sendResponse(WebResponse, SerializedMessage) - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
sendResponse(WebResponse, Function<SerializedMessage, CompletableFuture<Void>>) - Method in class io.fluxcapacitor.javaclient.web.WebResponseGateway
 
sendResultBatch(Session, List<RequestResult>) - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
sendServerError(HttpServerExchange) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
sendWebRequest(HttpServerExchange, WebRequest) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
SENT - Enum constant in enum class io.fluxcapacitor.common.Guarantee
Guarantees that the message or action was sent successfully.
sequenceNumber() - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
sequenceNumber() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
sequenceNumber() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the sequence number of the current entity.
sequenceNumber() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
sequential() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
Serialization - Search tag in interface io.fluxcapacitor.common.api.JsonType
Section
Serialization - Search tag in interface io.fluxcapacitor.common.api.search.Constraint
Section
SerializationException - Exception Class in io.fluxcapacitor.javaclient.common.serialization
Thrown to indicate that a problem occurred during the serialization of an object.
SerializationException(String) - Constructor for exception class io.fluxcapacitor.javaclient.common.serialization.SerializationException
 
SerializationException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.common.serialization.SerializationException
 
Serialization Format - Search tag in enum class io.fluxcapacitor.common.search.DefaultDocumentSerializer
Section
serialize() - Method in enum class io.fluxcapacitor.common.search.Document.EntryType
Serializes this entry type to a single byte.
serialize(Document) - Method in enum class io.fluxcapacitor.common.search.DefaultDocumentSerializer
Serializes the given Document into a compressed binary Data container.
serialize(Serializer) - Method in class io.fluxcapacitor.javaclient.common.Message
Serializes this message to a SerializedMessage using the provided Serializer.
serialize(Serializer) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
Serializes the request using the content type if applicable.
serialize(Serializer) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Serializes the response using the content type if applicable.
serialize(Object) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Serializes the given object to a Data wrapper using the default format.
serialize(Object, JsonGenerator, SerializerProvider) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter.FilteringSerializer
 
serialize(Object, String) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Serializes the given object into a byte-based Data object, using the specified format.
serialize(Object, String) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Serializes the given object into a Data wrapper using the specified format.
serialize(Object, String) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
serializeAction(BulkUpdate) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore
 
serializeAndThen(Object, JsonGenerator, ThrowingConsumer<Object>) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter.FilteringSerializer
Invokes the content filter if available and serializes the filtered result.
SerializedDocument - Class in io.fluxcapacitor.common.api.search
Represents a serialized form of a search document stored in a Flux Capacitor collection.
SerializedDocument(Document) - Constructor for class io.fluxcapacitor.common.api.search.SerializedDocument
Constructs a SerializedDocument from a deserialized Document representation.
SerializedDocument(String, Long, Long, String, Data<byte[]>, String, Set<FacetEntry>, Set<SortableEntry>) - Constructor for class io.fluxcapacitor.common.api.search.SerializedDocument
Constructs a new instance of the SerializedDocument class with the specified parameters.
SerializedMessage - Class in io.fluxcapacitor.common.api
Represents a fully serialized message for transmission or storage within the Flux platform.
SerializedMessage(Data<byte[]>, Metadata, String, Long) - Constructor for class io.fluxcapacitor.common.api.SerializedMessage
 
SerializedObject<T> - Interface in io.fluxcapacitor.common.api
 
SerializedSchedule - Class in io.fluxcapacitor.common.api.scheduling
Represents a scheduled message to be delivered at a specific SerializedSchedule.timestamp.
SerializedSchedule() - Constructor for class io.fluxcapacitor.common.api.scheduling.SerializedSchedule
 
SerializedSchedule.Metric - Class in io.fluxcapacitor.common.api.scheduling
Metric representation of the SerializedSchedule for tracking/monitoring.
serializer - Static variable in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
serializer() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Returns the primary serializer for serializing and deserializing message payloads.
serializer() - Method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Optionally provides a default Serializer implementation based on Jackson, automatically detecting and registering upcasters and downcasters from Spring-managed beans.
serializer() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the default serializer
Serializer - Interface in io.fluxcapacitor.javaclient.common.serialization
Mechanism to serialize and deserialize objects to and from byte[] representations.
serializeToOtherFormat(Object, String) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Converts common simple object types (e.g., String, byte[]) to the requested alternative format.
serializeWithType(Object, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonContentFilter.FilteringSerializer
 
ServeStatic - Annotation Interface in io.fluxcapacitor.javaclient.web
Declares a static file handler that serves files from a resource or file system location at the specified web path(s).
serveStaticFile(String, WebRequest) - Method in class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
ServiceException - Exception Class in io.fluxcapacitor.javaclient.common.exception
Exception thrown when a Request fails and an ErrorResult is returned by the Flux platform.
ServiceException(String) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.ServiceException
Constructs a new exception with the specified error message.
ServicePathBuilder - Class in io.fluxcapacitor.common
Utility class for constructing internal service endpoint paths used to route messages to the Flux platform.
ServicePathBuilder() - Constructor for class io.fluxcapacitor.common.ServicePathBuilder
 
ServiceUrlBuilder - Class in io.fluxcapacitor.javaclient.common.websocket
Utility class for constructing fully qualified service endpoint URLs for various Flux Platform features based on the client's configuration.
ServiceUrlBuilder() - Constructor for class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
 
SessionBacklog() - Constructor for class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint.SessionBacklog
 
SessionContext(Metadata, String, String) - Constructor for record class io.fluxcapacitor.proxy.WebsocketEndpoint.SessionContext
Creates an instance of a SessionContext record class.
sessionId() - Method in interface io.fluxcapacitor.javaclient.web.SocketSession
Retrieves the unique identifier for the current WebSocket session.
sessionIdKey - Static variable in class io.fluxcapacitor.javaclient.web.WebRequest
 
SessionPool - Class in io.fluxcapacitor.javaclient.common.websocket
A thread-safe pool of reusable WebSocket Session objects, supporting concurrent access and routing.
SessionPool(int, Supplier<Session>) - Constructor for class io.fluxcapacitor.javaclient.common.websocket.SessionPool
 
setClock(Clock) - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
setDefaultResponseType(MediaType) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setDelegate(Clock) - Method in class io.fluxcapacitor.common.DelegatingClock
 
setEnvironment(Environment) - Method in class io.fluxcapacitor.javaclient.configuration.spring.TrackSelfPostProcessor
Sets the Spring Environment used for context-aware scanning.
setField(Field, Object, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
setField(String, Object, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
setHost(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setMethod(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setPort(int) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setRemoteAddress(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setRequestPath(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setResetHeadersOnError(boolean) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setResponseCode(int) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setResponseCookie(Cookie) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setResponseHeader(String, String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setResponseLength(long) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setResponseType(MediaType, Charset) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setResponseType(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setRetentionTime(Duration) - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Sets the retention period for messages.
setRetentionTime(Duration) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.CollectionMessageStore
 
setRetentionTime(Duration) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Set a new retention duration for the underlying gateway's message log.
setRetentionTime(Duration, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.client.GatewayClient
Set a new retention duration for the underlying gateway's message log.
setRetentionTime(Duration, Guarantee) - Method in class io.fluxcapacitor.javaclient.publishing.client.WebsocketGatewayClient
 
setRetentionTime(Duration, Guarantee) - Method in class io.fluxcapacitor.javaclient.publishing.DefaultGenericGateway
 
setRetentionTime(Duration, Guarantee) - Method in interface io.fluxcapacitor.javaclient.publishing.GenericGateway
Set a new retention duration for the underlying gateway's message log.
setRetentionTime(Duration, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
SetRetentionTime - Class in io.fluxcapacitor.common.api.publishing
Command to set or update the retention period for a message log in the Flux platform.
SetRetentionTime() - Constructor for class io.fluxcapacitor.common.api.publishing.SetRetentionTime
 
setScheme(String) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
setSelfHandlerFilter(HandlerFilter) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.MergedHandlerRegistry
 
setSelfHandlerFilter(HandlerFilter) - Method in enum class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.NoOpHandlerRegistry
 
setSelfHandlerFilter(HandlerFilter) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HasLocalHandlers
Sets a custom filter to control whether a handler method is considered a local handler for the current application.
setupModule(Module.SetupContext) - Method in class io.fluxcapacitor.common.serialization.NullCollectionsAsEmptyModule
 
setupModule(Module.SetupContext) - Method in class io.fluxcapacitor.common.serialization.StripStringsModule
 
shouldCompress(SerializedMessage) - Method in class io.fluxcapacitor.javaclient.web.WebResponseCompressingInterceptor
Determines whether the given serialized message should be compressed based on specific criteria.
shouldCreateSnapshot(Entity<?>, List<AppliedEvent>) - Method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoSnapshotTrigger
Always returns false, indicating that a snapshot should never be created.
shouldCreateSnapshot(Entity<?>, List<AppliedEvent>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.PeriodicSnapshotTrigger
Determines whether a new snapshot should be created.
shouldCreateSnapshot(Entity<?>, List<AppliedEvent>) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.SnapshotTrigger
Determines whether a snapshot should be created for the given aggregate state and recent events.
shouldSendResponse(HandlerInvoker, DeserializingMessage, Object, ConsumerConfiguration) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
shutdown() - Method in class io.fluxcapacitor.common.DirectExecutorService
 
shutdown() - Method in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
shutdown() - Method in interface io.fluxcapacitor.common.TaskScheduler
Shuts down the scheduler and stops execution of any pending or future tasks.
shutdown(Tracker) - Method in interface io.fluxcapacitor.javaclient.tracking.BatchInterceptor
Optional lifecycle callback for cleanup when the tracker shuts down.
shutDown - Variable in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
shutDown() - Method in class io.fluxcapacitor.common.Backlog
Shuts down the internal executor service cleanly.
shutDown() - Method in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
 
shutDown() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Shuts down this client instance, releasing any underlying resources.
shutDown() - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
shutDown() - Method in class io.fluxcapacitor.proxy.WebsocketEndpoint
 
shutDown() - Method in class io.fluxcapacitor.testserver.websocket.ConsumerEndpoint
 
shutDown() - Method in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
Close all sessions on the websocket after an optional delay.
shutdownNow() - Method in class io.fluxcapacitor.common.DirectExecutorService
 
shutdownTasks - Variable in class io.fluxcapacitor.javaclient.configuration.client.AbstractClient
Tracks shutdown callbacks that will be run when AbstractClient.shutDown() is invoked.
shuttingDown - Variable in class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
SideEffectFreeEntity<T> - Class in io.fluxcapacitor.javaclient.modeling
A functional, non-persistent Entity wrapper that enables safe state mutation and validation without producing side effects such as event publication or snapshot creation.
SideEffectFreeEntity(Entity<T>) - Constructor for class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
signature(Executable) - Static method in class io.fluxcapacitor.common.reflection.ParameterRegistry
Generates a string representation of a method signature using a runtime reflection Executable.
signature(ExecutableElement) - Static method in class io.fluxcapacitor.common.reflection.ParameterRegistry
Generates a string representation of a method signature using compile-time elements.
SilentErrorHandler - Class in io.fluxcapacitor.javaclient.tracking
An ErrorHandler implementation that suppresses all processing errors and allows message tracking to continue.
SilentErrorHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.SilentErrorHandler
Constructs a SilentErrorHandler that does not log any errors.
SimpleInvoker() - Constructor for class io.fluxcapacitor.common.handling.HandlerInvoker.SimpleInvoker
 
SimplePropertySource - Class in io.fluxcapacitor.common.application
A simple in-memory implementation of the PropertySource interface backed by a Map.
SimplePropertySource() - Constructor for class io.fluxcapacitor.common.application.SimplePropertySource
 
SimpleTracker - Class in io.fluxcapacitor.common.tracking
 
SimpleTracker(String, int, Consumer<MessageBatch>) - Constructor for class io.fluxcapacitor.common.tracking.SimpleTracker
 
since(Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters documents with timestamps since the given start time (inclusive).
since(Instant, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
since(Instant, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Filters documents with timestamps since the given start time.
singleTracker() - Method in interface io.fluxcapacitor.common.tracking.Tracker
 
singleTracker() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
If true, designates a single tracker within this consumer as the "main" tracker, responsible for processing all messages across all segments.
singleValuedHeaders(Map<String, String>) - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
size - Enum constant in enum class io.fluxcapacitor.javaclient.persisting.caching.CacheEviction.Reason
The eviction occurred due to exceeding the configured cache size.
size() - Method in class io.fluxcapacitor.common.api.search.SearchDocumentsResult
Returns the number of matched documents.
size() - Method in interface io.fluxcapacitor.javaclient.persisting.caching.Cache
Returns the number of entries currently stored in the cache.
size() - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
size() - Method in class io.fluxcapacitor.javaclient.persisting.caching.NamedCache
 
size() - Method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
 
size() - Method in class io.fluxcapacitor.javaclient.persisting.caching.SelectiveCache
 
skip(long) - Method in class io.fluxcapacitor.common.LazyInputStream
 
skip(long) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
skip(Integer) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
skip(Integer) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Skips the first N results.
slowTrackingThreshold - Static variable in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
snapshotKey(Object) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultSnapshotStore
 
snapshotPeriod() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Enables snapshotting after a certain number of applied updates.
snapshotSerializer() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Returns the serializer used for serializing and deserializing snapshots of stateful entities.
snapshotStore() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the store for aggregate snapshots.
SnapshotStore - Interface in io.fluxcapacitor.javaclient.persisting.eventsourcing
Interface for managing snapshots of aggregates in an event-sourced system.
SnapshotTrigger - Interface in io.fluxcapacitor.javaclient.persisting.eventsourcing
Functional interface used to determine whether a new snapshot should be created for an aggregate.
SocketEndpoint - Annotation Interface in io.fluxcapacitor.javaclient.web
Declares a WebSocket endpoint that represents a single active client session.
SocketEndpoint.AliveCheck - Annotation Interface in io.fluxcapacitor.javaclient.web
Controls periodic keep-alive pings to detect inactive sessions.
SocketEndpointHandler - Class in io.fluxcapacitor.javaclient.web
A specialized Handler that manages lifecycle events and message dispatching for WebSocket endpoints annotated with SocketEndpoint.
SocketEndpointHandler(Class<?>, HandlerMatcher<Object, DeserializingMessage>, HandlerMatcher<Object, DeserializingMessage>, RepositoryProvider) - Constructor for class io.fluxcapacitor.javaclient.web.SocketEndpointHandler
 
SocketEndpointHandler.SocketEndpointWrapper - Class in io.fluxcapacitor.javaclient.web
A stateful wrapper around a WebSocket endpoint instance, managing per-session behavior and message handling.
socketEndpointPostProcessor() - Static method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Registers the SocketEndpointPostProcessor, used for handlers that manage WebSocket communication.
SocketEndpointPostProcessor - Class in io.fluxcapacitor.javaclient.configuration.spring
Spring BeanDefinitionRegistryPostProcessor that detects beans annotated with SocketEndpoint and registers them as FluxPrototype definitions for use in Flux Capacitor.
SocketEndpointPostProcessor() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.SocketEndpointPostProcessor
 
SocketEndpointWrapper() - Constructor for class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
SocketRequest - Class in io.fluxcapacitor.javaclient.web
A wrapper representing a serialized request sent over a WebSocket session.
SocketRequest() - Constructor for class io.fluxcapacitor.javaclient.web.SocketRequest
 
SocketResponse - Class in io.fluxcapacitor.javaclient.web
Represents a response to a SocketRequest sent over a WebSocket session.
SocketResponse() - Constructor for class io.fluxcapacitor.javaclient.web.SocketResponse
 
SocketSession - Interface in io.fluxcapacitor.javaclient.web
Represents a WebSocket session that allows sending messages, requests, pings, and handling session lifecycle actions.
SoftCacheReference(Object, Object) - Constructor for class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache.SoftCacheReference
 
Sortable - Annotation Interface in io.fluxcapacitor.common.search
Marker annotation on fields and getters that indicates that a property is to be used for sorting and filtering.
SortableEntry - Class in io.fluxcapacitor.common.api.search
Represents a sortable entry in a Document for use in search operations.
SortableEntry(String, Object) - Constructor for class io.fluxcapacitor.common.api.search.SortableEntry
Constructs a new SortableEntry by formatting the given object into a normalized, sortable string.
sortBy(String) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Sorts results by a specific document field.
sortBy(String, boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
sortBy(String, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Sorts results by a field, with control over the sort direction.
sortByScore() - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
sortByScore() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Sorts results by full-text relevance score.
sortByTimestamp() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Sorts results by timestamp in ascending order.
sortByTimestamp(boolean) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
sortByTimestamp(boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Sorts results by timestamp.
sorted() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
sorted(Comparator<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
split(String) - Static method in class io.fluxcapacitor.common.search.Document.Path
Splits a path string into individual elements (unescaped), using / as the delimiter.
spliterator() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
splitInSegments() - Method in class io.fluxcapacitor.common.api.tracking.Position
Splits the position map into contiguous segment ranges that share the same index.
splitInTerms(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Extracts quoted phrases and standalone terms from a free-form query string.
SpringBeanParameterResolver - Class in io.fluxcapacitor.javaclient.configuration.spring
Resolves handler method parameters annotated with Autowired from the Spring application context.
SpringBeanParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.SpringBeanParameterResolver
 
SpringHandlerRegistry - Interface in io.fluxcapacitor.javaclient.configuration.spring
A registry interface for registering Spring-based handler components with e.g.: a TestFixture.
SpringPropertySource - Class in io.fluxcapacitor.javaclient.configuration.spring
A PropertySource implementation that delegates property lookups to a Spring Environment.
SpringPropertySource() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.SpringPropertySource
 
stall() - Method in class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
 
StallingBatchInterceptor - Class in io.fluxcapacitor.javaclient.tracking
A BatchInterceptor that stalls batch processing until a minimum desired batch size is reached or a timeout occurs.
StallingBatchInterceptor() - Constructor for class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
 
Standard Metadata Keys - Search tag in interface io.fluxcapacitor.javaclient.publishing.correlation.CorrelationDataProvider
Section
start() - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Returns the configured start timestamp for this operation.
start() - Method in record class io.fluxcapacitor.javaclient.web.StaticFileHandler.ByteRange
Returns the value of the start record component.
start() - Method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
start(int) - Static method in class io.fluxcapacitor.testserver.TestServer
 
start(int, ProxyRequestHandler) - Static method in class io.fluxcapacitor.proxy.ProxyServer
 
start(Client) - Static method in class io.fluxcapacitor.proxy.ForwardProxyConsumer
 
start(FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
start(FluxCapacitor, Object...) - Method in interface io.fluxcapacitor.javaclient.tracking.Tracking
Starts the tracking process using the specified FluxCapacitor instance and the provided handlers.
start(FluxCapacitor, List<?>) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
Starts tracking by assigning the given handlers to configured consumers and creating topic-specific or shared trackers.
start(FluxCapacitor, List<?>) - Method in interface io.fluxcapacitor.javaclient.tracking.Tracking
Starts tracking messages using the provided FluxCapacitor and a list of handlers.
start(Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Sets the start time (timestamp) for the document.
start(Consumer<List<SerializedMessage>>, MessageType, ConsumerConfiguration, Client) - Static method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
Starts one or more trackers.
start(Consumer<List<SerializedMessage>>, MessageType, ConsumerConfiguration, FluxCapacitor) - Static method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
Starts one or more trackers.
start(Consumer<List<SerializedMessage>>, MessageType, String, ConsumerConfiguration, Client) - Static method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
Starts one or more trackers.
start(Consumer<List<SerializedMessage>>, MessageType, String, ConsumerConfiguration, FluxCapacitor) - Static method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
Starts one or more trackers.
start(Consumer<List<SerializedMessage>>, ConsumerConfiguration, TrackingClient) - Static method in class io.fluxcapacitor.javaclient.tracking.client.DefaultTracker
Starts one or more trackers that consume messages using the provided trackingClient and process them using the provided consumer.
startTrackerIfNeeded() - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
startTracking(ConsumerConfiguration, List<Handler<DeserializingMessage>>, FluxCapacitor) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
Stateful - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Declares that a class is a stateful message handler — i.e., one whose state is persisted and which can receive messages via Association.
StatefulHandler - Class in io.fluxcapacitor.javaclient.tracking.handling
A Handler implementation for classes annotated with Stateful, responsible for resolving and invoking stateful handler instances based on Association metadata.
StatefulHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
 
StatefulHandler.AssociationValue - Class in io.fluxcapacitor.javaclient.tracking.handling
 
StatefulHandler.StatefulHandlerInvoker - Class in io.fluxcapacitor.javaclient.tracking.handling
 
StatefulHandlerInvoker(HandlerInvoker, Entry<?>, DeserializingMessage) - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler.StatefulHandlerInvoker
 
statefulPostProcessor() - Static method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Registers the StatefulPostProcessor, enabling lifecycle and stateful behavior for beans.
StatefulPostProcessor - Class in io.fluxcapacitor.javaclient.configuration.spring
Spring BeanDefinitionRegistryPostProcessor that automatically detects beans annotated with Stateful and registers them as FluxPrototype definitions for use in Flux Capacitor.
StatefulPostProcessor() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.StatefulPostProcessor
 
StaticFileHandler - Class in io.fluxcapacitor.javaclient.web
 
StaticFileHandler() - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
StaticFileHandler(String, Path, URI, String, Set<String>, long) - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
StaticFileHandler(String) - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
StaticFileHandler(String, String) - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
StaticFileHandler(String, String, String) - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
StaticFileHandler(String, String, String, Set<String>) - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
StaticFileHandler(String, String, String, Set<String>, long) - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler
 
StaticFileHandler_params - Class in io.fluxcapacitor.javaclient.web
 
StaticFileHandler_params() - Constructor for class io.fluxcapacitor.javaclient.web.StaticFileHandler_params
 
StaticFileHandler.ByteRange - Record Class in io.fluxcapacitor.javaclient.web
 
StaticFileHandler.Compression - Enum Class in io.fluxcapacitor.javaclient.web
 
status() - Method in class io.fluxcapacitor.javaclient.web.WebResponse.Builder
 
statusKey - Static variable in class io.fluxcapacitor.javaclient.web.WebResponse
 
Stopping a Periodic Schedule - Search tag in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Section
stopTracker(DeserializingMessage, Handler<DeserializingMessage>, Throwable) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
store(String, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.KeyValueStore
Stores a value under the given key with the default Guarantee.SENT delivery guarantee.
store(String, Object, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.DefaultKeyValueStore
 
store(String, Object, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.KeyValueStore
Stores a value under the given key with the specified delivery guarantee.
STORE_AND_PUBLISH - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublicationStrategy
Store the applied update in the event store and also publish it to event handlers.
STORE_ONLY - Enum constant in enum class io.fluxcapacitor.javaclient.modeling.EventPublicationStrategy
Store the applied update in the event store but do not publish it to event handlers.
STORED - Enum constant in enum class io.fluxcapacitor.common.Guarantee
Guarantees that the message or action was stored by Flux Capacitor.
storeEvents(Object, Object...) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.EventStore
Stores one or more events for a given aggregate using the default strategy EventPublicationStrategy.STORE_AND_PUBLISH.
storeEvents(Object, List<?>) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.EventStore
Stores a list of events for a given aggregate using the default strategy EventPublicationStrategy.STORE_AND_PUBLISH.
storeEvents(Object, List<?>, EventPublicationStrategy) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultEventStore
 
storeEvents(Object, List<?>, EventPublicationStrategy) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.EventStore
Stores a list of events for the given aggregate using a specified publication strategy.
storeEvents(String, List<SerializedMessage>, boolean) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Stores a list of serialized events for a given aggregate identifier.
storeEvents(String, List<SerializedMessage>, boolean, Guarantee) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Stores events for a given aggregate with an explicit guarantee.
storeEvents(String, List<SerializedMessage>, boolean, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
storeEvents(String, List<SerializedMessage>, boolean, Guarantee) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Stores events for a specific aggregate, with control over store-only mode and delivery guarantee.
StoreIdentifier() - Constructor for class io.fluxcapacitor.testserver.TestServer.StoreIdentifier
 
storeIfAbsent(String, Object) - Method in class io.fluxcapacitor.javaclient.persisting.keyvalue.DefaultKeyValueStore
 
storeIfAbsent(String, Object) - Method in interface io.fluxcapacitor.javaclient.persisting.keyvalue.KeyValueStore
Stores a value only if there is no existing value for the specified key.
storeMessages(Map<String, SerializedDocument>) - Method in class io.fluxcapacitor.javaclient.persisting.search.client.InMemorySearchStore
 
storePosition(String, int[], long) - Method in class io.fluxcapacitor.common.tracking.InMemoryPositionStore
 
storePosition(String, int[], long) - Method in interface io.fluxcapacitor.common.tracking.PositionStore
Stores the latest processed index for a given segment range and consumer.
storePosition(String, int[], long) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Stores the last successfully processed position for a consumer.
storePosition(String, int[], long, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
 
storePosition(String, int[], long, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
 
storePosition(String, int[], long, Guarantee) - Method in interface io.fluxcapacitor.javaclient.tracking.client.TrackingClient
Stores the last successfully processed position for a consumer with a specific delivery guarantee.
storePosition(String, int[], long, Guarantee) - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
StorePosition - Class in io.fluxcapacitor.common.api.tracking
Command sent to the Flux platform to update the tracked position for a specific consumer and segment range.
StorePosition() - Constructor for class io.fluxcapacitor.common.api.tracking.StorePosition
 
storePositionManually() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Whether this consumer is taking manual control over storing its position in the log.
storeSnapshot(Entity<T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.DefaultSnapshotStore
 
storeSnapshot(Entity<T>) - Method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoOpSnapshotStore
 
storeSnapshot(Entity<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.SnapshotStore
Stores a new snapshot for the given aggregate entity.
StoreValueIfAbsent - Class in io.fluxcapacitor.common.api.keyvalue
Stores a key-value pair only if the specified key does not already exist in the key-value store.
StoreValueIfAbsent() - Constructor for class io.fluxcapacitor.common.api.keyvalue.StoreValueIfAbsent
 
StoreValueIfAbsent.Metric - Class in io.fluxcapacitor.common.api.keyvalue
Lightweight metric representation for logging or monitoring.
StoreValues - Class in io.fluxcapacitor.common.api.keyvalue
Legacy API: This command stores key-value pairs in the legacy key-value store mechanism.
StoreValues() - Constructor for class io.fluxcapacitor.common.api.keyvalue.StoreValues
 
StoreValues.Metric - Class in io.fluxcapacitor.common.api.keyvalue
Lightweight metric representation of this command.
StoreValuesAndWait - Class in io.fluxcapacitor.common.api.keyvalue
Deprecated.
Use StoreValues instead. This class remains for compatibility but is no longer used.
StoreValuesAndWait() - Constructor for class io.fluxcapacitor.common.api.keyvalue.StoreValuesAndWait
Deprecated.
 
StoreValuesAndWait.Metric - Class in io.fluxcapacitor.common.api.keyvalue
Deprecated.
Metric representation of the deprecated store call.
stream() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams matching values, deserializing each to the stored type.
stream(int) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams matching values, deserializing each to the stored type.
stream(Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams matching values, deserializing each to the specified type.
stream(Class<T>, int) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams matching values, deserializing each to the specified type.
streamHits() - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
streamHits() - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams raw search hits (document + metadata).
streamHits(int) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
streamHits(int) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams raw search hits (document + metadata).
streamHits(Class<T>) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
streamHits(Class<T>) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams raw search hits (document + metadata).
streamHits(Class<T>, int) - Method in class io.fluxcapacitor.javaclient.persisting.search.DefaultDocumentStore.DefaultSearch
 
streamHits(Class<T>, int) - Method in interface io.fluxcapacitor.javaclient.persisting.search.Search
Streams raw search hits (document + metadata).
StringResult - Class in io.fluxcapacitor.common.api
A generic response containing a string value.
StringResult() - Constructor for class io.fluxcapacitor.common.api.StringResult
 
StripStringsModule - Class in io.fluxcapacitor.common.serialization
A Jackson module that customizes the deserialization of strings.
StripStringsModule() - Constructor for class io.fluxcapacitor.common.serialization.StripStringsModule
 
submit(ThrowingRunnable) - Method in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
submit(ThrowingRunnable) - Method in interface io.fluxcapacitor.common.TaskScheduler
Immediately schedules a task for execution.
substituteProperties(String) - Method in interface io.fluxcapacitor.common.application.PropertySource
Substitutes all placeholders of the form ${property[:default]} in the given template string.
substituteProperties(String) - Static method in class io.fluxcapacitor.javaclient.configuration.ApplicationProperties
Substitutes placeholders in the given template using current property values.
substitutionPattern - Static variable in interface io.fluxcapacitor.common.application.PropertySource
Regex pattern used for property substitution in the form ${property.name[:default]}.
success(long, Object) - Static method in class io.fluxcapacitor.javaclient.web.SocketResponse
Creates a SocketResponse representing a successful response.
summarize(Object) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
Supported Annotations - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
Section
Supported Types - Search tag in enum class io.fluxcapacitor.common.search.Document.EntryType
Section
Support for @Path Annotations - Search tag in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
Section
Support for new entities - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.Member
Section
supports(Class) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext.DefaultConverter
 
SystemPropertiesSource - Class in io.fluxcapacitor.common.application
A PropertySource implementation that reads configuration properties from the JVM system properties.
SystemPropertiesSource() - Constructor for class io.fluxcapacitor.common.application.SystemPropertiesSource
 

T

takeWhile(Predicate<? super T>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
Task(ThrowingRunnable, long) - Constructor for class io.fluxcapacitor.common.InMemoryTaskScheduler.Task
 
taskScheduler() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Task scheduler used for asynchronous background task execution.
taskScheduler() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the TaskScheduler of this FluxCapacitor instance.
TaskScheduler - Interface in io.fluxcapacitor.common
Interface for in-memory scheduling of tasks in a way that supports deterministic testing and virtualized time.
TechnicalException - Exception Class in io.fluxcapacitor.javaclient.common.exception
Exception indicating a technical or unexpected failure within the application.
TechnicalException() - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.TechnicalException
 
TechnicalException(String) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.TechnicalException
 
TechnicalException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.TechnicalException
 
TechnicalException(String, Throwable, boolean, boolean) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.TechnicalException
 
TechnicalException(Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.common.exception.TechnicalException
 
Terminology - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Section
termPattern - Static variable in class io.fluxcapacitor.common.SearchUtils
Pattern for extracting search terms and quoted phrases from a string.
test(HasMessage, Executable, Class<? extends Annotation>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.PayloadFilter
 
test(HasMessage, Executable, Class<? extends Annotation>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.SegmentFilter
 
test(HasMessage, Executable, Class<? extends Annotation>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
Evaluates whether the given message should be accepted by the handler method based on the associated Trigger annotation.
test(DeserializingMessage, Executable, Class<? extends Annotation>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandleCustomFilter
 
test(DeserializingMessage, Executable, Class<? extends Annotation>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandleDocumentFilter
 
test(Class<?>, Executable) - Method in interface io.fluxcapacitor.common.handling.HandlerFilter
Evaluates whether the specified method on the given class should be considered a valid handler.
test(M, Executable, Class<? extends Annotation>) - Method in interface io.fluxcapacitor.common.handling.MessageFilter
Evaluates whether a message should be handled by a given method annotated with a specific handler annotation.
test(T) - Method in interface io.fluxcapacitor.common.ThrowingPredicate
Evaluates this predicate on the given argument.
TestServer - Class in io.fluxcapacitor.testserver
 
TestServer() - Constructor for class io.fluxcapacitor.testserver.TestServer
 
TestServer.StoreIdentifier - Class in io.fluxcapacitor.testserver
 
TestServerScheduleStore - Class in io.fluxcapacitor.testserver.scheduling
 
TestServerScheduleStore(InMemoryScheduleStore) - Constructor for class io.fluxcapacitor.testserver.scheduling.TestServerScheduleStore
 
TEXT - Enum constant in enum class io.fluxcapacitor.common.search.Document.EntryType
Represents textual values such as plain strings (e.g., "hello").
Thread-Local Binding - Search tag in class io.fluxcapacitor.javaclient.tracking.FluxCapacitorInterceptor
Section
threads() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
The number of tracker threads to allocate for this consumer.
Thread Safety - Search tag in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
Section
Thread Safety - Search tag in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
Section
Thread Safety - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.LocalHandlerRegistry
Section
Thread-Scoped Aggregates - Search tag in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
Section
throwIfUnauthorized() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.ForbidsAnyRole
Determines whether an exception should be thrown when the authorization check fails.
throwIfUnauthorized() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.ForbidsUser
Determines whether an exception should be thrown when the authorization check fails.
throwIfUnauthorized() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresAnyRole
Determines whether an exception should be thrown when the authorization check fails.
throwIfUnauthorized() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresUser
Determines whether an exception should be thrown when the authorization check fails.
throwIfUnauthorized() - Method in record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Returns the value of the throwIfUnauthorized record component.
ThrowingBiConsumer<T,U> - Interface in io.fluxcapacitor.common
BiConsumer-like interface whose ThrowingBiConsumer.accept(Object, Object) method may throw a checked Exception.
ThrowingBiFunction<T,U,R> - Interface in io.fluxcapacitor.common
Variant of BiFunction whose ThrowingBiFunction.apply(Object, Object) method is allowed to throw a checked Exception.
ThrowingConsumer<T> - Interface in io.fluxcapacitor.common
Functional counterpart to Consumer that allows the ThrowingConsumer.accept(Object) method to throw a checked Exception.
ThrowingErrorHandler - Class in io.fluxcapacitor.javaclient.tracking
An ErrorHandler implementation that forcefully halts message tracking by throwing any encountered errors.
ThrowingErrorHandler() - Constructor for class io.fluxcapacitor.javaclient.tracking.ThrowingErrorHandler
Constructs a default ThrowingErrorHandler that logs both functional and technical errors.
ThrowingFunction<T,R> - Interface in io.fluxcapacitor.common
Equivalent of Function whose ThrowingFunction.apply(Object) method may throw a checked Exception.
ThrowingPredicate<T> - Interface in io.fluxcapacitor.common
 
ThrowingRunnable - Interface in io.fluxcapacitor.common
Runnable-like interface whose ThrowingRunnable.run() method is allowed to throw a checked Exception.
time(Runnable, Consumer<Long>) - Static method in class io.fluxcapacitor.common.TimingUtils
Executes a task and measures its execution time in milliseconds.
time(Runnable, Consumer<Long>, TemporalUnit) - Static method in class io.fluxcapacitor.common.TimingUtils
Executes a task and measures its execution time in the specified TemporalUnit.
time(Callable<T>, Consumer<Long>) - Static method in class io.fluxcapacitor.common.TimingUtils
Executes a Callable and measures its execution time in milliseconds.
time(Callable<T>, Consumer<Long>, TemporalUnit) - Static method in class io.fluxcapacitor.common.TimingUtils
Executes a Callable and measures its execution time in the given TemporalUnit.
Timeout - Annotation Interface in io.fluxcapacitor.javaclient.publishing
Annotation to be placed on requests (i.e. queries and commands).
TimeoutException - Exception Class in io.fluxcapacitor.javaclient.publishing
 
TimeoutException(String) - Constructor for exception class io.fluxcapacitor.javaclient.publishing.TimeoutException
 
timestamp() - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
timestamp() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
timestamp() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the timestamp of the entity.
timestamp() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
timestamp(Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.IndexOperation
Sets both start and end time to the same instant (convenience method).
timestampFromIndex(long) - Static method in class io.fluxcapacitor.javaclient.tracking.IndexUtils
Converts the given index to a timestamp.
timestampPath() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Path to extract the main timestamp used in search indexing.
timestampPath() - Element in annotation interface io.fluxcapacitor.javaclient.persisting.search.Searchable
A path expression used to extract the primary timestamp from the object for indexing.
timestampPath() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Path to extract the main timestamp used in search indexing.
timeUnit() - Element in annotation interface io.fluxcapacitor.javaclient.publishing.Timeout
Returns the time unit for Timeout.value().
timeUnit() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
Returns the unit for Periodic.delay() and Periodic.initialDelay().
timeUnit() - Element in annotation interface io.fluxcapacitor.javaclient.web.SocketEndpoint.AliveCheck
Unit for ping intervals and timeouts.
timeZone() - Element in annotation interface io.fluxcapacitor.javaclient.scheduling.Periodic
A time zone id for which the cron expression will be resolved.
TimingUtils - Class in io.fluxcapacitor.common
Utility class for measuring execution time and retrying operations with configurable backoff and error handling.
TimingUtils() - Constructor for class io.fluxcapacitor.common.TimingUtils
 
toArray() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
toArray(IntFunction<A[]>) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
toBuilder() - Method in class io.fluxcapacitor.javaclient.web.WebRequest
Creates a mutable builder for this request.
toBuilder() - Method in class io.fluxcapacitor.javaclient.web.WebResponse
Converts this WebResponse instance into a builder, which can be used to create a modified copy of the instance.
toDocument(Object, String, int, String, String, Instant, Instant, Metadata) - Method in interface io.fluxcapacitor.common.search.Inverter
Converts the given object into a SerializedDocument, which is suitable for indexing or storage in a document store.
toDocument(Object, String, int, String, String, Instant, Instant, Metadata) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
toDocument(Object, String, String, Instant, Instant) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentSerializer
Serializes a given value into a SerializedDocument, using the specified identifiers and timestamps.
toDocument(Object, String, String, Instant, Instant, Metadata) - Method in class io.fluxcapacitor.javaclient.common.serialization.jackson.JacksonSerializer
 
toDocument(Object, String, String, Instant, Instant, Metadata) - Method in interface io.fluxcapacitor.javaclient.persisting.search.DocumentSerializer
Serializes a given value into a SerializedDocument, using the specified identifiers, timestamps, and metadata.
toJsonData(JsonNode, Data<byte[]>) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
toJsonNode(Document.Entry) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
toJsonNode(Object) - Method in class io.fluxcapacitor.common.search.JacksonInverter
 
toList() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
toMessage() - Method in interface io.fluxcapacitor.javaclient.common.HasMessage
Returns the underlying Message representation of this object.
toMessage() - Method in class io.fluxcapacitor.javaclient.common.Message
 
toMessage() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
toMessage() - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper.MessageWithEntity
 
toMessage(Throwable, Map<String, String>) - Method in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
toMessage(HttpResponse<byte[]>, Map<String, String>) - Method in class io.fluxcapacitor.javaclient.web.ForwardingWebConsumer
 
toMetric() - Method in class io.fluxcapacitor.common.api.eventsourcing.AppendEvents
Converts this command to a metric-friendly representation for logging and monitoring.
toMetric() - Method in class io.fluxcapacitor.common.api.eventsourcing.EventBatch
Transforms this batch into a lightweight metric representation for logging and monitoring.
toMetric() - Method in class io.fluxcapacitor.common.api.eventsourcing.GetEventsResult
Converts this result to a minimal metric object for performance logging or monitoring.
toMetric() - Method in interface io.fluxcapacitor.common.api.JsonType
Converts this object into a compact metric representation for logging or monitoring.
toMetric() - Method in class io.fluxcapacitor.common.api.keyvalue.GetValueResult
Lightweight representation of this response for metrics logging.
toMetric() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValueIfAbsent
 
toMetric() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValues
 
toMetric() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValuesAndWait
Deprecated.
 
toMetric() - Method in class io.fluxcapacitor.common.api.publishing.Append
 
toMetric() - Method in class io.fluxcapacitor.common.api.scheduling.GetScheduleResult
 
toMetric() - Method in class io.fluxcapacitor.common.api.scheduling.Schedule
 
toMetric() - Method in class io.fluxcapacitor.common.api.scheduling.SerializedSchedule
Returns a lightweight metric representation of this schedule for monitoring purposes.
toMetric() - Method in class io.fluxcapacitor.common.api.search.BulkUpdateDocuments
Metric representation of the bulk update, for logging or monitoring.
toMetric() - Method in class io.fluxcapacitor.common.api.search.GetDocumentResult
Converts this result to a compact representation for metrics logging.
toMetric() - Method in class io.fluxcapacitor.common.api.search.GetDocumentStatsResult
Returns a lightweight summary of this result for logging or metric tracking.
toMetric() - Method in class io.fluxcapacitor.common.api.search.GetFacetStatsResult
 
toMetric() - Method in class io.fluxcapacitor.common.api.search.IndexDocuments
 
toMetric() - Method in class io.fluxcapacitor.common.api.search.SearchDocumentsResult
Converts this result into a serializable metrics object that logs match count and timing, instead of full search result payloads.
toMetric() - Method in class io.fluxcapacitor.common.api.tracking.ClaimSegmentResult
Returns a compact metric representation of this claim for monitoring purposes.
toMetric() - Method in class io.fluxcapacitor.common.api.tracking.MessageBatch
Converts this batch into a compact, serializable representation for monitoring purposes.
toMetric() - Method in class io.fluxcapacitor.common.api.tracking.ReadFromIndexResult
Converts this result into a metric representation, which includes the number of messages and timestamp.
toMetric() - Method in class io.fluxcapacitor.common.api.tracking.ReadResult
Produces a metric-friendly summary of the result for publishing to the Flux metrics log.
toRequestHeaderString(HttpCookie) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Returns a formatted string for the Cookie request header containing the given cookie.
toResponseHeaderString(HttpCookie) - Static method in class io.fluxcapacitor.javaclient.web.WebUtils
Returns a properly formatted Set-Cookie header value for the given cookie.
toSortableString(Number) - Static method in class io.fluxcapacitor.common.api.search.SortableEntry
Converts a Number to a lexicographically sortable zero-padded string.
toString() - Method in class io.fluxcapacitor.common.api.eventsourcing.AppendEvents
Returns a human-readable description of the operation.
toString() - Method in class io.fluxcapacitor.common.api.eventsourcing.EventBatch
Returns a human-readable representation of this batch, including its aggregate ID and event count.
toString() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValueIfAbsent
 
toString() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValues
 
toString() - Method in class io.fluxcapacitor.common.api.keyvalue.StoreValuesAndWait
Deprecated.
 
toString() - Method in class io.fluxcapacitor.common.api.Metadata
Returns the string representation of this object, which is the string representation of the underlying entries map.
toString() - Method in class io.fluxcapacitor.common.api.publishing.Append
 
toString() - Method in class io.fluxcapacitor.common.api.scheduling.Schedule
 
toString() - Method in class io.fluxcapacitor.common.api.search.BulkUpdateDocuments
 
toString() - Method in class io.fluxcapacitor.common.api.search.IndexDocuments
 
toString() - Method in class io.fluxcapacitor.common.api.tracking.MessageBatch
 
toString() - Method in class io.fluxcapacitor.common.handling.DefaultHandler
 
toString() - Method in class io.fluxcapacitor.common.handling.HandlerInspector.MethodHandlerMatcher.MethodHandlerInvoker
 
toString() - Method in class io.fluxcapacitor.common.handling.HandlerInvoker.DelegatingHandlerInvoker
 
toString() - Method in class io.fluxcapacitor.common.tracking.SimpleTracker
 
toString() - Method in class io.fluxcapacitor.common.tracking.WebSocketTracker
 
toString() - Method in class io.fluxcapacitor.javaclient.common.LazyId
Returns the ID value as a string.
toString() - Method in class io.fluxcapacitor.javaclient.common.serialization.casting.AnnotatedCaster
 
toString() - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
toString() - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
toString() - Method in class io.fluxcapacitor.javaclient.modeling.Id
Returns the id under which the entity will be stored in a repository.
toString() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
toString() - Method in class io.fluxcapacitor.javaclient.publishing.client.WebsocketGatewayClient
 
toString() - Method in record class io.fluxcapacitor.javaclient.publishing.DefaultRequestHandler.ResponseCallback
Returns a string representation of this record class.
toString() - Method in class io.fluxcapacitor.javaclient.scheduling.client.InMemoryScheduleStore
 
toString() - Method in class io.fluxcapacitor.javaclient.scheduling.CronExpression
 
toString() - Method in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
 
toString() - Method in class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
toString() - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor.InterceptedHandler
 
toString() - Method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler
 
toString() - Method in record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Returns a string representation of this record class.
toString() - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler
 
toString() - Method in record class io.fluxcapacitor.javaclient.web.StaticFileHandler.ByteRange
Returns a string representation of this record class.
toString() - Method in record class io.fluxcapacitor.proxy.WebsocketEndpoint.SessionContext
Returns a string representation of this record class.
toString() - Method in class io.fluxcapacitor.testserver.websocket.ConsumerEndpoint
 
TRACE - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
 
Tracker - Class in io.fluxcapacitor.javaclient.tracking
Represents the client-side tracking context during message consumption in Flux Capacitor.
Tracker - Interface in io.fluxcapacitor.common.tracking
A Tracker represents an active consumer of messages for a particular ConsumerConfiguration.
Tracker() - Constructor for class io.fluxcapacitor.javaclient.tracking.Tracker
 
TrackerCluster - Class in io.fluxcapacitor.common.tracking
Represents the current set of Trackers that are connected for a specific consumer.
TrackerCluster(int) - Constructor for class io.fluxcapacitor.common.tracking.TrackerCluster
Creates a new, empty cluster with the given number of segments.
trackerId() - Method in record class io.fluxcapacitor.proxy.WebsocketEndpoint.SessionContext
Returns the value of the trackerId record component.
TrackerMonitor - Class in io.fluxcapacitor.javaclient.tracking.metrics
 
TrackerMonitor() - Constructor for class io.fluxcapacitor.javaclient.tracking.metrics.TrackerMonitor
 
tracking(MessageType) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
tracking(MessageType) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns a client to assist with the tracking of a given message type.
Tracking - Interface in io.fluxcapacitor.javaclient.tracking
The Tracking interface provides a mechanism to start and manage the tracking of messages by a given set of handlers.
TrackingClient - Interface in io.fluxcapacitor.javaclient.tracking.client
Low-level client interface for tracking and consuming messages from a message log.
TrackingClientConfig() - Constructor for class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient.TrackingClientConfig
 
TrackingException - Exception Class in io.fluxcapacitor.javaclient.tracking
Exception thrown during the initialization of message tracking in Flux Capacitor.
TrackingException(String) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.TrackingException
Constructs a new TrackingException with the specified message.
TrackingException(String, Throwable) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.TrackingException
Constructs a new TrackingException with the specified message and cause.
Tracking Fields - Search tag in class io.fluxcapacitor.common.api.SerializedMessage
Section
Tracking Isolation - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Section
Tracking Mechanics - Search tag in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
Section
trackingPath(MessageType) - Static method in class io.fluxcapacitor.common.ServicePathBuilder
Returns the tracking path used to read (track) messages of the given MessageType.
TrackingStrategy - Interface in io.fluxcapacitor.common.tracking
A TrackingStrategy defines how a Tracker consumes messages from a message log or distributed segment space.
trackingUrl(MessageType, String, WebSocketClient.ClientConfig) - Static method in class io.fluxcapacitor.javaclient.common.websocket.ServiceUrlBuilder
Builds the URL to subscribe to messages from a tracking endpoint for the specified message type and topic.
TrackSelf - Annotation Interface in io.fluxcapacitor.javaclient.tracking
Indicates that a message payload class can handle itself as a message handler.
trackSelfPostProcessor() - Static method in class io.fluxcapacitor.javaclient.configuration.spring.FluxCapacitorSpringConfig
Registers the TrackSelfPostProcessor, which supports payload classes that track and handle their own type.
TrackSelfPostProcessor - Class in io.fluxcapacitor.javaclient.configuration.spring
Spring BeanDefinitionRegistryPostProcessor that detects classes annotated with TrackSelf and registers them as FluxPrototype beans for use by Flux Capacitor.
TrackSelfPostProcessor() - Constructor for class io.fluxcapacitor.javaclient.configuration.spring.TrackSelfPostProcessor
 
Transforming and Updating Documents - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleDocument
Section
Trigger - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling
Injects the **triggering message** that caused the current message to be published or handled.
TriggerParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling
Resolves parameters annotated with Trigger by loading the original trigger message that caused the current handler method to execute.
TriggerParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.TriggerParameterResolver
 
truncate(T, TemporalUnit) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Truncates a Temporal (e.g., LocalDateTime) to the specified unit (e.g., MONTHS or YEARS).
tryAccept(Consumer<? super T>) - Static method in class io.fluxcapacitor.common.ObjectUtils
Returns a consumer that logs errors instead of propagating them.
tryAdvance(Consumer<? super DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage.MessageSpliterator
 
tryCatch(Runnable) - Static method in class io.fluxcapacitor.common.ObjectUtils
Wraps a runnable in a try/catch block that logs any exception on execution.
tryCompleteRequest(DeserializingMessage) - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
tryHandle(DeserializingMessage, Handler<DeserializingMessage>, ConsumerConfiguration, boolean) - Method in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
 
tryHandleRequest(DeserializingMessage, Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.web.DefaultSocketSession
 
tryLoadFile(File) - Static method in class io.fluxcapacitor.common.FileUtils
Attempts to load file content from a File.
tryLoadFile(File, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Attempts to load file content from a File with specified charset.
tryLoadFile(Class<?>, String) - Static method in class io.fluxcapacitor.common.FileUtils
Attempts to load file content relative to a reference class.
tryLoadFile(Class<?>, String, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Attempts to load file content with specified reference class and charset.
tryLoadFile(String) - Static method in class io.fluxcapacitor.common.FileUtils
Attempts to load file content relative to the caller class, returns empty if not found.
tryLoadFile(String, Charset) - Static method in class io.fluxcapacitor.common.FileUtils
Attempts to load file content with specified charset.
tryPublishMetrics(JsonType, Metadata) - Method in class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient
 
tryRun(Runnable) - Static method in class io.fluxcapacitor.common.ObjectUtils
Executes the runnable and logs any thrown exception.
tryRunTask(InMemoryTaskScheduler.Task) - Method in class io.fluxcapacitor.common.InMemoryTaskScheduler
 
trySchedulePing() - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
tryUpgrade(WebRequest, HttpServerExchange) - Method in class io.fluxcapacitor.proxy.ProxyRequestHandler
 
type() - Element in annotation interface io.fluxcapacitor.javaclient.common.serialization.casting.Downcast
The fully qualified type name this downcaster applies to (e.g., the latest version's class name).
type() - Element in annotation interface io.fluxcapacitor.javaclient.common.serialization.casting.Upcast
The fully qualified type name this upcaster applies to (e.g., the original serialized class name).
type() - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
type() - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Retrieves the type of the entity.
type() - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
type() - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
type() - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
type() - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
type() - Element in annotation interface io.fluxcapacitor.javaclient.web.WebParam
The source of the parameter within the request (e.g. path, query, header).
Type constraints on handler updates - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Stateful
Section
TypedParameterResolver<M> - Class in io.fluxcapacitor.common.handling
Abstract base class for ParameterResolvers that resolve parameters based on type matching.
TypedParameterResolver() - Constructor for class io.fluxcapacitor.common.handling.TypedParameterResolver
 
typeFactory() - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Provides access to the TypeFactory instance used by the writer.
typeFilter() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.Consumer
Optional regular expression used to filter message payload types on the Flux platform.
typeFromId(DatabindContext, String) - Method in class io.fluxcapacitor.common.serialization.GlobalTypeIdResolver
 
TypeRegistry - Interface in io.fluxcapacitor.common.serialization
Interface for resolving registered types by alias or simplified name.
TypeRegistryProcessor - Class in io.fluxcapacitor.common.serialization
 
TypeRegistryProcessor() - Constructor for class io.fluxcapacitor.common.serialization.TypeRegistryProcessor
 
Type Resolution via @class - Search tag in class io.fluxcapacitor.common.serialization.JsonUtils
Section
TYPES_FILE - Static variable in class io.fluxcapacitor.common.serialization.TypeRegistryProcessor
 
Typical usage - Search tag in class io.fluxcapacitor.common.api.tracking.ClaimSegment
Section
Typical usage - Search tag in interface io.fluxcapacitor.javaclient.scheduling.MessageScheduler
Section
Typical Usage - Search tag in class io.fluxcapacitor.javaclient.scheduling.Schedule
Section
Typical Usage - Search tag in class io.fluxcapacitor.javaclient.tracking.DefaultTracking
Section
Typical Use - Search tag in class io.fluxcapacitor.common.Backlog
Section
Typical Use - Search tag in class io.fluxcapacitor.common.api.SerializedMessage
Section
Typical Use Case: Disabling Metrics - Search tag in class io.fluxcapacitor.javaclient.publishing.AdhocDispatchInterceptor
Section

U

2. Updating an entity with a new state - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.eventsourcing.Apply
Section
UnauthenticatedException - Exception Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
Thrown to signal that the user is not authenticated.
UnauthenticatedException(String) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.handling.authentication.UnauthenticatedException
Constructs a new UnauthenticatedException with the specified detail message.
UnauthorizedException - Exception Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
Thrown when an authenticated user attempts to access a resource or perform an action for which they lack the required permissions.
UnauthorizedException(String) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.handling.authentication.UnauthorizedException
Constructs a new UnauthorizedException with the specified detail message.
unescapeFieldName(String) - Static method in class io.fluxcapacitor.common.SearchUtils
Unescapes slashes and quotes in field names.
UnknownTypeStrategy - Enum Class in io.fluxcapacitor.javaclient.common.serialization
Defines the strategy for handling unknown or unresolvable types during deserialization.
unordered() - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.AggregateEventStream
 
unwrap() - Method in interface io.fluxcapacitor.javaclient.configuration.client.Client
Returns the underlying Client implementation.
unwrap() - Method in class io.fluxcapacitor.javaclient.web.SocketEndpointHandler.SocketEndpointWrapper
 
unwrap(DefaultCache.CacheReference) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
unwrap(Class<T>) - Method in interface io.fluxcapacitor.common.tracking.MessageStore
Attempts to unwrap the current instance to a concrete implementation or extension of MessageStore.
unwrapException(Throwable) - Static method in class io.fluxcapacitor.common.ObjectUtils
Recursively unwraps the cause of common wrapping exceptions.
Upcast - Annotation Interface in io.fluxcapacitor.javaclient.common.serialization.casting
Declares a method that transforms an object from a previous revision to a newer one.
upcastType(String) - Method in class io.fluxcapacitor.javaclient.common.serialization.AbstractSerializer
Resolves the current type from a potentially chained upcast mapping.
upcastType(String) - Method in interface io.fluxcapacitor.javaclient.common.serialization.Serializer
Returns the upcasted type name for a legacy type identifier.
upcastType(String) - Method in class io.fluxcapacitor.proxy.ProxySerializer
 
update(UnaryOperator<T>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Updates the current entity's value using the specified unary operator and returns a new entity containing the updated value.
update(UnaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableAggregateRoot
 
update(UnaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
update(UnaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
update(UnaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
update(UnaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableEntity
 
update(UnaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
update(UnaryOperator<T>) - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
Update() - Constructor for class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository.Update
 
updateOwner(Object, Entity<?>, Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.AnnotatedEntityHolder
Updates the parent object with the new state of a child entity.
updateRelationships(UpdateRelationships) - Method in interface io.fluxcapacitor.javaclient.persisting.eventsourcing.client.EventStoreClient
Updates entity relationships in the event store (e.g. parent-child, references).
updateRelationships(UpdateRelationships) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.InMemoryEventStore
 
updateRelationships(UpdateRelationships) - Method in class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Sends a request to update the relationships of an entity or aggregate.
updateRelationships(Entity<?>, Entity<?>) - Method in class io.fluxcapacitor.javaclient.persisting.repository.CachingAggregateRepository
 
UpdateRelationships - Class in io.fluxcapacitor.common.api.modeling
Command to inform the Flux platform about changes in entity-aggregate relationships.
UpdateRelationships() - Constructor for class io.fluxcapacitor.common.api.modeling.UpdateRelationships
 
updates() - Method in class io.fluxcapacitor.javaclient.modeling.BatchingHandlerRepository
 
upgrade(ServerSentEmitter.Handler) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
upgrade(WebSocket.Initializer) - Method in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
 
URI Parsing - Search tag in class io.fluxcapacitor.javaclient.web.WebPattern
Section
urlKey - Static variable in class io.fluxcapacitor.javaclient.web.WebRequest
 
Usage - Search tag in annotation interface io.fluxcapacitor.common.serialization.RegisterType
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnBean
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingBean
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingProperty
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnProperty
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.modeling.Aggregate
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.persisting.search.Searchable
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Section
Usage - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.ForbidsAnyRole
Section
Usage - Search tag in class io.fluxcapacitor.common.api.RequestBatch
Section
Usage - Search tag in class io.fluxcapacitor.common.api.eventsourcing.EventBatch
Section
Usage - Search tag in class io.fluxcapacitor.common.api.eventsourcing.GetEvents
Section
Usage - Search tag in class io.fluxcapacitor.common.api.scheduling.Schedule
Section
Usage - Search tag in class io.fluxcapacitor.common.serialization.compression.CompressionUtils
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.common.serialization.casting.DefaultCasterChain
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.configuration.client.LocalClient
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.configuration.spring.SocketEndpointPostProcessor
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.configuration.spring.StatefulPostProcessor
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.configuration.spring.TrackSelfPostProcessor
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.Invocation
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.web.ParameterValue
Section
Usage - Search tag in class io.fluxcapacitor.javaclient.web.WebParameterProcessor
Section
Usage - Search tag in interface io.fluxcapacitor.common.Registration
Section
Usage - Search tag in interface io.fluxcapacitor.javaclient.configuration.client.Client
Section
Usage - Search tag in interface io.fluxcapacitor.javaclient.tracking.BatchInterceptor
Section
Usage - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry
Section
Usage - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.validation.Validator
Section
Usage - Search tag in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Section
Usage: - Search tag in class io.fluxcapacitor.common.encryption.ChaCha20Poly1305Encryption
Section
Usage Considerations - Search tag in class io.fluxcapacitor.javaclient.tracking.StallingBatchInterceptor
Section
Usage Example - Search tag in class io.fluxcapacitor.common.RetryConfiguration
Section
Usage Example - Search tag in class io.fluxcapacitor.common.api.Metadata
Section
Usage Example - Search tag in class io.fluxcapacitor.javaclient.tracking.NoOpFlowRegulator
Section
Usage Example - Search tag in interface io.fluxcapacitor.common.handling.HandlerFilter
Section
Usage Example - Search tag in interface io.fluxcapacitor.javaclient.persisting.search.GroupSearch
Section
Usage Examples - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresUser
Section
Usage Examples - Search tag in class io.fluxcapacitor.common.api.search.constraints.QueryConstraint
Section
Usage Examples: - Search tag in enum class io.fluxcapacitor.common.MessageType
Section
Usage in Routing - Search tag in class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext
Section
Usage Modes: - Search tag in class io.fluxcapacitor.javaclient.common.websocket.SessionPool
Section
Usage Note: - Search tag in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
Section
Usage Notes - Search tag in class io.fluxcapacitor.common.api.keyvalue.DeleteValue
Section
Usage Notes - Search tag in class io.fluxcapacitor.common.api.keyvalue.GetValue
Section
Usage Patterns - Search tag in interface io.fluxcapacitor.javaclient.FluxCapacitor
Section
Use Cases - Search tag in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleMetrics
Section
Use Cases - Search tag in class io.fluxcapacitor.common.api.ConnectEvent
Section
Use Cases - Search tag in class io.fluxcapacitor.common.api.DisconnectEvent
Section
Use Cases - Search tag in class io.fluxcapacitor.common.api.tracking.DisconnectTracker
Section
Use Cases - Search tag in class io.fluxcapacitor.common.api.tracking.GetPosition
Section
Use Cases - Search tag in class io.fluxcapacitor.common.api.tracking.GetPositionResult
Section
Use Cases - Search tag in class io.fluxcapacitor.javaclient.tracking.client.CachingTrackingClient
Section
Use Cases - Search tag in class io.fluxcapacitor.javaclient.tracking.client.InMemoryMessageStore
Section
Use Cases - Search tag in class io.fluxcapacitor.javaclient.tracking.client.LocalTrackingClient
Section
Use Cases - Search tag in exception class io.fluxcapacitor.javaclient.tracking.BatchProcessingException
Section
Use Cases - Search tag in interface io.fluxcapacitor.common.api.HasId
Section
Use Cases - Search tag in interface io.fluxcapacitor.javaclient.tracking.handling.ResponseMapper
Section
User - Interface in io.fluxcapacitor.javaclient.tracking.handling.authentication
Represents an authenticated or system-level user identity within the Flux platform.
UserParameterResolver - Class in io.fluxcapacitor.javaclient.tracking.handling.authentication
Resolves parameters of type User, typically representing the current user in a request context.
UserParameterResolver(UserProvider) - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.authentication.UserParameterResolver
 
userProvider() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Returns the provider used to determine the current authenticated or active user.
userProvider() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the UserProvider used by Flux Capacitor to authenticate users.
UserProvider - Interface in io.fluxcapacitor.javaclient.tracking.handling.authentication
Service interface for managing User identities in Flux Capacitor.
UuidFactory - Class in io.fluxcapacitor.javaclient.common
Default implementation of IdentityProvider that generates random UUIDs.
UuidFactory() - Constructor for class io.fluxcapacitor.javaclient.common.UuidFactory
Creates a UuidFactory that removes dashes (default behavior).

V

validateMethod(Element, TypeMirror) - Method in class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
 
validateReturnType(Element, TypeMirror, TypeMirror) - Method in class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
 
ValidateWith - Annotation Interface in io.fluxcapacitor.javaclient.tracking.handling.validation
Specifies validation groups to apply when validating the annotated class.
ValidatingInterceptor - Class in io.fluxcapacitor.javaclient.tracking.handling.validation
A HandlerInterceptor that validates the payload of messages before they are handled.
ValidatingInterceptor() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidatingInterceptor
 
Validation - Search tag in class io.fluxcapacitor.common.api.search.SearchQuery
Section
Validation - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
Section
ValidationException - Exception Class in io.fluxcapacitor.javaclient.tracking.handling.validation
Indicates that a request (typically a command or query) contains one or more field-level violations that prevent further processing.
ValidationException(String, Set<String>) - Constructor for exception class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationException
 
Validation Rules - Search tag in class io.fluxcapacitor.javaclient.tracking.handling.RequestAnnotationProcessor
Section
ValidationUtils - Class in io.fluxcapacitor.javaclient.tracking.handling.validation
Utility class providing common validation and authorization routines for message payloads such as commands, queries, and web requests.
ValidationUtils() - Constructor for class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils
 
ValidationUtils.RequiredRole - Record Class in io.fluxcapacitor.javaclient.tracking.handling.validation
 
Validator - Interface in io.fluxcapacitor.javaclient.tracking.handling.validation
Strategy interface for validating message payloads and other objects prior to handler invocation.
value() - Element in annotation interface io.fluxcapacitor.common.search.Facet
Optional argument that defines the name of the facet.
value() - Element in annotation interface io.fluxcapacitor.common.search.SearchExclude
Optional argument that defines whether this annotation is active (true) or not (false).
value() - Element in annotation interface io.fluxcapacitor.common.search.Sortable
Optional argument that defines the name of the indexed property.
value() - Element in annotation interface io.fluxcapacitor.common.serialization.Revision
The revision number of the annotated class.
value() - Element in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnBean
 
value() - Element in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingBean
 
value() - Element in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnMissingProperty
 
value() - Element in annotation interface io.fluxcapacitor.javaclient.configuration.spring.ConditionalOnProperty
 
value() - Element in annotation interface io.fluxcapacitor.javaclient.publishing.routing.RoutingKey
Returns the metadata key or property name to use to look up the routing key.
value() - Element in annotation interface io.fluxcapacitor.javaclient.publishing.Timeout
Configures the maximum number of time units before a request with this annotation will time out.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Association
Returns names of properties in the message payload to associate with.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.ForbidsAnyRole
One or more roles that should be excluded.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.authentication.RequiresAnyRole
One or more role names (case-sensitive) that grant access.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleCustom
Specifies the topic name.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleDocument
Optional name of the document collection.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.HandleMessage
The type of message this handler annotation is intended to process.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.LocalHandler
Whether the handler is local.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.Trigger
Restricts the trigger message by payload type.
value() - Element in annotation interface io.fluxcapacitor.javaclient.tracking.handling.validation.ValidateWith
One or more validation groups to include when validating this class.
value() - Method in record class io.fluxcapacitor.javaclient.tracking.handling.validation.ValidationUtils.RequiredRole
Returns the value of the value record component.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.CookieParam
Cookie parameter name.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.FormParam
Form parameter name.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleDelete
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleGet
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleHead
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleOptions
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePatch
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePost
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandlePut
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketClose
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketHandshake
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketMessage
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketOpen
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleSocketPong
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleTrace
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HandleWeb
One or more path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.HeaderParam
Header parameter name.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.Path
Defines the URI path segment.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.PathParam
Parameter name in the URI pattern.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.QueryParam
Query parameter name.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.ServeStatic
One or more web path patterns this handler applies to (e.g.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.SocketEndpoint.AliveCheck
Whether the keep-alive mechanism is enabled.
value() - Element in annotation interface io.fluxcapacitor.javaclient.web.WebParam
Optional name of the parameter (e.g. path variable or query param).
valueOf(Association) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.StatefulHandler.AssociationValue
 
valueOf(Object) - Static method in class io.fluxcapacitor.javaclient.web.SocketRequest
Creates a new SocketRequest with an auto-incremented ID and the given request object.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.api.search.BulkUpdate.Type
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.application.EnvironmentVariablesSource
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.application.NoOpPropertySource
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.Guarantee
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.MessageType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.search.DefaultDocumentSerializer
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.search.Document.EntryType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.serialization.compression.CompressionAlgorithm
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.common.serialization.NoOpTypeRegistry
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.common.serialization.UnknownTypeStrategy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.modeling.EventPublication
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.modeling.EventPublicationStrategy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.persisting.caching.CacheEviction.Reason
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoOpSnapshotStore
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoSnapshotTrigger
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.publishing.correlation.DefaultCorrelationDataProvider
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.NoOpHandlerRegistry
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.web.HttpVersion
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.fluxcapacitor.javaclient.web.WebParameterSource
Returns the enum constant of this class with the specified name.
values() - Static method in enum class io.fluxcapacitor.common.api.search.BulkUpdate.Type
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.application.EnvironmentVariablesSource
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.application.NoOpPropertySource
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.encryption.NoOpEncryption
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.Guarantee
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.MessageType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.search.DefaultDocumentSerializer
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.search.Document.EntryType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.serialization.compression.CompressionAlgorithm
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.common.serialization.NoOpTypeRegistry
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.common.serialization.UnknownTypeStrategy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.modeling.EventPublication
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.modeling.EventPublicationStrategy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.persisting.caching.CacheEviction.Reason
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.persisting.caching.NoOpCache
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoOpSnapshotStore
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.persisting.eventsourcing.NoSnapshotTrigger
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.publishing.correlation.DefaultCorrelationDataProvider
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.tracking.handling.authentication.NoOpUserProvider
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.tracking.handling.HandlerRegistry.NoOpHandlerRegistry
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.web.HttpVersion
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.web.StaticFileHandler.Compression
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.fluxcapacitor.javaclient.web.WebParameterSource
Returns an array containing the constants of this enum class, in the order they are declared.
valueToTree(Object) - Static method in class io.fluxcapacitor.common.serialization.JsonUtils
Converts an object to a JsonNode of type JsonUtils.
VoidResult - Class in io.fluxcapacitor.common.api
A generic response indicating successful completion of a request without returning any payload.
VoidResult() - Constructor for class io.fluxcapacitor.common.api.VoidResult
 

W

waitForMessages(Tracker, MessageBatch, PositionStore) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
waitForResults(Duration, Collection<? extends Future<?>>) - Static method in class io.fluxcapacitor.javaclient.common.ClientUtils
Blocks until all futures are complete or the maximum duration has elapsed.
waitForUpdate(Tracker, MessageBatch, Runnable) - Method in class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy
 
WaitingTracker() - Constructor for class io.fluxcapacitor.common.tracking.DefaultTrackingStrategy.WaitingTracker
 
warnedAboutMissingProperty - Static variable in interface io.fluxcapacitor.javaclient.common.HasMessage
 
WebHandlerMatcher - Class in io.fluxcapacitor.javaclient.web
Specialized HandlerMatcher that routes DeserializingMessages of type MessageType.WEBREQUEST to matching handler methods based on annotated URI patterns, HTTP methods, and optional origins.
WebHandlerMatcher(Object, List<HandlerInspector.MethodHandlerMatcher<DeserializingMessage>>) - Constructor for class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
 
WebParam - Annotation Interface in io.fluxcapacitor.javaclient.web
Meta-annotation for parameter annotations used to inject values from an HTTP request.
WebParameterProcessor - Class in io.fluxcapacitor.javaclient.web
Annotation processor that generates parameter name metadata for web request handler methods annotated with @QueryParam, @PathParam, @HeaderParam, @CookieParam, or @FormParam.
WebParameterProcessor() - Constructor for class io.fluxcapacitor.javaclient.web.WebParameterProcessor
 
WebParameters - Class in io.fluxcapacitor.javaclient.web
Internal configuration holder used to expand the URI and method mappings of a web request handler method.
WebParameters() - Constructor for class io.fluxcapacitor.javaclient.web.WebParameters
 
WebParameterSource - Enum Class in io.fluxcapacitor.javaclient.web
Enumerates the sources of parameter values in an HTTP or WebSocket request.
WebParamParameterResolver - Class in io.fluxcapacitor.javaclient.web
Resolves method parameters in web handler methods based on meta-annotations derived from WebParam.
WebParamParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.web.WebParamParameterResolver
 
WebPattern - Class in io.fluxcapacitor.javaclient.web
Represents a pattern used to match incoming WebRequests to handler methods.
WebPattern() - Constructor for class io.fluxcapacitor.javaclient.web.WebPattern
 
WebPattern Matching - Search tag in class io.fluxcapacitor.javaclient.web.WebHandlerMatcher
Section
WebPayloadParameterResolver - Class in io.fluxcapacitor.javaclient.web
Resolves a method parameter from the payload of a WebRequest.
WebPayloadParameterResolver() - Constructor for class io.fluxcapacitor.javaclient.web.WebPayloadParameterResolver
 
WebRequest - Class in io.fluxcapacitor.javaclient.web
Represents a web request message within the Flux platform.
WebRequest(Message) - Constructor for class io.fluxcapacitor.javaclient.web.WebRequest
Constructs a new WebRequest instance using the provided Message.
WEBREQUEST - Enum constant in enum class io.fluxcapacitor.common.MessageType
A tracked web request routed to a handler via HTTP or WebSocket.
WebRequest.Builder - Class in io.fluxcapacitor.javaclient.web
Fluent builder for WebRequest.
WebRequestContext - Interface in io.fluxcapacitor.javaclient.web
Interface representing a context for handling web requests.
webRequestGateway() - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Returns the gateway for sending web requests.
WebRequestGateway - Interface in io.fluxcapacitor.javaclient.publishing
Gateway for sending outbound web requests via Flux Capacitor’s proxy mechanism.
WebRequestSettings - Class in io.fluxcapacitor.javaclient.web
Configuration settings for a WebRequest sent via the WebRequestGateway.
WebRequestSettings() - Constructor for class io.fluxcapacitor.javaclient.web.WebRequestSettings
 
WebResponse - Class in io.fluxcapacitor.javaclient.web
Represents a response to a WebRequest in the Flux platform.
WebResponse(Message) - Constructor for class io.fluxcapacitor.javaclient.web.WebResponse
Constructs a new WebResponse instance using the provided Message object.
WEBRESPONSE - Enum constant in enum class io.fluxcapacitor.common.MessageType
A response to a MessageType.WEBREQUEST, typically an HTTP or WebSocket reply.
WebResponse.Builder - Class in io.fluxcapacitor.javaclient.web
Fluent builder for WebResponse.
WebResponseCompressingInterceptor - Class in io.fluxcapacitor.javaclient.web
A DispatchInterceptor that applies GZIP compression to outgoing WebResponse messages based on request headers and response size.
WebResponseCompressingInterceptor() - Constructor for class io.fluxcapacitor.javaclient.web.WebResponseCompressingInterceptor
Creates a new interceptor with a default compression threshold of 2048 bytes.
WebResponseCompressingInterceptor(int) - Constructor for class io.fluxcapacitor.javaclient.web.WebResponseCompressingInterceptor
Creates a new interceptor with a custom compression threshold.
WebResponseGateway - Class in io.fluxcapacitor.javaclient.web
Specialized implementation of the ResultGateway interface for sending web response messages.
WebResponseGateway() - Constructor for class io.fluxcapacitor.javaclient.web.WebResponseGateway
 
webResponseMapper() - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorConfiguration
Mapper used for converting web handler return values into WebResponse objects.
WebResponseMapper - Interface in io.fluxcapacitor.javaclient.web
Specialization of ResponseMapper for mapping responses to WebResponse messages.
WebSocketClient - Class in io.fluxcapacitor.javaclient.configuration.client
A Client implementation that connects to the Flux Platform using WebSocket connections.
WebSocketClient() - Constructor for class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient
 
WebSocketClient.ClientConfig - Class in io.fluxcapacitor.javaclient.configuration.client
Configuration class for creating a WebSocketClient.
WebSocketClient.TrackingClientConfig - Class in io.fluxcapacitor.javaclient.configuration.client
Configuration for a tracking client assigned to a specific MessageType.
WebsocketDeploymentUtils - Class in io.fluxcapacitor.testserver.websocket
 
WebsocketDeploymentUtils() - Constructor for class io.fluxcapacitor.testserver.websocket.WebsocketDeploymentUtils
 
WebsocketEndpoint - Class in io.fluxcapacitor.proxy
 
WebsocketEndpoint - Class in io.fluxcapacitor.testserver.websocket
 
WebsocketEndpoint() - Constructor for class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
WebsocketEndpoint(Client) - Constructor for class io.fluxcapacitor.proxy.WebsocketEndpoint
 
WebsocketEndpoint(Executor) - Constructor for class io.fluxcapacitor.testserver.websocket.WebsocketEndpoint
 
WebsocketEndpoint.ClientMessage - Class in io.fluxcapacitor.testserver.websocket
 
WebsocketEndpoint.SessionBacklog - Class in io.fluxcapacitor.testserver.websocket
 
WebsocketEndpoint.SessionContext - Record Class in io.fluxcapacitor.proxy
 
WebSocketEventStoreClient - Class in io.fluxcapacitor.javaclient.persisting.eventsourcing.client
WebSocket-based implementation of the EventStoreClient, enabling interaction with the Flux Platform's event store via a persistent WebSocket connection.
WebSocketEventStoreClient(String, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Creates a new WebSocketEventStoreClient with a default batch size of 8192.
WebSocketEventStoreClient(URI, int, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Creates a new WebSocketEventStoreClient with a specified batch size.
WebSocketEventStoreClient(URI, int, WebSocketClient, boolean) - Constructor for class io.fluxcapacitor.javaclient.persisting.eventsourcing.client.WebSocketEventStoreClient
Constructs the WebSocket client with full customization.
WebsocketFilter - Class in io.fluxcapacitor.proxy
 
WebsocketFilter() - Constructor for class io.fluxcapacitor.proxy.WebsocketFilter
 
WebsocketGatewayClient - Class in io.fluxcapacitor.javaclient.publishing.client
A GatewayClient implementation that sends serialized messages to the Flux Platform over a WebSocket connection.
WebsocketGatewayClient(String, WebSocketClient, MessageType, String) - Constructor for class io.fluxcapacitor.javaclient.publishing.client.WebsocketGatewayClient
Constructs a new WebsocketGatewayClient instance using the specified parameters.
WebsocketGatewayClient(URI, WebSocketClient, MessageType, String, boolean) - Constructor for class io.fluxcapacitor.javaclient.publishing.client.WebsocketGatewayClient
Constructs a new WebsocketGatewayClient instance using the specified parameters.
WebsocketHandlerDecorator - Class in io.fluxcapacitor.javaclient.web
Decorator that adds WebSocket session support to handler classes and enables parameter injection for SocketSession.
WebsocketHandlerDecorator() - Constructor for class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
 
WebsocketKeyValueClient - Class in io.fluxcapacitor.javaclient.persisting.keyvalue.client
WebSocket-based implementation of the KeyValueClient interface for interacting with the Flux Platform.
WebsocketKeyValueClient(String, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.persisting.keyvalue.client.WebsocketKeyValueClient
Constructs a WebsocketKeyValueClient instance using the specified endpoint URL and WebSocket client.
WebsocketKeyValueClient(URI, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.persisting.keyvalue.client.WebsocketKeyValueClient
Constructs a WebsocketKeyValueClient instance with the provided WebSocket endpoint URI and client.
WebsocketKeyValueClient(URI, WebSocketClient, boolean) - Constructor for class io.fluxcapacitor.javaclient.persisting.keyvalue.client.WebsocketKeyValueClient
Constructs a new WebsocketKeyValueClient instance.
WebSocketRequest() - Constructor for class io.fluxcapacitor.javaclient.common.websocket.AbstractWebsocketClient.WebSocketRequest
 
WebsocketResponseInterceptor - Class in io.fluxcapacitor.javaclient.web
A DispatchInterceptor that modifies outgoing WebResponse messages in response to WebSocket-based WebRequests.
WebsocketResponseInterceptor() - Constructor for class io.fluxcapacitor.javaclient.web.WebsocketResponseInterceptor
 
WebsocketSchedulingClient - Class in io.fluxcapacitor.javaclient.scheduling.client
WebSocket-based implementation of the SchedulingClient interface that communicates with the Flux Platform.
WebsocketSchedulingClient(String, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.scheduling.client.WebsocketSchedulingClient
Constructs a scheduling client connected to the given endpoint URL.
WebsocketSchedulingClient(URI, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.scheduling.client.WebsocketSchedulingClient
Constructs a scheduling client connected to the given endpoint URI.
WebsocketSchedulingClient(URI, WebSocketClient, boolean) - Constructor for class io.fluxcapacitor.javaclient.scheduling.client.WebsocketSchedulingClient
Constructs a scheduling client connected to the given endpoint URI with an option to enable or disable metrics tracking.
WebSocketSearchClient - Class in io.fluxcapacitor.javaclient.persisting.search.client
WebSocket-based implementation of the SearchClient that connects to the Flux platform.
WebSocketSearchClient(String, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
WebSocketSearchClient(URI, WebSocketClient) - Constructor for class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
WebSocketSearchClient(URI, WebSocketClient, boolean) - Constructor for class io.fluxcapacitor.javaclient.persisting.search.client.WebSocketSearchClient
 
WebSocketTracker - Class in io.fluxcapacitor.common.tracking
 
WebSocketTracker(Read, MessageType, String, String, Consumer<MessageBatch>) - Constructor for class io.fluxcapacitor.common.tracking.WebSocketTracker
 
WebsocketTrackingClient - Class in io.fluxcapacitor.javaclient.tracking.client
WebSocket-based implementation of the TrackingClient that connects to the Flux platform.
WebsocketTrackingClient(String, WebSocketClient, MessageType, String) - Constructor for class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
WebsocketTrackingClient(URI, WebSocketClient, MessageType, String, boolean) - Constructor for class io.fluxcapacitor.javaclient.tracking.client.WebsocketTrackingClient
 
WebUtils - Class in io.fluxcapacitor.javaclient.web
Utility methods for working with web request and response data, including cookies, headers, and handler annotations.
WebUtils() - Constructor for class io.fluxcapacitor.javaclient.web.WebUtils
 
WebUtilsInternal - Class in io.fluxcapacitor.javaclient.web.internal
 
WebUtilsInternal() - Constructor for class io.fluxcapacitor.javaclient.web.internal.WebUtilsInternal
 
whenBatchCompletes(ThrowingConsumer<Throwable>) - Static method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
whenBatchCompletes(Throwable) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
whenHandlerCompletes(Throwable) - Method in class io.fluxcapacitor.javaclient.modeling.ModifiableAggregateRoot
 
whenHandlerCompletes(BiConsumer<Object, Throwable>) - Static method in class io.fluxcapacitor.javaclient.tracking.handling.Invocation
Registers a callback to be executed when the current handler invocation completes.
with(Metadata) - Method in class io.fluxcapacitor.common.api.Metadata
Creates a new instance of Metadata by combining the current metadata with the given metadata.
with(Object...) - Method in class io.fluxcapacitor.common.api.Metadata
Creates a new Metadata instance by adding the specified key-value pairs.
with(Object, Object) - Method in class io.fluxcapacitor.common.api.Metadata
Returns a new Metadata instance with the specified key-value pair added or updated in the current entries.
with(Map<?, ?>) - Method in class io.fluxcapacitor.common.api.Metadata
Returns a new Metadata instance that includes all the current entries and the mappings provided in the given map.
withActiveTracker(Tracker) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Marks the given tracker as actively processing messages.
withAggregateCache(Class<?>, Cache) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor.Builder
 
withAggregateCache(Class<?>, Cache) - Method in interface io.fluxcapacitor.javaclient.configuration.FluxCapacitorBuilder
Configures a dedicated cache for a specific aggregate type.
withClock(Clock) - Method in class io.fluxcapacitor.javaclient.configuration.DefaultFluxCapacitor
 
withClock(Clock) - Method in interface io.fluxcapacitor.javaclient.FluxCapacitor
Have Flux Capacitor use the given Clock when generating timestamps, e.g. when creating a Message.
withData(Data<byte[]>) - Method in class io.fluxcapacitor.common.api.SerializedMessage
 
withData(Data<byte[]>) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
withData(Data<T>) - Method in class io.fluxcapacitor.common.api.Data
Replaces this instance with another Data object.
withData(Data<T>) - Method in interface io.fluxcapacitor.common.api.SerializedObject
Returns a new SerializedObject with the given data object.
withEntity(Entity<?>) - Method in class io.fluxcapacitor.javaclient.modeling.DefaultEntityHelper.MessageWithEntity
 
wither() - Element in annotation interface io.fluxcapacitor.javaclient.modeling.Member
Optionally defines the name of a method that should be used to apply updates to the container of the nested entity.
withEventIndex(Long, String) - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
withEventIndex(Long, String) - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
withEventIndex(Long, String) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Updates the event index and message ID of the entity and returns the updated version of the entity.
withEventIndex(Long, String) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableAggregateRoot
 
withEventIndex(Long, String) - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
withGatewaySessions(MessageType, int) - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient.ClientConfig
Returns a new ClientConfig with a modified gateway session count for the specified message type.
withLastTrackerIndex(Long) - Method in interface io.fluxcapacitor.common.tracking.Tracker
Returns a copy of this tracker with its last index updated.
withMessageId(String) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new instance with the given message ID.
withMessageId(String) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
withMessageId(String) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
withMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
withMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new instance with the given metadata.
withMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
withMetadata(Metadata) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
without(Object) - Method in class io.fluxcapacitor.common.api.Metadata
Returns a new Metadata instance without the specified key.
withoutIf(Predicate<String>) - Method in class io.fluxcapacitor.common.api.Metadata
Returns a new instance of Metadata, excluding all entries where the provided predicate evaluates to true for the entry keys.
withoutTracker(Tracker) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Removes the tracker from the cluster.
withPaths(List<String>) - Method in class io.fluxcapacitor.common.api.search.constraints.ExistsConstraint
 
withPaths(List<String>) - Method in class io.fluxcapacitor.common.api.search.constraints.PathConstraint
 
withPayload(Object) - Method in class io.fluxcapacitor.javaclient.common.Message
Returns a new message instance with the provided payload and existing metadata, ID, and timestamp.
withPayload(Object) - Method in class io.fluxcapacitor.javaclient.common.serialization.DeserializingMessage
 
withPayload(Object) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new instance with the given payload.
withPayload(Object) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
withPayload(Object) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
withSequenceNumber(long) - Method in interface io.fluxcapacitor.javaclient.modeling.AggregateRoot
 
withSequenceNumber(long) - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
withSequenceNumber(long) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Returns an updated entity based on this with the specified sequence number.
withSequenceNumber(long) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableAggregateRoot
 
withSequenceNumber(long) - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
withTimestamp(Instant) - Method in class io.fluxcapacitor.javaclient.scheduling.Schedule
Returns a new instance with the given timestamp.
withTimestamp(Instant) - Method in class io.fluxcapacitor.javaclient.web.WebRequest
 
withTimestamp(Instant) - Method in class io.fluxcapacitor.javaclient.web.WebResponse
 
withTrace(Object, Object) - Method in class io.fluxcapacitor.common.api.Metadata
Adds a trace entry with the specified key and value to the metadata.
withTrackingConfig(MessageType, WebSocketClient.TrackingClientConfig) - Method in class io.fluxcapacitor.javaclient.configuration.client.WebSocketClient.ClientConfig
Returns a new ClientConfig with a modified tracking config for the specified message type.
withType(Class<T>) - Method in class io.fluxcapacitor.javaclient.modeling.DelegatingEntity
 
withType(Class<T>) - Method in interface io.fluxcapacitor.javaclient.modeling.Entity
Sets the type of the entity to the specified class and returns the updated entity.
withType(Class<T>) - Method in class io.fluxcapacitor.javaclient.modeling.ImmutableEntity
 
withType(Class<T>) - Method in class io.fluxcapacitor.javaclient.modeling.LazyAggregateRoot
 
withType(Class<T>) - Method in class io.fluxcapacitor.javaclient.modeling.NoOpEntity
 
withType(Class<T>) - Method in class io.fluxcapacitor.javaclient.modeling.SideEffectFreeEntity
 
withWaitingTracker(Tracker) - Method in class io.fluxcapacitor.common.tracking.TrackerCluster
Adds or updates the tracker as waiting (not currently processing).
withZone(ZoneId) - Method in class io.fluxcapacitor.common.DelegatingClock
 
wrap(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.scheduling.SchedulingInterceptor
 
wrap(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.authentication.AuthenticatingInterceptor
 
wrap(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.DocumentHandlerDecorator
 
wrap(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.tracking.handling.HandlerDecorator.MergedDecorator
 
wrap(Handler<DeserializingMessage>) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerDecorator
Wraps the given handler with additional behavior.
wrap(Handler<DeserializingMessage>) - Method in interface io.fluxcapacitor.javaclient.tracking.handling.HandlerInterceptor
Wraps a Handler with this interceptor, producing an intercepted handler.
wrap(Handler<DeserializingMessage>) - Method in class io.fluxcapacitor.javaclient.web.WebsocketHandlerDecorator
Wraps a websocket-compatible handler with websocket-specific functionality.
wrap(Object, Object) - Method in class io.fluxcapacitor.javaclient.persisting.caching.DefaultCache
 
Wrapper() - Constructor for class io.fluxcapacitor.javaclient.web.DefaultWebRequestContext.Wrapper
 
write(byte[], int, int) - Method in class io.fluxcapacitor.javaclient.web.OutputStreamCapturer
 
write(int) - Method in class io.fluxcapacitor.javaclient.web.OutputStreamCapturer
 
writeFile(String, String) - Static method in class io.fluxcapacitor.common.FileUtils
Writes a string to a file using UTF-8 encoding.
writeProperty(String, Object, Object) - Static method in class io.fluxcapacitor.common.reflection.ReflectionUtils
 
writer - Static variable in class io.fluxcapacitor.common.serialization.JsonUtils
Preconfigured JsonMapper for writing/serializing objects to JSON.
WS_CLOSE - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Represents an explicit closure of a WebSocket session.
WS_HANDSHAKE - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Synthetic method representing a WebSocket handshake (initial HTTP upgrade).
WS_MESSAGE - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Represents a message sent over an established WebSocket connection.
WS_OPEN - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Represents the WebSocket session being formally opened after handshake.
WS_PONG - Static variable in interface io.fluxcapacitor.javaclient.web.HttpRequestMethod
Represents a pong response received for a ping message.
A B C D E F G H I J K L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form