- AbstractAggregateFactory<T> - Class in org.axonframework.eventsourcing
-
Abstract AggregateFactory implementation that is aware of snapshot events.
- AbstractAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
-
Initialize an Aggregate Factory for the given aggregateBaseType
.
- AbstractAggregateFactory(AggregateModel<T>) - Constructor for class org.axonframework.eventsourcing.AbstractAggregateFactory
-
Initializes an Aggregate Factory for the given aggregateModel
.
- AbstractAnnotatedParameterResolverFactory<A extends Annotation,P> - Class in org.axonframework.messaging.annotation
-
ParameterResolverFactory that will supply a parameter resolver when a matching parameter annotation is paired
with a suitable type of parameter.
- AbstractAnnotatedParameterResolverFactory(Class<A>, Class<P>) - Constructor for class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-
Initialize a ParameterResolverFactory instance that resolves parameters of type
declaredParameterType
annotated with the given annotationType
.
- AbstractAnnotationHandlerBeanPostProcessor<I,T extends I> - Class in org.axonframework.spring.config
-
Abstract bean post processor that finds candidates for proxying.
- AbstractAnnotationHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
-
- AbstractCacheAdapter<L> - Class in org.axonframework.common.caching
-
Abstract implementation of the Cache interface which makes it easier to implement Adapters.
- AbstractCacheAdapter() - Constructor for class org.axonframework.common.caching.AbstractCacheAdapter
-
- AbstractChildEntityDefinition - Class in org.axonframework.modelling.command.inspection
-
Abstract implementation of the
ChildEntityDefinition
to provide reusable functionality for collections of
ChildEntityDefinitions.
- AbstractChildEntityDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
-
- AbstractCommandGateway - Class in org.axonframework.commandhandling.gateway
-
Abstract implementation of a CommandGateway, which handles the dispatch interceptors and retrying on failure.
- AbstractCommandGateway(AbstractCommandGateway.Builder) - Constructor for class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
- AbstractCommandGateway.Builder - Class in org.axonframework.commandhandling.gateway
-
- AbstractDeadlineManager - Class in org.axonframework.deadline
-
Abstract implementation of the
DeadlineManager
to be implemented by concrete solutions for the
DeadlineManager.
- AbstractDeadlineManager() - Constructor for class org.axonframework.deadline.AbstractDeadlineManager
-
- AbstractDomainEventEntry<T> - Class in org.axonframework.eventhandling
-
Abstract base class of a serialized domain event.
- AbstractDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.AbstractDomainEventEntry
-
Construct a new event entry from a published domain event message to enable storing the event or sending it to a
remote location.
- AbstractDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventhandling.AbstractDomainEventEntry
-
Reconstruct an event entry from a stored object.
- AbstractDomainEventEntry() - Constructor for class org.axonframework.eventhandling.AbstractDomainEventEntry
-
Default constructor required by JPA
- AbstractEventBus - Class in org.axonframework.eventhandling
-
Base class for the Event Bus.
- AbstractEventBus(AbstractEventBus.Builder) - Constructor for class org.axonframework.eventhandling.AbstractEventBus
-
- AbstractEventBus.Builder - Class in org.axonframework.eventhandling
-
- AbstractEventEntry<T> - Class in org.axonframework.eventhandling
-
Abstract base class of a serialized event.
- AbstractEventEntry(EventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.AbstractEventEntry
-
Construct a new event entry from a published event message to enable storing the event or sending it to a remote
location.
- AbstractEventEntry(String, Object, String, String, T, T) - Constructor for class org.axonframework.eventhandling.AbstractEventEntry
-
Reconstruct an event entry from a stored object.
- AbstractEventEntry() - Constructor for class org.axonframework.eventhandling.AbstractEventEntry
-
Default constructor required by JPA
- AbstractEventGateway - Class in org.axonframework.eventhandling.gateway
-
Abstract implementation of an EventGateway, which handles the dispatch interceptors.
- AbstractEventGateway(AbstractEventGateway.Builder) - Constructor for class org.axonframework.eventhandling.gateway.AbstractEventGateway
-
- AbstractEventGateway.Builder - Class in org.axonframework.eventhandling.gateway
-
- AbstractEventProcessor - Class in org.axonframework.eventhandling
-
- AbstractEventProcessor(AbstractEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.AbstractEventProcessor
-
- AbstractEventProcessor.Builder - Class in org.axonframework.eventhandling
-
- AbstractEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
-
Abstract
EventStorageEngine
implementation that takes care of event serialization and upcasting.
- AbstractEventStorageEngine(AbstractEventStorageEngine.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
- AbstractEventStorageEngine.Builder - Class in org.axonframework.eventsourcing.eventstore
-
- AbstractEventStore - Class in org.axonframework.eventsourcing.eventstore
-
- AbstractEventStore(AbstractEventStore.Builder) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- AbstractEventStore.Builder - Class in org.axonframework.eventsourcing.eventstore
-
- AbstractEventTableFactory - Class in org.axonframework.eventsourcing.eventstore.jdbc
-
Abstract implementation of an
EventTableFactory
that provides Jdbc "create table" statements compatible with
most databases.
- AbstractEventTableFactory() - Constructor for class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
- AbstractMessage<T> - Class in org.axonframework.messaging
-
Abstract base class for Messages.
- AbstractMessage(String) - Constructor for class org.axonframework.messaging.AbstractMessage
-
Initializes a new message with given identifier.
- AbstractMethodPropertyAccessStrategy - Class in org.axonframework.common.property
-
Abstract implementation of the PropertyAccessStrategy that uses a no-arg, public method to access the property
value.
- AbstractMethodPropertyAccessStrategy() - Constructor for class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-
- AbstractQualifiedBeanCondition - Class in org.axonframework.springboot.util
-
Abstract implementations for conditions that match against the availability of beans of a specific type with a
given qualifier.
- AbstractQualifiedBeanCondition(String, String, String) - Constructor for class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
-
Initialize the condition, looking for properties on a given annotation
- AbstractRepository<T,A extends Aggregate<T>> - Class in org.axonframework.modelling.command
-
Abstract implementation of the
Repository
that takes care of the dispatching of events when an aggregate is
persisted.
- AbstractRepository(AbstractRepository.Builder<T>) - Constructor for class org.axonframework.modelling.command.AbstractRepository
-
- AbstractRepository.Builder<T> - Class in org.axonframework.modelling.command
-
- AbstractResourceInjector - Class in org.axonframework.modelling.saga
-
Abstract implementation of a
ResourceInjector
for sagas that injects field and method resources.
- AbstractResourceInjector() - Constructor for class org.axonframework.modelling.saga.AbstractResourceInjector
-
- AbstractResponseType<R> - Class in org.axonframework.messaging.responsetypes
-
Abstract implementation of the
ResponseType
which contains
match functions for the majority of the
Type
options available.
- AbstractResponseType(Class<?>) - Constructor for class org.axonframework.messaging.responsetypes.AbstractResponseType
-
Instantiate a
ResponseType
with the given
expectedResponseType
as the type to be matched against and to which the query response should be
converted to, as is or as the contained type for an array/list/etc.
- AbstractRetryScheduler - Class in org.axonframework.commandhandling.gateway
-
- AbstractRetryScheduler(AbstractRetryScheduler.Builder) - Constructor for class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
-
- AbstractRetryScheduler.Builder<B extends AbstractRetryScheduler.Builder> - Class in org.axonframework.commandhandling.gateway
-
- AbstractRoutingStrategy - Class in org.axonframework.commandhandling.distributed
-
Abstract implementation of the RoutingStrategy interface that uses a policy to prescribe what happens when a routing
cannot be resolved.
- AbstractRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
-
Initializes the strategy using given unresolvedRoutingKeyPolicy
prescribing what happens when a
routing key cannot be resolved.
- AbstractSagaEntry<T> - Class in org.axonframework.modelling.saga.repository.jpa
-
Java Persistence Entity allowing sagas to be stored in a relational database.
- AbstractSagaEntry(Object, String, Serializer, Class<T>) - Constructor for class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
Constructs a new SagaEntry for the given saga
.
- AbstractSagaEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
Default constructor required by JPA.
- AbstractSagaManager<T> - Class in org.axonframework.modelling.saga
-
Abstract implementation of the SagaManager interface that provides basic functionality required by most SagaManager
implementations.
- AbstractSagaManager(AbstractSagaManager.Builder<T>) - Constructor for class org.axonframework.modelling.saga.AbstractSagaManager
-
- AbstractSagaManager.Builder<T> - Class in org.axonframework.modelling.saga
-
- AbstractSequencedDomainEventEntry<T> - Class in org.axonframework.eventhandling
-
Abstract base class of a serialized domain event.
- AbstractSequencedDomainEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.AbstractSequencedDomainEventEntry
-
Construct a new default domain event entry from a published domain event message to enable storing the event or
sending it to a remote location.
- AbstractSequencedDomainEventEntry() - Constructor for class org.axonframework.eventhandling.AbstractSequencedDomainEventEntry
-
Default constructor required by JPA
- AbstractSnapshotEventEntry<T> - Class in org.axonframework.eventsourcing.eventstore
-
Abstract base class of a serialized snapshot event storing the state of an aggregate.
- AbstractSnapshotEventEntry(DomainEventMessage<?>, Serializer, Class<T>) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
Construct a new event entry from a published domain event message to enable storing the event or sending it to a
remote location.
- AbstractSnapshotEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
Reconstruct an event entry from a stored object.
- AbstractSnapshotEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
Default constructor required by JPA
- AbstractSnapshotEventEntry.PK - Class in org.axonframework.eventsourcing.eventstore
-
Primary key definition of the AbstractEventEntry class.
- AbstractSnapshotter - Class in org.axonframework.eventsourcing
-
Abstract implementation of the
Snapshotter
that uses a task executor to
creates snapshots.
- AbstractSnapshotter(AbstractSnapshotter.Builder) - Constructor for class org.axonframework.eventsourcing.AbstractSnapshotter
-
- AbstractSnapshotter.Builder - Class in org.axonframework.eventsourcing
-
- AbstractTokenEntry<T> - Class in org.axonframework.eventhandling.tokenstore
-
Abstract base class of a JPA entry containing a serialized tracking token belonging to a given process.
- AbstractTokenEntry(TrackingToken, Serializer, Class<T>) - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Initializes a new token entry for given token
, process
and segment
.
- AbstractTokenEntry(T, String, String, String) - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Initializes a token entry from existing data.
- AbstractTokenEntry() - Constructor for class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Default constructor required for JPA
- AbstractUnitOfWork<T extends Message<?>> - Class in org.axonframework.messaging.unitofwork
-
Abstract implementation of the Unit of Work.
- AbstractUnitOfWork() - Constructor for class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- AbstractXStreamSerializer - Class in org.axonframework.serialization
-
Abstract implementation for XStream based serializers.
- AbstractXStreamSerializer(AbstractXStreamSerializer.Builder) - Constructor for class org.axonframework.serialization.AbstractXStreamSerializer
-
- AbstractXStreamSerializer.Builder - Class in org.axonframework.serialization
-
- accept(T) - Method in interface org.axonframework.test.eventscheduler.EventConsumer
-
Performs this operation on the given argument.
- accept(Field) - Method in class org.axonframework.test.matchers.AllFieldsFilter
-
- accept(Field) - Method in interface org.axonframework.test.matchers.FieldFilter
-
Indicates whether the given field
should be accepted for processing, or skipped/ignored.
- accept(Field) - Method in class org.axonframework.test.matchers.IgnoreField
-
- accept(Field) - Method in class org.axonframework.test.matchers.MatchAllFieldFilter
-
- accept(Field) - Method in class org.axonframework.test.matchers.NonStaticFieldsFilter
-
- accept(Field) - Method in class org.axonframework.test.matchers.NonTransientFieldsFilter
-
- AcceptAll - Enum in org.axonframework.commandhandling.distributed.commandfilter
-
A command filter that accepts all CommandMessages
- ACK_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- ACK_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- ACK_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- ACK_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- ACK_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- ACK_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- acquireAttempts(int) - Method in class org.axonframework.common.lock.PessimisticLockFactory.Builder
-
Indicates howmany attempts should be done to acquire a lock.
- activate() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-
Activates this lifecycle instance.
- ACTIVE_THREADS_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- ActiveGrpcChannelChecker - Class in org.axonframework.axonserver.connector.heartbeat.connection.checker
-
ConnectionSanityChecker
implementation that verifies if
the gRPC channel between client and Axon Server is connected.
- ActiveGrpcChannelChecker(AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.heartbeat.connection.checker.ActiveGrpcChannelChecker
-
- activeProcessorThreads() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Returns an approximation of the number of threads currently processing events.
- activeSubscriptions() - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
-
Provides the set of running subscription queries.
- ActivityHandle() - Constructor for class org.axonframework.lifecycle.ShutdownLatch.ActivityHandle
-
- actualVersion() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
-
The actual version of the loaded aggregate
- actualVersion() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
-
- add(AssociationValue) - Method in interface org.axonframework.modelling.saga.AssociationValues
-
Adds the given associationValue
, if it has not been previously added.
- add(AssociationValue) - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-
- add(AssociationValue, String, String) - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
-
Adds an association between the given associationValue
and sagaIdentifier
.
- addAlias(String, Class) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Adds an alias to use instead of the fully qualified class name.
- addAllBlacklist(Iterable<? extends PayloadDescription>) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- addAllColumn(Iterable<String>) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- addAllDetails(Iterable<String>) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- addAllIdValues(Iterable<? extends QueryValue>) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- addAllProcessingInstructions(Iterable<? extends ProcessingInstruction>) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- addAllProcessingInstructions(Iterable<? extends ProcessingInstruction>) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- addAllProcessingInstructions(Iterable<? extends ProcessingInstruction>) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- addAllProcessingInstructions(Iterable<? extends ProcessingInstruction>) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- addAllSegmentStatus(Iterable<? extends EventProcessorInfo.SegmentStatus>) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- addAllSortValues(Iterable<? extends QueryValue>) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- addBlacklist(PayloadDescription) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- addBlacklist(int, PayloadDescription) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- addBlacklist(PayloadDescription.Builder) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- addBlacklist(int, PayloadDescription.Builder) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- addBlacklistBuilder() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- addBlacklistBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- addCachedAssociations(Iterable<AssociationValue>, String, Class<?>) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore
-
Registers the associations of a saga with given sagaIdentifier
and given sagaType
with the
associations cache.
- addColumn(String) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- addColumnBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- addDetails(String) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- addDetailsBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- addDisconnectListener(String, Runnable) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Registers a disconnect listener which executes a given action
when the connection is disconnected for
given the context
.
- addDisconnectListener(Consumer<String>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Registers a disconnect listener which executes a given action
when a connection is disconnected.
- addedAssociations() - Method in interface org.axonframework.modelling.saga.AssociationValues
-
- addedAssociations() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-
- addFieldAlias(String, Class, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Adds an alias to use for a given field in the given class.
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Register the given handler
with the Unit of Work.
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- addHandler(UnitOfWork.Phase, Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Adds a handler to the collection.
- addIdValues(QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- addIdValues(int, QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- addIdValues(QueryValue.Builder) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- addIdValues(int, QueryValue.Builder) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- addIdValuesBuilder() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- addIdValuesBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- addMessageSource(String, StreamableMessageSource<TrackedEventMessage<?>>) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource.Builder
-
Adds a message source to the list of sources.
- addPackageAlias(String, String) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Add an alias for a package.
- addProcessingInstructions(ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- addProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- addProcessingInstructions(ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- addProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- addProcessingInstructions(ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- addProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- addProcessingInstructions(ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- addProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- addProcessingInstructions(ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- addProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- addProcessingInstructions(ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- addProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- addProcessingInstructions(ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- addProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- addProcessingInstructions(ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- addProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- addProcessingInstructionsBuilder() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- addProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- addProcessingInstructionsBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- addProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- addProcessingInstructionsBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- addProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- addProcessingInstructionsBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- addProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- addReconnectInterceptor(Function<Consumer<String>, Consumer<String>>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Registers an interceptor that may alter the behavior on an incoming "reconnect request" from the server.
- addReconnectListener(String, Runnable) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Registers a reconnect listener for the given context
that executes given action
when a
connection is re-established for the given context
.
- addReconnectListener(Consumer<String>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Registers a reconnect listener that executes given action
when a connection is re-established.
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- addSegmentStatus(EventProcessorInfo.SegmentStatus) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- addSegmentStatus(int, EventProcessorInfo.SegmentStatus) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- addSegmentStatus(EventProcessorInfo.SegmentStatus.Builder) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- addSegmentStatus(int, EventProcessorInfo.SegmentStatus.Builder) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- addSegmentStatusBuilder() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- addSegmentStatusBuilder(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- addSortValues(QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- addSortValues(int, QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- addSortValues(QueryValue.Builder) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- addSortValues(int, QueryValue.Builder) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- addSortValuesBuilder() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- addSortValuesBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- advancedTo(TrackingToken) - Method in class org.axonframework.eventhandling.MergedTrackingToken
-
- advancedTo(String, TrackingToken) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
-
Advances a single token within the tokenMap
- advancedTo(TrackingToken) - Method in class org.axonframework.eventhandling.ReplayToken
-
- advancedTo(TrackingToken) - Method in interface org.axonframework.eventhandling.WrappedToken
-
Advance this token to the given newToken
.
- advanceTimeBy(Duration, DeadlineConsumer) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
Advances time by the given duration
and invokes the given deadlineConsumer
for each deadline
scheduled until that time.
- advanceTimeBy(Duration, EventConsumer<EventMessage<?>>) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
Advance time by the given duration
and invokes the given eventConsumer
for each
event scheduled for publication until that time.
- advanceTimeTo(Instant, DeadlineConsumer) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
Advances time to the given newDateTime
and invokes the given deadlineConsumer
for each deadline
scheduled until that time.
- advanceTimeTo(Instant, EventConsumer<EventMessage<?>>) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
Advance time to the given newDateTime
and invokes the given eventConsumer
for each
event scheduled for publication until that time.
- advanceTo(long, int) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
-
- advanceToNextTrigger() - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
Advances the "current time" of the manager to the next scheduled deadline, and returns that deadline.
- advanceToNextTrigger() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
Advances the "current time" of the scheduler to the next scheduled Event, and returns that event.
- afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
Process given events
after the Unit of Work has been committed.
- afterCommit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-
- afterCommit(Consumer<UnitOfWork<T>>) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- afterCommit(Consumer<UnitOfWork<T>>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Register given handler
with the Unit of Work.
- afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
- afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
- afterPropertiesSet() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
-
- afterPropertiesSet() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- afterPropertiesSet() - Method in class org.axonframework.spring.config.EventHandlerRegistrar
-
- afterPropertiesSet() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- afterPropertiesSet() - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-
- afterPropertiesSet() - Method in class org.axonframework.spring.messaging.ApplicationContextEventPublisher
-
- afterPropertiesSet() - Method in class org.axonframework.spring.messaging.OutboundEventMessageChannelAdapter
-
Subscribes this event listener to the event bus.
- afterShutdown(EventProcessorTask) - Method in interface org.axonframework.eventhandling.async.EventProcessorTask.ShutdownCallback
-
Called when event processing is complete.
- Aggregate<T> - Interface in org.axonframework.modelling.command
-
Interface that describes an aggregate.
- Aggregate - Annotation Type in org.axonframework.spring.stereotype
-
Annotation that informs Axon's auto configurer for Spring that a given Component
is an aggregate instance.
- AGGREGATE_ID - Static variable in class org.axonframework.messaging.Headers
-
Key pointing to the aggregate identifier of a message.
- AGGREGATE_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- AGGREGATE_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
- AGGREGATE_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
- AGGREGATE_IDENTIFIER_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.Event
-
- AGGREGATE_SEQ - Static variable in class org.axonframework.messaging.Headers
-
Key pointing to the aggregate sequence of a message.
- AGGREGATE_SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.Event
-
- AGGREGATE_TYPE - Static variable in class org.axonframework.messaging.Headers
-
Key pointing to the aggregate type of a message.
- AGGREGATE_TYPE_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.Event
-
- AggregateAnnotationCommandHandler<T> - Class in org.axonframework.modelling.command
-
Command handler that handles commands based on
CommandHandler
annotations on an aggregate.
- AggregateAnnotationCommandHandler(AggregateAnnotationCommandHandler.Builder<T>) - Constructor for class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
-
- AggregateAnnotationCommandHandler.Builder<T> - Class in org.axonframework.modelling.command
-
- AggregateBlacklistedException - Exception in org.axonframework.disruptor.commandhandling
-
Exception indicating that an aggregate has been blacklisted by the DisruptorCommandBus.
- AggregateBlacklistedException(String, String, Throwable) - Constructor for exception org.axonframework.disruptor.commandhandling.AggregateBlacklistedException
-
Initializes the exception with given aggregateIdentifier
, given explanatory message
and cause
.
- AggregateCacheEntry<T> - Class in org.axonframework.eventsourcing
-
- AggregateCacheEntry(EventSourcedAggregate<T>) - Constructor for class org.axonframework.eventsourcing.AggregateCacheEntry
-
- AggregateConfiguration<A> - Interface in org.axonframework.config
-
Specialization of the Module Configuration for modules that define an Aggregate Configuration.
- AggregateConfigurer<A> - Class in org.axonframework.config
-
Axon Configuration API extension that allows the definition of an Aggregate.
- AggregateConfigurer(Class<A>) - Constructor for class org.axonframework.config.AggregateConfigurer
-
- AggregateCreationPolicy - Enum in org.axonframework.modelling.command
-
Enumeration containing the possible creation policies for aggregates.
- AggregateDeletedException - Exception in org.axonframework.eventsourcing
-
Special case of the
AggregateNotFoundException
that indicates that historic
information of an aggregate was found, but the aggregate has been deleted.
- AggregateDeletedException(String, String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
-
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier
and
given message
.
- AggregateDeletedException(String) - Constructor for exception org.axonframework.eventsourcing.AggregateDeletedException
-
Initialize a AggregateDeletedException for an aggregate identifier by given aggregateIdentifier
and
a default message
.
- AggregateEntityNotFoundException - Exception in org.axonframework.modelling.command
-
Exception indicating that the an entity for an aggregate could not be found.
- AggregateEntityNotFoundException(String) - Constructor for exception org.axonframework.modelling.command.AggregateEntityNotFoundException
-
Initialize a AggregateEntityNotFoundException with given message
.
- AggregateEntityNotFoundException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateEntityNotFoundException
-
Initialize a AggregateEntityNotFoundException with given message
and cause
.
- aggregateFactories(AggregateFactory<?>...) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
-
Sets the aggregateFactories
supported by this snapshotter.
- aggregateFactories(List<AggregateFactory<?>>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter.Builder
-
Sets the aggregateFactories
supported by this snapshotter.
- AggregateFactory<T> - Interface in org.axonframework.eventsourcing
-
Interface describing objects capable of creating instances of aggregates to be initialized with an event stream.
- aggregateFactory(AggregateFactory<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-
- aggregateIdentifier() - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictDescription
-
The identifier of the conflicting aggregate, as a String.
- aggregateIdentifier() - Method in class org.axonframework.eventsourcing.conflictresolution.DefaultConflictDescription
-
- AggregateIdentifier - Annotation Type in org.axonframework.modelling.command
-
Field annotation that identifies the field containing the identifier of the Aggregate.
- aggregateIdentifierColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the aggregate identifier of the event.
- aggregateIdentifierColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
-
Sets the name of the event identifier column.
- AggregateInvocationException - Exception in org.axonframework.modelling.command
-
Exception thrown when an invocation on a method of an aggregate gives rise to an exception.
- AggregateInvocationException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateInvocationException
-
Initializes the exception using the given message
and cause
.
- AggregateLifecycle - Class in org.axonframework.modelling.command
-
Abstract base class of a component that models an aggregate's life cycle.
- AggregateLifecycle() - Constructor for class org.axonframework.modelling.command.AggregateLifecycle
-
- AggregateMember - Annotation Type in org.axonframework.modelling.command
-
Marker annotation for a field that references one or more Entities capable of handling Commands or Events.
- AggregateMemberAnnotatedChildEntityCollectionDefinition - Class in org.axonframework.modelling.command.inspection
-
- AggregateMemberAnnotatedChildEntityCollectionDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityCollectionDefinition
-
- AggregateMemberAnnotatedChildEntityDefinition - Class in org.axonframework.modelling.command.inspection
-
- AggregateMemberAnnotatedChildEntityDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityDefinition
-
- AggregateMemberAnnotatedChildEntityMapDefinition - Class in org.axonframework.modelling.command.inspection
-
- AggregateMemberAnnotatedChildEntityMapDefinition() - Constructor for class org.axonframework.modelling.command.inspection.AggregateMemberAnnotatedChildEntityMapDefinition
-
- AggregateMetaModelFactory - Interface in org.axonframework.modelling.command.inspection
-
Interface of a factory for an
AggregateModel
for any given type defining an aggregate.
- aggregateModel() - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
Gets the aggregate model.
- aggregateModel(AggregateModel<T>) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-
- aggregateModel() - Method in class org.axonframework.modelling.command.AbstractRepository
-
Returns the aggregate model stored by this repository.
- aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.AbstractRepository.Builder
-
- aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
-
- aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.GenericJpaRepository.Builder
-
- AggregateModel<T> - Interface in org.axonframework.modelling.command.inspection
-
Specialized EntityModel that describes the capabilities and properties of an aggregate root of type T
.
- aggregateModel(AggregateModel<T>) - Method in class org.axonframework.modelling.command.LockingRepository.Builder
-
- AggregateModellingException - Exception in org.axonframework.modelling.command.inspection
-
Thrown if an aggregate model is invalid.
- AggregateModellingException(String) - Constructor for exception org.axonframework.modelling.command.inspection.AggregateModellingException
-
Constructs this exception with given message
explaining the cause.
- AggregateNotFoundException - Exception in org.axonframework.modelling.command
-
Exception indicating that the an aggregate could not be found in the repository.
- AggregateNotFoundException(String, String) - Constructor for exception org.axonframework.modelling.command.AggregateNotFoundException
-
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier
and given message
.
- AggregateNotFoundException(String, String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateNotFoundException
-
Initialize a AggregateNotFoundException for an aggregate identifier by given aggregateIdentifier
and
with the given message
and cause
.
- AggregateRolledBackException - Exception in org.axonframework.modelling.command
-
Exception indicating that an aggregate has been part of a Unit of Work that was rolled back and that the validity of
its state cannot be guaranteed.
- AggregateRolledBackException(String) - Constructor for exception org.axonframework.modelling.command.AggregateRolledBackException
-
Initialize the exception for an aggregate with given aggregateIdentifier
.
- AggregateRoot - Annotation Type in org.axonframework.modelling.command
-
Annotation placed on types that should be treated as the root of an aggregate.
- AggregateScopeDescriptor - Class in org.axonframework.commandhandling.model
-
- AggregateScopeDescriptor(String, Object) - Constructor for class org.axonframework.commandhandling.model.AggregateScopeDescriptor
-
Deprecated.
Instantiate a AggregateScopeDescriptor with the provided type
and identifier
.
- AggregateScopeDescriptor - Class in org.axonframework.modelling.command
-
Describes the scope of an Aggregate by means of its type and identifier.
- AggregateScopeDescriptor(String, Supplier<Object>) - Constructor for class org.axonframework.modelling.command.AggregateScopeDescriptor
-
Instantiate an AggregateScopeDescriptor with a type
and identifierSupplier
.
- AggregateScopeDescriptor(String, Object) - Constructor for class org.axonframework.modelling.command.AggregateScopeDescriptor
-
Instantiate an AggregateScopeDescriptor with the provided type
and identifier
.
- AggregateSnapshotter - Class in org.axonframework.eventsourcing
-
Implementation of a snapshotter that uses the actual aggregate and its state to create a snapshot event.
- AggregateSnapshotter(AggregateSnapshotter.Builder) - Constructor for class org.axonframework.eventsourcing.AggregateSnapshotter
-
- aggregateSnapshotter(Configuration, HandlerDefinition, ParameterResolverFactory, EventStore, TransactionManager) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-
- AggregateSnapshotter.Builder - Class in org.axonframework.eventsourcing
-
- AggregateStateCorruptedException - Exception in org.axonframework.disruptor.commandhandling
-
Exception indicating that the changes in an aggregate (generated events) are ignored by the DisruptorCommandBus,
because it cannot guarantee that these changes have been applied to an aggregate instance with the correct state.
- AggregateStateCorruptedException(String, String) - Constructor for exception org.axonframework.disruptor.commandhandling.AggregateStateCorruptedException
-
Initializes the exception with given aggregateIdentifier
and given explanatory
message
.
- AggregateStateCorruptedException(String, String, Throwable) - Constructor for exception org.axonframework.disruptor.commandhandling.AggregateStateCorruptedException
-
Initializes the exception with given aggregateIdentifier
, given explanatory message
and cause
.
- AggregateStreamCreationException - Exception in org.axonframework.modelling.command
-
Exception indicating that concurrent access to a repository was detected.
- AggregateStreamCreationException(String) - Constructor for exception org.axonframework.modelling.command.AggregateStreamCreationException
-
Initialize the exception with the given message
.
- AggregateStreamCreationException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.AggregateStreamCreationException
-
Initialize the exception with the given message
and cause
- AggregateTestFixture<T> - Class in org.axonframework.test.aggregate
-
A test fixture that allows the execution of given-when-then style test cases.
- AggregateTestFixture(Class<T>) - Constructor for class org.axonframework.test.aggregate.AggregateTestFixture
-
Initializes a new given-when-then style test fixture for the given aggregateType
.
- aggregateType() - Method in interface org.axonframework.config.AggregateConfiguration
-
Returns the type of Aggregate defined in this Configuration.
- aggregateType() - Method in class org.axonframework.config.AggregateConfigurer
-
- aggregateType - Variable in class org.axonframework.modelling.command.AbstractRepository.Builder
-
- aggregateType(Class<T>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
-
Sets the
aggregateType
as a
Class
, specifying the type of aggregate an
AggregateModel
should be created for.
- AggregateVersion - Annotation Type in org.axonframework.modelling.command
-
Field annotation that indicates the field contains the value that represents the version of the Aggregate, used for
optimistic locking, as well as state validation for commands.
- allCommandHandlerInterceptors() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
Gets all command handler interceptors per type in this aggregate hierarchy.
- allCommandHandlers() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
Gets all command handlers per type in this aggregate hierarchy.
- allEventHandlers() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
Gets all event handlers per type in this aggregate hierarchy.
- AllFieldsFilter - Class in org.axonframework.test.matchers
-
FieldFilter implementation that accepts all Fields.
- ALLOW_SNAPSHOTS_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- AllowReplay - Annotation Type in org.axonframework.eventhandling
-
Annotation marking a Handler (or class) as being capable of handling replays, or not, depending on the value
passed.
- and(CommandMessageFilter) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.AcceptAll
-
- and(CommandMessageFilter) - Method in class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-
- and(CommandMessageFilter) - Method in enum org.axonframework.commandhandling.distributed.commandfilter.DenyAll
-
- and(CommandMessageFilter) - Method in class org.axonframework.commandhandling.distributed.commandfilter.DenyCommandNameFilter
-
- and(CommandMessageFilter) - Method in interface org.axonframework.commandhandling.distributed.CommandMessageFilter
-
Returns a filter that matches when both this instance and the given other
match.
- and(String, Object) - Method in class org.axonframework.messaging.MetaData
-
Returns a MetaData instances containing the current entries, and the given key
and given
value
.
- andBatchSize(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
- AndCommandMessageFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
-
Filter that matches whenever both supplied filters match
- AndCommandMessageFilter(CommandMessageFilter, CommandMessageFilter) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.AndCommandMessageFilter
-
Initialize the filter to match when both the first
and the second
filter match.
- andEventAvailabilityTimeout(long, TimeUnit) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
Set the duration where a Tracking Processor will wait for the availability of Events, in each cycle, before
extending the claim on the tokens it owns.
- andGiven(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- andGiven(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- andGiven(Object...) - Method in interface org.axonframework.test.aggregate.TestExecutor
-
Configures the given domainEvents
as the "given" events.
- andGiven(List<?>) - Method in interface org.axonframework.test.aggregate.TestExecutor
-
Configures the given domainEvents
as the "given" events.
- andGivenCommands(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- andGivenCommands(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- andGivenCommands(Object...) - Method in interface org.axonframework.test.aggregate.TestExecutor
-
Configures the given commands
as the command that will provide the "given" events.
- andGivenCommands(List<?>) - Method in interface org.axonframework.test.aggregate.TestExecutor
-
Configures the given commands
as the command that will provide the "given" events.
- andGivenCurrentTime(Instant) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- andGivenCurrentTime(Instant) - Method in interface org.axonframework.test.aggregate.TestExecutor
-
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start
of the given state.
- andIfNotPresent(String, Supplier<Object>) - Method in class org.axonframework.messaging.MetaData
-
Returns a MetaData instances containing the current entries, and the given key
if it was
not yet present in this MetaData.
- andInitialSegmentsCount(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
- andInitialTrackingToken(Function<StreamableMessageSource<TrackedEventMessage<?>>, TrackingToken>) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
Sets the Builder to use to create the initial tracking token.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandMessage
-
Returns a copy of this CommandMessage with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.commandhandling.CommandResultMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.commandhandling.GenericCommandResultMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.deadline.DeadlineMessage
-
Returns a copy of this DeadlineMessage with its MetaData merged with given additionalMetaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.deadline.GenericDeadlineMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.DomainEventMessage
-
Returns a copy of this DomainEventMessage with its MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.eventhandling.EventMessage
-
Returns a copy of this EventMessage with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.AbstractMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.GenericResultMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.Message
-
Returns a copy of this Message with it MetaData merged with the given metaData
.
- andMetaData(Map<String, ?>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.messaging.ResultMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericQueryResponseMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
-
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.QueryMessage
-
Returns a copy of this QueryMessage with its MetaData merged with given metaData
.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.QueryResponseMessage
-
Returns a copy of this QueryResponseMessage with its MetaData merged with given metaData
.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.SubscriptionQueryMessage
-
Returns a copy of this SubscriptionQueryMessage with its MetaData merged with given metaData
.
- andMetaData(Map<String, ?>) - Method in interface org.axonframework.queryhandling.SubscriptionQueryUpdateMessage
-
- andMetaData(Map<String, ?>) - Method in class org.axonframework.serialization.SerializedMessage
-
- andNoMore() - Static method in class org.axonframework.test.matchers.Matchers
-
Matches against null
or void
.
- andThen(Runnable) - Method in interface org.axonframework.modelling.command.ApplyMore
-
Execute the given runnable
after applying the previous event.
- andThen(Runnable) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
- andThenAggregate(String) - Method in interface org.axonframework.test.saga.ContinuedGivenState
-
Use this method to indicate that an aggregate with given identifier published certain events.
- andThenAggregate(String) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- andThenApply(Supplier<?>) - Method in interface org.axonframework.modelling.command.ApplyMore
-
Apply a subsequent event to the aggregate after applying another event.
- andThenApply(Supplier<?>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
- andThenAPublished(Object) - Method in interface org.axonframework.test.saga.ContinuedGivenState
-
Indicates that the given event
has been published in the past.
- andThenAPublished(Object, Map<String, ?>) - Method in interface org.axonframework.test.saga.ContinuedGivenState
-
Indicates that the given event
with given metaData
has been published in the past.
- andThenAPublished(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- andThenAPublished(Object, Map<String, ?>) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- andThenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.aggregate.TestExecutor
-
- andThenTimeAdvancesTo(Instant) - Method in interface org.axonframework.test.saga.ContinuedGivenState
-
Simulate time shifts in the current given state.
- andThenTimeAdvancesTo(Instant) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- andThenTimeElapses(Duration) - Method in interface org.axonframework.test.aggregate.TestExecutor
-
- andThenTimeElapses(Duration) - Method in interface org.axonframework.test.saga.ContinuedGivenState
-
Simulate time shifts in the current given state.
- andThenTimeElapses(Duration) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- andThreadFactory(Function<String, ThreadFactory>) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
Sets the ThreadFactory to use to create the threads to process events on.
- andTokenClaimInterval(long, TimeUnit) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
Sets the time to wait after a failed attempt to claim any token, before making another attempt.
- AnnotatedAggregate<T> - Class in org.axonframework.modelling.command.inspection
-
Implementation of the
Aggregate
interface that allows for an aggregate root to be a POJO with annotations on
its Command and Event Handler methods.
- AnnotatedAggregate(T, AggregateModel<T>, EventBus) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
Initialize an Aggregate instance for the given aggregateRoot
, described by the given
aggregateModel
that will publish events to the given eventBus
.
- AnnotatedAggregate(T, AggregateModel<T>, EventBus, RepositoryProvider) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
Initialize an Aggregate instance for the given aggregateRoot
, described by the given
aggregateModel
that will publish events to the given eventBus
.
- AnnotatedAggregate(AggregateModel<T>, EventBus) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
Initialize an Aggregate instance for the given aggregateRoot
, described by the given
aggregateModel
that will publish events to the given eventBus
.
- AnnotatedAggregate(AggregateModel<T>, EventBus, RepositoryProvider) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
Initialize an Aggregate instance for the given aggregateRoot
, described by the given
aggregateModel
that will publish events to the given eventBus
.
- AnnotatedAggregateMetaModelFactory - Class in org.axonframework.modelling.command.inspection
-
AggregateMetaModelFactory implementation that uses annotations on the target aggregate's members to build up the
meta model of the aggregate.
- AnnotatedAggregateMetaModelFactory() - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
-
Initializes an instance which uses the default, classpath based, ParameterResolverFactory to detect parameters
for annotated handlers.
- AnnotatedAggregateMetaModelFactory(ParameterResolverFactory) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
-
Initializes an instance which uses the given parameterResolverFactory
to detect parameters for
annotated handlers.
- AnnotatedAggregateMetaModelFactory(ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
-
Initializes an instance which uses the given parameterResolverFactory
to detect parameters for
annotated handlers and handlerDefinition
to create concrete handlers.
- AnnotatedChildEntity<P,C> - Class in org.axonframework.modelling.command.inspection
-
Implementation of a
ChildEntity
that uses annotations on a target entity to resolve event and command
handlers.
- AnnotatedChildEntity(EntityModel<C>, boolean, BiFunction<CommandMessage<?>, P, C>, BiFunction<EventMessage<?>, P, Stream<C>>) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedChildEntity
-
Initiates a new AnnotatedChildEntity instance that uses the provided entityModel
to delegate command
and event handling to an annotated child entity.
- AnnotatedCommandHandlerInterceptor<T> - Class in org.axonframework.modelling.command.inspection
-
Annotated command handler interceptor on aggregate.
- AnnotatedCommandHandlerInterceptor(MessageHandlingMember<T>, T) - Constructor for class org.axonframework.modelling.command.inspection.AnnotatedCommandHandlerInterceptor
-
Initializes annotated command handler interceptor with delegate handler and target on which handler is to be
invoked.
- AnnotatedHandlerInspector<T> - Class in org.axonframework.messaging.annotation
-
Inspector for a message handling target of type T
that uses annotations on the target to inspect the
capabilities of the target.
- AnnotatedMessageHandlingMember<T> - Class in org.axonframework.messaging.annotation
-
Implementation of a
MessageHandlingMember
that is used to invoke message handler methods on the target type.
- AnnotatedMessageHandlingMember(Executable, Class<? extends Message>, Class<?>, ParameterResolverFactory) - Constructor for class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
Initializes a new instance that will invoke the given executable
(method) on a target to handle a message
of the given messageType
.
- AnnotatedMessageHandlingMemberDefinition - Class in org.axonframework.messaging.annotation
-
The default HandlerDefinition implementation in Axon.
- AnnotatedMessageHandlingMemberDefinition() - Constructor for class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
-
- AnnotatedSaga<T> - Class in org.axonframework.modelling.saga
-
Implementation of the
interface
that allows for a POJO instance with annotated message handlers to act
as a Saga.
- AnnotatedSaga(String, Set<AssociationValue>, T, SagaModel<T>) - Constructor for class org.axonframework.modelling.saga.AnnotatedSaga
-
Creates an AnnotatedSaga instance to wrap the given annotatedSaga
, identifier with the given
sagaId
and associated with the given associationValues
.
- AnnotatedSagaManager<T> - Class in org.axonframework.modelling.saga
-
Implementation of the SagaManager that uses annotations on the Sagas to describe the lifecycle management.
- AnnotatedSagaManager(AnnotatedSagaManager.Builder<T>) - Constructor for class org.axonframework.modelling.saga.AnnotatedSagaManager
-
- AnnotatedSagaManager.Builder<T> - Class in org.axonframework.modelling.saga
-
- AnnotatedSagaRepository<T> - Class in org.axonframework.modelling.saga.repository
-
- AnnotatedSagaRepository(AnnotatedSagaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
-
- AnnotatedSagaRepository.Builder<T> - Class in org.axonframework.modelling.saga.repository
-
- annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
- annotationAttributes(Class<? extends Annotation>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
-
Get the attributes of an annotation of given annotationType
on the method of the target entity.
- annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-
- annotationAttributes(Class<? extends Annotation>) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-
- AnnotationCommandHandlerAdapter<T> - Class in org.axonframework.commandhandling
-
- AnnotationCommandHandlerAdapter(T) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
Wraps the given annotatedCommandHandler
, allowing it to be subscribed to a Command Bus.
- AnnotationCommandHandlerAdapter(T, ParameterResolverFactory) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
Wraps the given annotatedCommandHandler
, allowing it to be subscribed to a Command Bus.
- AnnotationCommandHandlerAdapter(T, ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
Wraps the given annotatedCommandHandler
, allowing it to be subscribed to a Command Bus.
- AnnotationCommandHandlerBeanPostProcessor - Class in org.axonframework.spring.config.annotation
-
Spring Bean post processor that automatically generates an adapter for each bean containing
CommandHandler
annotated methods.
- AnnotationCommandHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
-
- AnnotationCommandTargetResolver - Class in org.axonframework.modelling.command
-
CommandTargetResolver that uses annotations on the command to identify the methods that provide the
Aggregate Identifier of the targeted Aggregate and optionally the expected version of the aggregate.
- AnnotationCommandTargetResolver() - Constructor for class org.axonframework.modelling.command.AnnotationCommandTargetResolver
-
- AnnotationCommandTargetResolver(AnnotationCommandTargetResolver.Builder) - Constructor for class org.axonframework.modelling.command.AnnotationCommandTargetResolver
-
- AnnotationCommandTargetResolver.Builder - Class in org.axonframework.modelling.command
-
- AnnotationDriven - Annotation Type in org.axonframework.spring.config
-
Annotation for
@Configuration
that will automatically
subscribe
@CommandHandler
and
@QueryHandler
annotated beans with the
CommandBus and QueryBus, respectively.
- AnnotationDrivenRegistrar - Class in org.axonframework.spring.config
-
Spring @Configuration related class that adds Axon Annotation PostProcessors to the BeanDefinitionRegistry.
- AnnotationDrivenRegistrar() - Constructor for class org.axonframework.spring.config.AnnotationDrivenRegistrar
-
- AnnotationEventHandlerAdapter - Class in org.axonframework.eventhandling
-
- AnnotationEventHandlerAdapter(Object) - Constructor for class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-
Wraps the given annotatedEventListener
, allowing it to be subscribed to an Event Bus.
- AnnotationEventHandlerAdapter(Object, ParameterResolverFactory) - Constructor for class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-
Wraps the given annotatedEventListener
, allowing it to be subscribed to an Event Bus.
- AnnotationEventHandlerAdapter(Object, ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-
Wraps the given annotatedEventListener
, allowing it to be subscribed to an Event Bus.
- AnnotationQueryHandlerAdapter<T> - Class in org.axonframework.queryhandling.annotation
-
- AnnotationQueryHandlerAdapter(T) - Constructor for class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
-
Initializes the adapter, forwarding call to the given target
.
- AnnotationQueryHandlerAdapter(T, ParameterResolverFactory) - Constructor for class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
-
Initializes the adapter, forwarding call to the given target
, resolving parameters using the given
parameterResolverFactory
.
- AnnotationQueryHandlerAdapter(T, ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
-
Initializes the adapter, forwarding call to the given target
, resolving parameters using the given
parameterResolverFactory
and creating handlers using handlerDefinition
.
- AnnotationQueryHandlerBeanPostProcessor - Class in org.axonframework.spring.config.annotation
-
Spring Bean post processor that automatically generates an adapter for each bean containing
QueryHandler
annotated methods.
- AnnotationQueryHandlerBeanPostProcessor() - Constructor for class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
-
- AnnotationRevisionResolver - Class in org.axonframework.serialization
-
Revision Resolver implementation that checks for the presence of an
@Revision
annotation.
- AnnotationRevisionResolver() - Constructor for class org.axonframework.serialization.AnnotationRevisionResolver
-
- AnnotationRoutingStrategy - Class in org.axonframework.commandhandling.distributed
-
RoutingStrategy that expects an
RoutingKey
(meta-)annotation on the command
message's payload.
- AnnotationRoutingStrategy() - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that fails when an incoming command does not define a field as the
RoutingKey
to base the routing on.
- AnnotationRoutingStrategy(Class<? extends Annotation>) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier.
- AnnotationRoutingStrategy(UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that uses the given
unresolvedRoutingKeyPolicy
when an incoming
command does not define a
RoutingKey
annotated field to base the routing on.
- AnnotationRoutingStrategy(Class<? extends Annotation>, UnresolvedRoutingKeyPolicy) - Constructor for class org.axonframework.commandhandling.distributed.AnnotationRoutingStrategy
-
Initializes a Routing Strategy that uses the given annotation to resolve the targeted identifier and the given
unresolvedRoutingKeyPolicy
when an incoming command does not define an Identifier to base the routing key
on.
- AnnotationSagaMetaModelFactory - Class in org.axonframework.modelling.saga.metamodel
-
- AnnotationSagaMetaModelFactory() - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
-
- AnnotationSagaMetaModelFactory(ParameterResolverFactory) - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
-
- AnnotationSagaMetaModelFactory(ParameterResolverFactory, HandlerDefinition) - Constructor for class org.axonframework.modelling.saga.metamodel.AnnotationSagaMetaModelFactory
-
- AnnotationUtils - Class in org.axonframework.common.annotation
-
Utility class for locating annotations and attribute values on elements.
- append(Event) - Method in class org.axonframework.axonserver.connector.event.AppendEventTransaction
-
- appendEvent(StreamObserver<Confirmation>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreImplBase
-
Accepts a stream of Events returning a Confirmation when completed.
- appendEvent(StreamObserver<Confirmation>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreStub
-
Accepts a stream of Events returning a Confirmation when completed.
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Append given events
to the backing database.
- appendEvents(EventMessage<?>...) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Append one or more events to the event storage.
- appendEvents(List<? extends EventMessage<?>>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Append a list of events to the event storage.
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- appendEvents(Connection, List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- appendEvents(AppendEventsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- appendEvents(Connection, EventSchema, Class<?>, List<? extends EventMessage<?>>, Serializer, TimestampWriter) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
-
- appendEvents(List<? extends EventMessage<?>>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- appendEvents(EventMessage<?>...) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-
- appendEvents(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-
- AppendEventsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
-
- AppendEventTransaction - Class in org.axonframework.axonserver.connector.event
-
Sends one or more events to AxonServer in a single transaction.
- AppendEventTransaction(int, StreamObserver<Event>, CompletableFuture<Confirmation>, EventCipher) - Constructor for class org.axonframework.axonserver.connector.event.AppendEventTransaction
-
- appendSnapshot(Event) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreBlockingStub
-
Accepts a Snapshot event returning a Confirmation when completed.
- appendSnapshot(Event) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreFutureStub
-
Accepts a Snapshot event returning a Confirmation when completed.
- appendSnapshot(Event, StreamObserver<Confirmation>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreImplBase
-
Accepts a Snapshot event returning a Confirmation when completed.
- appendSnapshot(Event, StreamObserver<Confirmation>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreStub
-
Accepts a Snapshot event returning a Confirmation when completed.
- appendSnapshot(Event) - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
- appendSnapshot(String, Event) - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
Add a snapshot event to the Event Store.
- appendSnapshot(Connection, DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- appendSnapshot(AppendSnapshotStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- appendSnapshot(Connection, EventSchema, Class<?>, DomainEventMessage<?>, Serializer, TimestampWriter) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
-
- AppendSnapshotStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
-
- ApplicationContextEventPublisher - Class in org.axonframework.spring.messaging
-
Component that forward events received from a
SubscribableMessageSource
as Spring
ApplicationEvent
to the ApplicationContext.
- ApplicationContextEventPublisher(SubscribableMessageSource<? extends EventMessage<?>>) - Constructor for class org.axonframework.spring.messaging.ApplicationContextEventPublisher
-
Initialize the publisher to forward events received from the given messageSource
to the application
context that this bean is part of.
- ApplicationContextLookupParameterResolverFactory - Class in org.axonframework.spring.config
-
FactoryBean implementation that create a ParameterResolverFactory, which auto-detects beans implementing
ParameterResolverFactory beans in the application context.
- ApplicationContextLookupParameterResolverFactory(List<ParameterResolverFactory>) - Constructor for class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
-
Creates an instance, using the given defaultFactories
.
- apply(EventProcessor) - Method in class org.axonframework.axonserver.connector.processor.grpc.GrpcEventProcessorMapping
-
- apply(MetaData) - Method in class org.axonframework.axonserver.connector.util.GrpcMetadataSerializer
-
- apply(O) - Method in class org.axonframework.axonserver.connector.util.GrpcObjectSerializer
-
- apply(Message) - Method in class org.axonframework.axonserver.connector.util.GrpcPayloadSerializer
-
- apply(Connection) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlFunction
-
- apply(ResultSet) - Method in interface org.axonframework.common.jdbc.JdbcUtils.SqlResultConverter
-
Convert the given resultSet to a result of type R
.
- apply(Object, MetaData) - Static method in class org.axonframework.modelling.command.AggregateLifecycle
-
Apply a
DomainEventMessage
with given payload and metadata (metadata
from interceptors will be combined with the provided metadata).
- apply(Object) - Static method in class org.axonframework.modelling.command.AggregateLifecycle
-
Apply a
DomainEventMessage
with given payload without metadata (though
interceptors can also be used to provide metadata).
- apply(Statement, Description) - Method in class org.axonframework.test.aggregate.StubAggregateLifecycleRule
-
- applyMessageOrPayload(Object) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
Apply a new event message to the aggregate and then publish this message to external systems.
- ApplyMore - Interface in org.axonframework.modelling.command
-
Interface that describes a mechanism that enables the application of an additional event after another event is
applied.
- asCollection(Object) - Static method in class org.axonframework.common.CollectionUtils
-
Returns a Collection instance that contains the elements of the given potentialCollection
.
- asCommandMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandMessage
-
Returns the given command as a CommandMessage.
- asCommandResultMessage(Object) - Static method in class org.axonframework.commandhandling.GenericCommandResultMessage
-
- asCommandResultMessage(Throwable) - Static method in class org.axonframework.commandhandling.GenericCommandResultMessage
-
Creates a Command Result Message with the given exception
result.
- asDeadlineMessage(String, Object) - Static method in class org.axonframework.deadline.GenericDeadlineMessage
-
- asDeadlineMessage(String, Object, Instant) - Static method in class org.axonframework.deadline.GenericDeadlineMessage
-
Returns the given deadlineName
and messageOrPayload
as a DeadlineMessage which expires at the
given expiryTime
.
- asDomainEventMessage(EventMessage<T>) - Static method in class org.axonframework.eventhandling.EventUtils
-
- asEventMessage(Object) - Static method in class org.axonframework.eventhandling.GenericEventMessage
-
Returns the given event as an EventMessage.
- asMessage(Object) - Static method in class org.axonframework.messaging.GenericMessage
-
Returns a Message representing the given payloadOrMessage
, either by wrapping it or by returning it
as-is.
- asNullableResponseMessage(Class<R>, Object) - Static method in class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Creates a QueryResponseMessage for the given result
with a declaredType
as the result type.
- asResponseMessage(Object) - Static method in class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Creates a QueryResponseMessage for the given result
.
- asResponseMessage(Class<R>, Throwable) - Static method in class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Creates a Query Response Message with given declaredType
and exception
.
- asResultMessage(Object) - Static method in class org.axonframework.messaging.GenericResultMessage
-
- asResultMessage(Throwable) - Static method in class org.axonframework.messaging.GenericResultMessage
-
Creates a ResultMessage with the given exception
result.
- Assert - Class in org.axonframework.common
-
Utility class (inspired by Springs Assert class) for doing assertions on parameters and object state.
- assertActiveSagas(int) - Method in class org.axonframework.test.saga.RepositoryContentValidator
-
Asserts that the repsitory contains the given expected
amount of active sagas.
- assertAssociationPresent(String, String) - Method in class org.axonframework.test.saga.RepositoryContentValidator
-
Asserts that an association is present for the given associationKey
and
associationValue
.
- assertDeadlinesMet(Object...) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
-
Asserts that the given expected
deadlines have been met (which have passed in time).
- assertDeadlinesMetMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
-
Asserts that deadlines have been met (which have passed in time) match the given matcher
.
- assertDispatchedEqualTo(Object...) - Method in class org.axonframework.test.saga.CommandValidator
-
Assert that the given commands have been dispatched in the exact sequence provided.
- assertDispatchedMatching(Matcher<?>) - Method in class org.axonframework.test.saga.CommandValidator
-
Assert that commands matching the given matcher
has been dispatched on the command bus.
- assertNoAssociationPresent(String, String) - Method in class org.axonframework.test.saga.RepositoryContentValidator
-
Asserts that no association is present for the given associationKey
and
associationValue
.
- assertNonEmpty(String, String) - Static method in class org.axonframework.common.BuilderUtils
-
Assert that the given string
is not null and does not equal an empty String.
- assertNonNull(T, Supplier<? extends X>) - Static method in class org.axonframework.common.Assert
-
Assert that the given value
is non null.
- assertNonNull(T, String) - Static method in class org.axonframework.common.BuilderUtils
-
Assert that the given value
is non null.
- assertNoScheduledDeadlineMatching(Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
-
Asserts that no deadline matching the given matcher
has been scheduled.
- assertNoScheduledDeadlines() - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
-
Asserts that no deadlines are scheduled.
- assertNoScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
-
Asserts that no event matching the given matcher
has been scheduled after the given duration
.
- assertNoScheduledEventMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
-
Asserts that no event matching the given matcher
has been scheduled at the given scheduledTime
.
- assertNoScheduledEvents() - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
-
Asserts that no events are scheduled for publication.
- assertPositive(int, String) - Static method in class org.axonframework.common.BuilderUtils
-
Assert that the given value
is positive, meaning greater than, or equal to, zero.
- assertPositive(long, String) - Static method in class org.axonframework.common.BuilderUtils
-
Assert that the given value
is positive, meaning greater than, or equal to, zero.
- assertPublishedEvents(Object...) - Method in class org.axonframework.test.saga.EventValidator
-
Assert that the given expected
events have been published.
- assertPublishedEventsMatching(Matcher<? extends Iterable<?>>) - Method in class org.axonframework.test.saga.EventValidator
-
Asserts that events have been published matching the given matcher
.
- assertScheduledDeadlineMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
-
Asserts that a deadline scheduled after given duration
matches the given matcher
.
- assertScheduledDeadlineMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
-
Asserts that a deadline scheduled at the given scheduledTime
matches the given matcher
.
- assertScheduledEventMatching(Duration, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
-
Asserts that an event matching the given matcher
is scheduled for publication after the given duration
.
- assertScheduledEventMatching(Instant, Matcher<?>) - Method in class org.axonframework.test.eventscheduler.EventSchedulerValidator
-
Asserts that an event matching the given matcher
is scheduled for publication at the given scheduledTime
.
- assertStrictPositive(int, String) - Static method in class org.axonframework.common.BuilderUtils
-
Assert that the given value
is strictly positive, meaning greater than zero.
- assertStrictPositive(long, String) - Static method in class org.axonframework.common.BuilderUtils
-
Assert that the given value
is strictly positive, meaning greater than zero.
- assertThat(T, Predicate<T>, Supplier<? extends X>) - Static method in class org.axonframework.common.Assert
-
Assert that the given
value
will result to
true
through the
assertion
Predicate
.
- assertThat(T, Predicate<T>, String) - Static method in class org.axonframework.common.BuilderUtils
-
Assert that the given
value
will result to
true
through the
assertion
Predicate
.
- assertValidRecording() - Method in class org.axonframework.test.aggregate.ResultValidatorImpl
-
Makes sure the execution phase has finishes without any Errors ir FixtureExecutionExceptions.
- asSet() - Method in interface org.axonframework.modelling.saga.AssociationValues
-
Returns this instance as a Set of Association Values.
- asSet() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-
- assignHandlerInstancesMatching(String, Predicate<Object>) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
Configures a rule to assign Event Handler beans that match the given criteria
to the Processing Group
with given name
, with neutral priority (value 0).
- assignHandlerInstancesMatching(String, int, Predicate<Object>) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
Configures a rule to assign Event Handler beans that match the given criteria
to the Processing Group
with given name
, with given priority
.
- assignHandlerInstancesMatching(String, int, Predicate<Object>) - Method in class org.axonframework.config.EventProcessingModule
-
- assignHandlerTypesMatching(String, Predicate<Class<?>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
Configures a rule to assign Event Handler beans that match the given criteria
to the Processing Group
with given name
, with neutral priority (value 0).
- assignHandlerTypesMatching(String, int, Predicate<Class<?>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
Configures a rule to assign Event Handler beans that match the given criteria
to the Processing Group
with given name
, with given priority
.
- assignHandlerTypesMatching(String, int, Predicate<Class<?>>) - Method in class org.axonframework.config.EventProcessingModule
-
- assignProcessingGroup(String, String) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
Defines a mapping for assigning processing groups to processors.
- assignProcessingGroup(Function<String, String>) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
Defines a rule for assigning processing groups to processors if processing group to processor name mapping does
not contain the entry.
- assignProcessingGroup(String, String) - Method in class org.axonframework.config.EventProcessingModule
-
- assignProcessingGroup(Function<String, String>) - Method in class org.axonframework.config.EventProcessingModule
-
- associateWith(String, String) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
-
Registers a AssociationValue with the currently active saga.
- associateWith(String, Number) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
-
Registers a AssociationValue with the currently active saga.
- associateWith(AssociationValue) - Static method in class org.axonframework.modelling.saga.SagaLifecycle
-
Registers a AssociationValue with the currently active saga.
- AssociationResolver - Interface in org.axonframework.modelling.saga
-
Used to derive the value of an association property as designated by the association property name.
- associationsCache(Cache) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
-
Sets the
associationsCache
of type
Cache
used to store Saga associations with.
- AssociationValue - Class in org.axonframework.modelling.saga
-
A combination of key and value by which a Saga can be found.
- AssociationValue(String, String) - Constructor for class org.axonframework.modelling.saga.AssociationValue
-
Creates a Association Value instance with the given key
and value
.
- AssociationValueEntry - Class in org.axonframework.modelling.saga.repository.jpa
-
JPA wrapper around an Association Value.
- AssociationValueEntry(String, String, AssociationValue) - Constructor for class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
-
Initialize a new AssociationValueEntry for a saga with given sagaIdentifier
and
associationValue
.
- AssociationValueEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
-
Constructor required by JPA.
- associationValueEntryTable() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
-
Returns the name of the associationValueEntry table
- AssociationValueMap - Class in org.axonframework.modelling.saga.repository
-
In-memory storage for AssociationValue to Saga mappings.
- AssociationValueMap() - Constructor for class org.axonframework.modelling.saga.repository.AssociationValueMap
-
Initializes a new and empty AssociationValueMap.
- AssociationValues - Interface in org.axonframework.modelling.saga
-
- associationValues() - Method in interface org.axonframework.modelling.saga.repository.SagaStore.Entry
-
Returns the Set of association values of the fetched Saga entry.
- AssociationValuesImpl - Class in org.axonframework.modelling.saga
-
Default implementation of the AssociationValues interface.
- AssociationValuesImpl() - Constructor for class org.axonframework.modelling.saga.AssociationValuesImpl
-
Initializes a new AssociationValues object without initial associations.
- AssociationValuesImpl(Set<AssociationValue>) - Constructor for class org.axonframework.modelling.saga.AssociationValuesImpl
-
Initializes a new AssociationValues object with given initial associations.
- asStream() - Method in interface org.axonframework.common.stream.BlockingStream
-
Returns this MessageStream as a
Stream
of Messages.
- asStream(BlockingStream<M>) - Static method in class org.axonframework.common.stream.StreamUtils
-
Convert the given
messageStream
to a regular java
Stream
.
- asStream() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
Returns this DomainEventStream as a
Stream
of DomainEventMessages.
- asStream(DomainEventStream) - Static method in class org.axonframework.eventsourcing.EventStreamUtils
-
Convert the given
domainEventStream
to a regular java
Stream
of domain event messages.
- asTrackedEventMessage(EventMessage<T>, TrackingToken) - Static method in class org.axonframework.eventhandling.EventUtils
-
- asUpdateMessage(Object) - Static method in class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
-
- AsynchronousCommandBus - Class in org.axonframework.commandhandling
-
Specialization of the SimpleCommandBus that processed Commands asynchronously from the calling thread.
- AsynchronousCommandBus(AsynchronousCommandBus.Builder) - Constructor for class org.axonframework.commandhandling.AsynchronousCommandBus
-
- AsynchronousCommandBus.Builder - Class in org.axonframework.commandhandling
-
- AsynchronousEventProcessingStrategy - Class in org.axonframework.eventhandling.async
-
- AsynchronousEventProcessingStrategy(Executor, SequencingPolicy<? super EventMessage<?>>) - Constructor for class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
-
Initializes a new
AsynchronousEventProcessingStrategy
that uses the given
executor
to execute
event processing tasks and
sequencingPolicy
that determines if an event may be processed in sequence or
in parallel.
- attachTransaction(TransactionManager) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Attach a transaction to this Unit of Work, using the given transactionManager
.
- AutoConfiguration() - Constructor for class org.axonframework.springboot.MetricsProperties.AutoConfiguration
-
- AutowiredResourceInjector - Class in org.axonframework.test.utils
-
- AutowiredResourceInjector(Iterable<Object>) - Constructor for class org.axonframework.test.utils.AutowiredResourceInjector
-
Deprecated.
Initializes the resource injector to inject to given resources
.
- AVAILABLE_THREADS_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- availableProcessorThreads() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Returns the number of threads this processor has available to assign segments.
- awaitCompletion(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Wait for completion of the command, or for the timeout to expire.
- AXON_CONFIGURATION_BEAN - Static variable in class org.axonframework.spring.config.SpringAxonAutoConfigurer
-
- AXON_CONFIGURER_BEAN - Static variable in class org.axonframework.spring.config.SpringAxonAutoConfigurer
-
- AxonAssertionError - Error in org.axonframework.test
-
Error indication that an Assertion failed during a test case.
- AxonAssertionError(String) - Constructor for error org.axonframework.test.AxonAssertionError
-
Create a new error instance using the given detailMessage
.
- AxonAutoConfiguration - Class in org.axonframework.springboot.autoconfig
-
- AxonAutoConfiguration(EventProcessorProperties, SerializerProperties, TagsConfigurationProperties, ApplicationContext) - Constructor for class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-
- AxonConfiguration - Class in org.axonframework.spring.config
-
Spring Configuration class that defines a number of conditional beans.
- AxonConfiguration(Configurer) - Constructor for class org.axonframework.spring.config.AxonConfiguration
-
Initializes a new
AxonConfiguration
that uses the given
configurer
to build the configuration.
- AxonConfigurationException - Exception in org.axonframework.common
-
Exception indicating that a configuration error has been made in the Axon configuration.
- AxonConfigurationException(String) - Constructor for exception org.axonframework.common.AxonConfigurationException
-
Initializes the exception using the given message
.
- AxonConfigurationException(String, Throwable) - Constructor for exception org.axonframework.common.AxonConfigurationException
-
Initializes the exception using the given message
and cause
.
- AxonException - Exception in org.axonframework.common
-
Base exception of all Axon Framework related exceptions.
- AxonException(String) - Constructor for exception org.axonframework.common.AxonException
-
Initializes the exception using the given message
.
- AxonException(String, Throwable) - Constructor for exception org.axonframework.common.AxonException
-
Initializes the exception using the given message
and cause
.
- axonFrameworkVersionResolver(Supplier<String>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
-
Sets the Axon Framework version resolver used in order to communicate the client version to send to Axon
Server.
- AxonFrameworkVersionResolver - Class in org.axonframework.axonserver.connector.util
-
Provides Axon Framework current version.
- AxonFrameworkVersionResolver() - Constructor for class org.axonframework.axonserver.connector.util.AxonFrameworkVersionResolver
-
- AxonNonTransientException - Exception in org.axonframework.common
-
Exception indicating an error has been cause that cannot be resolved without intervention.
- AxonNonTransientException(String) - Constructor for exception org.axonframework.common.AxonNonTransientException
-
Initializes the exception using the given message
.
- AxonNonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonNonTransientException
-
Initializes the exception using the given message
and cause
.
- AxonServerAutoConfiguration - Class in org.axonframework.springboot.autoconfig
-
Configures Axon Server as implementation for the CommandBus, QueryBus and EventStore.
- AxonServerAutoConfiguration() - Constructor for class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-
- AxonServerCommandBus - Class in org.axonframework.axonserver.connector.command
-
Axon
CommandBus
implementation that connects to Axon Server to submit and receive commands and command
responses.
- AxonServerCommandBus(AxonServerConnectionManager, AxonServerConfiguration, CommandBus, Serializer, RoutingStrategy) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-
- AxonServerCommandBus(AxonServerConnectionManager, AxonServerConfiguration, CommandBus, Serializer, RoutingStrategy, CommandPriorityCalculator) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-
- AxonServerCommandBus(AxonServerConnectionManager, AxonServerConfiguration, CommandBus, Serializer, RoutingStrategy, CommandPriorityCalculator, TargetContextResolver<? super CommandMessage<?>>) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-
- AxonServerCommandBus(AxonServerCommandBus.Builder) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-
- axonServerCommandBus(AxonServerConnectionManager, AxonServerConfiguration, CommandBus, Serializer, RoutingStrategy, CommandPriorityCalculator, CommandLoadFactorProvider, TargetContextResolver<? super CommandMessage<?>>) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-
- AxonServerCommandBus.Builder - Class in org.axonframework.axonserver.connector.command
-
- AxonServerCommandDispatchException - Exception in org.axonframework.axonserver.connector.command
-
Exception thrown if there is a problem dispatching a command on Axon Server.
- AxonServerCommandDispatchException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
-
Initialize the exception with given errorCode
and errorMessage
.
- AxonServerConfiguration - Class in org.axonframework.axonserver.connector
-
Configuration class provided configurable fields and defaults for anything Axon Server related.
- AxonServerConfiguration() - Constructor for class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- axonServerConfiguration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
-
- axonServerConfiguration() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-
- AxonServerConfiguration.Builder - Class in org.axonframework.axonserver.connector
-
- AxonServerConfiguration.FlowControlConfiguration - Class in org.axonframework.axonserver.connector
-
Configuration class for Flow Control of specific message types.
- AxonServerConnectionManager - Class in org.axonframework.axonserver.connector
-
The component which manages all the connections which an Axon client can establish with an Axon Server instance.
- AxonServerConnectionManager(AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
- AxonServerConnectionManager(AxonServerConfiguration, TagsConfiguration) - Constructor for class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
- AxonServerConnectionManager(AxonServerConnectionManager.Builder) - Constructor for class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
- axonServerConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
-
- axonServerConnectionManager(AxonServerConnectionManager) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
-
- AxonServerConnectionManager.Builder - Class in org.axonframework.axonserver.connector
-
- AxonServerEventStore - Class in org.axonframework.axonserver.connector.event.axon
-
Axon EventStore implementation that connects to the AxonIQ AxonServer Server to store and retrieve Events.
- AxonServerEventStore(AxonServerEventStore.Builder) - Constructor for class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
-
- AxonServerEventStore.Builder - Class in org.axonframework.axonserver.connector.event.axon
-
- AxonServerEventStoreClient - Class in org.axonframework.axonserver.connector.event
-
Generic client for EventStore through AxonServer.
- AxonServerEventStoreClient(AxonServerConfiguration, AxonServerConnectionManager) - Constructor for class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
Initialize the Event Store Client using given eventStoreConfiguration
and given platformConnectionManager
.
- AxonServerException - Exception in org.axonframework.axonserver.connector
-
Generic exception indicating an error related to AxonServer.
- AxonServerException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
-
Initializes the exception using the given code
and errorMessage
.
- AxonServerException(String, String) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
-
Initializes the exception using the given code
and message
.
- AxonServerException(String, String, String, List<String>) - Constructor for exception org.axonframework.axonserver.connector.AxonServerException
-
Initializes the exception using the given message
, code
, source
and details
.
- AxonServerQueryBus - Class in org.axonframework.axonserver.connector.query
-
Axon
QueryBus
implementation that connects to Axon Server to submit and receive queries and query responses.
- AxonServerQueryBus(AxonServerConnectionManager, AxonServerConfiguration, QueryUpdateEmitter, QueryBus, Serializer, Serializer, QueryPriorityCalculator) - Constructor for class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
- AxonServerQueryBus(AxonServerConnectionManager, AxonServerConfiguration, QueryUpdateEmitter, QueryBus, Serializer, Serializer, QueryPriorityCalculator, TargetContextResolver<? super QueryMessage<?, ?>>) - Constructor for class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
- AxonServerQueryBus(AxonServerQueryBus.Builder) - Constructor for class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
- AxonServerQueryBus.Builder - Class in org.axonframework.axonserver.connector.query
-
- AxonServerQueryDispatchException - Exception in org.axonframework.axonserver.connector.query
-
An AxonServer Exception which is thrown on a Query Dispatching exception.
- AxonServerQueryDispatchException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
-
Initializes an AxonServer Query Dispatch Exception using the given code
and errorMessage
.
- AxonServerQueryDispatchException(String, String) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
-
Initializes an AxonServer Query Dispatch Exception using the given code
and message
.
- AxonServerQueryDispatchException(String, String, String, List<String>) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
-
Initializes an AxonServer Query Dispatch Exception using the given message
, code
, source
and details
.
- AxonServerRegistration - Class in org.axonframework.axonserver.connector.command
-
- AxonServerRegistration(Registration, Runnable) - Constructor for class org.axonframework.axonserver.connector.command.AxonServerRegistration
-
- AxonServerRemoteCommandHandlingException - Exception in org.axonframework.axonserver.connector.command
-
Exception indicating a problem that was reported by the remote end of a connection.
- AxonServerRemoteCommandHandlingException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
-
Initialize the exception with given errorCode
and errorMessage
.
- AxonServerRemoteQueryHandlingException - Exception in org.axonframework.axonserver.connector.query
-
An AxonServer Exception which is thrown on a Query Handling exception.
- AxonServerRemoteQueryHandlingException(String, ErrorMessage) - Constructor for exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
-
Initialize a Query Handling exception from a remote source.
- AxonServerSubscriptionQueryResult - Class in org.axonframework.axonserver.connector.query.subscription
-
A
SubscriptionQueryResult
that emits initial response and update when subscription query response message is
received.
- AxonServerSubscriptionQueryResult(SubscriptionQuery, Function<StreamObserver<SubscriptionQueryResponse>, StreamObserver<SubscriptionQueryRequest>>, AxonServerConfiguration, SubscriptionQueryBackpressure, int, Runnable) - Constructor for class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
-
- AxonThreadFactory - Class in org.axonframework.common
-
Thread factory that created threads in a given group.
- AxonThreadFactory(String) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that creates each thread in a group with given groupName
with
default priority.
- AxonThreadFactory(ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that create each thread in the given group
with default
priority.
- AxonThreadFactory(int, ThreadGroup) - Constructor for class org.axonframework.common.AxonThreadFactory
-
Initializes a ThreadFactory instance that create each thread in the given group
with given
priority
.
- axonTransactionManager() - Method in class org.axonframework.springboot.autoconfig.NoOpTransactionAutoConfiguration
-
- axonTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.springboot.autoconfig.TransactionAutoConfiguration
-
- AxonTransientException - Exception in org.axonframework.common
-
Exception indicating an error occurred that might be resolved by retrying the operation that caused the exception.
- AxonTransientException(String) - Constructor for exception org.axonframework.common.AxonTransientException
-
Initializes the exception using the given message
.
- AxonTransientException(String, Throwable) - Constructor for exception org.axonframework.common.AxonTransientException
-
Initializes the exception using the given message
and cause
.
- Cache - Interface in org.axonframework.common.caching
-
Abstraction for a Caching mechanism.
- cache(Cache) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
-
Sets the
Cache
in which loaded aggregates will be stored.
- cache - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-
- cache(Cache) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-
Sets the
Cache
which services repositories for specific aggregate types.
- Cache.EntryListener - Interface in org.axonframework.common.caching
-
Interface describing callback methods, which are invoked when changes are made in the underlying cache.
- Cache.EntryListenerAdapter - Class in org.axonframework.common.caching
-
Adapter implementation for the EntryListener, allowing for overriding only specific callback methods.
- cachedEvents(int) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
-
Sets the maximum number of events in the cache that is shared between the streams of tracking event
processors.
- CachingEventSourcingRepository<T> - Class in org.axonframework.eventsourcing
-
Implementation of the event sourcing repository that uses a cache to improve loading performance.
- CachingEventSourcingRepository(EventSourcingRepository.Builder<T>) - Constructor for class org.axonframework.eventsourcing.CachingEventSourcingRepository
-
- CachingSagaStore<T> - Class in org.axonframework.modelling.saga.repository
-
Saga Repository implementation that adds caching behavior to the repository it wraps.
- CachingSagaStore(CachingSagaStore.Builder<T>) - Constructor for class org.axonframework.modelling.saga.repository.CachingSagaStore
-
- CachingSagaStore.Builder<T> - Class in org.axonframework.modelling.saga.repository
-
- CachingSupplier<T> - Class in org.axonframework.serialization
-
A Supplier that caches its result, useful if the supplier operation is expensive and expected to always yield the
same result.
- calculateChain(Class<S>, Class<T>, Collection<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serialization.ChainedConverter
-
Returns a converter that can convert an IntermediateRepresentation from the given sourceType
to the
given targetType
using a chain formed with given candidates
.
- CallbackBehavior - Interface in org.axonframework.test.utils
-
Interface towards a mechanism that replicates the behavior of a Command Handling component.
- callbacks() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
Returns the callbacks mapped by callback identifier.
- cancel() - Method in class org.axonframework.axonserver.connector.command.AxonServerRegistration
-
- cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.DeserializedResult
-
- cancel() - Method in class org.axonframework.axonserver.connector.query.subscription.DisposableResult
-
- cancel(Throwable) - Method in class org.axonframework.axonserver.connector.util.BufferingSpliterator
-
Cancel further element retrieval of this queue.
- cancel(boolean) - Method in interface org.axonframework.axonserver.connector.util.Scheduler.ScheduledTask
-
Cancels the scheduled registration.
- cancel() - Method in interface org.axonframework.common.Registration
-
Cancels this Registration.
- cancel() - Method in class org.axonframework.queryhandling.DefaultSubscriptionQueryResult
-
- cancelAll(String) - Method in interface org.axonframework.deadline.DeadlineManager
-
Cancels all the deadlines corresponding to the given deadlineName
.
- cancelAll(String) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-
- cancelAll(String) - Method in class org.axonframework.deadline.SimpleDeadlineManager
-
- cancelAll(String) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
- cancelAllWithinScope(String) - Method in interface org.axonframework.deadline.DeadlineManager
-
- cancelAllWithinScope(String, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
-
Cancels all deadlines corresponding to the given deadlineName
and scope
.
- cancelAllWithinScope(String, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-
- cancelAllWithinScope(String, ScopeDescriptor) - Method in class org.axonframework.deadline.SimpleDeadlineManager
-
- cancelAllWithinScope(String, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
- cancelCallbacks(A) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
- cancelCallbacksForChannel(A) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
Removes all callbacks for a given channel.
- cancelSchedule(String, String) - Method in interface org.axonframework.deadline.DeadlineManager
-
Cancels the deadline corresponding to the given deadlineName
/ scheduleId
combination.
- cancelSchedule(String, String) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-
- cancelSchedule(String, String) - Method in class org.axonframework.deadline.SimpleDeadlineManager
-
- cancelSchedule(ScheduleToken) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Cancel the publication of a scheduled event.
- cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- cancelSchedule(ScheduleToken) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- cancelSchedule(String, String) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
- cancelSchedule(ScheduleToken) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
- canConvert(Class<S>, Class<T>, List<ContentTypeConverter<?, ?>>) - Static method in class org.axonframework.serialization.ChainedConverter
-
Indicates whether this converter is capable of converting the given sourceContentType
into
targetContentType
, using the given converters
.
- canConvert(Class<?>, Class<?>) - Method in class org.axonframework.serialization.ChainingConverter
-
- canConvert(Class<?>, Class<?>) - Method in interface org.axonframework.serialization.Converter
-
Indicates whether this converter is capable of converting the given sourceType
to the targetType
.
- canHandle(CommandMessage<?>) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
- canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-
Indicates whether the processor can/should handle the given eventMessage
for the given segment
.
- canHandle(EventMessage<?>) - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-
- canHandle(EventMessage<?>, Segment) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
-
Check whether or not this invoker has handlers that can handle the given eventMessage
for a given
segment
.
- canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
-
- canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- canHandle(EventMessage<?>, Collection<Segment>) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Indicates whether any of the components handling events for this Processor are able to handle the given eventMessage
for any of the given segments
.
- canHandle(Message<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
- canHandle(Message<?>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
-
Checks if this handler is capable of handling the given message
.
- canHandle(Message<?>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-
- canHandle(T) - Method in interface org.axonframework.messaging.MessageHandler
-
Indicates whether this handler can handle the given message
- canHandle(CommandMessage<?>) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
-
- canHandle(Message<?>) - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-
- canHandle(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-
- canHandle(EventMessage<?>, Segment) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager
-
- canHandle(QueryMessage<?, ?>) - Method in class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
-
- canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-
- canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-
- canHandleType(Class<?>) - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
-
Check whether or not this invoker has handlers that can handle the given payloadType
.
- canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
-
- canHandleType(Class<?>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- canHandleType(Class<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMember
-
- canHandleType(Class<?>) - Method in interface org.axonframework.messaging.annotation.MessageHandlingMember
-
Checks if this handler is capable of handling messages with the given payloadType
.
- canHandleType(Class<?>) - Method in class org.axonframework.messaging.annotation.WrappedMessageHandlingMember
-
- canHandleType(Class<?>) - Method in interface org.axonframework.messaging.MessageHandler
-
Indicates whether this handler can handle messages of given type
- CannotConvertBetweenTypesException - Exception in org.axonframework.serialization
-
Exception indicating that a conversion is required between to upcasters, but there is no converter capable of doing
the conversion.
- CannotConvertBetweenTypesException(String) - Constructor for exception org.axonframework.serialization.CannotConvertBetweenTypesException
-
Initializes the exception with the given message
.
- CannotConvertBetweenTypesException(String, Throwable) - Constructor for exception org.axonframework.serialization.CannotConvertBetweenTypesException
-
Initializing the exception with given message
and cause
.
- canResolve(ScopeDescriptor) - Method in interface org.axonframework.messaging.ScopeAware
-
Check whether this implementation can resolve a
Scope
object based on the provided
scopeDescription
.
- canResolve(ScopeDescriptor) - Method in class org.axonframework.modelling.command.AbstractRepository
-
- canResolve(ScopeDescriptor) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
- canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
-
Deprecated.
- canSerializeTo(Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- canSerializeTo(Class<T>) - Method in interface org.axonframework.serialization.Serializer
-
Indicates whether this Serializer is capable of serializing to the given expectedRepresentation
.
- canUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
-
Checks if this upcaster can upcast the given intermediateRepresentation
.
- canUpcast(T, C) - Method in class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
-
Checks if this upcaster can upcast the given intermediateRepresentation
.
- canUpcast(IntermediateEventRepresentation) - Method in class org.axonframework.serialization.upcasting.event.EventTypeUpcaster
-
- canUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
-
Checks if this upcaster can upcast the given intermediateRepresentation
.
- canUpcast(T) - Method in class org.axonframework.serialization.upcasting.SingleEntryUpcaster
-
Checks if this upcaster can upcast the given intermediateRepresentation
.
- CapacityMonitor - Class in org.axonframework.metrics
-
Calculates capacity by tracking, within the configured time window, the average message processing time
and multiplying that by the amount of messages processed.
- CapacityMonitor() - Constructor for class org.axonframework.metrics.CapacityMonitor
-
Creates a capacity monitor with the default time window 10 minutes
- CapacityMonitor(long, TimeUnit) - Constructor for class org.axonframework.metrics.CapacityMonitor
-
Creates a capacity monitor with the default time window 10 minutes
- CapacityMonitor(long, TimeUnit, Clock) - Constructor for class org.axonframework.metrics.CapacityMonitor
-
Creates a capacity monitor with the given time window.
- CapacityMonitor - Class in org.axonframework.micrometer
-
Calculates capacity by tracking, within the configured time window, the average message processing time
and multiplying that by the amount of messages processed.
- CAUGHT_UP_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- ChainedConverter<S,T> - Class in org.axonframework.serialization
-
A converter that delegates to a chain of other ContentTypeConverters to convert from a source to a target for which
there is not necessarily a single converter available.
- ChainedConverter(List<ContentTypeConverter<?, ?>>) - Constructor for class org.axonframework.serialization.ChainedConverter
-
Creates a new instance that uses the given delegates
to form a chain of converters.
- ChainingConverter - Class in org.axonframework.serialization
-
Converter implementation that will combine converters to form chains of converters to be able to convert
from one type to another, for which there is no suitable single converter.
- ChainingConverter() - Constructor for class org.axonframework.serialization.ChainingConverter
-
Initialize a new ChainingConverter with the context ClassLoader for this thread.
- ChainingConverter(ClassLoader) - Constructor for class org.axonframework.serialization.ChainingConverter
-
Initialize a new ChainingConverter.
- changePhase(UnitOfWork.Phase...) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Ask the unit of work to transition to the given phases
sequentially.
- characteristics() - Method in class org.axonframework.axonserver.connector.util.BufferingSpliterator
-
- charset(Charset) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
-
Sets the
Charset
used for the in- and output streams required by
XStream
for the to and from
xml function calls.
- charset(Charset) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
-
- ChildEntity<T> - Interface in org.axonframework.modelling.command.inspection
-
Interface describing en entity that is a child of another entity.
- ChildEntityDefinition - Interface in org.axonframework.modelling.command.inspection
-
Interface describing the definition of a Child Entity.
- ChildForwardingCommandMessageHandlingMember<P,C> - Class in org.axonframework.modelling.command.inspection
-
- ChildForwardingCommandMessageHandlingMember(List<MessageHandlingMember<? super C>>, MessageHandlingMember<? super C>, BiFunction<CommandMessage<?>, P, C>) - Constructor for class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-
- claim(String, TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Attempt to claim ownership of this token.
- claimTimeout(TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
-
Sets the
claimTimeout
specifying the amount of time this process will wait after which this process
will force a claim of a
TrackingToken
.
- claimTimeout(TemporalAmount) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
-
Sets the
claimTimeout
specifying the amount of time this process will wait after which this process
will force a claim of a
TrackingToken
.
- claimToken(Connection, AbstractTokenEntry<?>) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Tries to claim the given token entry
.
- classForType(SerializedType) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
- classForType(SerializedType) - Method in class org.axonframework.serialization.JavaSerializer
-
Deprecated.
- classForType(SerializedType) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- classForType(SerializedType) - Method in interface org.axonframework.serialization.Serializer
-
Returns the class for the given type identifier.
- classLoader(ClassLoader) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
-
- ClasspathHandlerDefinition - Class in org.axonframework.messaging.annotation
-
HandlerDefinition instance that locates other HandlerDefinition instances on the class path.
- ClasspathHandlerEnhancerDefinition - Class in org.axonframework.messaging.annotation
-
HandlerEnhancerDefinition instance that locates other HandlerEnhancerDefinition instances on the class path.
- ClasspathParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
ParameterResolverFactory instance that locates other ParameterResolverFactory instances on the class path.
- cleanGaps(CleanGapsStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- cleanGaps(Connection, SortedSet<Long>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- cleanGaps(Connection, EventSchema, SortedSet<Long>) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
-
Set the PreparedStatement to be used on internal cleanGaps operation.
- CleanGapsStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
-
- cleanupDelay(long) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
-
Sets the delay between two clean ups of lagging event processors.
- clear() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- clear() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- clear() - Method in class org.axonframework.messaging.MetaData
-
This operation is not supported.
- clear(UnitOfWork<?>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Clears the UnitOfWork currently bound to the current thread, if that UnitOfWork is the given
unitOfWork
.
- clear() - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
-
Clears all the associations.
- clearAck() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- clearAck() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- clearAck() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- clearAck() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- clearAck() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- clearAck() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- clearActiveThreads() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The number of threads currently actively processing Events
- clearAggregateId() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The identifier of the aggregate to read events for
- clearAggregateId() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The identifier to fetch the snapshots for
- clearAggregateId() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Identifier of the Aggregate for which to load events
- clearAggregateIdentifier() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The identifier of the Aggregate instance that published this event, if any
- clearAggregateSequenceNumber() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The sequence number of the Event in the Aggregate instance that published it, if any
- clearAggregateType() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Type of the Aggregate instance that published this Event, if any
- clearAllowSnapshots() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
Whether a snapshot may be returned as first element in the stream
- clearAvailableThreads() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The number of threads the processor has available to assign to Segments.
- clearBlacklist() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- clearBooleanValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The boolean value
- clearBooleanValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The boolean value of the Meta Data entry.
- clearBytesValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The binary value of the Meta Data entry.
- clearCaughtUp() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Indicates whether the Segment has "Caught Up" with the Head of the Event Stream
- clearClientId() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the component dispatching this message
- clearClientId() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The unique identifier of the component instance subscribing
- clearClientId() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
A unique identifier for this client instance.
- clearClientId() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The unique identifier of this client instance.
- clearClientId() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The ClientID of the component providing additional permits
- clearClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The unique identifier of the client instance dispatching the query
- clearClientId() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of the Client Instance containing the Query Handler
- clearClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The identifier of the Client instance providing the Update
- clearClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The identifier of the Client instance providing the Update
- clearClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The identifier of the Client instance providing the Update
- clearColumn() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- clearColumns() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response contains the names of the columns the response contains.
- clearCommand() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
A command for this component to process
- clearCommand() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name of the command the component can handle
- clearCommandResponse() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Sends a result of Command processing
- clearCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
-
Clears all the commands recorded by this Command Bus.
- clearComplete() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query is complete, and no more Updates will be sent
- clearCompleteExceptionally() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name/type of the component dispatching this message
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name/type of the component handling the command
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
The name of the component.
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The component name of this client instance.
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The Name of the Component dispatching the query
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Component containing the Query Handler
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The Component Name of the Client providing the Update
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The Component Name of the Client providing the Update
- clearComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Component Name of the Client providing the Update
- clearData() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- clearData() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- clearData() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- clearData() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The actual data representing the object in serialized form.
- clearDetails() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- clearDoubleValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The (64 bits) floating point value
- clearDoubleValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The floating point value of the Meta Data entry.
- clearError() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Flag indicating whether the processor, when stopped, did so because of an irrecoverable Error
- clearError() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Set if instruction acknowledgement failed.
- clearErrorCode() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
An error code describing the error, if any
- clearErrorCode() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
An Error Code identifying the type of error
- clearErrorCode() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
An Error Code identifying the type of error, if any
- clearErrorCode() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Code describing the type of Error that occurred
- clearErrorMessage() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
A detailed description of the error
- clearErrorMessage() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
A detailed description of the error, if any
- clearErrorMessage() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
A detailed description of the error, if available
- clearErrorState() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Information about the error state of the Segment, if applicable.
- clearEvent() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The actual Event Message
- clearEventProcessorInfo() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about Tracking Processors defined in the application.
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- clearFilesCompleted() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when all historic events have been included in the query results
- clearFlowControl() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to increase the number of instructions AxonServer may send to this component
- clearFlowControl() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Grant permits to AxonServer to send a number of messages to the client
- clearFlowControl() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Allows the Server to provide additional Updates to be sent.
- clearFromSequenceNr() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Sequence Number of the first event expected
- clearGetInitialResult() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Requests the initial result of a subscription query to be sent.
- clearGrpcPort() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The port number for gRPC connections
- clearHeartbeat() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- clearHeartbeat() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- clearHostName() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The host name to use when connecting to this node
- clearHttpPort() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The port number for HTTP connections
- clearIdValues() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- clearInitialResult() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Initial Response
- clearInitialSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The sequence number of the first event to receive
- clearInitialSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The minimal sequence number of the snapshots to retrieve
- clearInstant() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
Timestamp expressed as milliseconds since epoch
- clearInstructionId() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Instruction identifier.
- clearInstructionId() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction identifier.
- clearInstructionId() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Instruction identifier.
- clearInstructionId() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction identifier.
- clearInstructionId() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
The identifier of the instruction
- clearInstructionId() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Instruction identifier.
- clearInstructionId() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Instruction identifier.
- clearKey() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The type of processing message.
- clearLiveEvents() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
Whether to keep the query running against incoming events once the Head of the Stream is reached
- clearLoadFactor() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A number that represents the client's relative load capacity compared to other clients.
- clearLocation() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A description of the location (client component, server) where the error occurred
- clearMaxResults() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The maximum number of results to stream
- clearMaxSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The maximum sequence number of the snapshots to retrieve
- clearMergeEventProcessorSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to merge two Segments in a Tracking Event Processor
- clearMessage() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A human readable message explaining the error
- clearMessageId() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A unique identifier for this subscription.
- clearMessageId() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
A unique identifier for this message
- clearMessageId() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of this Message
- clearMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the Command Message
- clearMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the response message
- clearMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The unique identifier of this event
- clearMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The message ID of the incoming Query
- clearMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Response Message
- clearMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The unique identifier of this Update
- clearMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The unique identifier for this message
- clearMetaData() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- clearMetaData() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- clearMetaData() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- clearMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- clearMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- clearMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- clearMode() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- clearName() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name of the command, used for routing it to a destination capable of handling it
- clearNodeName() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The unique name of the node to connect with, for purpose of debugging
- clearNodeNotification() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- clearNrOfHandlers() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The number of Query Handlers registered within this Component with the same details.
- clearNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The number of messages the server may send before it needs to wait for more permits
- clearNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The number of results AxonServer may send before new permits need to be provided
- clearNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The number of messages the Server may send before needing to await additional permits
- clearNumberValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The (64 bits) integer value
- clearNumberValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The numeric value of the Meta Data entry.
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- clearOnePartOf() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The fraction this segment processes.
- clearPauseEventProcessor() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- clearPayload() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The payload of the Command, providing details on the instructions for the recipient
- clearPayload() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The payload to provide as a result to the dispatcher
- clearPayload() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Payload of the Event
- clearPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
A payload accompanying the Query
- clearPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The Payload of the Response Message
- clearPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The object representing the Update
- clearPermits() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The number of permits to provide
- clearPrimary() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
The connection details of the node the client should connect with
- clearProcessingInstructions() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- clearProcessingInstructions() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- clearProcessingInstructions() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- clearProcessingInstructions() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- clearProcessor() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The name of the processor requesting this stream.
- clearProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The logical name of this processor.
- clearProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
The name of the Event Processor
- clearProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The name of the Event Processor
- clearQuery() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The query to execute against the Event Stream
- clearQuery() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Query, for which this component is expected to provide a response
- clearQuery() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The name of the Query to execute
- clearQuery() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Query the Handler is subscribed to
- clearQueryComplete() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Indicator that all responses for Query have been sent
- clearQueryRequest() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The Query describing the desire for information
- clearQueryResponse() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a Response to a Query received via the inbound stream
- clearRegister() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about the client being connected.
- clearReleaseSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- clearReplaying() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Indicates whether the Segment is "Replaying" historic events after a Reset.
- clearRequest() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- clearRequest() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- clearRequest() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- clearRequest() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- clearRequest() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- clearRequest() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- clearRequest() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- clearRequestEventProcessorInfo() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- clearRequestId() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
The identifier of the incoming query to complete
- clearRequestIdentifier() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the Command Message for which this is the response
- clearRequestIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Query to which this is a response
- clearRequestReconnect() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer to the Application to migrate its connection to another node.
- clearResponse() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- clearResponseType() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
An object describing the expectations of the Response Type
- clearResultName() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The type of Result this Handler produces
- clearRevision() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The revision of the Payload Type
- clearRevision() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The revision of the serialized form of the given type.
- clearRow() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response message contains results of the Query
- clearRunning() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Flag indicating whether the processor is running
- clearSameConnection() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
Flag indicating that the connection may be reused to connect.
- clearSegmentId() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The ID of the Segment for which the status is reported
- clearSegmentIdentifier() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The identifier of the Segment
- clearSegmentStatus() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- clearSnapshot() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
Flag indicating whether the Event is a snapshot Event
- clearSortValues() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- clearSplitEventProcessorSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to split a Segment in a Tracking Event Processor
- clearStartEventProcessor() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- clearSubscribe() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to subscribe this component as handler of a specific type of command
- clearSubscribe() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Registers a Query Handler with AxonServer
- clearSubscribe() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Start a Subscription Query with the given details.
- clearSubscriptionIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A unique identifier for this subscription
- clearSubscriptionIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The identifier of the subscription query this is a response for
- clearSubscriptionQueryRequest() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- clearSubscriptionQueryResponse() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- clearSubscriptions() - Method in class org.axonframework.test.utils.RecordingCommandBus
-
Clears all subscribed handlers on this command bus.
- clearSuccess() - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
True when successful, otherwise false
- clearSuccess() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Indicator whether the instruction was acknowledged successfully
- clearTags() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- clearTextValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The text value
- clearTextValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The text value of the Meta Data entry.
- clearTimestamp() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The time at which the command was dispatched
- clearTimestamp() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The timestamp of the Event
- clearTimestamp() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The timestamp of the Query creation
- clearToken() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The Token representing the position of this Event in the Stream
- clearToken() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
The value of the Token
- clearTokenPosition() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The approximate position of the token in the stream.
- clearToSequenceNr() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
The sequence number of the latest event
- clearTrackingToken() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The token to start streaming from
- clearType() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The type identifier of the Payload
- clearType() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The type identifier of the serialized object.
- clearUnsubscribe() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to unsubscribe this component as handler of a specific type of command
- clearUnsubscribe() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Unregisters a Query Handler with AxonServer
- clearUnsubscribe() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Ends a previously started Subscription Query with the given details
- clearUpdate() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Update Response
- clearUpdateResponseType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A description of the type of Object expected as Update Responses
- clearValue() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The value associated with the processing key.
- clearValues() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- clearVersion() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Axon framework version used by the client application instance
- clearVersion() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The version identifier of the API
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.Command
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.FlowControl
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- CLIENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- ClientConnectionException - Exception in org.axonframework.axonserver.connector.event
-
Exception describing an error reported by the AxonIQ Event Store Client.
- ClientConnectionException(String, Throwable) - Constructor for exception org.axonframework.axonserver.connector.event.ClientConnectionException
-
Initialize the exception with given message
and cause
- clientId(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- ClientIdentification - Class in io.axoniq.axonserver.grpc.control
-
Message containing details about the Client Application
- ClientIdentification.Builder - Class in io.axoniq.axonserver.grpc.control
-
Message containing details about the Client Application
- ClientIdentificationOrBuilder - Interface in io.axoniq.axonserver.grpc.control
-
- clock - Static variable in class org.axonframework.eventhandling.GenericEventMessage
-
Clock
instance used to set the time on new events.
- clock - Static variable in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
The clock used to persist timestamps in this entry.
- clone() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- clone() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- clone() - Method in interface org.axonframework.common.caching.Cache.EntryListener
-
Clone operation used by some Cache implementations.
- clone() - Method in class org.axonframework.common.caching.Cache.EntryListenerAdapter
-
- close() - Method in class org.axonframework.axonserver.connector.event.axon.EventBuffer
-
- close() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResultBuffer
-
- close(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
-
Close the given connection
, which was wrapped by the ConnectionWrapperFactory.
- close(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
-
- close() - Method in interface org.axonframework.common.lock.Lock
-
Releases this lock.
- close() - Method in interface org.axonframework.common.Registration
-
Cancels this Registration.
- close() - Method in interface org.axonframework.common.stream.BlockingStream
-
- close() - Method in class org.axonframework.lifecycle.ShutdownLatch.ActivityHandle
-
- close() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-
Closes this lifecycle instance, restoring to the situation prior to this lifecycle being started.
- closeQuietly(AutoCloseable) - Static method in class org.axonframework.common.io.IOUtils
-
Closes any AutoCloseable object, while suppressing any IOExceptions it will generate.
- closeQuietly(ResultSet) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given resultSet
, if possible.
- closeQuietly(Statement) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given statement
, if possible.
- closeQuietly(Connection) - Static method in class org.axonframework.common.jdbc.JdbcUtils
-
Close the given connection
, if possible.
- closeQuietlyIfCloseable(Object) - Static method in class org.axonframework.common.io.IOUtils
-
Closes any object if that object implements
AutoCloseable
, while suppressing any IOExceptions it will
generate.
- code() - Method in exception org.axonframework.axonserver.connector.AxonServerException
-
- code() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
-
Return a
String
defining the error code.
- CollectionUtils - Class in org.axonframework.common
-
Utility methods for operations on collections.
- COLUMN_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
- COLUMNS_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- ColumnsResponse - Class in io.axoniq.axonserver.grpc.event
-
Message containing the names of the columns returned in a Query
- ColumnsResponse.Builder - Class in io.axoniq.axonserver.grpc.event
-
Message containing the names of the columns returned in a Query
- ColumnsResponseOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- Command - Class in io.axoniq.axonserver.grpc.command
-
A message representing a Command that needs to be routed to a component capable of handling it
- Command.Builder - Class in io.axoniq.axonserver.grpc.command
-
A message representing a Command that needs to be routed to a component capable of handling it
- COMMAND_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- COMMAND_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- COMMAND_RESPONSE_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- CommandBus - Interface in org.axonframework.commandhandling
-
The mechanism that dispatches Command objects to their appropriate CommandHandler.
- commandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway.Builder
-
- commandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory.Builder
-
- commandBus(CommandBus) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway.Builder
-
- commandBus() - Method in interface org.axonframework.config.Configuration
-
Returns the Command Bus defined in this Configuration.
- commandBus() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- commandBus(TransactionManager, AxonConfiguration, DuplicateCommandHandlerResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-
- CommandBusConnector - Interface in org.axonframework.commandhandling.distributed
-
Interface describing the component that remotely connects multiple CommandBus instances.
- CommandBusConnectorCommunicationException - Exception in org.axonframework.commandhandling.distributed
-
Exception thrown when the CommandBusConnector has a communication failure
- CommandBusConnectorCommunicationException(String) - Constructor for exception org.axonframework.commandhandling.distributed.CommandBusConnectorCommunicationException
-
Initializes the CommandBusConnectorCommunicationException
- CommandBusConnectorCommunicationException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.CommandBusConnectorCommunicationException
-
Initializes the CommandBusConnectorCommunicationException
- CommandCallback<C,R> - Interface in org.axonframework.commandhandling
-
Interface describing a callback that is invoked when command handler execution has finished.
- CommandCallbackRepository<A> - Class in org.axonframework.commandhandling.distributed
-
This class retains a list of callbacks for CommandCallbackConnectors to use.
- CommandCallbackRepository() - Constructor for class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
- CommandCallbackWrapper<A,C,R> - Class in org.axonframework.commandhandling.distributed
-
Wrapper for a Command callback.
- CommandCallbackWrapper(A, CommandMessage<C>, CommandCallback<? super C, ? super R>) - Constructor for class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
-
Initializes a
CommandCallbackWrapper
which wraps the original callback and holds on to the
command
message
and
channelId
of the channel on which the message is sent.
- CommandDispatchException - Exception in org.axonframework.commandhandling.distributed
-
Exception indicating that an error has occurred while trying to dispatch a command to another (potentially remote)
segment of the CommandBus.
- CommandDispatchException(String) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
-
Initializes the exception using the given message
.
- CommandDispatchException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.CommandDispatchException
-
Initializes the exception using the given message
and cause
.
- CommandExecutionException - Exception in org.axonframework.commandhandling
-
Indicates that an exception has occurred while handling a command.
- CommandExecutionException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
-
Initializes the exception with given message
and cause
.
- CommandExecutionException(String, Throwable, Object) - Constructor for exception org.axonframework.commandhandling.CommandExecutionException
-
Initializes the exception with given message
, cause
and an object providing application-specific
details
.
- commandFlowControl(int, int, int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- CommandGateway - Interface in org.axonframework.commandhandling.gateway
-
Interface towards the Command Handling components of an application.
- commandGateway() - Method in interface org.axonframework.config.Configuration
-
Returns the Command Gateway defined in this Configuration.
- commandGateway(CommandBus) - Method in class org.axonframework.spring.config.AxonConfiguration
-
Returns the CommandGateway used to send commands to command handlers.
- commandGateway(CommandBus) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-
- CommandGatewayFactory - Class in org.axonframework.commandhandling.gateway
-
Factory that creates Gateway implementations from custom interface definitions.
- CommandGatewayFactory(CommandGatewayFactory.Builder) - Constructor for class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
- CommandGatewayFactory.Builder - Class in org.axonframework.commandhandling.gateway
-
- CommandGatewayFactory.InvocationHandler<R> - Interface in org.axonframework.commandhandling.gateway
-
Interface towards the mechanism that handles a method call on a gateway interface method.
- CommandHandler - Annotation Type in org.axonframework.commandhandling
-
Marker annotation to mark any method on an object as being a CommandHandler.
- CommandHandlerInterceptor - Annotation Type in org.axonframework.modelling.command
-
Annotation used to mark methods on Aggregate members which can intercept commands.
- CommandHandlerInterceptorHandlingMember<T> - Interface in org.axonframework.modelling.command.inspection
-
Interface specifying a message handler capable of intercepting a command.
- commandHandlerInterceptors() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
- commandHandlerInterceptors(Class<? extends T>) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
Gets command handler interceptors for provided type
in this aggregate hierarchy.
- CommandHandlerInvoker - Class in org.axonframework.disruptor.commandhandling
-
Component of the DisruptorCommandBus that invokes the command handler.
- CommandHandlerInvoker(Cache, int) - Constructor for class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
-
Create an aggregate invoker instance for the given segment
and cache
.
- commandHandlers() - Method in class org.axonframework.modelling.command.inspection.AnnotatedChildEntity
-
- commandHandlers() - Method in interface org.axonframework.modelling.command.inspection.ChildEntity
-
Returns the command handlers declared in this entity
- commandHandlers() - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
- commandHandlers(Class<? extends T>) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
Gets command handlers for provided type
in this aggregate hierarchy.
- CommandHandlerSubscriber - Class in org.axonframework.spring.config
-
Registers Spring beans that implement both MessageHandler and SupportedCommandNamesAware with the command bus.
- CommandHandlerSubscriber() - Constructor for class org.axonframework.spring.config.CommandHandlerSubscriber
-
- CommandHandlingEntry - Class in org.axonframework.disruptor.commandhandling
-
DataHolder for the DisruptorCommandBus.
- CommandHandlingEntry() - Constructor for class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Initializes the CommandHandlingEntry
- commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- commandIdentifier - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- commandLoadFactor(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- CommandLoadFactorProvider - Interface in org.axonframework.axonserver.connector.command
-
Provides the load factor value of the client for the specific command.
- commandLoadFactorProvider(AxonServerConfiguration) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-
- CommandMessage<T> - Interface in org.axonframework.commandhandling
-
Represents a Message carrying a command as its payload.
- CommandMessageFilter - Interface in org.axonframework.commandhandling.distributed
-
Interface describing a filter that can be applied to commands to describe the type of commands supported by a node
in a cluster.
- CommandMessageHandler - Interface in org.axonframework.commandhandling
-
MessageHandler specialization for handlers of Command Messages.
- CommandMessageHandlingMember<T> - Interface in org.axonframework.commandhandling
-
Interface describing a message handler capable of handling a specific command.
- commandName() - Method in interface org.axonframework.commandhandling.CommandMessageHandlingMember
-
Returns the name of the command that can be handled.
- commandName - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- commandName() - Method in class org.axonframework.modelling.command.inspection.ChildForwardingCommandMessageHandlingMember
-
- CommandNameFilter - Class in org.axonframework.commandhandling.distributed.commandfilter
-
A filter for CommandMessages which filters CommandMessages by a Command Name.
- CommandNameFilter(Set<String>) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-
- CommandNameFilter(String) - Constructor for class org.axonframework.commandhandling.distributed.commandfilter.CommandNameFilter
-
- CommandOrBuilder - Interface in io.axoniq.axonserver.grpc.command
-
- CommandOuterClass - Class in io.axoniq.axonserver.grpc.command
-
- CommandPriorityCalculator - Interface in org.axonframework.axonserver.connector.command
-
- commandPriorityCalculator() - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-
- CommandProviderInbound - Class in io.axoniq.axonserver.grpc.command
-
An instruction or confirmation from AxonServer towards the component that provides the Command Handler
- CommandProviderInbound.Builder - Class in io.axoniq.axonserver.grpc.command
-
An instruction or confirmation from AxonServer towards the component that provides the Command Handler
- CommandProviderInbound.RequestCase - Enum in io.axoniq.axonserver.grpc.command
-
- CommandProviderInboundOrBuilder - Interface in io.axoniq.axonserver.grpc.command
-
- CommandProviderOutbound - Class in io.axoniq.axonserver.grpc.command
-
An instruction from the components that provides the Command Handler towards AxonServer.
- CommandProviderOutbound.Builder - Class in io.axoniq.axonserver.grpc.command
-
An instruction from the components that provides the Command Handler towards AxonServer.
- CommandProviderOutbound.RequestCase - Enum in io.axoniq.axonserver.grpc.command
-
- CommandProviderOutboundOrBuilder - Interface in io.axoniq.axonserver.grpc.command
-
- CommandResponse - Class in io.axoniq.axonserver.grpc.command
-
Message representing the result of Command Handler execution
- CommandResponse.Builder - Class in io.axoniq.axonserver.grpc.command
-
Message representing the result of Command Handler execution
- CommandResponseOrBuilder - Interface in io.axoniq.axonserver.grpc.command
-
- CommandResultMessage<R> - Interface in org.axonframework.commandhandling
-
- CommandRouter - Interface in org.axonframework.commandhandling.distributed
-
Interface describing a mechanism used to find a suitable member of a cluster capable of handling given command
message.
- commandRouter(CommandRouter) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
-
Sets the
CommandRouter
used to determine the target node for each dispatched command.
- CommandSerializer - Class in org.axonframework.axonserver.connector.command
-
- CommandSerializer(Serializer, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.command.CommandSerializer
-
- CommandServiceGrpc - Class in io.axoniq.axonserver.grpc.command
-
The CommandService defines the gRPC requests necessary for subscribing command handlers, and dispatching commands.
- CommandServiceGrpc.CommandServiceBlockingStub - Class in io.axoniq.axonserver.grpc.command
-
The CommandService defines the gRPC requests necessary for subscribing command handlers, and dispatching commands.
- CommandServiceGrpc.CommandServiceFutureStub - Class in io.axoniq.axonserver.grpc.command
-
The CommandService defines the gRPC requests necessary for subscribing command handlers, and dispatching commands.
- CommandServiceGrpc.CommandServiceImplBase - Class in io.axoniq.axonserver.grpc.command
-
The CommandService defines the gRPC requests necessary for subscribing command handlers, and dispatching commands.
- CommandServiceGrpc.CommandServiceStub - Class in io.axoniq.axonserver.grpc.command
-
The CommandService defines the gRPC requests necessary for subscribing command handlers, and dispatching commands.
- CommandServiceImplBase() - Constructor for class io.axoniq.axonserver.grpc.command.CommandServiceGrpc.CommandServiceImplBase
-
- CommandSubscription - Class in io.axoniq.axonserver.grpc.command
-
Message describing a component's capability of handling a command type
- CommandSubscription.Builder - Class in io.axoniq.axonserver.grpc.command
-
Message describing a component's capability of handling a command type
- CommandSubscriptionOrBuilder - Interface in io.axoniq.axonserver.grpc.command
-
- commandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
-
Sets the
CommandTargetResolver
that must be used to indicate which Aggregate instance will be
invoked by an incoming command.
- commandTargetResolver(CommandTargetResolver) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler.Builder
-
- CommandTargetResolver - Interface in org.axonframework.modelling.command
-
Interface towards a mechanism that is capable of extracting an Aggregate Identifier and Version form a command that
identifies the aggregate instance the command should be invoked on.
- CommandValidator - Class in org.axonframework.test.saga
-
Helper class for validation of dispatched commands.
- CommandValidator(RecordingCommandBus, FieldFilter) - Constructor for class org.axonframework.test.saga.CommandValidator
-
Creates a validator which monitors the given commandBus
.
- commit() - Method in class org.axonframework.axonserver.connector.event.AppendEventTransaction
-
- commit(Connection) - Method in interface org.axonframework.common.jdbc.ConnectionWrapperFactory.ConnectionCloseHandler
-
Commits the underlying transaction
- commit(Connection) - Method in class org.axonframework.common.jdbc.ConnectionWrapperFactory.NoOpCloseHandler
-
- commit() - Method in interface org.axonframework.common.transaction.Transaction
-
Commit this transaction.
- commit(List<? extends EventMessage<?>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
Process given events
while the Unit of Work root is being committed.
- commit() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- commit() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Commits the current UnitOfWork.
- commit() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Commits the Unit of Work.
- commit() - Method in interface org.axonframework.modelling.saga.AssociationValues
-
Resets the tracked changes.
- commit() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-
- commit(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
-
Commits the given modified saga
to the underlying saga store.
- commitTransaction(TransactionStatus) - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
-
Commits the transaction with given status
if the transaction is new and not completed.
- Common - Class in io.axoniq.axonserver.grpc
-
- CompactDriver - Class in org.axonframework.serialization.xml
-
XStream HierarchicalStreamDriver implementation that uses a CompactWriter to write XML without newlines and
indentation, while writing it using the (default) XPPReader.
- CompactDriver() - Constructor for class org.axonframework.serialization.xml.CompactDriver
-
- compare(T, T) - Method in class org.axonframework.common.annotation.PriorityAnnotationComparator
-
- compareTo(PropertyAccessStrategy) - Method in class org.axonframework.common.property.PropertyAccessStrategy
-
- compareTo(GlobalSequenceTrackingToken) - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
-
- compareTo(Segment) - Method in class org.axonframework.eventhandling.Segment
-
- compareTo(ScheduledDeadlineInfo) - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
-
- compareTo(StubScheduleToken) - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
-
- complete(Predicate<SubscriptionQueryMessage<?, ?, ?>>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
-
Completes subscription queries matching given filter.
- complete(Class<Q>, Predicate<? super Q>) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
-
Completes subscription queries matching given query type and filter.
- complete(Predicate<SubscriptionQueryMessage<?, ?, ?>>) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
-
- COMPLETE_EXCEPTIONALLY_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- COMPLETE_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- CompletedEmitterException - Exception in org.axonframework.queryhandling
-
Exception indicating that
QueryUpdateEmitter
is completed, thus cannot be used to emit messages and report
errors.
- CompletedEmitterException(String) - Constructor for exception org.axonframework.queryhandling.CompletedEmitterException
-
Initializes the exception with given message
.
- completeExceptionally(Predicate<SubscriptionQueryMessage<?, ?, ?>>, Throwable) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
-
Completes with an error subscription queries matching given filter.
- completeExceptionally(Class<Q>, Predicate<? super Q>, Throwable) - Method in interface org.axonframework.queryhandling.QueryUpdateEmitter
-
Completes with an error subscription queries matching given query type and filter
- completeExceptionally(Predicate<SubscriptionQueryMessage<?, ?, ?>>, Throwable) - Method in class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
-
- completeRequestStream() - Method in class org.axonframework.axonserver.connector.util.UpstreamAwareStreamObserver
-
Completes the request steam related to this stream observer.
- Component<B> - Class in org.axonframework.config
-
A Component used in the Axon Configurer.
- Component(Configuration, String, Function<Configuration, ? extends B>) - Constructor for class org.axonframework.config.Component
-
Creates a component for the given config
with given name
created by the given builderFunction
.
- Component(Supplier<Configuration>, String, Function<Configuration, ? extends B>) - Constructor for class org.axonframework.config.Component
-
Creates a component for the given config
with given name
created by the given builderFunction
.
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.Command
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- COMPONENT_NAME_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- componentName(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- computeRetryInterval(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
-
Compute the amount of milliseconds delay until the next retry, given the information passed.
- computeRetryInterval(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>) - Method in class org.axonframework.commandhandling.gateway.ExponentialBackOffIntervalRetryScheduler
-
- computeRetryInterval(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>) - Method in class org.axonframework.commandhandling.gateway.IntervalRetryScheduler
-
- computeSegment(int, int...) - Static method in class org.axonframework.eventhandling.Segment
-
Creates a Segment instance for the given segmentId
based on the given availableSegmentsIds
.
- computeSegments(int...) - Static method in class org.axonframework.eventhandling.Segment
-
Compute the
Segment
's from a given list of segmentId's.
- concat(DomainEventStream, DomainEventStream) - Static method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
Concatenate two DomainEventStreams.
- ConcatenatingDomainEventStream - Class in org.axonframework.eventsourcing.eventstore
-
DomainEventStream implementation that concatenates multiple streams, taking into account that some sequence
numbers may appear in more than one stream.
- ConcatenatingDomainEventStream(DomainEventStream...) - Constructor for class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
-
Initialize the stream, concatenating the given streams
.
- ConcatenatingDomainEventStream(Collection<DomainEventStream>) - Constructor for class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
-
Initialize the stream, concatenating the given streams
.
- ConcludesBatch - Annotation Type in org.axonframework.eventhandling
-
Annotation indication that a parameter on an
EventHandler
method should be
injected with a value that informs whether the event is the last event of a processed batch of events.
- ConcludesBatchParameterResolverFactory - Class in org.axonframework.eventhandling
-
Paramater resolver factory for boolean event handler parameters annotated with
ConcludesBatch
.
- ConcludesBatchParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-
Initialize a ConcludesBatchParameterResolverFactory.
- ConcurrencyException - Exception in org.axonframework.modelling.command
-
Exception indicating that concurrent access to a repository was detected.
- ConcurrencyException(String) - Constructor for exception org.axonframework.modelling.command.ConcurrencyException
-
Initialize a ConcurrencyException with the given message
.
- ConcurrencyException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.ConcurrencyException
-
Initialize a ConcurrencyException with the given message
and cause
.
- ConditionalOnMissingQualifiedBean - Annotation Type in org.axonframework.springboot.util
-
Conditional
that only matches when for the specified bean class in the BeanFactory
there is an
instance which has the given qualifier
set on it.
- ConditionalOnQualifiedBean - Annotation Type in org.axonframework.springboot.util
-
Conditional
that only matches when for the specified bean class in the BeanFactory
there is an
instance which has the given qualifier
set on it.
- configuration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
-
Sets the
AxonServerConfiguration
used to configure several components within the Axon Server Command
Bus, like setting the client id or the number of command handling threads used.
- configuration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
-
- configuration(AxonServerConfiguration) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
-
Sets the
AxonServerConfiguration
used to configure several components within the Axon Server Query
Bus, like setting the client id or the number of query handling threads used.
- Configuration - Interface in org.axonframework.config
-
Interface describing the Global Configuration for Axon components.
- ConfigurationParameterResolverFactory - Class in org.axonframework.config
-
ParameterResolverFactory implementation that resolves parameters from available components in the Configuration
instance it was configured with.
- ConfigurationParameterResolverFactory(Configuration) - Constructor for class org.axonframework.config.ConfigurationParameterResolverFactory
-
Initialize an instance using given configuration
to supply the value to resolve parameters with
- ConfigurationResourceInjector - Class in org.axonframework.config
-
ResourceInjector implementation that injects resources defined in the Axon Configuration.
- ConfigurationResourceInjector(Configuration) - Constructor for class org.axonframework.config.ConfigurationResourceInjector
-
Initializes the ResourceInjector to inject the resources found in the given configuration
.
- ConfigurationScopeAwareProvider - Class in org.axonframework.config
-
- ConfigurationScopeAwareProvider(Configuration) - Constructor for class org.axonframework.config.ConfigurationScopeAwareProvider
-
- configureAggregate(AggregateConfiguration<A>) - Method in interface org.axonframework.config.Configurer
-
Configures an Aggregate in this configuration based on the given aggregateConfiguration
.
- configureAggregate(Class<A>) - Method in interface org.axonframework.config.Configurer
-
Configures an Aggregate using default settings.
- configureAggregate(AggregateConfiguration<A>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureAggregateFactory(Function<Configuration, AggregateFactory<A>>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the factory to use to to create new Aggregates instances of the type under configuration.
- configureCache(Function<Configuration, Cache>) - Method in class org.axonframework.config.AggregateConfigurer
-
Configures the Cache to use for the repository created for this Aggregate type.
- configureCommandBus(Function<Configuration, CommandBus>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Command Bus to use in this configuration.
- configureCommandHandler(Function<Configuration, AggregateAnnotationCommandHandler<A>>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the AggregateAnnotationCommandHandler instance to use.
- configureCommandTargetResolver(Function<Configuration, CommandTargetResolver>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the CommandTargetResolver to use for the Aggregate type under configuration.
- configureCorrelationDataProviders(Function<Configuration, List<CorrelationDataProvider>>) - Method in interface org.axonframework.config.Configurer
-
Configures the CorrelationDataProviders that Message processing components should use to attach correlation data
to outgoing messages.
- configureCorrelationDataProviders(Function<Configuration, List<CorrelationDataProvider>>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureDefaultStreamableMessageSource(Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
- configureDefaultStreamableMessageSource(Function<Configuration, StreamableMessageSource<TrackedEventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-
- configureDefaultSubscribableMessageSource(Function<Configuration, SubscribableMessageSource<EventMessage<?>>>) - Method in interface org.axonframework.config.EventProcessingConfigurer
-
- configureDefaultSubscribableMessageSource(Function<Configuration, SubscribableMessageSource<EventMessage<?>>>) - Method in class org.axonframework.config.EventProcessingModule
-
- configureEmbeddedEventStore(Function<Configuration, EventStorageEngine>) - Method in interface org.axonframework.config.Configurer
-
Configures an Embedded Event Store which uses the given Event Storage Engine to store its events.
- configureEmbeddedEventStore(Function<Configuration, EventStorageEngine>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureEventBus(Function<Configuration, EventBus>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Event Bus to use in this configuration.
- configureEventHandling(EventProcessingConfigurer, ApplicationContext) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-
- configureEventSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
-
Configures the given event Serializer to use in this configuration.
- configureEventSerializer(Function<Configuration, Serializer>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureEventStore(Function<Configuration, EventStore>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Event Store to use in this configuration.
- configureEventStreamFilter(Function<Configuration, Predicate<? super DomainEventMessage<?>>>) - Method in class org.axonframework.config.AggregateConfigurer
-
Configures an event stream filter for the EventSourcingRepository for the Aggregate type under configuration.
- configureFilterEventsByType(Function<Configuration, Boolean>) - Method in class org.axonframework.config.AggregateConfigurer
-
Configures a function that determines whether or not the EventSourcingRepository for the Aggregate type under
configuration should filter out events with non-matching types.
- configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in interface org.axonframework.config.Configurer
-
Configures the Message Monitor to use for the Message processing components in this configuration, unless more
specific configuration based on the component's type, or type and name is available.
- configureMessageMonitor(Class<?>, Function<Configuration, MessageMonitor<Message<?>>>) - Method in interface org.axonframework.config.Configurer
-
Configures the builder function to create the Message Monitor for the Message processing components in this
configuration that match the given componentType, unless more specific configuration based on both type and name
is available.
- configureMessageMonitor(Class<?>, MessageMonitorFactory) - Method in interface org.axonframework.config.Configurer
-
Configures the factory to create the Message Monitor for the Message processing components in this configuration
that match the given componentType, unless more specific configuration based on both type and name is available.
- configureMessageMonitor(Class<?>, String, Function<Configuration, MessageMonitor<Message<?>>>) - Method in interface org.axonframework.config.Configurer
-
Configures the builder function to create the Message Monitor for the Message processing components in this
configuration that match the given class and name.
- configureMessageMonitor(Class<?>, String, MessageMonitorFactory) - Method in interface org.axonframework.config.Configurer
-
Configures the factory create the Message Monitor for those Message processing components in this configuration
that match the given class and name.
- configureMessageMonitor(Function<Configuration, BiFunction<Class<?>, String, MessageMonitor<Message<?>>>>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureMessageMonitor(Class<?>, MessageMonitorFactory) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureMessageMonitor(Class<?>, String, MessageMonitorFactory) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureMessageSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
-
Configures the given event Serializer to use in this configuration.
- configureMessageSerializer(Function<Configuration, Serializer>) - Method in class org.axonframework.config.DefaultConfigurer
-
- configureModule(Configurer) - Method in class org.axonframework.axonserver.connector.ServerConnectorConfigurerModule
-
- configureModule(Configurer) - Method in interface org.axonframework.config.ConfigurerModule
-
Configure this module to the given global
Configurer
.
- configureModule(Configurer) - Method in class org.axonframework.metrics.MetricsConfigurerModule
-
- configureModule(Configurer) - Method in class org.axonframework.micrometer.MetricsConfigurerModule
-
- configureQueryBus(Function<Configuration, QueryBus>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Query Bus to use in this configuration.
- configureQueryUpdateEmitter(Function<Configuration, QueryUpdateEmitter>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Query Update Emitter to use in this configuration.
- Configurer - Interface in org.axonframework.config
-
Entry point of the Axon Configuration API.
- configureRepository(Function<Configuration, Repository<A>>) - Method in class org.axonframework.config.AggregateConfigurer
-
Defines the repository to use to load and store Aggregates of this type.
- configureRepository(Function<Configuration, SagaRepository<T>>) - Method in class org.axonframework.config.SagaConfigurer
-
- configureResourceInjector(Function<Configuration, ResourceInjector>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Resource Injector to use for Sagas in this configuration.
- ConfigurerFactoryBean - Class in org.axonframework.spring.config
-
FactoryBean that creates an instance of a
Configurer
for use in a Spring Application Context.
- ConfigurerFactoryBean(Configurer) - Constructor for class org.axonframework.spring.config.ConfigurerFactoryBean
-
Initialize the factory bean, using the given configurer
to make available in the Application Context,
once configured by the ConfigurerModules in that context.
- ConfigurerModule - Interface in org.axonframework.config
-
Interface describing a configurer for a module in the Axon Configuration API.
- configureSagaManager(Function<Configuration, AbstractSagaManager<T>>) - Method in class org.axonframework.config.SagaConfigurer
-
Configures a Saga Manager for this Saga.
- configureSagaStore(Function<Configuration, SagaStore<? super T>>) - Method in class org.axonframework.config.SagaConfigurer
-
- configureSerializer(Function<Configuration, Serializer>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Serializer to use in this configuration.
- configureSnapshotTrigger(Function<Configuration, SnapshotTriggerDefinition>) - Method in class org.axonframework.config.AggregateConfigurer
-
Configures snapshotting for the Aggregate type under configuration.
- configureTags(Function<Configuration, TagsConfiguration>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Tags Configuration to use in this configuration.
- configureTransactionManager(Function<Configuration, TransactionManager>) - Method in interface org.axonframework.config.Configurer
-
Configures the given Transaction Manager to use in this configuration.
- configureWeakReferenceCache() - Method in class org.axonframework.config.AggregateConfigurer
-
Configures a WeakReferenceCache to be used for the repository created for this Aggregate type.
- Confirmation - Class in io.axoniq.axonserver.grpc.event
-
A confirmation to a request from the client
- Confirmation.Builder - Class in io.axoniq.axonserver.grpc.event
-
A confirmation to a request from the client
- ConfirmationOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- ConflictDescription - Interface in org.axonframework.eventsourcing.conflictresolution
-
Descries a conflict between expected and actual version of an aggregate.
- ConflictExceptionSupplier<T extends Exception> - Interface in org.axonframework.eventsourcing.conflictresolution
-
Interface describing a factory for exceptions that indicate an unresolved conflict in an aggregate instance.
- ConflictingAggregateVersionException - Exception in org.axonframework.modelling.command
-
Exception indicating that the (actual) version of a loaded aggregate did not match the given expected version number.
- ConflictingAggregateVersionException(String, long, long) - Constructor for exception org.axonframework.modelling.command.ConflictingAggregateVersionException
-
Initializes the exception using the given message
.
- ConflictingAggregateVersionException(String, long, long, Throwable) - Constructor for exception org.axonframework.modelling.command.ConflictingAggregateVersionException
-
Initializes the exception using the given message
and cause
.
- ConflictingModificationException - Exception in org.axonframework.modelling.command
-
Root of a hierarchy of exceptions indicating the detection of conflicting concurrent modifications.
- ConflictingModificationException(String) - Constructor for exception org.axonframework.modelling.command.ConflictingModificationException
-
Initializes the exception using the given message
.
- ConflictingModificationException(String, Throwable) - Constructor for exception org.axonframework.modelling.command.ConflictingModificationException
-
Initializes the exception using the given message
and cause
.
- ConflictResolution - Class in org.axonframework.eventsourcing.conflictresolution
-
ParameterResolverFactory that add support for the ConflictResolver parameter type in annotated handlers.
- ConflictResolution() - Constructor for class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
-
- ConflictResolver - Interface in org.axonframework.eventsourcing.conflictresolution
-
Interface describing an object that is capable of detecting conflicts between changes to be applied to an aggregate,
and unseen changes made to the aggregate.
- Conflicts - Class in org.axonframework.eventsourcing.conflictresolution
-
Utility class providing common Predicates used to detect conflicts between the actual state of an event sourced
aggregate and the expected state of the aggregate.
- ConnectionProvider - Interface in org.axonframework.common.jdbc
-
Interface towards a mechanism that provides access to a JDBC Connection.
- connectionProvider(ConnectionProvider) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
-
- connectionProvider(ConnectionProvider) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- connectionProvider(ConnectionProvider) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
-
- connectionProvider(DataSource) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
-
- ConnectionSanityChecker - Interface in org.axonframework.axonserver.connector.heartbeat
-
Sanity check that verify the state of the connection with AxonServer.
- ConnectionWrapperFactory - Class in org.axonframework.common.jdbc
-
Factory for creating wrappers around a Connection, allowing one to override the behavior of the
Connection.close()
method.
- ConnectionWrapperFactory.ConnectionCloseHandler - Interface in org.axonframework.common.jdbc
-
Interface defining an operation to close the wrapped connection
- ConnectionWrapperFactory.NoOpCloseHandler - Class in org.axonframework.common.jdbc
-
Implementation of ConnectionCloseHandler that does nothing on close or commit.
- connector(CommandBusConnector) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus.Builder
-
Sets the
CommandBusConnector
which performs the actual transport of the message to the destination
node.
- connectTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- ConsistentHash - Class in org.axonframework.commandhandling.distributed
-
Component used by command routers to find members capable of handling a given command.
- ConsistentHash() - Constructor for class org.axonframework.commandhandling.distributed.ConsistentHash
-
- ConsistentHash(Function<String, String>) - Constructor for class org.axonframework.commandhandling.distributed.ConsistentHash
-
Initializes a new
ConsistentHash
using the given
hashFunction
to calculate positions for each
member on the ring.
- ConsistentHash.ConsistentHashMember - Class in org.axonframework.commandhandling.distributed
-
- ConsistentHashChangeListener - Interface in org.axonframework.commandhandling.distributed
-
Represents a listener that is notified when a ConsistentHash instance of the component it is registered with has
changed.
- consume(ScopeDescriptor, DeadlineMessage<?>) - Method in interface org.axonframework.test.deadline.DeadlineConsumer
-
Consumes given deadlineMessage
.
- ContainerManagedEntityManagerProvider - Class in org.axonframework.springboot.util.jpa
-
EntityManagerProvider implementation that expects the container to inject the default container managed
EntityManager
instance.
- ContainerManagedEntityManagerProvider() - Constructor for class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
-
- contains(AssociationValue) - Method in interface org.axonframework.modelling.saga.AssociationValues
-
Indicates whether this instance contains the given associationValue
.
- contains(AssociationValue) - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-
- containsKey(Object) - Method in interface org.axonframework.common.caching.Cache
-
Indicates whether there is an item stored under given key
.
- containsKey(Object) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- containsKey(Object) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- containsKey(Object) - Method in class org.axonframework.common.caching.NoCache
-
- containsKey(Object) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- containsKey(Object) - Method in class org.axonframework.messaging.MetaData
-
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.command.Command
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- containsMetaData(String) - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Any meta data entries providing contextual information back to the dispatcher
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Any meta data entries providing contextual information back to the dispatcher
- containsMetaData(String) - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Any meta data entries providing contextual information back to the dispatcher
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Meta Data of the Event
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Meta Data of the Event
- containsMetaData(String) - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Meta Data of the Event
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Meta Data providing contextual information of the Query
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Meta Data providing contextual information of the Query
- containsMetaData(String) - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Meta Data providing contextual information of the Query
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any Meta Data describing the context of the Response Message
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any Meta Data describing the context of the Response Message
- containsMetaData(String) - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any Meta Data describing the context of the Response Message
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
Meta Data providing contextual information of the Update
- containsMetaData(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
Meta Data providing contextual information of the Update
- containsMetaData(String) - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
Meta Data providing contextual information of the Update
- containsTags(String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- containsTags(String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- containsTags(String) - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- containsValue(Object) - Method in class org.axonframework.messaging.MetaData
-
- containsValues(String) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The actual data values for each of the columns, as a column name -> value mapping
- containsValues(String) - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The actual data values for each of the columns, as a column name -> value mapping
- containsValues(String) - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The actual data values for each of the columns, as a column name -> value mapping
- contentType(Class<?>) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
-
Sets the
contentType
to which a
TrackingToken
should be serialized.
- ContentTypeConverter<S,T> - Interface in org.axonframework.serialization
-
Interface describing a mechanism that converts the data type of IntermediateRepresentations of SerializedObjects for
Upcasters.
- context(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- ContextAddingInterceptor - Class in org.axonframework.axonserver.connector.util
-
Interceptor around a gRPC request to add a Context element to the metadata.
- ContextAddingInterceptor(String) - Constructor for class org.axonframework.axonserver.connector.util.ContextAddingInterceptor
-
- ContextAwareConflictExceptionSupplier<T> - Interface in org.axonframework.eventsourcing.conflictresolution
-
ConflictExceptionSupplier that is provided with more details of a version conflict.
- ContextAwareEventMultiUpcaster<C> - Class in org.axonframework.serialization.upcasting.event
-
Abstract implementation of a
SingleEntryMultiUpcaster
and an
EventUpcaster
that eases the common
process of upcasting one intermediate event representation to several other representations by applying a flat
mapping function to the input stream of intermediate representations.
- ContextAwareEventMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.ContextAwareEventMultiUpcaster
-
- ContextAwareSingleEntryMultiUpcaster<T,C> - Class in org.axonframework.serialization.upcasting
-
Abstract implementation of an
Upcaster
that eases the common process of upcasting one intermediate
representation to several other representations by applying a simple flat mapping function to the input stream of
intermediate representations.
- ContextAwareSingleEntryMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.ContextAwareSingleEntryMultiUpcaster
-
- ContextAwareSingleEntryUpcaster<T,C> - Class in org.axonframework.serialization.upcasting
-
Abstract implementation of an
Upcaster
that eases the common process of upcasting one intermediate
representation to another representation by applying a simple mapping function to the input stream of intermediate
representations.
- ContextAwareSingleEntryUpcaster() - Constructor for class org.axonframework.serialization.upcasting.ContextAwareSingleEntryUpcaster
-
- ContextAwareSingleEventUpcaster<C> - Class in org.axonframework.serialization.upcasting.event
-
Abstract implementation of an event
Upcaster
that eases the common process of upcasting one intermediate
event representation to another representation by applying a simple mapping function to the input stream of
intermediate representations.
- ContextAwareSingleEventUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.ContextAwareSingleEventUpcaster
-
- ContinuedGivenState - Interface in org.axonframework.test.saga
-
Interface describing methods that can be executed after the first "given" state has been supplied.
- Control - Class in io.axoniq.axonserver.grpc.control
-
- convert(ErrorMessage, Supplier<Object>) - Method in enum org.axonframework.axonserver.connector.ErrorCode
-
Converts the errorMessage
to the relevant AxonException
- convert(ErrorMessage) - Method in enum org.axonframework.axonserver.connector.ErrorCode
-
Converts the errorMessage
to the relevant AxonException
- convert(Throwable) - Method in enum org.axonframework.axonserver.connector.ErrorCode
-
Converts the throwable
to the relevant AxonException
- convert(String, Throwable) - Method in enum org.axonframework.axonserver.connector.ErrorCode
-
Converts the source
and the throwable
to the relevant AxonException
- convert(Map<String, MetaDataValue>) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
-
Convert the given
Map
of
MetaDataValue
s to a Map containing the Java representations of each of
those values.
- convert(Set<ConstraintViolation<Object>>) - Static method in exception org.axonframework.messaging.interceptors.JSR303ViolationException
-
Convert the violations to a human readable format, sorted by class and property e.g.
- convert(Object) - Method in class org.axonframework.messaging.responsetypes.MultipleInstancesResponseType
-
Converts the given
response
of type
Object
into the type
List
with
generic type
R
from this
ResponseType
instance.
- convert(Object) - Method in class org.axonframework.messaging.responsetypes.OptionalResponseType
-
- convert(Object) - Method in interface org.axonframework.messaging.responsetypes.ResponseType
-
- convert(S, Class<S>, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Convert the given source
, of type sourceType
to the given targetType
.
- convert(S) - Method in class org.axonframework.serialization.ChainedConverter
-
- convert(Object, Class<?>, Class<T>) - Method in class org.axonframework.serialization.ChainingConverter
-
- convert(S) - Method in interface org.axonframework.serialization.ContentTypeConverter
-
Converts the given object into another.
- convert(Object, Class<T>) - Method in interface org.axonframework.serialization.Converter
-
Converts the given object into another.
- convert(Object, Class<?>, Class<T>) - Method in interface org.axonframework.serialization.Converter
-
Converts the given object into another using the source type to find the conversion path.
- convert(SerializedObject<?>, Class<T>) - Method in interface org.axonframework.serialization.Converter
-
Converts the data format of the given original
IntermediateRepresentation to the target data type.
- convert(Blob) - Method in class org.axonframework.serialization.converters.BlobToInputStreamConverter
-
- convert(byte[]) - Method in class org.axonframework.serialization.converters.ByteArrayToInputStreamConverter
-
- convert(byte[]) - Method in class org.axonframework.serialization.converters.ByteArrayToStringConverter
-
- convert(InputStream) - Method in class org.axonframework.serialization.converters.InputStreamToByteArrayConverter
-
- convert(String) - Method in class org.axonframework.serialization.converters.StringToByteArrayConverter
-
- convert(byte[]) - Method in class org.axonframework.serialization.json.ByteArrayToJsonNodeConverter
-
- convert(JsonNode) - Method in class org.axonframework.serialization.json.JsonNodeToByteArrayConverter
-
- convert(Document) - Method in class org.axonframework.serialization.xml.Dom4JToByteArrayConverter
-
- convert(InputStream) - Method in class org.axonframework.serialization.xml.InputStreamToDom4jConverter
-
- convert(InputStream) - Method in class org.axonframework.serialization.xml.InputStreamToXomConverter
-
- convert(Document) - Method in class org.axonframework.serialization.xml.XomToStringConverter
-
- convert(EventMessage<?>) - Method in class org.axonframework.spring.messaging.ApplicationContextEventPublisher
-
Converts the given Axon eventMessage
to a Spring ApplicationEvent.
- converter(Converter) - Method in class org.axonframework.serialization.AbstractXStreamSerializer.Builder
-
Sets the
Converter
used as a converter factory providing converter instances utilized by upcasters
to convert between different content types.
- Converter - Interface in org.axonframework.serialization
-
Interface describing a mechanism that can convert data from one to another type.
- converter(Converter) - Method in class org.axonframework.serialization.json.JacksonSerializer.Builder
-
Sets the
Converter
used as a converter factory providing converter instances utilized by upcasters
to convert between different content types.
- converter(Converter) - Method in class org.axonframework.serialization.xml.XStreamSerializer.Builder
-
- convertFromInboundMessage(Message<T>) - Method in class org.axonframework.spring.messaging.DefaultEventMessageConverter
-
- convertFromInboundMessage(Message<T>) - Method in interface org.axonframework.spring.messaging.EventMessageConverter
-
Converts a Spring inbound message
into an Axon event Message
- convertFromMetaDataValue(MetaDataValue) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
-
- ConvertingResponseMessage<R> - Class in org.axonframework.messaging.responsetypes
-
Implementation of a QueryResponseMessage that is aware of the requested response type and performs a just-in-time
conversion to ensure the response is formatted as requested.
- ConvertingResponseMessage(ResponseType<R>, QueryResponseMessage<?>) - Constructor for class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
Initialize a response message, using expectedResponseType
to convert the payload from the responseMessage
, if necessary.
- convertToMetaDataValue(Object) - Method in class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
-
Convert the given
value
into a
MetaDataValue
, attempting to maintain the source type as much as
possible in the returned
MetaDataValue
.
- convertToOutboundMessage(EventMessage<T>) - Method in class org.axonframework.spring.messaging.DefaultEventMessageConverter
-
- convertToOutboundMessage(EventMessage<T>) - Method in interface org.axonframework.spring.messaging.EventMessageConverter
-
Converts Axon event
into Spring message.
- coolingDownPeriod(long) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus.Builder
-
Sets the cooling down period in milliseconds.
- correlationData() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Returns the Correlation Data attached to the current Unit of Work, or an empty
MetaData
instance
if no Unit of Work is started.
- correlationDataFor(Message<?>) - Method in interface org.axonframework.messaging.correlation.CorrelationDataProvider
-
Provides a map with the entries to attach as correlation data to generated messages while processing given
message
.
- correlationDataFor(Message<?>) - Method in class org.axonframework.messaging.correlation.MessageOriginProvider
-
- correlationDataFor(Message<?>) - Method in class org.axonframework.messaging.correlation.MultiCorrelationDataProvider
-
- correlationDataFor(Message<?>) - Method in class org.axonframework.messaging.correlation.SimpleCorrelationDataProvider
-
- CorrelationDataInterceptor<T extends Message<?>> - Class in org.axonframework.messaging.interceptors
-
- CorrelationDataInterceptor(CorrelationDataProvider...) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
-
Initializes the interceptor that registers given correlationDataProviders
with the current Unit of Work.
- CorrelationDataInterceptor(Collection<CorrelationDataProvider>) - Constructor for class org.axonframework.messaging.interceptors.CorrelationDataInterceptor
-
Initializes the interceptor that registers given correlationDataProviders
with the current Unit of Work.
- CorrelationDataProvider - Interface in org.axonframework.messaging.correlation
-
Object defining the data from a Message that should be attached as correlation data to messages generated as
result of the processing of that message.
- correlationDataProviders() - Method in interface org.axonframework.config.Configuration
-
Returns the Correlation Data Providers defined in this Configuration.
- correlationDataProviders() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Provides the collection of registered Correlation Data Providers of this Unit of Work.
- correlationDataProviders() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- covers(TrackingToken) - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
-
- covers(TrackingToken) - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
-
- covers(TrackingToken) - Method in class org.axonframework.eventhandling.MergedTrackingToken
-
- covers(TrackingToken) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
-
Compares this token to other
checking each member token with its counterpart to see if they are covered
in the other
token.
- covers(TrackingToken) - Method in class org.axonframework.eventhandling.ReplayToken
-
- covers(TrackingToken) - Method in interface org.axonframework.eventhandling.TrackingToken
-
Indicates whether this token covers the other
token completely.
- create(Configuration, Class<?>, String) - Method in interface org.axonframework.config.MessageMonitorFactory
-
Function to create a Message Monitor based on the given configuration, component type and component name.
- createAggregateRoot(String, DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
- createAggregateRoot(String, DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.AggregateFactory
-
Instantiate the aggregate root using the given aggregate identifier and first event.
- createAggregateRoot(String, DomainEventMessage<?>) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-
- createAppendEventConnection() - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
- createAppendEventConnection(String) - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
Create a transaction to append events with.
- createChildDefinition(Field, EntityModel<T>) - Method in class org.axonframework.modelling.command.inspection.AbstractChildEntityDefinition
-
- createChildDefinition(Field, EntityModel<T>) - Method in interface org.axonframework.modelling.command.inspection.ChildEntityDefinition
-
Inspect the given field
, which is declared on the given declaringEntity
for the presence of a
Child Entity.
- createDomainEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
- createDomainEventTable(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory
-
Creates a PreparedStatement that allows for the creation of the table to store Event entries.
- createDomainEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-
- createEventEntity(EventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Returns a Jpa event entity for given eventMessage
.
- createGateway(Class<T>) - Method in class org.axonframework.commandhandling.gateway.CommandGatewayFactory
-
Creates a gateway instance for the given gatewayInterface
.
- createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in class org.axonframework.messaging.annotation.AnnotatedMessageHandlingMemberDefinition
-
- createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in interface org.axonframework.messaging.annotation.HandlerDefinition
-
- createHandler(Class<T>, Executable, ParameterResolverFactory) - Method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
-
- createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- createHeadToken() - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Creates a token that is at the head of an event stream - that tracks all new events.
- createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- createHeadToken(CreateHeadTokenStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- createHeadToken(Connection) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- createHeadToken(Connection, EventSchema) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
-
- createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- createHeadToken() - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- createHeadToken() - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-
- createHeadToken() - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
-
- createHeadToken() - Method in interface org.axonframework.messaging.StreamableMessageSource
-
Creates the token at the end of an event stream.
- CreateHeadTokenStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.commandhandling.InterceptorChainParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.config.ConfigurationParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventhandling.replay.ReplayParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventhandling.TrackingTokenParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.DefaultParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in interface org.axonframework.messaging.annotation.ParameterResolverFactory
-
If available, creates a ParameterResolver instance that can provide a parameter of type
parameterType
for a given message.
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
-
- createInstance(String, Supplier<T>) - Method in class org.axonframework.modelling.saga.repository.LockingSagaRepository
-
Creates a new Saga instance.
- createInstance(String, Supplier<T>) - Method in interface org.axonframework.modelling.saga.SagaRepository
-
Creates a new Saga instance.
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
-
- createInstance(Executable, Parameter[], int) - Method in class org.axonframework.test.FixtureResourceParameterResolverFactory
-
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.AbstractCacheAdapter
-
Creates an adapter for the given cacheEntryListener
.
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- createListenerAdapter(Cache.EntryListener) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- createMessage(P, MetaData) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
- createModel(Class<? extends T>) - Method in interface org.axonframework.modelling.command.inspection.AggregateMetaModelFactory
-
Create an Aggregate meta model for the given aggregateType
.
- createModel(Class<? extends T>, Set<Class<? extends T>>) - Method in interface org.axonframework.modelling.command.inspection.AggregateMetaModelFactory
-
Create an Aggregate meta model for the given aggregateType
and provided subtypes
.
- createModel(Class<? extends T>, Set<Class<? extends T>>) - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregateMetaModelFactory
-
- createNew(Class<T>, Callable<T>) - Static method in class org.axonframework.modelling.command.AggregateLifecycle
-
Creates a new aggregate instance.
- createNullStatement(Connection) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
-
Creates a prepared statement that acts as a null object.
- createReader(Reader) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createReader(InputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createReader(URL) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createReader(File) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createReplayToken(TrackingToken, TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
-
Creates a new TrackingToken that represents the given startPosition
of a stream, in reset state,
when appropriate.
- createReplayToken(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
-
Creates a new TrackingToken that represents the tail position of a stream, in reset state, when appropriate.
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
-
Create a repository instance for an aggregate created by the given aggregateFactory
.
- createRepository(EventStore, RepositoryProvider, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory, HandlerDefinition) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
-
Create a repository instance for an aggregate created by the given aggregateFactory
.
- createRepository(EventStore, AggregateFactory<T>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
eventStore
and aggregateFactory
.
- createRepository(EventStore, AggregateFactory<T>, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
eventStore
and aggregateFactory
.
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate, source from given eventStore
, that is
created by the given aggregateFactory
.
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate, source from given eventStore
, that is
created by the given aggregateFactory
.
- createRepository(EventStore, AggregateFactory<T>, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
and sourced from given eventStore
.
- createRepository(EventStore, AggregateFactory<T>, ParameterResolverFactory, HandlerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate that is created by the given
aggregateFactory
and sourced from given eventStore
.
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate, sourced from given eventStore
, that is
created by the given aggregateFactory
.
- createRepository(EventStore, AggregateFactory<T>, SnapshotTriggerDefinition, ParameterResolverFactory, HandlerDefinition, RepositoryProvider) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Creates a repository instance for an Event Sourced aggregate, sourced from given eventStore
, that is
created by the given aggregateFactory
.
- createSagaEntry(Object, String, Serializer) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
-
Intended for clients to override.
- createSagaIdentifier(Segment) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-
Creates a Saga identifier that will cause a Saga instance to be considered part of the given segment
.
- createSchema(TokenTableFactory) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Performs the DDL queries to create the schema necessary for this token store implementation.
- createSchema(EventTableFactory) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Performs the DDL queries to create the schema necessary for this storage engine implementation.
- createSchema() - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
-
Creates the SQL Schema required to store Sagas and their associations,.
- createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Creates a snapshot event for an aggregate of which passed events are available in the given eventStream
.
- createSnapshot(Class<?>, String, DomainEventStream) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-
- createSnapshotEntity(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Returns a Jpa snapshot entity for given snapshot
of an aggregate.
- createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.AbstractEventTableFactory
-
- createSnapshotEventTable(Connection, EventSchema) - Method in interface org.axonframework.eventsourcing.eventstore.jdbc.EventTableFactory
-
Creates a PreparedStatement that allows for the creation of the table to store Snapshots.
- createSnapshotEventTable(Connection, EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.Oracle11EventTableFactory
-
- createSnapshotterTask(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Creates an instance of a task that contains the actual snapshot creation logic.
- createSortedSetOf(Collection<Long>, long) - Static method in class org.axonframework.eventhandling.GapAwareTrackingToken
-
Construct a
SortedSet
of the given
gaps
to be set in this Tracking Token.
- createStreamableMessageSourceForContext(String) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
-
Creates a
StreamableMessageSource
that streams events from the given
context
, rather than the
default context the application was configured to connect to.
- createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
-
- createTable(Connection, TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.Oracle11TokenTableFactory
-
- createTable(Connection, TokenSchema) - Method in interface org.axonframework.eventhandling.tokenstore.jdbc.TokenTableFactory
-
Creates a PreparedStatement that allows for the creation of the table to store tracking token entries.
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- createTailToken() - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Creates a token that is at the tail of an event stream - that tracks events from the beginning of time.
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- createTailToken(CreateTailTokenStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- createTailToken(Connection) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- createTailToken(Connection, EventSchema) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
-
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- createTailToken() - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- createTailToken() - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-
- createTailToken() - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
-
- createTailToken() - Method in interface org.axonframework.messaging.StreamableMessageSource
-
Creates the token at the beginning of an event stream.
- CreateTailTokenStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
-
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- createTokenAt(Instant) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Creates a token that tracks all events after given dateTime
.
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- createTokenAt(CreateTokenAtStatementBuilder) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- createTokenAt(Connection, Instant) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- createTokenAt(Connection, EventSchema, Instant) - Static method in class org.axonframework.eventsourcing.eventstore.jdbc.statements.JdbcEventStorageEngineStatements
-
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-
- createTokenAt(Instant) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
-
- createTokenAt(Instant) - Method in interface org.axonframework.messaging.StreamableMessageSource
-
Creates a token that tracks all events after given dateTime
.
- CreateTokenAtStatementBuilder - Interface in org.axonframework.eventsourcing.eventstore.jdbc.statements
-
- createTokenSince(Duration) - Method in class org.axonframework.eventsourcing.MultiStreamableMessageSource
-
- createTokenSince(Duration) - Method in interface org.axonframework.messaging.StreamableMessageSource
-
Creates a token that tracks all events since the last duration
.
- createWriter(Writer) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- createWriter(OutputStream) - Method in class org.axonframework.serialization.xml.CompactDriver
-
- CreationPolicy - Annotation Type in org.axonframework.modelling.command
-
Annotation used to specify the creation policy for a command handler.
- creationPolicy() - Method in interface org.axonframework.modelling.command.inspection.CreationPolicyMember
-
- CreationPolicyMember<T> - Interface in org.axonframework.modelling.command.inspection
-
Interface specifying a message handler containing a creation policy definition.
- currentDateTime() - Method in class org.axonframework.test.deadline.DeadlineManagerValidator
-
- currentTime() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- currentTime() - Method in interface org.axonframework.test.aggregate.TestExecutor
-
Returns the time as "known" by the fixture.
- currentTime() - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Returns the time as "known" by the fixture.
- currentTime() - Method in class org.axonframework.test.saga.SagaTestFixture
-
- CurrentUnitOfWork - Class in org.axonframework.messaging.unitofwork
-
Default entry point to gain access to the current UnitOfWork.
- CurrentUnitOfWorkParameterResolverFactory - Class in org.axonframework.commandhandling
-
ParameterResolverFactory that add support for the UnitOfWork parameter type in annotated handlers.
- CurrentUnitOfWorkParameterResolverFactory() - Constructor for class org.axonframework.commandhandling.CurrentUnitOfWorkParameterResolverFactory
-
- GapAwareTrackingToken - Class in org.axonframework.eventhandling
-
Implementation of a
TrackingToken
that uses the global insertion sequence number of the event to determine
tracking order and additionally stores a set of possible gaps that have been detected while tracking the event
store.
- GapAwareTrackingToken(long, Collection<Long>) - Constructor for class org.axonframework.eventhandling.GapAwareTrackingToken
-
This constructor is mean't to be used for deserialization.
- GapAwareTrackingToken - Class in org.axonframework.eventsourcing.eventstore
-
- GapAwareTrackingToken(long, Collection<Long>) - Constructor for class org.axonframework.eventsourcing.eventstore.GapAwareTrackingToken
-
Deprecated.
- gapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken.
- gapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken.
- gapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out.
- gapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out.
- generateIdentifier() - Method in class org.axonframework.common.DefaultIdentifierFactory
-
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
- generateIdentifier() - Method in class org.axonframework.common.IdentifierFactory
-
Generates a unique identifier for use by Entities (generally the Aggregate Root) and Events.
- GenericAggregateFactory<T> - Class in org.axonframework.eventsourcing
-
Aggregate factory that uses a convention to create instances of aggregates.
- GenericAggregateFactory(Class<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
-
Initialize the AggregateFactory for creating instances of the given aggregateType
.
- GenericAggregateFactory(AggregateModel<T>) - Constructor for class org.axonframework.eventsourcing.GenericAggregateFactory
-
Initialize the AggregateFactory for creating instances of the given aggregateModel
.
- GenericCommandMessage<T> - Class in org.axonframework.commandhandling
-
Implementation of the CommandMessage that takes all properties as constructor parameters.
- GenericCommandMessage(T) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload and empty metaData
- GenericCommandMessage(T, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage with the given command
as payload.
- GenericCommandMessage(Message<T>, String) - Constructor for class org.axonframework.commandhandling.GenericCommandMessage
-
Create a CommandMessage from the given delegate
message containing payload, metadata and message
identifier, and the given commandName
.
- GenericCommandResultMessage<R> - Class in org.axonframework.commandhandling
-
- GenericCommandResultMessage(R) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
-
Creates a Command Result Message with the given commandResult
as the payload.
- GenericCommandResultMessage(Throwable) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
-
Creates a Command Result Message with the given exception
.
- GenericCommandResultMessage(R, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
-
Creates a Command Result Message with the given commandResult
as the payload and metaData
as
the meta data.
- GenericCommandResultMessage(Throwable, Map<String, ?>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
-
Creates a Command Result Message with the given exception
and metaData
.
- GenericCommandResultMessage(Message<R>) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
-
Creates a new Command Result Message with given delegate
message.
- GenericCommandResultMessage(Message<R>, Throwable) - Constructor for class org.axonframework.commandhandling.GenericCommandResultMessage
-
Creates a Command Result Message with given delegate
message and exception
.
- GenericDeadlineMessage<T> - Class in org.axonframework.deadline
-
- GenericDeadlineMessage(String) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
-
Instantiate a GenericDeadlineMessage with the given
deadlineName
, a
null
payload and en empty
MetaData
.
- GenericDeadlineMessage(String, T) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
-
Instantiate a GenericDeadlineMessage with the given
deadlineName
, a
payload
of type
T
and en empty
MetaData
.
- GenericDeadlineMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
-
Instantiate a GenericDeadlineMessage with the given deadlineName
, a payload
of type T
and the given metaData
.
- GenericDeadlineMessage(String, String, T, Map<String, ?>, Instant) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
-
Constructor to reconstructs a DeadlineMessage using existing data.
- GenericDeadlineMessage(String, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.deadline.GenericDeadlineMessage
-
Constructor to reconstruct a DeadlineMessage using existing data.
- GenericDomainEventEntry<T> - Class in org.axonframework.eventhandling
-
Generic implementation of a serialized domain event entry.
- GenericDomainEventEntry(String, String, long, String, Object, String, String, T, T) - Constructor for class org.axonframework.eventhandling.GenericDomainEventEntry
-
Reconstruct an event entry from a stored object.
- GenericDomainEventMessage<T> - Class in org.axonframework.eventhandling
-
- GenericDomainEventMessage(String, String, long, T) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
and payload
.
- GenericDomainEventMessage(String, String, long, T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
and payload
and metaData
.
- GenericDomainEventMessage(String, String, long, T, Map<String, ?>, String, Instant) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate using existing data.
- GenericDomainEventMessage(String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate using existing data.
- GenericDomainEventMessage(String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate with the given aggregateIdentifier
,
with given sequenceNumber
and payload
, metaData
and timestamp
.
- GenericEventMessage<T> - Class in org.axonframework.domain
-
- GenericEventMessage() - Constructor for class org.axonframework.domain.GenericEventMessage
-
Deprecated.
- GenericEventMessage<T> - Class in org.axonframework.eventhandling
-
Generic implementation of the EventMessage interface.
- GenericEventMessage(T) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Creates a GenericEventMessage with given payload
, and an empty MetaData.
- GenericEventMessage(T, Map<String, ?>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Creates a GenericEventMessage with given payload
and given metaData
.
- GenericEventMessage(String, T, Map<String, ?>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Constructor to reconstruct an EventMessage using existing data.
- GenericEventMessage(Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
Constructor to reconstruct an EventMessage using existing data.
- GenericEventMessage(Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericEventMessage
-
- GenericJpaRepository<T> - Class in org.axonframework.modelling.command
-
Generic repository implementation that stores JPA annotated aggregates.
- GenericJpaRepository(GenericJpaRepository.Builder<T>) - Constructor for class org.axonframework.modelling.command.GenericJpaRepository
-
- GenericJpaRepository.Builder<T> - Class in org.axonframework.modelling.command
-
- GenericMessage<T> - Class in org.axonframework.domain
-
- GenericMessage() - Constructor for class org.axonframework.domain.GenericMessage
-
Deprecated.
- GenericMessage<T> - Class in org.axonframework.messaging
-
Generic implementation of a
Message
that contains the payload and metadata as unserialized values.
- GenericMessage(T) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructs a Message for the given payload
using the correlation data of the current Unit of Work, if
present.
- GenericMessage(T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructs a Message for the given payload
and meta data
.
- GenericMessage(Class<T>, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructs a Message for the given payload
and meta data
.
- GenericMessage(String, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructor to reconstruct a Message using existing data.
- GenericMessage(String, Class<T>, T, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericMessage
-
Constructor to reconstruct a Message using existing data.
- GenericQueryMessage<T,R> - Class in org.axonframework.queryhandling
-
Generic implementation of the QueryMessage.
- GenericQueryMessage(T, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
-
Initializes the message with the given payload
and expected responseType
.
- GenericQueryMessage(T, String, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
-
Initializes the message with the given payload
, queryName
and expected responseType
.
- GenericQueryMessage(Message<T>, String, ResponseType<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryMessage
-
Initialize the Query Message, using given delegate
as the carrier of payload and metadata and given
queryName
and expecting the given responseType
.
- GenericQueryResponseMessage<R> - Class in org.axonframework.queryhandling
-
QueryResponseMessage implementation that takes all properties as constructor parameters.
- GenericQueryResponseMessage(R) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Initialize the response message with given result
.
- GenericQueryResponseMessage(Class<R>, R) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Initialize a response message with given result
and declaredResultType
.
- GenericQueryResponseMessage(Class<R>, Throwable) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Initialize the response message with given declaredResultType
and exception
.
- GenericQueryResponseMessage(R, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Initialize the response message with given result
and metaData
.
- GenericQueryResponseMessage(Class<R>, R, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Initialize the response message with a specific declaredResultType
, the given result
as payload
and metaData
.
- GenericQueryResponseMessage(Class<R>, Throwable, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Initialize the response message with given declaredResultType
, exception
and metaData
.
- GenericQueryResponseMessage(Message<R>) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Copy-constructor that takes the payload, meta data and message identifier of the given delegate
for this
message.
- GenericQueryResponseMessage(Message<R>, Throwable) - Constructor for class org.axonframework.queryhandling.GenericQueryResponseMessage
-
Copy-constructor that takes the payload, meta data and message identifier of the given delegate
for this
message and given exception
as a cause for the failure.
- GenericResultMessage<R> - Class in org.axonframework.messaging
-
- GenericResultMessage(R) - Constructor for class org.axonframework.messaging.GenericResultMessage
-
Creates a ResultMessage with the given result
as the payload.
- GenericResultMessage(Throwable) - Constructor for class org.axonframework.messaging.GenericResultMessage
-
Creates a ResultMessage with the given exception
.
- GenericResultMessage(R, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericResultMessage
-
Creates a ResultMessage with the given result
as the payload and metaData
as the meta data.
- GenericResultMessage(Throwable, Map<String, ?>) - Constructor for class org.axonframework.messaging.GenericResultMessage
-
Creates a ResultMessage with the given exception
and metaData
.
- GenericResultMessage(Message<R>) - Constructor for class org.axonframework.messaging.GenericResultMessage
-
Creates a new ResultMessage with given delegate
message.
- GenericResultMessage(Message<R>, Throwable) - Constructor for class org.axonframework.messaging.GenericResultMessage
-
Creates a ResultMessage with given delegate
message and exception
.
- GenericSagaSqlSchema - Class in org.axonframework.modelling.saga.repository.jdbc
-
Generic SagaSqlSchema implementation, for use in most databases.
- GenericSagaSqlSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
Initialize a GenericSagaSqlSchema using default settings.
- GenericSagaSqlSchema(SagaSchema) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
Initialize a GenericSagaSqlSchema.
- genericSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus.Builder
-
- GenericSubscriptionQueryMessage<Q,I,U> - Class in org.axonframework.queryhandling
-
- GenericSubscriptionQueryMessage(Q, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
-
Initializes the message with the given payload
, expected responseType
and expected updateResponseType
.
- GenericSubscriptionQueryMessage(Q, String, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
-
Initializes the message with the given payload
, queryName
, expected responseType
and
expected updateResponseType
.
- GenericSubscriptionQueryMessage(Message<Q>, String, ResponseType<I>, ResponseType<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
-
Initializes the message, using given delegate
as the carrier of payload and metadata and given queryName
, expected responseType
and expected updateResponseType
.
- GenericSubscriptionQueryUpdateMessage<U> - Class in org.axonframework.queryhandling
-
- GenericSubscriptionQueryUpdateMessage(U) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
-
- GenericSubscriptionQueryUpdateMessage(Class<U>, U) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
-
- GenericSubscriptionQueryUpdateMessage(Class<U>, U, Map<String, ?>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
-
- GenericSubscriptionQueryUpdateMessage(Message<U>) - Constructor for class org.axonframework.queryhandling.GenericSubscriptionQueryUpdateMessage
-
Initializes a new decorator with given delegate
message.
- GenericTokenEntry<T> - Class in org.axonframework.eventhandling.tokenstore
-
Generic implementation of a token entry.
- GenericTokenEntry(TrackingToken, Serializer, Class<T>, String, int) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
Initializes a new token entry for given token
, process
and segment
.
- GenericTokenEntry(T, String, String, String, String, int, Class<T>) - Constructor for class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
Initializes a token entry from existing data.
- GenericTokenTableFactory - Class in org.axonframework.eventhandling.tokenstore.jdbc
-
Jdbc token entry table factory compatible with most databases.
- GenericTokenTableFactory() - Constructor for class org.axonframework.eventhandling.tokenstore.jdbc.GenericTokenTableFactory
-
- GenericTrackedDomainEventMessage<T> - Class in org.axonframework.eventhandling
-
- GenericTrackedDomainEventMessage(TrackingToken, DomainEventMessage<T>) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
-
Initialize a DomainEventMessage originating from an aggregate.
- GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
-
Initialize a DomainEventMessage originating from an Aggregate using existing data.
- GenericTrackedDomainEventMessage(TrackingToken, String, String, long, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericTrackedDomainEventMessage
-
Initialize a DomainEventMessage originating from an aggregate.
- GenericTrackedEventMessage<T> - Class in org.axonframework.eventhandling
-
- GenericTrackedEventMessage(TrackingToken, EventMessage<T>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
-
Creates a GenericTrackedEventMessage with given trackingToken
and delegate event message.
- GenericTrackedEventMessage(TrackingToken, Message<T>, Supplier<Instant>) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
-
Creates a GenericTrackedEventMessage with given trackingToken
and delegate event message.
- GenericTrackedEventMessage(TrackingToken, Message<T>, Instant) - Constructor for class org.axonframework.eventhandling.GenericTrackedEventMessage
-
- GenericUpcasterChain<T> - Class in org.axonframework.serialization.upcasting
-
Implementation of an
Upcaster
that is formed of a chain of other upcasters which are combined to upcast a
stream of intermediate objects.
- GenericUpcasterChain(Upcaster<T>...) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
-
Initializes an upcaster chain from one or more upcasters.
- GenericUpcasterChain(List<? extends Upcaster<T>>) - Constructor for class org.axonframework.serialization.upcasting.GenericUpcasterChain
-
Initializes an upcaster chain from the given list of upcasters.
- get(String, Case) - Method in class org.axonframework.axonserver.connector.DefaultHandlers
-
- get(String) - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
-
- get(String, Case) - Method in interface org.axonframework.axonserver.connector.Handlers
-
Gets all handlers that match given context
and requestCase
.
- get() - Method in class org.axonframework.axonserver.connector.query.subscription.AxonServerSubscriptionQueryResult
-
- get() - Method in class org.axonframework.axonserver.connector.util.AxonFrameworkVersionResolver
-
Provides the current Axon Framework version, and cache it in memory during the first call.
- get() - Method in class org.axonframework.axonserver.connector.util.GrpcMetaData
-
- get(K) - Method in interface org.axonframework.common.caching.Cache
-
Returns an item from the cache, or null
if no item was stored under that key
- get(K) - Method in class org.axonframework.common.caching.EhCacheAdapter
-
- get(K) - Method in class org.axonframework.common.caching.JCacheAdapter
-
- get(K) - Method in class org.axonframework.common.caching.NoCache
-
- get(K) - Method in class org.axonframework.common.caching.WeakReferenceCache
-
- get() - Method in class org.axonframework.config.Component
-
Retrieves the object contained in this component, triggering the builder function if the component hasn't been
built yet.
- get(Object) - Method in class org.axonframework.messaging.MetaData
-
- get() - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Gets the UnitOfWork bound to the current thread.
- get() - Method in class org.axonframework.serialization.CachingSupplier
-
- get() - Method in class org.axonframework.util.MavenArtifactVersionResolver
-
Returns the specified jar version.
- GET_INITIAL_RESULT_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getAck() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderInboundOrBuilder
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Acknowledgement of previously sent instruction via outbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Acknowledgement of previously sent instruction via inbound stream
- getAck() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderInboundOrBuilder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Acknowledgement of previously sent instruction via outbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Acknowledgement of previously sent instruction via inbound stream
- getAckOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Acknowledgement of previously sent instruction via inbound stream
- getActiveThreads() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The number of threads currently actively processing Events
- getActiveThreads() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
The number of threads currently actively processing Events
- getActiveThreads() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
The number of threads currently actively processing Events
- getActualVersion() - Method in exception org.axonframework.modelling.command.ConflictingAggregateVersionException
-
Returns the actual version of the aggregate, as loaded by the repository.
- getAdapterInterfaces() - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
-
Returns the interface that the adapter implements to connect the annotated method to the actual interface
definition.
- getAdapterInterfaces() - Method in class org.axonframework.spring.config.annotation.AnnotationCommandHandlerBeanPostProcessor
-
- getAdapterInterfaces() - Method in class org.axonframework.spring.config.annotation.AnnotationQueryHandlerBeanPostProcessor
-
- getAdditionalEntries() - Method in class org.axonframework.test.matchers.MapEntryMatcher
-
- GetAggregateEventsRequest - Class in io.axoniq.axonserver.grpc.event
-
Request describing the desire to read events for a specific Aggregate
- GetAggregateEventsRequest.Builder - Class in io.axoniq.axonserver.grpc.event
-
Request describing the desire to read events for a specific Aggregate
- GetAggregateEventsRequestOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- getAggregateFactory(Class<?>) - Method in class org.axonframework.eventsourcing.AggregateSnapshotter
-
Returns the AggregateFactory registered for the given aggregateType
, or null
if no such
AggregateFactory is known.
- getAggregateFactory() - Method in class org.axonframework.eventsourcing.EventSourcingRepository
-
Returns the factory used by this repository.
- getAggregateFactory(Class<?>) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
-
- getAggregateId() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The identifier of the aggregate to read events for
- getAggregateId() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
The identifier of the aggregate to read events for
- getAggregateId() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateEventsRequestOrBuilder
-
The identifier of the aggregate to read events for
- getAggregateId() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The identifier to fetch the snapshots for
- getAggregateId() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
The identifier to fetch the snapshots for
- getAggregateId() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequestOrBuilder
-
The identifier to fetch the snapshots for
- getAggregateId() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Identifier of the Aggregate for which to load events
- getAggregateId() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
The Identifier of the Aggregate for which to load events
- getAggregateId() - Method in interface io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequestOrBuilder
-
The Identifier of the Aggregate for which to load events
- getAggregateIdBytes() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The identifier of the aggregate to read events for
- getAggregateIdBytes() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
The identifier of the aggregate to read events for
- getAggregateIdBytes() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateEventsRequestOrBuilder
-
The identifier of the aggregate to read events for
- getAggregateIdBytes() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The identifier to fetch the snapshots for
- getAggregateIdBytes() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
The identifier to fetch the snapshots for
- getAggregateIdBytes() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequestOrBuilder
-
The identifier to fetch the snapshots for
- getAggregateIdBytes() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Identifier of the Aggregate for which to load events
- getAggregateIdBytes() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
The Identifier of the Aggregate for which to load events
- getAggregateIdBytes() - Method in interface io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequestOrBuilder
-
The Identifier of the Aggregate for which to load events
- getAggregateIdentifier() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The identifier of the Aggregate instance that published this event, if any
- getAggregateIdentifier() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The identifier of the Aggregate instance that published this event, if any
- getAggregateIdentifier() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The identifier of the Aggregate instance that published this event, if any
- getAggregateIdentifier() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
- getAggregateIdentifier() - Method in exception org.axonframework.disruptor.commandhandling.AggregateStateCorruptedException
-
Returns the identifier of the blacklisted aggregate.
- getAggregateIdentifier() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Returns the identifier of the aggregate to recover.
- getAggregateIdentifier() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
-
- getAggregateIdentifier() - Method in interface org.axonframework.eventhandling.DomainEventData
-
Returns the Identifier of the Aggregate to which the Event was applied.
- getAggregateIdentifier() - Method in interface org.axonframework.eventhandling.DomainEventMessage
-
Returns the identifier of the Aggregate that generated this DomainEvent.
- getAggregateIdentifier() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-
- getAggregateIdentifier() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-
- getAggregateIdentifier() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
- getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.AggregateNotFoundException
-
Returns the identifier of the aggregate that could not be found.
- getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.AggregateRolledBackException
-
Returns the identifier of the compromised aggregate.
- getAggregateIdentifier() - Method in exception org.axonframework.modelling.command.ConflictingAggregateVersionException
-
Returns the identifier of the aggregate which version is not as expected.
- getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getAggregateIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the Identifier of the Aggregate to which the Event owning the object to upcast, was applied.
- getAggregateIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getAggregateIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The identifier of the Aggregate instance that published this event, if any
- getAggregateIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The identifier of the Aggregate instance that published this event, if any
- getAggregateIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The identifier of the Aggregate instance that published this event, if any
- getAggregateRoot() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
Get the annotated aggregate instance.
- getAggregateSequenceNumber() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The sequence number of the Event in the Aggregate instance that published it, if any
- getAggregateSequenceNumber() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The sequence number of the Event in the Aggregate instance that published it, if any
- getAggregateSequenceNumber() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The sequence number of the Event in the Aggregate instance that published it, if any
- GetAggregateSnapshotsRequest - Class in io.axoniq.axonserver.grpc.event
-
Request message to retrieve Snapshot Events for a specific Aggregate instance
- GetAggregateSnapshotsRequest.Builder - Class in io.axoniq.axonserver.grpc.event
-
Request message to retrieve Snapshot Events for a specific Aggregate instance
- GetAggregateSnapshotsRequestOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- getAggregateType() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Type of the Aggregate instance that published this Event, if any
- getAggregateType() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Type of the Aggregate instance that published this Event, if any
- getAggregateType() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Type of the Aggregate instance that published this Event, if any
- getAggregateType() - Method in class org.axonframework.eventsourcing.AbstractAggregateFactory
-
- getAggregateType() - Method in interface org.axonframework.eventsourcing.AggregateFactory
-
Returns the type of aggregate this factory creates.
- getAggregateType() - Method in class org.axonframework.modelling.command.AbstractRepository
-
Returns the aggregate type stored by this repository.
- getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getAggregateType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the Type of the Aggregate to which the Event owning the object to upcast, was applied.
- getAggregateType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getAggregateType() - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-
- getAggregateTypeBytes() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Type of the Aggregate instance that published this Event, if any
- getAggregateTypeBytes() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Type of the Aggregate instance that published this Event, if any
- getAggregateTypeBytes() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Type of the Aggregate instance that published this Event, if any
- getAllHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
-
Gets all handlers per type for inspected entity.
- getAllowSnapshots() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
Whether a snapshot may be returned as first element in the stream
- getAllowSnapshots() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
Whether a snapshot may be returned as first element in the stream
- getAllowSnapshots() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateEventsRequestOrBuilder
-
Whether a snapshot may be returned as first element in the stream
- getAppendEventMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getAppendSnapshotMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getAppliedEventPayloads() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-
Returns the payloads of the Events applied while this lifecycle instance was active.
- getAppliedEvents() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-
Returns the list of applied Events for this lifecycle instance.
- getAssociationValue() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
-
Returns the association value contained in this entry.
- getAssociationValue(EventMessage<?>) - Method in class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
-
The AssociationValue to find the saga instance with, or null
if no AssociationValue can be found on
the given eventMessage
.
- getAssociationValues() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-
- getAssociationValues() - Method in interface org.axonframework.modelling.saga.Saga
-
Returns a view on the Association Values for this saga instance.
- getAutoConfiguration() - Method in class org.axonframework.springboot.MetricsProperties
-
Retrieves the AutoConfiguration settings for Metrics
- getAvailableThreads() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The number of threads the processor has available to assign to Segments.
- getAvailableThreads() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
The number of threads the processor has available to assign to Segments.
- getAvailableThreads() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
The number of threads the processor has available to assign to Segments.
- getBatchSize() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
- getBatchSize() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Returns the maximum size of a processing batch.
- getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.spring.config.annotation.SpringContextHandlerDefinitionBuilder
-
Create, if necessary, a bean definition for a HandlerDefinition and returns the reference to bean for use in
other Bean Definitions.
- getBeanReference(BeanDefinitionRegistry) - Static method in class org.axonframework.spring.config.annotation.SpringContextParameterResolverFactoryBuilder
-
Create, if necessary, a bean definition for a ParameterResolverFactory and returns the reference to bean for use
in other Bean Definitions.
- getBindAddr() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Returns the Address to bind the JGroups client to.
- getBindPort() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Returns the port to listen to JGroups connections (default 7800).
- getBlacklist(int) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklist(int) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
An enumeration of payload types that need to be blacklisted.
- getBlacklist(int) - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistBuilderList() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistCount() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistCount() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistCount() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistList() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistList() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistList() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistOrBuilderList() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistOrBuilderList() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
An enumeration of payload types that need to be blacklisted.
- getBlacklistOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
An enumeration of payload types that need to be blacklisted.
- getBooleanValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The boolean value
- getBooleanValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
The boolean value
- getBooleanValue() - Method in interface io.axoniq.axonserver.grpc.event.QueryValueOrBuilder
-
The boolean value
- getBooleanValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The boolean value of the Meta Data entry.
- getBooleanValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
The boolean value of the Meta Data entry.
- getBooleanValue() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
The boolean value of the Meta Data entry.
- getBytesValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The binary value of the Meta Data entry.
- getBytesValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
The binary value of the Meta Data entry.
- getBytesValue() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
The binary value of the Meta Data entry.
- getBytesValueBuilder() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The binary value of the Meta Data entry.
- getBytesValueOrBuilder() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The binary value of the Meta Data entry.
- getBytesValueOrBuilder() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
The binary value of the Meta Data entry.
- getBytesValueOrBuilder() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
The binary value of the Meta Data entry.
- getCallback() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Returns the CommandCallback instance for the executed command.
- getCaughtUp() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Indicates whether the Segment has "Caught Up" with the Head of the Event Stream
- getCaughtUp() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
Indicates whether the Segment has "Caught Up" with the Head of the Event Stream
- getCaughtUp() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatusOrBuilder
-
Indicates whether the Segment has "Caught Up" with the Head of the Event Stream
- getCertFile() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getChannel() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Returns a Channel for the default context, opening one if necessary.
- getChannel(String) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Returns a Channel representing the connection for the given context
, opening one if necessary.
- getChannelIdentifier() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
-
Returns the identifier of the channel over which the command message was sent.
- getCharset() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Returns the character set used to convert character to bytes and vice versa.
- getClientId() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the component dispatching this message
- getClientId() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The unique identifier of the component dispatching this message
- getClientId() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The unique identifier of the component dispatching this message
- getClientId() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The unique identifier of the component instance subscribing
- getClientId() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
The unique identifier of the component instance subscribing
- getClientId() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
The unique identifier of the component instance subscribing
- getClientId() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
A unique identifier for this client instance.
- getClientId() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
A unique identifier for this client instance.
- getClientId() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
A unique identifier for this client instance.
- getClientId() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The unique identifier of this client instance.
- getClientId() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The unique identifier of this client instance.
- getClientId() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The unique identifier of this client instance.
- getClientId() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The ClientID of the component providing additional permits
- getClientId() - Method in class io.axoniq.axonserver.grpc.FlowControl
-
The ClientID of the component providing additional permits
- getClientId() - Method in interface io.axoniq.axonserver.grpc.FlowControlOrBuilder
-
The ClientID of the component providing additional permits
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The unique identifier of the client instance dispatching the query
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The unique identifier of the client instance dispatching the query
- getClientId() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The unique identifier of the client instance dispatching the query
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of the Client Instance containing the Query Handler
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The unique identifier of the Client Instance containing the Query Handler
- getClientId() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The unique identifier of the Client Instance containing the Query Handler
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The identifier of the Client instance providing the Update
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The identifier of the Client instance providing the Update
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The identifier of the Client instance providing the Update
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
The identifier of the Client instance providing the Update
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The identifier of the Client instance providing the Update
- getClientId() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
The identifier of the Client instance providing the Update
- getClientId() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
The identifier of the Client instance providing the Update
- getClientId() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteOrBuilder
-
The identifier of the Client instance providing the Update
- getClientId() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The identifier of the Client instance providing the Update
- getClientId() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the component dispatching this message
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The unique identifier of the component dispatching this message
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The unique identifier of the component dispatching this message
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The unique identifier of the component instance subscribing
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
The unique identifier of the component instance subscribing
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
The unique identifier of the component instance subscribing
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
A unique identifier for this client instance.
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
A unique identifier for this client instance.
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
A unique identifier for this client instance.
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The unique identifier of this client instance.
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The unique identifier of this client instance.
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The unique identifier of this client instance.
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The ClientID of the component providing additional permits
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.FlowControl
-
The ClientID of the component providing additional permits
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.FlowControlOrBuilder
-
The ClientID of the component providing additional permits
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The unique identifier of the client instance dispatching the query
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The unique identifier of the client instance dispatching the query
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The unique identifier of the client instance dispatching the query
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of the Client Instance containing the Query Handler
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The unique identifier of the Client Instance containing the Query Handler
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The unique identifier of the Client Instance containing the Query Handler
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteOrBuilder
-
The identifier of the Client instance providing the Update
- getClientIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The identifier of the Client instance providing the Update
- getClusterName() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Returns the Cluster Name of the JGroups Cluster to connect with (defaults to "Axon").
- getCode() - Method in exception org.axonframework.axonserver.connector.event.util.EventStoreClientException
-
- getColumn(int) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- getColumn(int) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
The names of the columns provided in the query
- getColumn(int) - Method in interface io.axoniq.axonserver.grpc.event.ColumnsResponseOrBuilder
-
The names of the columns provided in the query
- getColumnBytes(int) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- getColumnBytes(int) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
The names of the columns provided in the query
- getColumnBytes(int) - Method in interface io.axoniq.axonserver.grpc.event.ColumnsResponseOrBuilder
-
The names of the columns provided in the query
- getColumnCount() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- getColumnCount() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
The names of the columns provided in the query
- getColumnCount() - Method in interface io.axoniq.axonserver.grpc.event.ColumnsResponseOrBuilder
-
The names of the columns provided in the query
- getColumnList() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- getColumnList() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
The names of the columns provided in the query
- getColumnList() - Method in interface io.axoniq.axonserver.grpc.event.ColumnsResponseOrBuilder
-
The names of the columns provided in the query
- getColumns() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response contains the names of the columns the response contains.
- getColumns() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
Provided when the response contains the names of the columns the response contains.
- getColumns() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsResponseOrBuilder
-
Provided when the response contains the names of the columns the response contains.
- getColumns() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
-
- getColumnsBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response contains the names of the columns the response contains.
- getColumnsOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response contains the names of the columns the response contains.
- getColumnsOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
Provided when the response contains the names of the columns the response contains.
- getColumnsOrBuilder() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsResponseOrBuilder
-
Provided when the response contains the names of the columns the response contains.
- getCommand() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
A command for this component to process
- getCommand() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
A command for this component to process
- getCommand() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderInboundOrBuilder
-
A command for this component to process
- getCommand() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name of the command the component can handle
- getCommand() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
The name of the command the component can handle
- getCommand() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
The name of the command the component can handle
- getCommandBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
A command for this component to process
- getCommandBus() - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Returns the CommandBus used by this gateway.
- getCommandBus() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- getCommandBus() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Returns the command bus used by this fixture.
- getCommandBus() - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Returns the command bus used by this fixture.
- getCommandBus() - Method in class org.axonframework.test.saga.SagaTestFixture
-
- getCommandBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name of the command the component can handle
- getCommandBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
The name of the command the component can handle
- getCommandBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
The name of the command the component can handle
- getCommandFilter() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-
Returns this member's filter describing the commands it supports
- getCommandFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the identifier of the command carried by this instance.
- getCommandIdentifier() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the identifier of the command for which this message is a reply.
- getCommandLoadFactor() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getCommandMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the CommandMessage wrapped in this Message.
- getCommandName() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-
- getCommandName() - Method in interface org.axonframework.commandhandling.CommandMessage
-
Returns the name of the command to execute.
- getCommandName() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the command name of the command carried by this instance.
- getCommandName() - Method in class org.axonframework.commandhandling.GenericCommandMessage
-
- getCommandOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
A command for this component to process
- getCommandOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
A command for this component to process
- getCommandOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderInboundOrBuilder
-
A command for this component to process
- getCommandResponse() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Sends a result of Command processing
- getCommandResponse() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Sends a result of Command processing
- getCommandResponse() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Sends a result of Command processing
- getCommandResponseBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Sends a result of Command processing
- getCommandResponseOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Sends a result of Command processing
- getCommandResponseOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Sends a result of Command processing
- getCommandResponseOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Sends a result of Command processing
- getCommandResultMessage(Serializer) - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- getCommandStream(String, StreamObserver<CommandProviderInbound>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Opens a Stream for incoming commands from AxonServer in the given context
.
- getCommandThreads() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getCommitTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getComplete() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query is complete, and no more Updates will be sent
- getComplete() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Indicates the Query is complete, and no more Updates will be sent
- getComplete() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Indicates the Query is complete, and no more Updates will be sent
- getCompleteBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query is complete, and no more Updates will be sent
- getCompleteExceptionally() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- getCompleteExceptionally() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- getCompleteExceptionally() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- getCompleteExceptionallyBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- getCompleteExceptionallyOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- getCompleteExceptionallyOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- getCompleteExceptionallyOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- getCompleteOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query is complete, and no more Updates will be sent
- getCompleteOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Indicates the Query is complete, and no more Updates will be sent
- getCompleteOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Indicates the Query is complete, and no more Updates will be sent
- getComponent(Class<T>) - Method in interface org.axonframework.config.Configuration
-
Returns the Component declared under the given componentType
, typically the interface the component
implements.
- getComponent(Class<T>, Supplier<T>) - Method in interface org.axonframework.config.Configuration
-
Returns the Component declared under the given componentType
, typically the interface the component
implements, reverting to the given defaultImpl
if no such component is defined.
- getComponent(Class<T>, Supplier<T>) - Method in class org.axonframework.spring.config.AxonConfiguration
-
- getComponentName() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name/type of the component dispatching this message
- getComponentName() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The name/type of the component dispatching this message
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The name/type of the component dispatching this message
- getComponentName() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name/type of the component handling the command
- getComponentName() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
The name/type of the component handling the command
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
The name/type of the component handling the command
- getComponentName() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
The name of the component.
- getComponentName() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
The name of the component.
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
The name of the component.
- getComponentName() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The component name of this client instance.
- getComponentName() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The component name of this client instance.
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The component name of this client instance.
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The Name of the Component dispatching the query
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The Name of the Component dispatching the query
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The Name of the Component dispatching the query
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Component containing the Query Handler
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The name of the Component containing the Query Handler
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The name of the Component containing the Query Handler
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The Component Name of the Client providing the Update
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The Component Name of the Client providing the Update
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The Component Name of the Client providing the Update
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
The Component Name of the Client providing the Update
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Component Name of the Client providing the Update
- getComponentName() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
The Component Name of the Client providing the Update
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
The Component Name of the Client providing the Update
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteOrBuilder
-
The Component Name of the Client providing the Update
- getComponentName() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The Component Name of the Client providing the Update
- getComponentName() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name/type of the component dispatching this message
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The name/type of the component dispatching this message
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The name/type of the component dispatching this message
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name/type of the component handling the command
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
The name/type of the component handling the command
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
The name/type of the component handling the command
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
The name of the component.
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
The name of the component.
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
The name of the component.
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The component name of this client instance.
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The component name of this client instance.
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The component name of this client instance.
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The Name of the Component dispatching the query
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The Name of the Component dispatching the query
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The Name of the Component dispatching the query
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Component containing the Query Handler
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The name of the Component containing the Query Handler
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The name of the Component containing the Query Handler
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteOrBuilder
-
The Component Name of the Client providing the Update
- getComponentNameBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The Component Name of the Client providing the Update
- getComponents() - Method in class org.axonframework.config.DefaultConfigurer
-
Returns a map of all registered components in this configuration.
- getConfig() - Method in class org.axonframework.config.DefaultConfigurer
-
Returns the current Configuration object being built by this Configurer, without initializing it.
- getConfigurationFile() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Returns the path to the configuration file to use to configure the Groups instance.
- getConfigurationPhase() - Method in class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
-
- getConflictResolver() - Static method in class org.axonframework.eventsourcing.conflictresolution.ConflictResolution
-
Returns the ConflictResolver instance that can be used to resolve conflicts of an Aggregate that has been
previously loaded in this Unit of Work.
- getConnection() - Method in interface org.axonframework.common.jdbc.ConnectionProvider
-
Returns a connection, ready for use.
- getConnection() - Method in class org.axonframework.common.jdbc.DataSourceConnectionProvider
-
- getConnection() - Method in class org.axonframework.common.jdbc.UnitOfWorkAwareConnectionProviderWrapper
-
- getConnection() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
- getConnection() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- getConnection() - Method in class org.axonframework.spring.jdbc.SpringDataSourceConnectionProvider
-
- getConnectionEndpoint(Class<T>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-
- getConnectionEndpoint(Class<T>) - Method in interface org.axonframework.commandhandling.distributed.Member
-
Get the endpoint of this Member given a protocol
.
- getConnectionEndpoint(Class<T>) - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-
- getConnectTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getContentType() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
-
- getContentType() - Method in class org.axonframework.serialization.SerializedMetaData
-
- getContentType() - Method in interface org.axonframework.serialization.SerializedObject
-
Returns the type of this representation's data.
- getContentType() - Method in class org.axonframework.serialization.SimpleSerializedObject
-
- getContext() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getConverter() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Returns the Converter used by this serialized.
- getConverter() - Method in class org.axonframework.serialization.JavaSerializer
-
Deprecated.
- getConverter() - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- getConverter() - Method in interface org.axonframework.serialization.Serializer
-
Returns the
Converter
used by this Serializer to convert between serialized representations.
- getCorrelationData() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- getCorrelationData() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Get the correlation data contained in the
message
being processed by the Unit of Work.
- getCounter() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
-
Retrieve the counter used to differentiate two deadlines scheduled at the same time.
- getCreationPolicy() - Method in class org.axonframework.modelling.saga.SagaInitializationPolicy
-
Returns the creation policy
- getCreationPolicy() - Method in class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
-
Returns the creation policy of the inspected method.
- getCurrentDateTime() - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
- getCurrentDateTime() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
Returns the "Current Date Time" as used by the scheduler.
- getCurrentPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
-
Return the estimated relative current token position this Segment represents.
- getCurrentScope() - Static method in class org.axonframework.messaging.Scope
-
Retrieve the current
Scope
.
- getCurrentToken() - Method in class org.axonframework.eventhandling.ReplayToken
-
Gets the current token.
- getData() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The actual data representing the object in serialized form.
- getData() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
The actual data representing the object in serialized form.
- getData() - Method in interface io.axoniq.axonserver.grpc.SerializedObjectOrBuilder
-
The actual data representing the object in serialized form.
- getData() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
-
- getData() - Method in class org.axonframework.serialization.SerializedMetaData
-
- getData() - Method in interface org.axonframework.serialization.SerializedObject
-
The actual data of the serialized object.
- getData() - Method in class org.axonframework.serialization.SimpleSerializedObject
-
- getData() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getData(Class<D>) - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getData() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Get the data of this representation.
- getData(Class<D>) - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Get the data of this representation.
- getData() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getData(Class<D>) - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getDataCase() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- getDataCase() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- getDataCase() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsResponseOrBuilder
-
- getDataCase() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- getDataCase() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
- getDataCase() - Method in interface io.axoniq.axonserver.grpc.event.QueryValueOrBuilder
-
- getDataCase() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- getDataCase() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
- getDataCase() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
- getDeadlineName() - Method in interface org.axonframework.deadline.DeadlineMessage
-
Retrieve a
String
representing the name of this DeadlineMessage.
- getDeadlineName() - Method in class org.axonframework.deadline.GenericDeadlineMessage
-
- getDeadlineName() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
-
Retrieve a
String
denoting the name of the deadline; can be used together with the
scheduleId
to
cancel the deadline.
- getDeadlineScope() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
-
Retrieve a description of the
Scope
in which the deadline is scheduled.
- getDeadlinesMet() - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
Return all deadlines which have been met.
- getDefaultContext() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Returns the name of the default context of this application.
- getDefaultCorrelationKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
-
Returns the default metadata key for the correlation id of a message.
- getDefaultFlowControlConfiguration() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.command.Command
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.Heartbeat
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.control.RequestReconnect
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.ErrorMessage
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.Confirmation
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.Event
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.QueryValue
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.RowResponse
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.event.TrackingToken
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.FlowControl
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.InstructionAck
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.MetaDataValue
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- getDefaultInstance() - Static method in class io.axoniq.axonserver.grpc.SerializedObject
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.Command
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.Confirmation
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.Event
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.FlowControl
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- getDefaultInstanceForType() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
- getDefaultTraceKey() - Static method in class org.axonframework.messaging.correlation.MessageOriginProvider
-
Returns the default metadata key for the trace id of a message.
- getDelegate() - Method in class org.axonframework.messaging.MessageDecorator
-
Returns the wrapped message delegate.
- getDelegates() - Method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
-
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
- getDelegates() - Method in class org.axonframework.messaging.annotation.MultiHandlerEnhancerDefinition
-
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
- getDelegates() - Method in class org.axonframework.messaging.annotation.MultiParameterResolverFactory
-
Returns the delegates of this instance, in the order they are evaluated to resolve parameters.
- getDescriptions() - Method in class org.axonframework.messaging.RemoteExceptionDescription
-
Returns the
List
of
String
s describing the causes of the exception on the remote end.
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.Command
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandOuterClass
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.Common
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.Control
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.Heartbeat
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.RequestReconnect
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.ErrorMessage
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.Confirmation
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.Event
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.EventOuterClass
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.QueryValue
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.RowResponse
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.TrackingToken
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.FlowControl
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.InstructionAck
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.MetaDataValue
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
- getDescriptor() - Static method in enum io.axoniq.axonserver.grpc.ProcessingKey
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.Query
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- getDescriptor() - Static method in class io.axoniq.axonserver.grpc.SerializedObject
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- getDescriptorForType() - Method in enum io.axoniq.axonserver.grpc.ProcessingKey
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- getDescriptorForType() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- getDetails(int) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- getDetails(int) - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A collection of messages providing more details about root causes of the error
- getDetails(int) - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A collection of messages providing more details about root causes of the error
- getDetails() - Method in exception org.axonframework.messaging.HandlerExecutionException
-
Returns an Optional containing application-specific details of the exception, if any were provided.
- getDetailsBytes(int) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- getDetailsBytes(int) - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A collection of messages providing more details about root causes of the error
- getDetailsBytes(int) - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A collection of messages providing more details about root causes of the error
- getDetailsCount() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- getDetailsCount() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A collection of messages providing more details about root causes of the error
- getDetailsCount() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A collection of messages providing more details about root causes of the error
- getDetailsList() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- getDetailsList() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A collection of messages providing more details about root causes of the error
- getDetailsList() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A collection of messages providing more details about root causes of the error
- getDispatchedCommands() - Method in class org.axonframework.test.utils.RecordingCommandBus
-
Returns a list with all commands that have been dispatched by this command bus.
- getDispatchMethod() - Static method in class io.axoniq.axonserver.grpc.command.CommandServiceGrpc
-
- getDomainEventData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Extracts the next domain event entry from the given resultSet
.
- getDoubleValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The (64 bits) floating point value
- getDoubleValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
The (64 bits) floating point value
- getDoubleValue() - Method in interface io.axoniq.axonserver.grpc.event.QueryValueOrBuilder
-
The (64 bits) floating point value
- getDoubleValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The floating point value of the Meta Data entry.
- getDoubleValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
The floating point value of the Meta Data entry.
- getDoubleValue() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
The floating point value of the Meta Data entry.
- getEligibleMembers(String) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
-
- getEntityManager() - Method in interface org.axonframework.common.jpa.EntityManagerProvider
-
Returns the EntityManager instance to use.
- getEntityManager() - Method in class org.axonframework.common.jpa.SimpleEntityManagerProvider
-
- getEntityManager() - Method in class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
-
- getError() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Flag indicating whether the processor, when stopped, did so because of an irrecoverable Error
- getError() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
Flag indicating whether the processor, when stopped, did so because of an irrecoverable Error
- getError() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
Flag indicating whether the processor, when stopped, did so because of an irrecoverable Error
- getError() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Set if instruction acknowledgement failed.
- getError() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
Set if instruction acknowledgement failed.
- getError() - Method in interface io.axoniq.axonserver.grpc.InstructionAckOrBuilder
-
Set if instruction acknowledgement failed.
- getError() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
-
Returns the exception that caused processing to fail, if present.
- getErrorBuilder() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Set if instruction acknowledgement failed.
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
An error code describing the error, if any
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
An error code describing the error, if any
- getErrorCode() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
An error code describing the error, if any
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
An Error Code identifying the type of error
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
An Error Code identifying the type of error
- getErrorCode() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
An Error Code identifying the type of error
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
An Error Code identifying the type of error, if any
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
An Error Code identifying the type of error, if any
- getErrorCode() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
An Error Code identifying the type of error, if any
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Code describing the type of Error that occurred
- getErrorCode() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
The Code describing the type of Error that occurred
- getErrorCode() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
The Code describing the type of Error that occurred
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
-
Returns the error code as reported by the server.
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
-
Returns the error code as reported by the server.
- getErrorCode() - Method in exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
-
Return a
String
defining the error code.
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
An error code describing the error, if any
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
An error code describing the error, if any
- getErrorCodeBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
An error code describing the error, if any
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
An Error Code identifying the type of error
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
An Error Code identifying the type of error
- getErrorCodeBytes() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
An Error Code identifying the type of error
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
An Error Code identifying the type of error, if any
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
An Error Code identifying the type of error, if any
- getErrorCodeBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
An Error Code identifying the type of error, if any
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Code describing the type of Error that occurred
- getErrorCodeBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
The Code describing the type of Error that occurred
- getErrorCodeBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
The Code describing the type of Error that occurred
- getErrorMessage() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
A detailed description of the error
- getErrorMessage() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
A detailed description of the error
- getErrorMessage() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
A detailed description of the error
- getErrorMessage() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
A detailed description of the error, if any
- getErrorMessage() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
A detailed description of the error, if any
- getErrorMessage() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
A detailed description of the error, if any
- getErrorMessage() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
A detailed description of the error, if available
- getErrorMessage() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
A detailed description of the error, if available
- getErrorMessage() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
A detailed description of the error, if available
- getErrorMessageBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
A detailed description of the error
- getErrorMessageBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
A detailed description of the error, if any
- getErrorMessageBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
A detailed description of the error, if available
- getErrorMessageOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
A detailed description of the error
- getErrorMessageOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
A detailed description of the error
- getErrorMessageOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
A detailed description of the error
- getErrorMessageOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
A detailed description of the error, if any
- getErrorMessageOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
A detailed description of the error, if any
- getErrorMessageOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
A detailed description of the error, if any
- getErrorMessageOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
A detailed description of the error, if available
- getErrorMessageOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
A detailed description of the error, if available
- getErrorMessageOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionallyOrBuilder
-
A detailed description of the error, if available
- getErrorOrBuilder() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Set if instruction acknowledgement failed.
- getErrorOrBuilder() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
Set if instruction acknowledgement failed.
- getErrorOrBuilder() - Method in interface io.axoniq.axonserver.grpc.InstructionAckOrBuilder
-
Set if instruction acknowledgement failed.
- getErrorState() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Information about the error state of the Segment, if applicable.
- getErrorState() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
Information about the error state of the Segment, if applicable.
- getErrorState() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatusOrBuilder
-
Information about the error state of the Segment, if applicable.
- getErrorStateBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Information about the error state of the Segment, if applicable.
- getErrorStateBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
Information about the error state of the Segment, if applicable.
- getErrorStateBytes() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatusOrBuilder
-
Information about the error state of the Segment, if applicable.
- getEvent() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The actual Event Message
- getEvent() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
The actual Event Message
- getEvent() - Method in interface io.axoniq.axonserver.grpc.event.EventWithTokenOrBuilder
-
The actual Event Message
- getEvent() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
-
The Event scheduled for publication.
- getEvent() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
-
- getEventAvailabilityTimeout() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
- getEventBuilder() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The actual Event Message
- getEventBus() - Method in class org.axonframework.eventhandling.gateway.AbstractEventGateway
-
Returns the EventBus used by this EventGateway.
- getEventBus() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- getEventBus() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Returns the event bus used by this fixture.
- getEventBus() - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Returns the event bus used by this fixture.
- getEventBus() - Method in class org.axonframework.test.saga.SagaTestFixture
-
- getEventCipher() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getEventFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getEventIdentifier() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
- getEventIdentifier() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-
- getEventIdentifier() - Method in interface org.axonframework.eventhandling.EventData
-
Returns the identifier of the serialized event.
- getEventIdentifier() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-
- getEventOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The actual Event Message
- getEventOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
The actual Event Message
- getEventOrBuilder() - Method in interface io.axoniq.axonserver.grpc.event.EventWithTokenOrBuilder
-
The actual Event Message
- getEventProcessorInfo() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about Tracking Processors defined in the application.
- getEventProcessorInfo() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Information about Tracking Processors defined in the application.
- getEventProcessorInfo() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Information about Tracking Processors defined in the application.
- getEventProcessorInfoBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about Tracking Processors defined in the application.
- getEventProcessorInfoOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about Tracking Processors defined in the application.
- getEventProcessorInfoOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Information about Tracking Processors defined in the application.
- getEventProcessorInfoOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Information about Tracking Processors defined in the application.
- getEvents() - Method in class org.axonframework.springboot.SerializerProperties
-
The type of serializer to use to serialize the payload and meta data of Event Messages.
- getEventSerializer() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Get the serializer used by this storage engine when storing and retrieving events.
- GetEventsRequest - Class in io.axoniq.axonserver.grpc.event
-
Request message to open an Event Stream from the Event Store.
- GetEventsRequest.Builder - Class in io.axoniq.axonserver.grpc.event
-
Request message to open an Event Stream from the Event Store.
- GetEventsRequestOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- getEventStore() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Returns the event store this snapshotter uses to load domain events and store snapshot events.
- getEventStore() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- getEventStore() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Returns the event store used by this fixture.
- getExactSuperType(Type, Class<?>) - Static method in class org.axonframework.common.TypeReflectionUtils
-
Finds the most specific supertype of type whose erasure is searchClass.
- getExceptionDescriptions() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
-
Returns a
List
of
String
s describing the remote exception.
- getExceptionDescriptions() - Method in exception org.axonframework.messaging.RemoteHandlingException
-
Returns a
List
of
String
s describing the remote exception.
- getExceptionResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
-
Get the execution result in case the result is an exception.
- getExceptionRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the exception revision of the serialized reply message.
- getExceptionType() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the exception type of the serialized reply message.
- getExecutionResult() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- getExecutionResult() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Get the result of processing the
Message
.
- getExecutionResult() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Get the result of the task that was executed by this Unit of Work.
- getExecutionResults() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- getExecutor() - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
Returns the executor that executes snapshot taking tasks.
- getExpectedResponseType() - Method in class org.axonframework.messaging.responsetypes.AbstractResponseType
-
- getExpectedResponseType() - Method in interface org.axonframework.messaging.responsetypes.ResponseType
-
Gets actual response type or generic placeholder.
- getExpectedVersion() - Method in exception org.axonframework.modelling.command.ConflictingAggregateVersionException
-
Returns the version expected by the component loading the aggregate.
- getFailedField() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
-
Returns the field that failed comparison, if any.
- getFailedFieldActualValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
-
Returns the actual value of a failed field comparison, if any.
- getFailedFieldExpectedValue() - Method in class org.axonframework.test.matchers.EqualFieldsMatcher
-
Returns the expected value of a failed field comparison, if any.
- getFallbackUrl() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
-
Returns the URL relative to the host's root to retrieve Instance Meta Data from.
- getFieldValue(Field, Object) - Static method in class org.axonframework.common.ReflectionUtils
-
Returns the value of the given field
in the given object
.
- getFilesCompleted() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when all historic events have been included in the query results
- getFilesCompleted() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
Provided when all historic events have been included in the query results
- getFilesCompleted() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsResponseOrBuilder
-
Provided when all historic events have been included in the query results
- getFilesCompletedBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when all historic events have been included in the query results
- getFilesCompletedOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when all historic events have been included in the query results
- getFilesCompletedOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
Provided when all historic events have been included in the query results
- getFilesCompletedOrBuilder() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsResponseOrBuilder
-
Provided when all historic events have been included in the query results
- getFirstToken(GetFirstTokenRequest) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreBlockingStub
-
Retrieves the first token available in event store (typically 0).
- getFirstToken(GetFirstTokenRequest) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreFutureStub
-
Retrieves the first token available in event store (typically 0).
- getFirstToken(GetFirstTokenRequest, StreamObserver<TrackingToken>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreImplBase
-
Retrieves the first token available in event store (typically 0).
- getFirstToken(GetFirstTokenRequest, StreamObserver<TrackingToken>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreStub
-
Retrieves the first token available in event store (typically 0).
- getFirstToken() - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
- getFirstToken(String) - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
Asynchronously returns the first
TrackingToken
available in Event Store.
- GetFirstTokenRequest - Class in io.axoniq.axonserver.grpc.event
-
Request message to receive the first Token (Tail Token) of the Event Stream
- GetFirstTokenRequest.Builder - Class in io.axoniq.axonserver.grpc.event
-
Request message to receive the first Token (Tail Token) of the Event Stream
- GetFirstTokenRequestOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- getFlowControl() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to increase the number of instructions AxonServer may send to this component
- getFlowControl() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction to increase the number of instructions AxonServer may send to this component
- getFlowControl() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction to increase the number of instructions AxonServer may send to this component
- getFlowControl() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Grant permits to AxonServer to send a number of messages to the client
- getFlowControl() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Grant permits to AxonServer to send a number of messages to the client
- getFlowControl() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Grant permits to AxonServer to send a number of messages to the client
- getFlowControl() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Allows the Server to provide additional Updates to be sent.
- getFlowControl() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Allows the Server to provide additional Updates to be sent.
- getFlowControl() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Allows the Server to provide additional Updates to be sent.
- getFlowControlBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to increase the number of instructions AxonServer may send to this component
- getFlowControlBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Grant permits to AxonServer to send a number of messages to the client
- getFlowControlBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Allows the Server to provide additional Updates to be sent.
- getFlowControlOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to increase the number of instructions AxonServer may send to this component
- getFlowControlOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction to increase the number of instructions AxonServer may send to this component
- getFlowControlOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction to increase the number of instructions AxonServer may send to this component
- getFlowControlOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Grant permits to AxonServer to send a number of messages to the client
- getFlowControlOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Grant permits to AxonServer to send a number of messages to the client
- getFlowControlOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Grant permits to AxonServer to send a number of messages to the client
- getFlowControlOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Allows the Server to provide additional Updates to be sent.
- getFlowControlOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Allows the Server to provide additional Updates to be sent.
- getFlowControlOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Allows the Server to provide additional Updates to be sent.
- getFor(String) - Method in interface org.axonframework.axonserver.connector.command.CommandLoadFactorProvider
-
Returns the load factor value for the specific command
- getFromCode(String) - Static method in enum org.axonframework.axonserver.connector.ErrorCode
-
- getFromSequenceNr() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Sequence Number of the first event expected
- getFromSequenceNr() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
The Sequence Number of the first event expected
- getFromSequenceNr() - Method in interface io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequestOrBuilder
-
The Sequence Number of the first event expected
- getGaps() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
-
- getGeneral() - Method in class org.axonframework.springboot.SerializerProperties
-
The type of serializer to use to serialize any type of object, for which no more specific serializer is
configured.
- getGetFirstTokenMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getGetInitialResult() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Requests the initial result of a subscription query to be sent.
- getGetInitialResult() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Requests the initial result of a subscription query to be sent.
- getGetInitialResult() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Requests the initial result of a subscription query to be sent.
- getGetInitialResultBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Requests the initial result of a subscription query to be sent.
- getGetInitialResultOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Requests the initial result of a subscription query to be sent.
- getGetInitialResultOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Requests the initial result of a subscription query to be sent.
- getGetInitialResultOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Requests the initial result of a subscription query to be sent.
- getGetLastTokenMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getGetPlatformServerMethod() - Static method in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc
-
- getGetTokenAtMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getGlobalIndex() - Method in class org.axonframework.eventhandling.GlobalSequenceTrackingToken
-
Get the global sequence number of the event
- getGossip() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
- getGroupIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
-
Returns the Quartz group identifier.
- getGrpcPort() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The port number for gRPC connections
- getGrpcPort() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
The port number for gRPC connections
- getGrpcPort() - Method in interface io.axoniq.axonserver.grpc.control.NodeInfoOrBuilder
-
The port number for gRPC connections
- getHandlerEnhancerDefinition() - Method in class org.axonframework.messaging.annotation.MultiHandlerDefinition
-
Returns handler enhancer definition used to wrap handlers.
- getHandlerInterceptors() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-
- getHandlerInterceptors() - Method in interface org.axonframework.eventhandling.EventProcessor
-
- getHandlers() - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
-
- getHandlers(Class<?>) - Method in class org.axonframework.messaging.annotation.AnnotatedHandlerInspector
-
Returns a list of detected members of given type
that are capable of handling certain messages.
- getHeartbeat() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- getHeartbeat() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- getHeartbeat() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- getHeartbeat() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- getHeartbeat() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- getHeartbeat() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- getHeartbeatBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- getHeartbeatBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- getHeartbeatOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- getHeartbeatOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- getHeartbeatOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- getHeartbeatOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- getHeartbeatOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- getHeartbeatOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- getHostName() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The host name to use when connecting to this node
- getHostName() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
The host name to use when connecting to this node
- getHostName() - Method in interface io.axoniq.axonserver.grpc.control.NodeInfoOrBuilder
-
The host name to use when connecting to this node
- getHostNameBytes() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The host name to use when connecting to this node
- getHostNameBytes() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
The host name to use when connecting to this node
- getHostNameBytes() - Method in interface io.axoniq.axonserver.grpc.control.NodeInfoOrBuilder
-
The host name to use when connecting to this node
- getHosts() - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
-
- getHttpPort() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The port number for HTTP connections
- getHttpPort() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
The port number for HTTP connections
- getHttpPort() - Method in interface io.axoniq.axonserver.grpc.control.NodeInfoOrBuilder
-
The port number for HTTP connections
- getId() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
-
The unique identifier of this entry.
- getIdentifier() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-
- getIdentifier() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- getIdentifier() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-
- getIdentifier() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- getIdentifier() - Method in class org.axonframework.domain.GenericMessage
-
Deprecated.
Get the message's identifier.
- getIdentifier() - Method in interface org.axonframework.eventhandling.EventMessage
-
Returns the identifier of this event.
- getIdentifier() - Method in class org.axonframework.messaging.AbstractMessage
-
- getIdentifier() - Method in interface org.axonframework.messaging.Message
-
Returns the identifier of this message.
- getIdentifier() - Method in class org.axonframework.messaging.MessageDecorator
-
- getIdentifier() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- getIdentifier() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
-
The identifier of the Aggregate targeted with this scope
- getIdentifier(T) - Method in interface org.axonframework.modelling.command.inspection.EntityModel
-
Get the identifier of the given target
entity.
- getIdentifier() - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
-
Returns the identifier of the targeted Aggregate.
- getIdentifier() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
-
The identifier of the Saga targeted with this scope
- getIdentifiers() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
-
- getIdValues(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- getIdValues(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The values which, when combined, uniquely update this row.
- getIdValues(int) - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The values which, when combined, uniquely update this row.
- getIdValuesBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- getIdValuesBuilderList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- getIdValuesCount() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- getIdValuesCount() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The values which, when combined, uniquely update this row.
- getIdValuesCount() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The values which, when combined, uniquely update this row.
- getIdValuesList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- getIdValuesList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The values which, when combined, uniquely update this row.
- getIdValuesList() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The values which, when combined, uniquely update this row.
- getIdValuesOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- getIdValuesOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The values which, when combined, uniquely update this row.
- getIdValuesOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The values which, when combined, uniquely update this row.
- getIdValuesOrBuilderList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- getIdValuesOrBuilderList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The values which, when combined, uniquely update this row.
- getIdValuesOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The values which, when combined, uniquely update this row.
- getIndex() - Method in class org.axonframework.eventhandling.GapAwareTrackingToken
-
Get the highest global sequence of events seen up until the point of this tracking token.
- getInitialAssociationValue() - Method in class org.axonframework.modelling.saga.SagaInitializationPolicy
-
Returns the initial association value for a newly created saga.
- getInitialNrOfPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-
- getInitialNrOfPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getInitialResult() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Initial Response
- getInitialResult() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Provides an Initial Response
- getInitialResult() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Provides an Initial Response
- getInitialResultBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Initial Response
- getInitialResultOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Initial Response
- getInitialResultOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Provides an Initial Response
- getInitialResultOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Provides an Initial Response
- getInitialSegmentCount() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Returns the number of initial segments that should be created, if no segments are already present.
- getInitialSegmentsCount() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
- getInitialSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The sequence number of the first event to receive
- getInitialSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
The sequence number of the first event to receive
- getInitialSequence() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateEventsRequestOrBuilder
-
The sequence number of the first event to receive
- getInitialSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The minimal sequence number of the snapshots to retrieve
- getInitialSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
The minimal sequence number of the snapshots to retrieve
- getInitialSequence() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequestOrBuilder
-
The minimal sequence number of the snapshots to retrieve
- getInitialTrackingToken() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
- getInstance() - Static method in class org.axonframework.common.annotation.PriorityAnnotationComparator
-
Returns the instance of the comparator.
- getInstance() - Static method in class org.axonframework.common.IdentifierFactory
-
Returns an instance of the IdentifierFactory discovered on the classpath.
- getInstance() - Static method in class org.axonframework.common.IdentifierValidator
-
Returns the singleton instance of the IdentifierValidator.
- getInstance() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
-
- getInstance() - Static method in class org.axonframework.modelling.saga.SagaLifecycle
-
- getInstant() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
Timestamp expressed as milliseconds since epoch
- getInstant() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest
-
Timestamp expressed as milliseconds since epoch
- getInstant() - Method in interface io.axoniq.axonserver.grpc.event.GetTokenAtRequestOrBuilder
-
Timestamp expressed as milliseconds since epoch
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
Instruction identifier.
- getInstructionId() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderInboundOrBuilder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction identifier.
- getInstructionId() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Instruction identifier.
- getInstructionId() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction identifier.
- getInstructionId() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
The identifier of the instruction
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
The identifier of the instruction
- getInstructionId() - Method in interface io.axoniq.axonserver.grpc.InstructionAckOrBuilder
-
The identifier of the instruction
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Instruction identifier.
- getInstructionId() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Instruction identifier.
- getInstructionId() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Instruction identifier.
- getInstructionId() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
Instruction identifier.
- getInstructionIdBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderInboundOrBuilder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction identifier.
- getInstructionIdBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Instruction identifier.
- getInstructionIdBytes() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction identifier.
- getInstructionIdBytes() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
The identifier of the instruction
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
The identifier of the instruction
- getInstructionIdBytes() - Method in interface io.axoniq.axonserver.grpc.InstructionAckOrBuilder
-
The identifier of the instruction
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Instruction identifier.
- getInstructionIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Instruction identifier.
- getInstructionIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Instruction identifier.
- getInstructionIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Instruction identifier.
- getInvocationInterceptorChain() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Returns the InterceptorChain for the invocation process registered with this entry, or null
if none
is available.
- getInvokerId() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Returns the Identifier of the invoker that is chosen to handle this entry.
- getIsLive() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
- getIsLive() - Method in class org.axonframework.modelling.command.AggregateLifecycle
-
Indicates whether this Aggregate instance is 'live'.
- getIsLive() - Method in class org.axonframework.modelling.command.inspection.AnnotatedAggregate
-
- getIsLive() - Method in class org.axonframework.test.aggregate.StubAggregateLifecycle
-
- getJgroups() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
-
Returns the JGroups configuration to use (if JGroups is on the classpath).
- getJobIdentifier() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzScheduleToken
-
Returns the Quartz job identifier.
- getKeepAliveTime() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getKeepAliveTimeout() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getKey() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The type of processing message.
- getKey() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
The type of processing message.
- getKey() - Method in interface io.axoniq.axonserver.grpc.ProcessingInstructionOrBuilder
-
The type of processing message.
- getKey() - Method in class org.axonframework.modelling.saga.AssociationValue
-
Returns the key of this association value.
- getKeyValue() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The type of processing message.
- getKeyValue() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
The type of processing message.
- getKeyValue() - Method in interface io.axoniq.axonserver.grpc.ProcessingInstructionOrBuilder
-
The type of processing message.
- getLastSeparator() - Method in class org.axonframework.test.matchers.ListMatcher
-
The separator to use between the two last events.
- getLastSeparator() - Method in class org.axonframework.test.matchers.ListWithAnyOfMatcher
-
- getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.ConcatenatingDomainEventStream
-
- getLastSequenceNumber() - Method in interface org.axonframework.eventsourcing.eventstore.DomainEventStream
-
Get the highest known sequence number in the upstream event entry stream.
- getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.FilteringDomainEventStream
-
- getLastSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.IteratorBackedDomainEventStream
-
- getLastToken(GetLastTokenRequest) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreBlockingStub
-
Retrieves the last committed token in event store.
- getLastToken(GetLastTokenRequest) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreFutureStub
-
Retrieves the last committed token in event store.
- getLastToken(GetLastTokenRequest, StreamObserver<TrackingToken>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreImplBase
-
Retrieves the last committed token in event store.
- getLastToken(GetLastTokenRequest, StreamObserver<TrackingToken>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreStub
-
Retrieves the last committed token in event store.
- getLastToken() - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
- getLastToken(String) - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
Asynchronously returns the last
TrackingToken
committed in Event Store.
- GetLastTokenRequest - Class in io.axoniq.axonserver.grpc.event
-
Request message to receive the last Token (Head Token) of the Event Stream
- GetLastTokenRequest.Builder - Class in io.axoniq.axonserver.grpc.event
-
Request message to receive the last Token (Head Token) of the Event Stream
- GetLastTokenRequestOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- getListAggregateEventsMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getListAggregateSnapshotsMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getListenerInvocationErrorHandler() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- getListEventsMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getLiveEvents() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
Whether to keep the query running against incoming events once the Head of the Stream is reached
- getLiveEvents() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
Whether to keep the query running against incoming events once the Head of the Stream is reached
- getLiveEvents() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsRequestOrBuilder
-
Whether to keep the query running against incoming events once the Head of the Stream is reached
- getLoadFactor() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A number that represents the client's relative load capacity compared to other clients.
- getLoadFactor() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
A number that represents the client's relative load capacity compared to other clients.
- getLoadFactor() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
A number that represents the client's relative load capacity compared to other clients.
- getLoadFactor() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Returns the current load factor of this node.
- getLoadFactor() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
-
Returns the load factor for this instance of the Distributed Command Bus (default 100).
- getLocation() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A description of the location (client component, server) where the error occurred
- getLocation() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A description of the location (client component, server) where the error occurred
- getLocation() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A description of the location (client component, server) where the error occurred
- getLocationBytes() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A description of the location (client component, server) where the error occurred
- getLocationBytes() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A description of the location (client component, server) where the error occurred
- getLocationBytes() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A description of the location (client component, server) where the error occurred
- getMask() - Method in class org.axonframework.eventhandling.Segment
-
Getter for the segment mask.
- getMatchers() - Method in class org.axonframework.test.matchers.ListMatcher
-
Returns a read-only list of Matchers, in the order they were provided in the constructor.
- getMatchOutcome(ConditionContext, AnnotatedTypeMetadata) - Method in class org.axonframework.springboot.util.AbstractQualifiedBeanCondition
-
- getMaxGrpcBufferedMessages() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getMaxMessageSize() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getMaxResults() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The maximum number of results to stream
- getMaxResults() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
The maximum number of results to stream
- getMaxResults() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequestOrBuilder
-
The maximum number of results to stream
- getMaxSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The maximum sequence number of the snapshots to retrieve
- getMaxSequence() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
The maximum sequence number of the snapshots to retrieve
- getMaxSequence() - Method in interface io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequestOrBuilder
-
The maximum sequence number of the snapshots to retrieve
- getMaxThreadCount() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
- getMeasurements() - Method in class org.axonframework.micrometer.reservoir.SlidingTimeWindowReservoir
-
Retrieve the measurements
- getMember(String, CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
-
Returns the member instance to which the given message
should be routed.
- getMembers() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash
-
Returns the set of members registered with this consistent hash instance.
- getMergeEventProcessorSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to merge two Segments in a Tracking Event Processor
- getMergeEventProcessorSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction to merge two Segments in a Tracking Event Processor
- getMergeEventProcessorSegment() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction to merge two Segments in a Tracking Event Processor
- getMergeEventProcessorSegmentBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to merge two Segments in a Tracking Event Processor
- getMergeEventProcessorSegmentOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to merge two Segments in a Tracking Event Processor
- getMergeEventProcessorSegmentOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction to merge two Segments in a Tracking Event Processor
- getMergeEventProcessorSegmentOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction to merge two Segments in a Tracking Event Processor
- getMessage() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A human readable message explaining the error
- getMessage() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A human readable message explaining the error
- getMessage() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A human readable message explaining the error
- getMessage() - Method in class org.axonframework.commandhandling.distributed.CommandCallbackWrapper
-
Returns the command message that was sent.
- getMessage() - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-
- getMessage() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- getMessage() - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- getMessage() - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Get the Message that is being processed in this context.
- getMessage() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Get the message that is being processed by the Unit of Work.
- getMessageBytes() - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A human readable message explaining the error
- getMessageBytes() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
A human readable message explaining the error
- getMessageBytes() - Method in interface io.axoniq.axonserver.grpc.ErrorMessageOrBuilder
-
A human readable message explaining the error
- getMessageId() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A unique identifier for this subscription.
- getMessageId() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
A unique identifier for this subscription.
- getMessageId() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
A unique identifier for this subscription.
- getMessageId() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
A unique identifier for this message
- getMessageId() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
A unique identifier for this message
- getMessageId() - Method in interface io.axoniq.axonserver.grpc.query.QueryCompleteOrBuilder
-
A unique identifier for this message
- getMessageId() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of this Message
- getMessageId() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The unique identifier of this Message
- getMessageId() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The unique identifier of this Message
- getMessageIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A unique identifier for this subscription.
- getMessageIdBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
A unique identifier for this subscription.
- getMessageIdBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandSubscriptionOrBuilder
-
A unique identifier for this subscription.
- getMessageIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
A unique identifier for this message
- getMessageIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
A unique identifier for this message
- getMessageIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryCompleteOrBuilder
-
A unique identifier for this message
- getMessageIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of this Message
- getMessageIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The unique identifier of this Message
- getMessageIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The unique identifier of this Message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the Command Message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The unique identifier of the Command Message
- getMessageIdentifier() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The unique identifier of the Command Message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the response message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
The unique identifier of the response message
- getMessageIdentifier() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
The unique identifier of the response message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The unique identifier of this event
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The unique identifier of this event
- getMessageIdentifier() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The unique identifier of this event
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The message ID of the incoming Query
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The message ID of the incoming Query
- getMessageIdentifier() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The message ID of the incoming Query
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Response Message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
The unique identifier of the Response Message
- getMessageIdentifier() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
The unique identifier of the Response Message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The unique identifier of this Update
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The unique identifier of this Update
- getMessageIdentifier() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The unique identifier of this Update
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The unique identifier for this message
- getMessageIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
The unique identifier for this message
- getMessageIdentifier() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
The unique identifier for this message
- getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getMessageIdentifier() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the identifier of the message wrapping the object to upcast.
- getMessageIdentifier() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the Command Message
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The unique identifier of the Command Message
- getMessageIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The unique identifier of the Command Message
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the response message
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
The unique identifier of the response message
- getMessageIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
The unique identifier of the response message
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The unique identifier of this event
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The unique identifier of this event
- getMessageIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The unique identifier of this event
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The message ID of the incoming Query
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The message ID of the incoming Query
- getMessageIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The message ID of the incoming Query
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Response Message
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
The unique identifier of the Response Message
- getMessageIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
The unique identifier of the Response Message
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The unique identifier of this Update
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The unique identifier of this Update
- getMessageIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The unique identifier of this Update
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The unique identifier for this message
- getMessageIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
The unique identifier for this message
- getMessageIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
The unique identifier for this message
- getMessages() - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
Get the batch of messages that is being processed (or has been processed) by this unit of work.
- getMessages() - Method in class org.axonframework.springboot.SerializerProperties
-
The type of serializer to use to serialize the payload and meta data of Messages.
- getMessageSource() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-
Returns the message source from which this processor receives its events
- getMessageSource() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
- getMetaData() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.command.Command
-
Deprecated.
- getMetaData() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Deprecated.
- getMetaData() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.event.Event
-
Deprecated.
- getMetaData() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Deprecated.
- getMetaData() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Deprecated.
- getMetaData() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
Deprecated.
- getMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
Deprecated.
- getMetaData() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
Deprecated.
- getMetaData() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-
- getMetaData() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
Returns the serialized data of the MetaData of the serialized Event.
- getMetaData() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- getMetaData() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-
- getMetaData() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- getMetaData() - Method in class org.axonframework.domain.GenericMessage
-
Deprecated.
Get the message's metadata.
- getMetaData() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-
- getMetaData() - Method in interface org.axonframework.eventhandling.EventData
-
Returns the serialized data of the MetaData of the serialized Event.
- getMetaData() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-
- getMetaData() - Method in class org.axonframework.messaging.GenericMessage
-
- getMetaData() - Method in interface org.axonframework.messaging.Message
-
Returns the meta data for this event.
- getMetaData() - Method in class org.axonframework.messaging.MessageDecorator
-
- getMetaData() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- getMetaData() - Method in class org.axonframework.serialization.SerializedMessage
-
- getMetaData() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getMetaData() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the meta data of the message wrapping the object being upcast.
- getMetaData() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.command.Command
-
- getMetaDataCount() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
- getMetaDataCount() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.event.Event
-
- getMetaDataCount() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Meta Data of the Event
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- getMetaDataCount() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Meta Data providing contextual information of the Query
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
- getMetaDataCount() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any Meta Data describing the context of the Response Message
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- getMetaDataCount() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- getMetaDataCount() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
Meta Data providing contextual information of the Update
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.command.Command
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataMap() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataMap() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Meta Data of the Event
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Meta Data of the Event
- getMetaDataMap() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Meta Data of the Event
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Meta Data providing contextual information of the Query
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Meta Data providing contextual information of the Query
- getMetaDataMap() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Meta Data providing contextual information of the Query
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any Meta Data describing the context of the Response Message
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any Meta Data describing the context of the Response Message
- getMetaDataMap() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any Meta Data describing the context of the Response Message
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
Meta Data providing contextual information of the Update
- getMetaDataMap() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
Meta Data providing contextual information of the Update
- getMetaDataMap() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
Meta Data providing contextual information of the Update
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.command.Command
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataOrDefault(String, MetaDataValue) - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataOrDefault(String, MetaDataValue) - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Meta Data of the Event
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Meta Data of the Event
- getMetaDataOrDefault(String, MetaDataValue) - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Meta Data of the Event
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Meta Data providing contextual information of the Query
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Meta Data providing contextual information of the Query
- getMetaDataOrDefault(String, MetaDataValue) - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Meta Data providing contextual information of the Query
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any Meta Data describing the context of the Response Message
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any Meta Data describing the context of the Response Message
- getMetaDataOrDefault(String, MetaDataValue) - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any Meta Data describing the context of the Response Message
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
Meta Data providing contextual information of the Update
- getMetaDataOrDefault(String, MetaDataValue) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
Meta Data providing contextual information of the Update
- getMetaDataOrDefault(String, MetaDataValue) - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
Meta Data providing contextual information of the Update
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.command.Command
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Meta Data entries of the Command Message, providing contextual information to the recipient
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Any meta data entries providing contextual information back to the dispatcher
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Meta Data of the Event
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Meta Data of the Event
- getMetaDataOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Meta Data of the Event
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Meta Data providing contextual information of the Query
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Meta Data providing contextual information of the Query
- getMetaDataOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Meta Data providing contextual information of the Query
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any Meta Data describing the context of the Response Message
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any Meta Data describing the context of the Response Message
- getMetaDataOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any Meta Data describing the context of the Response Message
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
Meta Data providing contextual information of the Update
- getMetaDataOrThrow(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
Meta Data providing contextual information of the Update
- getMetaDataOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
Meta Data providing contextual information of the Update
- getMetrics() - Method in class org.axonframework.metrics.CapacityMonitor
-
- getMetrics() - Method in class org.axonframework.metrics.EventProcessorLatencyMonitor
-
- getMetrics() - Method in class org.axonframework.metrics.MessageCountingMonitor
-
- getMetrics() - Method in class org.axonframework.metrics.MessageTimerMonitor
-
- getMetrics() - Method in class org.axonframework.metrics.PayloadTypeMessageMonitorWrapper
-
- getMissingEntries() - Method in class org.axonframework.test.matchers.MapEntryMatcher
-
- getMode() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- getMode() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- getMode() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- getMode() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Returns the type of processor to configure.
- getModeBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- getModeBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- getModeBytes() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- getModules() - Method in interface org.axonframework.config.Configuration
-
Returns all modules that have been registered with this Configuration.
- getModules() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- getMutableMetaData() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Deprecated.
- getMutableMetaData() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Deprecated.
- getMutableMetaData() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
Deprecated.
- getMutableMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Deprecated.
- getMutableMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Deprecated.
- getMutableMetaData() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
Deprecated.
- getMutableTags() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Deprecated.
- getMutableValues() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
Deprecated.
- getName() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name of the command, used for routing it to a destination capable of handling it
- getName() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The name of the command, used for routing it to a destination capable of handling it
- getName() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The name of the command, used for routing it to a destination capable of handling it
- getName() - Method in class org.axonframework.eventhandling.AbstractEventProcessor
-
- getName() - Method in interface org.axonframework.eventhandling.EventProcessor
-
Returns the name of this event processor.
- getName() - Method in interface org.axonframework.serialization.SerializedType
-
Returns the name of the serialized type.
- getName() - Method in class org.axonframework.serialization.SimpleSerializedType
-
- getNameBytes() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name of the command, used for routing it to a destination capable of handling it
- getNameBytes() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The name of the command, used for routing it to a destination capable of handling it
- getNameBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The name of the command, used for routing it to a destination capable of handling it
- getNewPermitsThreshold() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-
- getNewPermitsThreshold() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getNodeName() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The unique name of the node to connect with, for purpose of debugging
- getNodeName() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
The unique name of the node to connect with, for purpose of debugging
- getNodeName() - Method in interface io.axoniq.axonserver.grpc.control.NodeInfoOrBuilder
-
The unique name of the node to connect with, for purpose of debugging
- getNodeNameBytes() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The unique name of the node to connect with, for purpose of debugging
- getNodeNameBytes() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
The unique name of the node to connect with, for purpose of debugging
- getNodeNameBytes() - Method in interface io.axoniq.axonserver.grpc.control.NodeInfoOrBuilder
-
The unique name of the node to connect with, for purpose of debugging
- getNodeNotification() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- getNodeNotification() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- getNodeNotification() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- getNodeNotificationBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- getNodeNotificationOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- getNodeNotificationOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- getNodeNotificationOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- getNonEmptyOrDefault(T, T) - Static method in class org.axonframework.common.ObjectUtils
-
Returns the given instance, if not null
or of zero length, or otherwise the given defaultValue
.
- getNrOfHandlers() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The number of Query Handlers registered within this Component with the same details.
- getNrOfHandlers() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The number of Query Handlers registered within this Component with the same details.
- getNrOfHandlers() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The number of Query Handlers registered within this Component with the same details.
- getNrOfNewPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-
- getNrOfNewPermits() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.command.CommandProviderInbound.RequestCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.command.CommandProviderOutbound.RequestCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.RequestCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.RequestCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.event.QueryEventsResponse.DataCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.event.QueryValue.DataCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.MetaDataValue.DataCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.ProcessingKey
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.query.QueryProviderInbound.RequestCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.query.QueryProviderOutbound.RequestCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.RequestCase
-
- getNumber() - Method in enum io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.ResponseCase
-
- getNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The number of messages the server may send before it needs to wait for more permits
- getNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The number of messages the server may send before it needs to wait for more permits
- getNumberOfPermits() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The number of messages the server may send before it needs to wait for more permits
- getNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The number of results AxonServer may send before new permits need to be provided
- getNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
The number of results AxonServer may send before new permits need to be provided
- getNumberOfPermits() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsRequestOrBuilder
-
The number of results AxonServer may send before new permits need to be provided
- getNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The number of messages the Server may send before needing to await additional permits
- getNumberOfPermits() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
The number of messages the Server may send before needing to await additional permits
- getNumberOfPermits() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryOrBuilder
-
The number of messages the Server may send before needing to await additional permits
- getNumberValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The (64 bits) integer value
- getNumberValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
The (64 bits) integer value
- getNumberValue() - Method in interface io.axoniq.axonserver.grpc.event.QueryValueOrBuilder
-
The (64 bits) integer value
- getNumberValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The numeric value of the Meta Data entry.
- getNumberValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
The numeric value of the Meta Data entry.
- getNumberValue() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
The numeric value of the Meta Data entry.
- getObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
De-serializes the object and returns the result.
- getObject() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
- getObject() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
- getObject() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-
- getObject() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
-
- getObject() - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
-
- getObject() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
-
- getObject() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
-
- getObject() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- getObject() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- getObject() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
- getObjectMapper() - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Returns the ObjectMapper used by this serializer, allowing for configuration of the serialization settings.
- getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
- getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
- getObjectType() - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-
- getObjectType() - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
-
- getObjectType() - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
-
- getObjectType() - Method in class org.axonframework.spring.config.RepositoryFactoryBean
-
- getObjectType() - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
-
- getObjectType() - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- getObjectType() - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- getObjectType() - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
- getOnePartOf() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The fraction this segment processes.
- getOnePartOf() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
The fraction this segment processes.
- getOnePartOf() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatusOrBuilder
-
The fraction this segment processes.
- getOpenStreamMethod() - Static method in class io.axoniq.axonserver.grpc.command.CommandServiceGrpc
-
- getOpenStreamMethod() - Static method in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc
-
- getOpenStreamMethod() - Static method in class io.axoniq.axonserver.grpc.query.QueryServiceGrpc
-
- getOrComputeResource(String, Function<? super String, R>) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns the resource attached under given name
.
- getOrDefault(String, Case, Collection<Handler>) - Method in interface org.axonframework.axonserver.connector.Handlers
-
- getOrDefault(T, Supplier<T>) - Static method in class org.axonframework.common.ObjectUtils
-
Returns the given instance, if not null
, or otherwise the value provided by defaultProvider
.
- getOrDefault(T, T) - Static method in class org.axonframework.common.ObjectUtils
-
Returns the given instance, if not null
, or otherwise the given defaultValue
.
- getOrDefaultResource(String, R) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns the resource attached under given name
.
- getOriginServer() - Method in exception org.axonframework.axonserver.connector.command.AxonServerRemoteCommandHandlingException
-
Returns the name of the server that reported the error.
- getOverflowStrategy() - Method in class org.axonframework.queryhandling.SubscriptionQueryBackpressure
-
Gets the overflow strategy.
- getOwner() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the identifier of the process (JVM) having a claim on this token, or null
if the token isn't
claimed.
- getParserForType() - Method in class io.axoniq.axonserver.grpc.command.Command
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.Confirmation
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.Event
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.FlowControl
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- getParserForType() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
- getPauseEventProcessor() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- getPauseEventProcessor() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- getPauseEventProcessor() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- getPauseEventProcessorBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- getPauseEventProcessorOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- getPauseEventProcessorOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- getPauseEventProcessorOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- getPayload() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The payload of the Command, providing details on the instructions for the recipient
- getPayload() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The payload of the Command, providing details on the instructions for the recipient
- getPayload() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The payload of the Command, providing details on the instructions for the recipient
- getPayload() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The payload to provide as a result to the dispatcher
- getPayload() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
The payload to provide as a result to the dispatcher
- getPayload() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
The payload to provide as a result to the dispatcher
- getPayload() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Payload of the Event
- getPayload() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Payload of the Event
- getPayload() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Payload of the Event
- getPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
A payload accompanying the Query
- getPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
A payload accompanying the Query
- getPayload() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
A payload accompanying the Query
- getPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The Payload of the Response Message
- getPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
The Payload of the Response Message
- getPayload() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
The Payload of the Response Message
- getPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The object representing the Update
- getPayload() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The object representing the Update
- getPayload() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The object representing the Update
- getPayload() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-
- getPayload() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
- getPayload() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- getPayload() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-
- getPayload() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- getPayload() - Method in class org.axonframework.domain.GenericMessage
-
Deprecated.
Get the payload of this message.
- getPayload() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-
- getPayload() - Method in interface org.axonframework.eventhandling.EventData
-
Returns the serialized data of the Event Message's payload.
- getPayload() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-
- getPayload() - Method in class org.axonframework.messaging.GenericMessage
-
- getPayload() - Method in class org.axonframework.messaging.GenericResultMessage
-
- getPayload() - Method in interface org.axonframework.messaging.Message
-
Returns the payload of this Event.
- getPayload() - Method in class org.axonframework.messaging.MessageDecorator
-
- getPayload() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- getPayload() - Method in class org.axonframework.serialization.SerializedMessage
-
- getPayloadBuilder() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The payload of the Command, providing details on the instructions for the recipient
- getPayloadBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The payload to provide as a result to the dispatcher
- getPayloadBuilder() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Payload of the Event
- getPayloadBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
A payload accompanying the Query
- getPayloadBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The Payload of the Response Message
- getPayloadBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The object representing the Update
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The payload of the Command, providing details on the instructions for the recipient
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The payload of the Command, providing details on the instructions for the recipient
- getPayloadOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The payload of the Command, providing details on the instructions for the recipient
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The payload to provide as a result to the dispatcher
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
The payload to provide as a result to the dispatcher
- getPayloadOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
The payload to provide as a result to the dispatcher
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Payload of the Event
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The Payload of the Event
- getPayloadOrBuilder() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The Payload of the Event
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
A payload accompanying the Query
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
A payload accompanying the Query
- getPayloadOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
A payload accompanying the Query
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The Payload of the Response Message
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
The Payload of the Response Message
- getPayloadOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
The Payload of the Response Message
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The object representing the Update
- getPayloadOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
The object representing the Update
- getPayloadOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryUpdateOrBuilder
-
The object representing the Update
- getPayloadRevision() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the payload revision of the serialized payload of the command carried by this instance.
- getPayloadRevision() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the payload revision of the serialized reply message.
- getPayloadType() - Method in class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-
- getPayloadType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- getPayloadType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-
- getPayloadType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- getPayloadType() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the payload type of the serialized payload of the command carried by this instance.
- getPayloadType() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the payload type of the serialized reply message.
- getPayloadType() - Method in class org.axonframework.domain.GenericMessage
-
Deprecated.
Get the type of payload of this message.
- getPayloadType() - Method in class org.axonframework.messaging.GenericMessage
-
- getPayloadType() - Method in interface org.axonframework.messaging.Message
-
Returns the type of the payload.
- getPayloadType() - Method in class org.axonframework.messaging.MessageDecorator
-
- getPayloadType() - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- getPayloadType() - Method in class org.axonframework.serialization.SerializedMessage
-
- getPermits() - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The number of permits to provide
- getPermits() - Method in class io.axoniq.axonserver.grpc.FlowControl
-
The number of permits to provide
- getPermits() - Method in interface io.axoniq.axonserver.grpc.FlowControlOrBuilder
-
The number of permits to provide
- getPhase() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- getPhase() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
-
- getPhase() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
-
- getPlatformServer(ClientIdentification) - Method in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc.PlatformServiceBlockingStub
-
Obtains connection information for the Server that a Client should use for its connections.
- getPlatformServer(ClientIdentification) - Method in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc.PlatformServiceFutureStub
-
Obtains connection information for the Server that a Client should use for its connections.
- getPlatformServer(ClientIdentification, StreamObserver<PlatformInfo>) - Method in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc.PlatformServiceImplBase
-
Obtains connection information for the Server that a Client should use for its connections.
- getPlatformServer(ClientIdentification, StreamObserver<PlatformInfo>) - Method in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc.PlatformServiceStub
-
Obtains connection information for the Server that a Client should use for its connections.
- getPlatformStream(String, StreamObserver<PlatformOutboundInstruction>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Opens a Stream for platform instructions in given context
.
- getPrimary() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
The connection details of the node the client should connect with
- getPrimary() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
The connection details of the node the client should connect with
- getPrimary() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInfoOrBuilder
-
The connection details of the node the client should connect with
- getPrimaryBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
The connection details of the node the client should connect with
- getPrimaryOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
The connection details of the node the client should connect with
- getPrimaryOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
The connection details of the node the client should connect with
- getPrimaryOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInfoOrBuilder
-
The connection details of the node the client should connect with
- getPriority() - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-
- getPriority() - Method in class org.axonframework.common.property.DirectPropertyAccessStrategy
-
- getPriority() - Method in class org.axonframework.common.property.PropertyAccessStrategy
-
The priority of this strategy.
- getPriority() - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.command.Command
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructions(int) - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructions(int) - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructions(int) - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructions(int) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructions(int) - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsBuilderList() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsBuilderList() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsBuilderList() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsBuilderList() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.command.Command
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsCount() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsCount() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsCount() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsCount() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsCount() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.command.Command
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsList() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsList() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsList() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsList() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsList() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.Command
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.command.Command
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
Instructions for AxonServer when routing this Command Message
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
Instructions for AxonServer when routing this Command Response Message
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
Any instructions for components Routing or Handling the Query
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsOrBuilderList() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
Any instructions for components Routing or Handling the Response Message
- getProcessingInstructionsOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
Any instructions for components Routing or Handling the Response Message
- getProcessor() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The name of the processor requesting this stream.
- getProcessor() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The name of the processor requesting this stream.
- getProcessor() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The name of the processor requesting this stream.
- getProcessorBytes() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The name of the processor requesting this stream.
- getProcessorBytes() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The name of the processor requesting this stream.
- getProcessorBytes() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The name of the processor requesting this stream.
- getProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The logical name of this processor.
- getProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
The logical name of this processor.
- getProcessorName() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
The logical name of this processor.
- getProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
The name of the Event Processor
- getProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
The name of the Event Processor
- getProcessorName() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorReferenceOrBuilder
-
The name of the Event Processor
- getProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The name of the Event Processor
- getProcessorName() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
The name of the Event Processor
- getProcessorName() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorSegmentReferenceOrBuilder
-
The name of the Event Processor
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the name of the process to which this token belongs.
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
- getProcessorName() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
-
- getProcessorNameBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The logical name of this processor.
- getProcessorNameBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
The logical name of this processor.
- getProcessorNameBytes() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
The logical name of this processor.
- getProcessorNameBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
The name of the Event Processor
- getProcessorNameBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
The name of the Event Processor
- getProcessorNameBytes() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorReferenceOrBuilder
-
The name of the Event Processor
- getProcessorNameBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The name of the Event Processor
- getProcessorNameBytes() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
The name of the Event Processor
- getProcessorNameBytes() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorSegmentReferenceOrBuilder
-
The name of the Event Processor
- getProcessors() - Method in class org.axonframework.springboot.EventProcessorProperties
-
Returns the settings for each of the configured processors, by name.
- getProcessorsNotificationInitialDelay() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getProcessorsNotificationRate() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getProperty(Class<? extends T>, String) - Static method in class org.axonframework.common.property.PropertyAccessStrategy
-
Iterates over all known PropertyAccessStrategy implementations to create a
Property
instance for the
given parameters.
- getPublisherId() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Returns the Identifier of the publisher that is chosen to handle this entry.
- getPublisherInterceptorChain() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Returns the InterceptorChain for the publication process registered with this entry, or null
if
none is available.
- getQuery() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The query to execute against the Event Stream
- getQuery() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
The query to execute against the Event Stream
- getQuery() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsRequestOrBuilder
-
The query to execute against the Event Stream
- getQuery() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Query, for which this component is expected to provide a response
- getQuery() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Represents an incoming Query, for which this component is expected to provide a response
- getQuery() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Represents an incoming Query, for which this component is expected to provide a response
- getQuery() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The name of the Query to execute
- getQuery() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The name of the Query to execute
- getQuery() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The name of the Query to execute
- getQuery() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Query the Handler is subscribed to
- getQuery() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The name of the Query the Handler is subscribed to
- getQuery() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The name of the Query the Handler is subscribed to
- getQueryBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Query, for which this component is expected to provide a response
- getQueryBytes() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The query to execute against the Event Stream
- getQueryBytes() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
The query to execute against the Event Stream
- getQueryBytes() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsRequestOrBuilder
-
The query to execute against the Event Stream
- getQueryBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The name of the Query to execute
- getQueryBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The name of the Query to execute
- getQueryBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The name of the Query to execute
- getQueryBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Query the Handler is subscribed to
- getQueryBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The name of the Query the Handler is subscribed to
- getQueryBytes() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The name of the Query the Handler is subscribed to
- getQueryComplete() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Indicator that all responses for Query have been sent
- getQueryComplete() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Indicator that all responses for Query have been sent
- getQueryComplete() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Indicator that all responses for Query have been sent
- getQueryCompleteBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Indicator that all responses for Query have been sent
- getQueryCompleteOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Indicator that all responses for Query have been sent
- getQueryCompleteOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Indicator that all responses for Query have been sent
- getQueryCompleteOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Indicator that all responses for Query have been sent
- getQueryEventsMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getQueryFlowControl() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getQueryMethod() - Static method in class io.axoniq.axonserver.grpc.query.QueryServiceGrpc
-
- getQueryName() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- getQueryName() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- getQueryName() - Method in interface org.axonframework.queryhandling.annotation.QueryHandlingMember
-
Returns the name of the query the handler can handle
- getQueryName() - Method in class org.axonframework.queryhandling.GenericQueryMessage
-
- getQueryName() - Method in interface org.axonframework.queryhandling.QueryMessage
-
Returns the name identifying the query to be executed.
- getQueryOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Query, for which this component is expected to provide a response
- getQueryOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Represents an incoming Query, for which this component is expected to provide a response
- getQueryOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Represents an incoming Query, for which this component is expected to provide a response
- getQueryRequest() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The Query describing the desire for information
- getQueryRequest() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
The Query describing the desire for information
- getQueryRequest() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryOrBuilder
-
The Query describing the desire for information
- getQueryRequestBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The Query describing the desire for information
- getQueryRequestOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The Query describing the desire for information
- getQueryRequestOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
The Query describing the desire for information
- getQueryRequestOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryOrBuilder
-
The Query describing the desire for information
- getQueryResponse() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a Response to a Query received via the inbound stream
- getQueryResponse() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Sends a Response to a Query received via the inbound stream
- getQueryResponse() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Sends a Response to a Query received via the inbound stream
- getQueryResponseBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a Response to a Query received via the inbound stream
- getQueryResponseOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a Response to a Query received via the inbound stream
- getQueryResponseOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Sends a Response to a Query received via the inbound stream
- getQueryResponseOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Sends a Response to a Query received via the inbound stream
- getQueryStream(String, StreamObserver<QueryProviderInbound>) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Opens a Stream for incoming queries from AxonServer in the given context
.
- getQueryThreads() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getReader(Class<?>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Provides the ObjectReader, with which objects are read from the JSON form.
- getReadHighestSequenceNrMethod() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getRegister() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about the client being connected.
- getRegister() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Information about the client being connected.
- getRegister() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Information about the client being connected.
- getRegisterBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about the client being connected.
- getRegisterOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about the client being connected.
- getRegisterOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
Information about the client being connected.
- getRegisterOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
Information about the client being connected.
- getRegistration() - Method in class org.axonframework.queryhandling.UpdateHandlerRegistration
-
Gets the registration.
- getRegistry() - Method in class org.axonframework.metrics.GlobalMetricRegistry
-
Returns the global MetricRegistry
to which components are registered.
- getRegistry() - Method in class org.axonframework.micrometer.GlobalMetricRegistry
-
Returns the global MeterRegistry
to which components are registered.
- getReleaseSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- getReleaseSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- getReleaseSegment() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- getReleaseSegmentBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- getReleaseSegmentOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- getReleaseSegmentOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- getReleaseSegmentOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- getRemainingOfDeadline(long) - Static method in class org.axonframework.common.ObjectUtils
-
- getReplaying() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Indicates whether the Segment is "Replaying" historic events after a Reset.
- getReplaying() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
Indicates whether the Segment is "Replaying" historic events after a Reset.
- getReplaying() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatusOrBuilder
-
Indicates whether the Segment is "Replaying" historic events after a Reset.
- getRepository(Class<?>) - Static method in class org.axonframework.disruptor.commandhandling.CommandHandlerInvoker
-
Returns the Repository instance for Aggregate with given typeIdentifier
used by the
CommandHandlerInvoker that is running on the current thread.
- getRepository() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- getRepository() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Returns the repository used by this fixture.
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- getRequestCase() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderInboundOrBuilder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- getRequestCase() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- getRequestCase() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInboundInstructionOrBuilder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- getRequestCase() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- getRequestCase() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- getRequestCase() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- getRequestCase() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getRequestCase() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
- getRequestEventProcessorInfo() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- getRequestEventProcessorInfo() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
A request from AxonServer for status information of a specific Tracking Event Processor
- getRequestEventProcessorInfo() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- getRequestEventProcessorInfoBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- getRequestEventProcessorInfoOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- getRequestEventProcessorInfoOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
A request from AxonServer for status information of a specific Tracking Event Processor
- getRequestEventProcessorInfoOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- getRequestId() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
The identifier of the incoming query to complete
- getRequestId() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
The identifier of the incoming query to complete
- getRequestId() - Method in interface io.axoniq.axonserver.grpc.query.QueryCompleteOrBuilder
-
The identifier of the incoming query to complete
- getRequestIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
The identifier of the incoming query to complete
- getRequestIdBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
The identifier of the incoming query to complete
- getRequestIdBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryCompleteOrBuilder
-
The identifier of the incoming query to complete
- getRequestIdentifier() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the Command Message for which this is the response
- getRequestIdentifier() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
The unique identifier of the Command Message for which this is the response
- getRequestIdentifier() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
The unique identifier of the Command Message for which this is the response
- getRequestIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Query to which this is a response
- getRequestIdentifier() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
The unique identifier of the Query to which this is a response
- getRequestIdentifier() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
The unique identifier of the Query to which this is a response
- getRequestIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the Command Message for which this is the response
- getRequestIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
The unique identifier of the Command Message for which this is the response
- getRequestIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.command.CommandResponseOrBuilder
-
The unique identifier of the Command Message for which this is the response
- getRequestIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Query to which this is a response
- getRequestIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
The unique identifier of the Query to which this is a response
- getRequestIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.query.QueryResponseOrBuilder
-
The unique identifier of the Query to which this is a response
- getRequestReconnect() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer to the Application to migrate its connection to another node.
- getRequestReconnect() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
A request from AxonServer to the Application to migrate its connection to another node.
- getRequestReconnect() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
A request from AxonServer to the Application to migrate its connection to another node.
- getRequestReconnectBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer to the Application to migrate its connection to another node.
- getRequestReconnectOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer to the Application to migrate its connection to another node.
- getRequestReconnectOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
A request from AxonServer to the Application to migrate its connection to another node.
- getRequestReconnectOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
A request from AxonServer to the Application to migrate its connection to another node.
- getRequestStream() - Method in class org.axonframework.axonserver.connector.util.UpstreamAwareStreamObserver
-
Returns the request stream observer which allows interaction with the client stream.
- getResetPosition() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
-
Return the relative position at which a reset was triggered for this Segment.
- getResolver() - Method in class org.axonframework.eventhandling.ConcludesBatchParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.eventhandling.TimestampParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.messaging.annotation.AbstractAnnotatedParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.messaging.annotation.MessageIdentifierParameterResolverFactory
-
- getResolver() - Method in class org.axonframework.messaging.annotation.SourceIdParameterResolverFactory
-
- getResource(String) - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Returns the resource attached under given name
, or null
if no such resource is
available.
- getResponseCase() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- getResponseCase() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- getResponseCase() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
- getResponseType() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
An object describing the expectations of the Response Type
- getResponseType() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
An object describing the expectations of the Response Type
- getResponseType() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
An object describing the expectations of the Response Type
- getResponseType() - Method in class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- getResponseType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- getResponseType() - Method in class org.axonframework.queryhandling.GenericQueryMessage
-
- getResponseType() - Method in interface org.axonframework.queryhandling.QueryMessage
-
The type of response expected by the sender of the query
- getResponseTypeBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
An object describing the expectations of the Response Type
- getResponseTypeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
An object describing the expectations of the Response Type
- getResponseTypeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
An object describing the expectations of the Response Type
- getResponseTypeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
An object describing the expectations of the Response Type
- getResult() - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for the command handling to complete, and then returns its result.
- getResult(long, TimeUnit) - Method in class org.axonframework.commandhandling.callbacks.FutureCallback
-
Waits if necessary for at most the given time for the command handling to complete, and then retrieves its
result, if available.
- getResult() - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Returns the result of the command's execution, or null
if the command is not yet executed or
resulted in an exception.
- getResult() - Method in class org.axonframework.messaging.unitofwork.ExecutionResult
-
Return the execution result message.
- getResultName() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The type of Result this Handler produces
- getResultName() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The type of Result this Handler produces
- getResultName() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The type of Result this Handler produces
- getResultNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The type of Result this Handler produces
- getResultNameBytes() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
The type of Result this Handler produces
- getResultNameBytes() - Method in interface io.axoniq.axonserver.grpc.query.QuerySubscriptionOrBuilder
-
The type of Result this Handler produces
- getResultType() - Method in interface org.axonframework.queryhandling.annotation.QueryHandlingMember
-
Returns the return type declared by the handler
- getRevision() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The revision of the Payload Type
- getRevision() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
The revision of the Payload Type
- getRevision() - Method in interface io.axoniq.axonserver.grpc.event.PayloadDescriptionOrBuilder
-
The revision of the Payload Type
- getRevision() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The revision of the serialized form of the given type.
- getRevision() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
The revision of the serialized form of the given type.
- getRevision() - Method in interface io.axoniq.axonserver.grpc.SerializedObjectOrBuilder
-
The revision of the serialized form of the given type.
- getRevision() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
Returns the revision of the serialized saga
- getRevision() - Method in interface org.axonframework.serialization.SerializedType
-
Returns the revision identifier of the serialized object.
- getRevision() - Method in class org.axonframework.serialization.SimpleSerializedType
-
- getRevisionBytes() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The revision of the Payload Type
- getRevisionBytes() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
The revision of the Payload Type
- getRevisionBytes() - Method in interface io.axoniq.axonserver.grpc.event.PayloadDescriptionOrBuilder
-
The revision of the Payload Type
- getRevisionBytes() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The revision of the serialized form of the given type.
- getRevisionBytes() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
The revision of the serialized form of the given type.
- getRevisionBytes() - Method in interface io.axoniq.axonserver.grpc.SerializedObjectOrBuilder
-
The revision of the serialized form of the given type.
- getRevisionResolver() - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Returns the revision resolver used by this serializer.
- getRoutingKey(CommandMessage<?>) - Method in class org.axonframework.commandhandling.distributed.AbstractRoutingStrategy
-
- getRoutingKey(CommandMessage<?>) - Method in interface org.axonframework.commandhandling.distributed.RoutingStrategy
-
Generates a routing key for the given command
.
- getRow() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response message contains results of the Query
- getRow() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
Provided when the response message contains results of the Query
- getRow() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsResponseOrBuilder
-
Provided when the response message contains results of the Query
- getRowBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response message contains results of the Query
- getRowOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response message contains results of the Query
- getRowOrBuilder() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
Provided when the response message contains results of the Query
- getRowOrBuilder() - Method in interface io.axoniq.axonserver.grpc.event.QueryEventsResponseOrBuilder
-
Provided when the response message contains results of the Query
- getRunning() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Flag indicating whether the processor is running
- getRunning() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
Flag indicating whether the processor is running
- getRunning() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
Flag indicating whether the processor is running
- getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-
Returns the Saga Initialization Policy for a Saga of the given sagaType
and event
.
- getSagaCreationPolicy(EventMessage<?>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager
-
- getSagaId() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
Returns the identifier of the saga contained in this entry
- getSagaIdentifier() - Method in class org.axonframework.modelling.saga.AnnotatedSaga
-
- getSagaIdentifier() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
-
Returns the Saga Identifier contained in this entry.
- getSagaIdentifier() - Method in interface org.axonframework.modelling.saga.Saga
-
Returns the unique identifier of this saga.
- getSagaIdentifier() - Method in class org.axonframework.modelling.saga.SagaLifecycle
-
Retrieve a
String
denoting the identifier of this Saga.
- getSagaType() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-
Returns the class of Saga managed by this SagaManager
- getSagaType() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
Returns the type identifier of the serialized saga
- getSagaType() - Method in class org.axonframework.modelling.saga.repository.jpa.AssociationValueEntry
-
Returns the type (fully qualified class name) of the Saga this association value belongs to
- getSameConnection() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
Flag indicating that the connection may be reused to connect.
- getSameConnection() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
Flag indicating that the connection may be reused to connect.
- getSameConnection() - Method in interface io.axoniq.axonserver.grpc.control.PlatformInfoOrBuilder
-
Flag indicating that the connection may be reused to connect.
- getScheduledDeadlines() - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
Return all scheduled deadlines which have not been met (yet).
- getScheduledItems() - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
Returns a view of all the scheduled Events at the time this method is called.
- getScheduleId() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
-
Retrieve a
String
identifier representing the scheduled deadline; can be used together with the
deadlineName
to cancel the deadline.
- getScheduleTime() - Method in class org.axonframework.test.deadline.ScheduledDeadlineInfo
-
Retrieve the time as an
Instant
at which the deadline is scheduled.
- getScheduleTime() - Method in interface org.axonframework.test.eventscheduler.ScheduledItem
-
The time the event was scheduled for publication.
- getScheduleTime() - Method in class org.axonframework.test.eventscheduler.StubScheduleToken
-
- getSegment() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
-
The segment for which this status is valid.
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the segment index of the process to which this token belongs.
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.GenericTokenEntry
-
- getSegment() - Method in class org.axonframework.eventhandling.tokenstore.jpa.TokenEntry
-
- getSegmentId() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The ID of the Segment for which the status is reported
- getSegmentId() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
The ID of the Segment for which the status is reported
- getSegmentId() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatusOrBuilder
-
The ID of the Segment for which the status is reported
- getSegmentId() - Method in class org.axonframework.eventhandling.Segment
-
Getter for the segment identifier.
- getSegmentIdentifier() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The identifier of the Segment
- getSegmentIdentifier() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
The identifier of the Segment
- getSegmentIdentifier() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorSegmentReferenceOrBuilder
-
The identifier of the Segment
- getSegmentStatus(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatus(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatus(int) - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusBuilder(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusBuilderList() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusCount() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusCount() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusCount() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusList() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusList() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusList() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusOrBuilderList() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusOrBuilderList() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
Status details of each of the Segments for which Events are being processed.
- getSegmentStatusOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfoOrBuilder
-
Status details of each of the Segments for which Events are being processed.
- getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.FullConcurrencyPolicy
-
- getSequenceIdentifierFor(T) - Method in interface org.axonframework.eventhandling.async.SequencingPolicy
-
Returns the sequence identifier for the given event
.
- getSequenceIdentifierFor(EventMessage) - Method in class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-
- getSequenceIdentifierFor(Object) - Method in class org.axonframework.eventhandling.async.SequentialPolicy
-
- getSequenceNumber() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
- getSequenceNumber() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
-
- getSequenceNumber() - Method in interface org.axonframework.eventhandling.DomainEventData
-
Returns the sequence number of the event in the aggregate.
- getSequenceNumber() - Method in interface org.axonframework.eventhandling.DomainEventMessage
-
Returns the sequence number that allows DomainEvents originating from the same Aggregate to be placed in the
order of generation.
- getSequenceNumber() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-
- getSequenceNumber() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-
- getSequenceNumber() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
- getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getSequenceNumber() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the sequence number of the event in the aggregate, or an empty Optional if the message wrapping the
object being upcast does not contain a sequence number.
- getSequenceNumber() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getSequencingPolicy() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- getSequencingPolicy() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Returns the name of the bean that defines the Sequencing Policy for this processor.
- getSerializedException() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the serialized exception of the serialized reply message.
- getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the serialized metadata of the command carried by this instance.
- getSerializedMetaData() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the serialized meta data of the serialized reply message.
- getSerializedObject() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
Returns the serialized object to deserialize upon request
- getSerializedPayload() - Method in class org.axonframework.commandhandling.distributed.DispatchMessage
-
Returns the serialized payload of the command carried by this instance.
- getSerializedPayload() - Method in class org.axonframework.commandhandling.distributed.ReplyMessage
-
Returns the serialized payload of the serialized reply message.
- getSerializedSaga() - Method in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
Returns the serialized form of the Saga.
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.command.Command
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.Confirmation
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.Event
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.FlowControl
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- getSerializedSize() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
- getSerializedToken() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the serialized token.
- getSerializer() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
Returns the serializer to deserialize this object
- getServer() - Method in exception org.axonframework.axonserver.connector.command.AxonServerCommandDispatchException
-
Returns the name of the server that reported the error.
- getServer() - Method in exception org.axonframework.axonserver.connector.query.AxonServerRemoteQueryHandlingException
-
Return a
String
defining the location where the error originated.
- getServers() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getServiceDescriptor() - Static method in class io.axoniq.axonserver.grpc.command.CommandServiceGrpc
-
- getServiceDescriptor() - Static method in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc
-
- getServiceDescriptor() - Static method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- getServiceDescriptor() - Static method in class io.axoniq.axonserver.grpc.query.QueryServiceGrpc
-
- getSnapshot() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
Flag indicating whether the Event is a snapshot Event
- getSnapshot() - Method in class io.axoniq.axonserver.grpc.event.Event
-
Flag indicating whether the Event is a snapshot Event
- getSnapshot() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
Flag indicating whether the Event is a snapshot Event
- getSnapshotData(ResultSet) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Extracts the next snapshot entry from the given resultSet
.
- getSnapshotPrefetch() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getSnapshotSerializer() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Get the serializer used by this storage engine when storing and retrieving snapshots.
- getSnapshotTrigger() - Method in class org.axonframework.eventsourcing.EventSourcedAggregate
-
The trigger instance that monitors this aggregate to trigger a snapshot
- getSortValues(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- getSortValues(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The sorting values to use when sorting this response compared to the others.
- getSortValues(int) - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The sorting values to use when sorting this response compared to the others.
- getSortValues() - Method in class org.axonframework.axonserver.connector.event.axon.QueryResult
-
- getSortValuesBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesBuilderList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesCount() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesCount() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesCount() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesList() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesOrBuilder(int) - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesOrBuilder(int) - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesOrBuilderList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesOrBuilderList() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The sorting values to use when sorting this response compared to the others.
- getSortValuesOrBuilderList() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The sorting values to use when sorting this response compared to the others.
- getSource() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Returns the name of the bean that should be used as source for Event Messages.
- getSplitEventProcessorSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to split a Segment in a Tracking Event Processor
- getSplitEventProcessorSegment() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction to split a Segment in a Tracking Event Processor
- getSplitEventProcessorSegment() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction to split a Segment in a Tracking Event Processor
- getSplitEventProcessorSegmentBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to split a Segment in a Tracking Event Processor
- getSplitEventProcessorSegmentOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to split a Segment in a Tracking Event Processor
- getSplitEventProcessorSegmentOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction to split a Segment in a Tracking Event Processor
- getSplitEventProcessorSegmentOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction to split a Segment in a Tracking Event Processor
- getSpringCloud() - Method in class org.axonframework.springboot.DistributedCommandBusProperties
-
Returns the Spring Cloud configuration to use (if Spring Cloud is on the classpath).
- getStartEventProcessor() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- getStartEventProcessor() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction from AxonServer to Start a Tracking Event Processor.
- getStartEventProcessor() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- getStartEventProcessorBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- getStartEventProcessorOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- getStartEventProcessorOrBuilder() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
Instruction from AxonServer to Start a Tracking Event Processor.
- getStartEventProcessorOrBuilder() - Method in interface io.axoniq.axonserver.grpc.control.PlatformOutboundInstructionOrBuilder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- getState() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Get the state of the event processor.
- getSubscribe() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to subscribe this component as handler of a specific type of command
- getSubscribe() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction to subscribe this component as handler of a specific type of command
- getSubscribe() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction to subscribe this component as handler of a specific type of command
- getSubscribe() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Registers a Query Handler with AxonServer
- getSubscribe() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Registers a Query Handler with AxonServer
- getSubscribe() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Registers a Query Handler with AxonServer
- getSubscribe() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Start a Subscription Query with the given details.
- getSubscribe() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Start a Subscription Query with the given details.
- getSubscribe() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Start a Subscription Query with the given details.
- getSubscribeBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to subscribe this component as handler of a specific type of command
- getSubscribeBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Registers a Query Handler with AxonServer
- getSubscribeBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Start a Subscription Query with the given details.
- getSubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to subscribe this component as handler of a specific type of command
- getSubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction to subscribe this component as handler of a specific type of command
- getSubscribeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction to subscribe this component as handler of a specific type of command
- getSubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Registers a Query Handler with AxonServer
- getSubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Registers a Query Handler with AxonServer
- getSubscribeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Registers a Query Handler with AxonServer
- getSubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Start a Subscription Query with the given details.
- getSubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Start a Subscription Query with the given details.
- getSubscribeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Start a Subscription Query with the given details.
- getSubscriptionIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A unique identifier for this subscription
- getSubscriptionIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
A unique identifier for this subscription
- getSubscriptionIdentifier() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryOrBuilder
-
A unique identifier for this subscription
- getSubscriptionIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The identifier of the subscription query this is a response for
- getSubscriptionIdentifier() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
The identifier of the subscription query this is a response for
- getSubscriptionIdentifier() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
The identifier of the subscription query this is a response for
- getSubscriptionIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A unique identifier for this subscription
- getSubscriptionIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
A unique identifier for this subscription
- getSubscriptionIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryOrBuilder
-
A unique identifier for this subscription
- getSubscriptionIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The identifier of the subscription query this is a response for
- getSubscriptionIdentifierBytes() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
The identifier of the subscription query this is a response for
- getSubscriptionIdentifierBytes() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
The identifier of the subscription query this is a response for
- getSubscriptionMethod() - Static method in class io.axoniq.axonserver.grpc.query.QueryServiceGrpc
-
- getSubscriptionQueryRequest() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- getSubscriptionQueryRequest() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- getSubscriptionQueryRequest() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- getSubscriptionQueryRequestBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- getSubscriptionQueryRequestOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- getSubscriptionQueryRequestOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- getSubscriptionQueryRequestOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderInboundOrBuilder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- getSubscriptionQueryResponse() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- getSubscriptionQueryResponse() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Sends a response for a Subscription Query that has been received via the inbound stream
- getSubscriptionQueryResponse() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- getSubscriptionQueryResponseBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- getSubscriptionQueryResponseOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- getSubscriptionQueryResponseOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Sends a response for a Subscription Query that has been received via the inbound stream
- getSubscriptionQueryResponseOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- getSubscriptions() - Method in class org.axonframework.queryhandling.SimpleQueryBus
-
Returns the subscriptions for this query bus.
- getSubscriptions() - Method in class org.axonframework.test.utils.RecordingCommandBus
-
Returns a Map will all Command Names and their Command Handler that have been subscribed to this command bus.
- getSuccess() - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
True when successful, otherwise false
- getSuccess() - Method in class io.axoniq.axonserver.grpc.event.Confirmation
-
True when successful, otherwise false
- getSuccess() - Method in interface io.axoniq.axonserver.grpc.event.ConfirmationOrBuilder
-
True when successful, otherwise false
- getSuccess() - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Indicator whether the instruction was acknowledged successfully
- getSuccess() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
Indicator whether the instruction was acknowledged successfully
- getSuccess() - Method in interface io.axoniq.axonserver.grpc.InstructionAckOrBuilder
-
Indicator whether the instruction was acknowledged successfully
- getSuppressDownloadMessage() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getTags() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Deprecated.
- getTags() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
Deprecated.
- getTags() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Deprecated.
- getTags() - Method in class org.axonframework.config.TagsConfiguration
-
Gets tags.
- getTags() - Method in class org.axonframework.springboot.TagsConfigurationProperties
-
Gets tags.
- getTagsCount() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- getTagsCount() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- getTagsCount() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsMap() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsMap() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsMap() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsOrDefault(String, String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsOrDefault(String, String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsOrDefault(String, String) - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsOrThrow(String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsOrThrow(String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTagsOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Any tags associated with the client, which may provide hints and preferences for setting up connections
- getTargetType() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-
- getTargetType() - Method in interface org.axonframework.messaging.MessageHandler
-
Returns the instance type that this handler delegates to.
- getterName(String) - Method in class org.axonframework.common.property.AbstractMethodPropertyAccessStrategy
-
Returns the name of the method that is used to access the property.
- getterName(String) - Method in class org.axonframework.common.property.BeanPropertyAccessStrategy
-
- getterName(String) - Method in class org.axonframework.common.property.UniformPropertyAccessStrategy
-
- getTextValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The text value
- getTextValue() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
The text value
- getTextValue() - Method in interface io.axoniq.axonserver.grpc.event.QueryValueOrBuilder
-
The text value
- getTextValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The text value of the Meta Data entry.
- getTextValue() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
The text value of the Meta Data entry.
- getTextValue() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
The text value of the Meta Data entry.
- getTextValueBytes() - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The text value
- getTextValueBytes() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
The text value
- getTextValueBytes() - Method in interface io.axoniq.axonserver.grpc.event.QueryValueOrBuilder
-
The text value
- getTextValueBytes() - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The text value of the Meta Data entry.
- getTextValueBytes() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
The text value of the Meta Data entry.
- getTextValueBytes() - Method in interface io.axoniq.axonserver.grpc.MetaDataValueOrBuilder
-
The text value of the Meta Data entry.
- getThreadCount() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Returns the number of threads to use to process Events, when in "tracking" mode.
- getThreadFactory(String) - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
Provides the ThreadFactory to use to construct Threads for the processor with given processorName
- getTimestamp() - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The time at which the command was dispatched
- getTimestamp() - Method in class io.axoniq.axonserver.grpc.command.Command
-
The time at which the command was dispatched
- getTimestamp() - Method in interface io.axoniq.axonserver.grpc.command.CommandOrBuilder
-
The time at which the command was dispatched
- getTimestamp() - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The timestamp of the Event
- getTimestamp() - Method in class io.axoniq.axonserver.grpc.event.Event
-
The timestamp of the Event
- getTimestamp() - Method in interface io.axoniq.axonserver.grpc.event.EventOrBuilder
-
The timestamp of the Event
- getTimestamp() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The timestamp of the Query creation
- getTimestamp() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
The timestamp of the Query creation
- getTimestamp() - Method in interface io.axoniq.axonserver.grpc.query.QueryRequestOrBuilder
-
The timestamp of the Query creation
- getTimestamp() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
- getTimestamp() - Method in class org.axonframework.eventhandling.AbstractEventEntry
-
- getTimestamp() - Method in interface org.axonframework.eventhandling.EventData
-
Returns the timestamp at which the event was first created.
- getTimestamp() - Method in interface org.axonframework.eventhandling.EventMessage
-
Returns the timestamp of this event.
- getTimestamp() - Method in class org.axonframework.eventhandling.GenericEventMessage
-
- getTimestamp() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-
- getTimestamp() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
-
Deprecated.
Get the timestamp of the last event tracked by this token.
- getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getTimestamp() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the timestamp at which the event was first created.
- getTimestamp() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getToken() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The Token representing the position of this Event in the Stream
- getToken() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
The Token representing the position of this Event in the Stream
- getToken() - Method in interface io.axoniq.axonserver.grpc.event.EventWithTokenOrBuilder
-
The Token representing the position of this Event in the Stream
- getToken() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
The value of the Token
- getToken() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken
-
The value of the Token
- getToken() - Method in interface io.axoniq.axonserver.grpc.event.TrackingTokenOrBuilder
-
The value of the Token
- getToken() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- getToken(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
Returns the token, deserializing it with given serializer
- getTokenAt(GetTokenAtRequest) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreBlockingStub
-
Retrieves the token of the first token of an event from specified time in event store.
- getTokenAt(GetTokenAtRequest) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreFutureStub
-
Retrieves the token of the first token of an event from specified time in event store.
- getTokenAt(GetTokenAtRequest, StreamObserver<TrackingToken>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreImplBase
-
Retrieves the token of the first token of an event from specified time in event store.
- getTokenAt(GetTokenAtRequest, StreamObserver<TrackingToken>) - Method in class io.axoniq.axonserver.grpc.event.EventStoreGrpc.EventStoreStub
-
Retrieves the token of the first token of an event from specified time in event store.
- getTokenAt(Instant) - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
- getTokenAt(String, Instant) - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
Asynchronously returns a
TrackingToken
at the given
instant
from the Event Store.
- GetTokenAtRequest - Class in io.axoniq.axonserver.grpc.event
-
Request message to receive the Token that starts streaming events from the given timestamp
- GetTokenAtRequest.Builder - Class in io.axoniq.axonserver.grpc.event
-
Request message to receive the Token that starts streaming events from the given timestamp
- GetTokenAtRequestOrBuilder - Interface in io.axoniq.axonserver.grpc.event
-
- getTokenAtReset(TrackingToken) - Static method in class org.axonframework.eventhandling.ReplayToken
-
Return the relative position at which a reset was triggered for this Segment.
- getTokenAtReset() - Method in class org.axonframework.eventhandling.ReplayToken
-
Gets the token representing the position at which the reset was triggered.
- getTokenClaimInterval() - Method in class org.axonframework.eventhandling.TrackingEventProcessorConfiguration
-
Returns the time, in milliseconds, the processor should wait after a failed attempt to claim any segments for
processing.
- getTokenClaimInterval() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
- getTokenClaimIntervalTimeUnit() - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Returns the time unit used to define tokens claim interval.
- getTokenForStream(String) - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
-
Return the tracking token for an individual stream
- getTokenId() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
-
Returns the identifier of the scheduled task.
- getTokenPosition() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The approximate position of the token in the stream.
- getTokenPosition() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
The approximate position of the token in the stream.
- getTokenPosition() - Method in interface io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatusOrBuilder
-
The approximate position of the token in the stream.
- getTokenType() - Method in class org.axonframework.eventhandling.tokenstore.AbstractTokenEntry
-
- getToSequenceNr() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
The sequence number of the latest event
- getToSequenceNr() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse
-
The sequence number of the latest event
- getToSequenceNr() - Method in interface io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponseOrBuilder
-
The sequence number of the latest event
- getTrackedEventData(ResultSet, GapAwareTrackingToken) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Extracts the next tracked event entry from the given resultSet
.
- getTrackedEvents() - Method in class org.axonframework.mongo.eventsourcing.eventstore.MongoTrackingToken
-
Deprecated.
Gets tracked events.
- getTrackingToken() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The token to start streaming from
- getTrackingToken() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
The token to start streaming from
- getTrackingToken() - Method in interface io.axoniq.axonserver.grpc.event.GetEventsRequestOrBuilder
-
The token to start streaming from
- getTrackingToken() - Method in interface org.axonframework.eventhandling.EventTrackerStatus
-
The tracking token of the last event that has been seen by this Segment.
- getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getTrackingToken() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the tracking token of the event, or an empty Optional if the message wrapping the object being upcast
does not contain a tracking token.
- getTrackingToken() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getTrackingTokens() - Method in class org.axonframework.eventhandling.MultiSourceTrackingToken
-
Returns the map containing the constituent tokens.
- getType() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The type identifier of the Payload
- getType() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
The type identifier of the Payload
- getType() - Method in interface io.axoniq.axonserver.grpc.event.PayloadDescriptionOrBuilder
-
The type identifier of the Payload
- getType() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The type identifier of the serialized object.
- getType() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
The type identifier of the serialized object.
- getType() - Method in interface io.axoniq.axonserver.grpc.SerializedObjectOrBuilder
-
The type identifier of the serialized object.
- getType() - Method in class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
- getType() - Method in class org.axonframework.axonserver.connector.util.GrpcSerializedObject
-
- getType() - Method in class org.axonframework.eventhandling.AbstractDomainEventEntry
-
- getType() - Method in interface org.axonframework.eventhandling.DomainEventData
-
Returns the type identifier of the aggregate.
- getType() - Method in interface org.axonframework.eventhandling.DomainEventMessage
-
Returns the type of the Aggregate that generated this DomainEvent.
- getType() - Method in class org.axonframework.eventhandling.GenericDomainEventMessage
-
- getType() - Method in class org.axonframework.eventhandling.TrackedDomainEventData
-
- getType() - Method in class org.axonframework.eventsourcing.eventstore.AbstractSnapshotEventEntry
-
- getType() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
-
Returns the type of Aggregate, as String, targeted by this scope
- getType() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
-
The type of Saga described by this scope
- getType() - Method in class org.axonframework.serialization.LazyDeserializingObject
-
Returns the class of the serialized object.
- getType() - Method in class org.axonframework.serialization.SerializedMetaData
-
- getType() - Method in interface org.axonframework.serialization.SerializedObject
-
Returns the description of the type of object contained in the data.
- getType() - Method in class org.axonframework.serialization.SimpleSerializedObject
-
- getType() - Method in class org.axonframework.serialization.upcasting.event.InitialEventRepresentation
-
- getType() - Method in interface org.axonframework.serialization.upcasting.event.IntermediateEventRepresentation
-
Returns the type and version of the data contained in this representation.
- getType() - Method in class org.axonframework.serialization.upcasting.event.UpcastedEventRepresentation
-
- getTypeBytes() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The type identifier of the Payload
- getTypeBytes() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
The type identifier of the Payload
- getTypeBytes() - Method in interface io.axoniq.axonserver.grpc.event.PayloadDescriptionOrBuilder
-
The type identifier of the Payload
- getTypeBytes() - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The type identifier of the serialized object.
- getTypeBytes() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
The type identifier of the serialized object.
- getTypeBytes() - Method in interface io.axoniq.axonserver.grpc.SerializedObjectOrBuilder
-
The type identifier of the serialized object.
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.command.Command
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.command.CommandResponse
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.Heartbeat
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.ErrorMessage
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.Confirmation
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.Event
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.EventWithToken
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.QueryValue
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.event.TrackingToken
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.FlowControl
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.InstructionAck
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.MetaDataValue
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryComplete
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryResponse
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- getUnknownFields() - Method in class io.axoniq.axonserver.grpc.SerializedObject
-
- getUnsubscribe() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to unsubscribe this component as handler of a specific type of command
- getUnsubscribe() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction to unsubscribe this component as handler of a specific type of command
- getUnsubscribe() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction to unsubscribe this component as handler of a specific type of command
- getUnsubscribe() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Unregisters a Query Handler with AxonServer
- getUnsubscribe() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Unregisters a Query Handler with AxonServer
- getUnsubscribe() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Unregisters a Query Handler with AxonServer
- getUnsubscribe() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Ends a previously started Subscription Query with the given details
- getUnsubscribe() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Ends a previously started Subscription Query with the given details
- getUnsubscribe() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Ends a previously started Subscription Query with the given details
- getUnsubscribeBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to unsubscribe this component as handler of a specific type of command
- getUnsubscribeBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Unregisters a Query Handler with AxonServer
- getUnsubscribeBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Ends a previously started Subscription Query with the given details
- getUnsubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to unsubscribe this component as handler of a specific type of command
- getUnsubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
Instruction to unsubscribe this component as handler of a specific type of command
- getUnsubscribeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.command.CommandProviderOutboundOrBuilder
-
Instruction to unsubscribe this component as handler of a specific type of command
- getUnsubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Unregisters a Query Handler with AxonServer
- getUnsubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
Unregisters a Query Handler with AxonServer
- getUnsubscribeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.QueryProviderOutboundOrBuilder
-
Unregisters a Query Handler with AxonServer
- getUnsubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Ends a previously started Subscription Query with the given details
- getUnsubscribeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
Ends a previously started Subscription Query with the given details
- getUnsubscribeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryRequestOrBuilder
-
Ends a previously started Subscription Query with the given details
- getUpcasters() - Method in class org.axonframework.serialization.upcasting.GenericUpcasterChain
-
Returns the list of
upcasters
that makes up this chain.
- getUpdate() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Update Response
- getUpdate() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Provides an Update Response
- getUpdate() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Provides an Update Response
- getUpdateBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Update Response
- getUpdateOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Update Response
- getUpdateOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
Provides an Update Response
- getUpdateOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryResponseOrBuilder
-
Provides an Update Response
- getUpdateResponseType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A description of the type of Object expected as Update Responses
- getUpdateResponseType() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
A description of the type of Object expected as Update Responses
- getUpdateResponseType() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryOrBuilder
-
A description of the type of Object expected as Update Responses
- getUpdateResponseType() - Method in class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- getUpdateResponseType() - Method in class org.axonframework.queryhandling.GenericSubscriptionQueryMessage
-
- getUpdateResponseType() - Method in interface org.axonframework.queryhandling.SubscriptionQueryMessage
-
Returns the type of incremental responses.
- getUpdateResponseTypeBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A description of the type of Object expected as Update Responses
- getUpdateResponseTypeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A description of the type of Object expected as Update Responses
- getUpdateResponseTypeOrBuilder() - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
A description of the type of Object expected as Update Responses
- getUpdateResponseTypeOrBuilder() - Method in interface io.axoniq.axonserver.grpc.query.SubscriptionQueryOrBuilder
-
A description of the type of Object expected as Update Responses
- getUpdates() - Method in class org.axonframework.queryhandling.UpdateHandlerRegistration
-
Gets the updates.
- getValue() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The value associated with the processing key.
- getValue() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
The value associated with the processing key.
- getValue() - Method in interface io.axoniq.axonserver.grpc.ProcessingInstructionOrBuilder
-
The value associated with the processing key.
- getValue(T) - Method in class org.axonframework.common.property.DirectlyAccessedProperty
-
- getValue(T) - Method in class org.axonframework.common.property.MethodAccessedProperty
-
- getValue(T) - Method in interface org.axonframework.common.property.Property
-
Returns the value of the property on given target
.
- getValue() - Method in class org.axonframework.modelling.saga.AssociationValue
-
Returns the value of this association.
- getValueBuilder() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The value associated with the processing key.
- getValueDescriptor() - Method in enum io.axoniq.axonserver.grpc.ProcessingKey
-
- getValueOrBuilder() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The value associated with the processing key.
- getValueOrBuilder() - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction
-
The value associated with the processing key.
- getValueOrBuilder() - Method in interface io.axoniq.axonserver.grpc.ProcessingInstructionOrBuilder
-
The value associated with the processing key.
- getValues() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
Deprecated.
- getValues() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
Deprecated.
- getValues() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
Deprecated.
- getValues() - Method in class org.axonframework.domain.MetaData
-
Deprecated.
Get this metadata's mappings.
- getValuesCount() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- getValuesCount() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
- getValuesCount() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesMap() - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesMap() - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesMap() - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesOrDefault(String, QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesOrDefault(String, QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesOrDefault(String, QueryValue) - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesOrThrow(String) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesOrThrow(String) - Method in class io.axoniq.axonserver.grpc.event.RowResponse
-
The actual data values for each of the columns, as a column name -> value mapping
- getValuesOrThrow(String) - Method in interface io.axoniq.axonserver.grpc.event.RowResponseOrBuilder
-
The actual data values for each of the columns, as a column name -> value mapping
- getVersion() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Axon framework version used by the client application instance
- getVersion() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
Axon framework version used by the client application instance
- getVersion() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Axon framework version used by the client application instance
- getVersion() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The version identifier of the API
- getVersion() - Method in class io.axoniq.axonserver.grpc.control.NodeInfo
-
The version identifier of the API
- getVersion() - Method in interface io.axoniq.axonserver.grpc.control.NodeInfoOrBuilder
-
The version identifier of the API
- getVersion() - Static method in class org.axonframework.modelling.command.AggregateLifecycle
-
Gets the version of the aggregate.
- getVersion(T) - Method in interface org.axonframework.modelling.command.inspection.AggregateModel
-
Get the current version number of the given aggregate
.
- getVersion() - Method in class org.axonframework.modelling.command.VersionedAggregateIdentifier
-
Returns the version of the targeted Aggregate, or null
if the version is irrelevant.
- getVersionBytes() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Axon framework version used by the client application instance
- getVersionBytes() - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification
-
Axon framework version used by the client application instance
- getVersionBytes() - Method in interface io.axoniq.axonserver.grpc.control.ClientIdentificationOrBuilder
-
Axon framework version used by the client application instance
- getViolatingMethod() - Method in exception org.axonframework.messaging.annotation.UnsupportedHandlerException
-
A reference to the method that violated the event handler rules.
- getViolations() - Method in exception org.axonframework.messaging.interceptors.JSR303ViolationException
-
Returns the violations that were detected when this exception was thrown.
- getWrappedAggregate() - Method in class org.axonframework.modelling.command.LockAwareAggregate
-
Get the delegate aggregate wrapped by this instance.
- getWriter() - Method in class org.axonframework.serialization.json.JacksonSerializer
-
Provides the ObjectWriter, with which objects are serialized to JSON form.
- getXStream() - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
Returns a reference to the underlying XStream
instance, that does the actual
serialization.
- given(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- given(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- given(Object...) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Configures the given domainEvents
as the "given" events.
- given(List<?>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Configures the given domainEvents
as the "given" events.
- givenAggregate(String) - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Use this method to indicate that an aggregate with given identifier published certain events.
- givenAggregate(String) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- GivenAggregateEventPublisher - Interface in org.axonframework.test.saga
-
Interface to an object that publishes events on behalf of an aggregate.
- givenAPublished(Object) - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Indicates that the given applicationEvent
has been published in the past.
- givenAPublished(Object) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- givenCommands(Object...) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- givenCommands(List<?>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- givenCommands(Object...) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Configures the given commands
as the command that will provide the "given" events.
- givenCommands(List<?>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Configures the given commands
as the command that will provide the "given" events.
- givenCurrentTime(Instant) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- givenCurrentTime(Instant) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start
of the given state.
- givenCurrentTime(Instant) - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Use this method to indicate a specific moment as the initial current time "known" by the fixture at the start of
the given state.
- givenCurrentTime(Instant) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- givenNoPriorActivity() - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- givenNoPriorActivity() - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Indicates that no relevant activity has occurred in the past.
- givenNoPriorActivity() - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Indicates that no relevant activity has occurred in the past.
- givenNoPriorActivity() - Method in class org.axonframework.test.saga.SagaTestFixture
-
- givenState(Supplier<T>) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- givenState(Supplier<T>) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Sets the aggregate instance as supplied by given aggregateState
as the initial state for a test case.
- globalIndexColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
-
Sets the name of the global index column.
- globalIndexColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the global index of the event.
- GlobalMetricRegistry - Class in org.axonframework.metrics
-
Registry for application metrics with convenient ways to register Axon components.
- GlobalMetricRegistry() - Constructor for class org.axonframework.metrics.GlobalMetricRegistry
-
- GlobalMetricRegistry(MetricRegistry) - Constructor for class org.axonframework.metrics.GlobalMetricRegistry
-
- GlobalMetricRegistry - Class in org.axonframework.micrometer
-
Registry for application metrics with convenient ways to register Axon components.
- GlobalMetricRegistry() - Constructor for class org.axonframework.micrometer.GlobalMetricRegistry
-
- GlobalMetricRegistry(MeterRegistry) - Constructor for class org.axonframework.micrometer.GlobalMetricRegistry
-
- globalMetricRegistry(MetricRegistry) - Static method in class org.axonframework.springboot.autoconfig.MetricsAutoConfiguration
-
- globalMetricRegistry(MeterRegistry) - Static method in class org.axonframework.springboot.autoconfig.MicrometerMetricsAutoConfiguration
-
- GlobalSequenceTrackingToken - Class in org.axonframework.eventhandling
-
Tracking token based on the global sequence number of an event.
- GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventhandling.GlobalSequenceTrackingToken
-
- GlobalSequenceTrackingToken - Class in org.axonframework.eventsourcing.eventstore
-
- GlobalSequenceTrackingToken(long) - Constructor for class org.axonframework.eventsourcing.eventstore.GlobalSequenceTrackingToken
-
Deprecated.
- Gossip() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
-
- GRPC_PORT_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.NodeInfo
-
- GrpcBackedCommandMessage<C> - Class in org.axonframework.axonserver.connector.command
-
- GrpcBackedCommandMessage(Command, Serializer) - Constructor for class org.axonframework.axonserver.connector.command.GrpcBackedCommandMessage
-
- GrpcBackedDomainEventData - Class in org.axonframework.axonserver.connector.event.axon
-
DomainEventData implementation that retrieves its raw data from a protobuf
Event
message.
- GrpcBackedDomainEventData(Event) - Constructor for class org.axonframework.axonserver.connector.event.axon.GrpcBackedDomainEventData
-
Initialize using the given event
as the source of raw data.
- GrpcBackedQueryMessage<Q,R> - Class in org.axonframework.axonserver.connector.query
-
- GrpcBackedQueryMessage(QueryRequest, Serializer, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.GrpcBackedQueryMessage
-
- GrpcBackedResponseMessage<R> - Class in org.axonframework.axonserver.connector.query
-
- GrpcBackedResponseMessage(QueryResponse, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.GrpcBackedResponseMessage
-
- GrpcBackedSubscriptionQueryMessage<Q,I,U> - Class in org.axonframework.axonserver.connector.query.subscription
-
- GrpcBackedSubscriptionQueryMessage(SubscriptionQuery, Serializer, Serializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.GrpcBackedSubscriptionQueryMessage
-
- GrpcBufferingInterceptor - Class in org.axonframework.axonserver.connector.util
-
Interceptor that immediately requests a number of messages from the server, to increase the flow of messages.
- GrpcBufferingInterceptor(int) - Constructor for class org.axonframework.axonserver.connector.util.GrpcBufferingInterceptor
-
Initialize the interceptor to ask for additionalBuffer
amount of messages from the server.
- GrpcEventProcessorInfoSource - Class in org.axonframework.axonserver.connector.processor.grpc
-
- GrpcEventProcessorInfoSource(EventProcessingConfiguration, AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.processor.grpc.GrpcEventProcessorInfoSource
-
- GrpcEventProcessorMapping - Class in org.axonframework.axonserver.connector.processor.grpc
-
- GrpcEventProcessorMapping() - Constructor for class org.axonframework.axonserver.connector.processor.grpc.GrpcEventProcessorMapping
-
- GrpcExceptionParser - Class in org.axonframework.axonserver.connector.event.util
-
Converts GRPC Exceptions to EventStoreClientException
- GrpcExceptionParser() - Constructor for class org.axonframework.axonserver.connector.event.util.GrpcExceptionParser
-
- GrpcHeartbeatSource - Class in org.axonframework.axonserver.connector.heartbeat.source
-
- GrpcHeartbeatSource(AxonServerConnectionManager, String) - Constructor for class org.axonframework.axonserver.connector.heartbeat.source.GrpcHeartbeatSource
-
- GrpcMetaData - Class in org.axonframework.axonserver.connector.util
-
- GrpcMetaData(Map<String, MetaDataValue>, Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetaData
-
Instantiate a wrapper around the given
metaDataValues
providing access to them as a
MetaData
object.
- GrpcMetaDataConverter - Class in org.axonframework.axonserver.connector.util
-
Utility class for converting gRPC MetaData entries into a Java Map and vice versa.
- GrpcMetaDataConverter(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetaDataConverter
-
Initialize the converter, using the given serializer
to serialize Objects.
- GrpcMetadataSerializer - Class in org.axonframework.axonserver.connector.util
-
- GrpcMetadataSerializer(GrpcMetaDataConverter) - Constructor for class org.axonframework.axonserver.connector.util.GrpcMetadataSerializer
-
- GrpcObjectSerializer<O> - Class in org.axonframework.axonserver.connector.util
-
- GrpcObjectSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcObjectSerializer
-
- GrpcObjectSerializer.Serializer<A> - Interface in org.axonframework.axonserver.connector.util
-
- GrpcPayloadSerializer - Class in org.axonframework.axonserver.connector.util
-
- GrpcPayloadSerializer(Serializer) - Constructor for class org.axonframework.axonserver.connector.util.GrpcPayloadSerializer
-
- GrpcSerializedObject - Class in org.axonframework.axonserver.connector.util
-
- GrpcSerializedObject(SerializedObject) - Constructor for class org.axonframework.axonserver.connector.util.GrpcSerializedObject
-
- saga() - Method in interface org.axonframework.modelling.saga.repository.SagaStore.Entry
-
Returns the Saga instance in unserialized form.
- Saga<T> - Interface in org.axonframework.modelling.saga
-
Interface describing an implementation of a Saga.
- Saga - Annotation Type in org.axonframework.spring.stereotype
-
Annotation that informs Axon's auto configurer for Spring that a given Component
is a saga instance.
- sagaCache(Cache) - Method in class org.axonframework.modelling.saga.repository.CachingSagaStore.Builder
-
Sets the
sagaCache
of type
Cache
used to store Sagas with.
- sagaConfiguration(Class<T>) - Method in interface org.axonframework.config.EventProcessingConfiguration
-
- SagaConfiguration<S> - Interface in org.axonframework.config
-
Represents a set of components needed to configure a Saga.
- sagaConfigurations() - Method in interface org.axonframework.config.EventProcessingConfiguration
-
- sagaConfigurations() - Method in class org.axonframework.config.EventProcessingModule
-
- SagaConfigurer<T> - Class in org.axonframework.config
-
Provides mechanisms to configure the components used to manage and store Saga.
- SagaConfigurer(Class<T>) - Constructor for class org.axonframework.config.SagaConfigurer
-
Initializes a configurer for the given Saga Type.
- SagaCreationException - Exception in org.axonframework.modelling.saga.repository
-
Exception triggered when a new saga instance could not be instantiated.
- SagaCreationException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.repository.SagaCreationException
-
Initializes the exception using the given message
and cause
.
- SagaCreationPolicy - Enum in org.axonframework.modelling.saga
-
Enumeration containing the possible Creation Policies for Sagas.
- SagaEntry<T> - Class in org.axonframework.modelling.saga.repository.jpa
-
Java Persistence Entity allowing sagas to be stored in a relational database.
- SagaEntry(T, String, Serializer) - Constructor for class org.axonframework.modelling.saga.repository.jpa.SagaEntry
-
Constructs a new SagaEntry for the given saga
.
- SagaEntry() - Constructor for class org.axonframework.modelling.saga.repository.jpa.SagaEntry
-
Constructor required by JPA.
- sagaEntryEntityName() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
-
Intended for clients to override.
- sagaEntryTable() - Method in class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
-
Returns the name of the sagaEntry table
- SagaEventHandler - Annotation Type in org.axonframework.modelling.saga
-
Method-level annotation indicating that the annotated method is an event handler method for the saga instance.
- sagaEventProcessor(Class<?>) - Method in interface org.axonframework.config.EventProcessingConfiguration
-
- SagaExecutionException - Exception in org.axonframework.modelling.saga
-
Exception triggered by a saga while it is processing an event or processing a task.
- SagaExecutionException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaExecutionException
-
Initializes the exception using the given message
and cause
.
- sagaFactory(Supplier<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
-
Sets the
sagaFactory
of type
Supplier
responsible for creating new Saga instances.
- sagaFactory(Supplier<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-
- sagaId - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
- SagaInitializationPolicy - Class in org.axonframework.modelling.saga
-
Describes the conditions under which a Saga should be created, and which AssociationValue it should be initialized
with.
- SagaInitializationPolicy(SagaCreationPolicy, AssociationValue) - Constructor for class org.axonframework.modelling.saga.SagaInitializationPolicy
-
Creates an instance using the given creationPolicy
and initialAssociationValue
.
- SagaInstantiationException - Exception in org.axonframework.modelling.saga
-
Exception triggered during initialization of a Saga.
- SagaInstantiationException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaInstantiationException
-
Initializes the exception using the given message
and cause
.
- SagaLifecycle - Class in org.axonframework.modelling.saga
-
Abstract base class of a component that models a saga's life cycle.
- SagaLifecycle() - Constructor for class org.axonframework.modelling.saga.SagaLifecycle
-
- SagaMetaModelFactory - Interface in org.axonframework.modelling.saga.metamodel
-
Interface of a factory for a
SagaModel
for any given saga type.
- SagaMethodMessageHandlerDefinition - Class in org.axonframework.modelling.saga
-
Utility class that inspects annotation on a Saga instance and returns the relevant configuration for its Event
Handlers.
- SagaMethodMessageHandlerDefinition() - Constructor for class org.axonframework.modelling.saga.SagaMethodMessageHandlerDefinition
-
- SagaMethodMessageHandlingMember<T> - Class in org.axonframework.modelling.saga
-
- SagaMethodMessageHandlingMember(MessageHandlingMember<T>, SagaCreationPolicy, String, String, AssociationResolver, boolean) - Constructor for class org.axonframework.modelling.saga.SagaMethodMessageHandlingMember
-
Creates a SagaMethodMessageHandler.
- sagaModel(SagaModel<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-
- SagaModel<T> - Interface in org.axonframework.modelling.saga.metamodel
-
Interface of a model that describes a Saga of type T
.
- sagaModel(SagaModel<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
-
Sets the
SagaModel
of generic type
T
, describing the structure of the Saga this
SagaRepository
implementation will store.
- sagaProcessingGroup(Class<?>) - Method in interface org.axonframework.config.EventProcessingConfiguration
-
Gets the processing group for given sagaType
.
- sagaProcessingGroup(Class<?>) - Method in class org.axonframework.config.EventProcessingModule
-
- sagaRepository(SagaRepository<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
-
Sets the
SagaRepository
of generic type
T
used to save and load Saga instances.
- sagaRepository(SagaRepository<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-
- SagaRepository<T> - Interface in org.axonframework.modelling.saga
-
Interface towards the storage mechanism of Saga instances.
- sagaSchema() - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
Returns the
SagaSchema
used to configure this sql saga schema.
- SagaSchema - Class in org.axonframework.modelling.saga.repository.jdbc
-
SagaSchema allows specification of custom storage locations for the saga repositories.
- SagaSchema() - Constructor for class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
-
Initialize SagaSchema with default values.
- SagaSchema(String, String) - Constructor for class org.axonframework.modelling.saga.repository.jdbc.SagaSchema
-
Initialize SagaSchema with custom locations for event entry tables.
- SagaScopeDescriptor - Class in org.axonframework.eventhandling.saga
-
- SagaScopeDescriptor(String, Object) - Constructor for class org.axonframework.eventhandling.saga.SagaScopeDescriptor
-
Deprecated.
Instantiate a SagaScopeDescriptor with the provided type
and identifier
.
- SagaScopeDescriptor - Class in org.axonframework.modelling.saga
-
Describes the scope of a Saga by means of its type and identifier.
- SagaScopeDescriptor(String, Object) - Constructor for class org.axonframework.modelling.saga.SagaScopeDescriptor
-
Instantiate a SagaScopeDescriptor with the provided type
and identifier
.
- SagaSqlSchema - Interface in org.axonframework.modelling.saga.repository.jdbc
-
Interface describing the SQL statements that the JdbcSagaRepository needs to execute against the underlying
database.
- SagaStorageException - Exception in org.axonframework.modelling.saga
-
Exception indicating that an error has occurred while storing a Saga.
- SagaStorageException(String) - Constructor for exception org.axonframework.modelling.saga.SagaStorageException
-
Initialize a SagaStorageException with the given descriptive message
.
- SagaStorageException(String, Throwable) - Constructor for exception org.axonframework.modelling.saga.SagaStorageException
-
Initialize a SagaStorageException with the given descriptive message
and cause
.
- sagaStore() - Method in interface org.axonframework.config.EventProcessingConfiguration
-
Returns a
SagaStore
registered within this configuration.
- sagaStore() - Method in class org.axonframework.config.EventProcessingModule
-
- sagaStore(SagaStore<? super T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
-
Sets the
SagaStore
used to save and load saga instances.
- SagaStore<T> - Interface in org.axonframework.modelling.saga.repository
-
Provides a mechanism to find, load update and delete sagas of type T
from an underlying storage like a
database.
- sagaStore(ConnectionProvider, Serializer) - Method in class org.axonframework.springboot.autoconfig.JdbcAutoConfiguration
-
- sagaStore(Serializer, EntityManagerProvider) - Method in class org.axonframework.springboot.autoconfig.JpaAutoConfiguration
-
- SagaStore.Entry<T> - Interface in org.axonframework.modelling.saga.repository
-
Interface describing a Saga entry fetched from a SagaStore.
- SagaTestFixture<T> - Class in org.axonframework.test.saga
-
Fixture for testing Annotated Sagas based on events and time passing.
- SagaTestFixture(Class<T>) - Constructor for class org.axonframework.test.saga.SagaTestFixture
-
Creates an instance of the AnnotatedSagaTestFixture to test sagas of the given sagaType
.
- sagaType - Variable in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
-
- sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.AbstractSagaManager.Builder
-
Sets the
sagaType
as a
Class
managed by this instance.
- sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.AnnotatedSagaManager.Builder
-
- sagaType(Class<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository.Builder
-
- sagaType - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
- SAME_CONNECTION_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.PlatformInfo
-
- scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
- scatterGather(String, Q, ResponseType<R>, long, TimeUnit) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
-
- scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryBus
-
Dispatch the given query
to all QueryHandlers subscribed to the given query
's queryName/responseType.
- scatterGather(Q, ResponseType<R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryGateway
-
Sends given
query
over the
QueryBus
, expecting a response in the
form of
responseType
from several sources.
- scatterGather(String, Q, ResponseType<R>, long, TimeUnit) - Method in interface org.axonframework.queryhandling.QueryGateway
-
Sends given
query
over the
QueryBus
, expecting a response in the
form of
responseType
from several sources.
- scatterGather(QueryMessage<Q, R>, long, TimeUnit) - Method in class org.axonframework.queryhandling.SimpleQueryBus
-
- schedule(Instant, String) - Method in interface org.axonframework.deadline.DeadlineManager
-
Schedules a deadline at given triggerDateTime
with given deadlineName
.
- schedule(Instant, String, Object) - Method in interface org.axonframework.deadline.DeadlineManager
-
Schedules a deadline at given triggerDateTime
with given deadlineName
.
- schedule(Instant, String, Object, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
-
Schedules a deadline at given triggerDateTime
with provided context.
- schedule(Duration, String) - Method in interface org.axonframework.deadline.DeadlineManager
-
Schedules a deadline after the given triggerDuration
with given deadlineName
.
- schedule(Duration, String, Object) - Method in interface org.axonframework.deadline.DeadlineManager
-
Schedules a deadline after the given triggerDuration
.
- schedule(Duration, String, Object, ScopeDescriptor) - Method in interface org.axonframework.deadline.DeadlineManager
-
Schedules a deadline after the given triggerDuration
with provided context.
- schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-
- schedule(Duration, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-
- schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.deadline.SimpleDeadlineManager
-
- schedule(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.AsynchronousEventProcessingStrategy
-
Schedules this task for execution when all pre-conditions have been met.
- schedule(Instant, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Schedule the given event
for publication at the given triggerDateTime
.
- schedule(Duration, Object) - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Schedule the given event
for publication after the given triggerDuration
.
- schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- schedule(Instant, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- schedule(Duration, Object) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
- schedule(Instant, String, Object, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
- schedule(Duration, String, Object, ScopeDescriptor) - Method in class org.axonframework.test.deadline.StubDeadlineManager
-
- schedule(Instant, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
- schedule(Duration, Object) - Method in class org.axonframework.test.eventscheduler.StubEventScheduler
-
- ScheduledDeadlineInfo - Class in org.axonframework.test.deadline
-
Holds the data regarding deadline schedule.
- ScheduledDeadlineInfo(Instant, String, String, int, DeadlineMessage<?>, ScopeDescriptor) - Constructor for class org.axonframework.test.deadline.ScheduledDeadlineInfo
-
Instantiates a ScheduledDeadlineInfo.
- ScheduledEventProcessorInfoSource - Class in org.axonframework.axonserver.connector.processor.schedule
-
- ScheduledEventProcessorInfoSource(int, int, EventProcessorInfoSource) - Constructor for class org.axonframework.axonserver.connector.processor.schedule.ScheduledEventProcessorInfoSource
-
Initialize the
ScheduledEventProcessorInfoSource
using the given
initialDelay
and
schedulingPeriod
, as milliseconds, to schedule a notification through the
delegate
at a fixed rate.
- scheduledExecutorService(ScheduledExecutorService) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
-
- scheduledExecutorService(ScheduledExecutorService) - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler.Builder
-
- ScheduledItem - Interface in org.axonframework.test.eventscheduler
-
Interface describing an event to be scheduled at a given date and time.
- scheduleEvents(List<? extends EventMessage<?>>, Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.async.EventProcessorTask
-
Schedules a batch of events for processing.
- scheduler(ScheduledExecutorService) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager.Builder
-
Sets the
ScheduledExecutorService
used to schedule connection attempts given certain success and/or
failure scenarios of a channel.
- Scheduler - Interface in org.axonframework.axonserver.connector.util
-
Schedules tasks to be executed in future.
- scheduler(Scheduler) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
-
Sets the Scheduler
used for scheduling and triggering purposes of the deadlines.
- scheduler(Scheduler) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler.Builder
-
Sets the Scheduler
used for scheduling and triggering purposes of the deadlines.
- Scheduler.ScheduledTask - Interface in org.axonframework.axonserver.connector.util
-
- scheduleRetry(Runnable, long) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
-
Schedule the provided task to run after the given interval.
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in class org.axonframework.commandhandling.gateway.AbstractRetryScheduler
-
- scheduleRetry(CommandMessage, RuntimeException, List<Class<? extends Throwable>[]>, Runnable) - Method in interface org.axonframework.commandhandling.gateway.RetryScheduler
-
Inspect the given commandMessage
that failed with given lastFailure
.
- scheduleSnapshot(Class<?>, String) - Method in class org.axonframework.eventsourcing.AbstractSnapshotter
-
- scheduleSnapshot(Class<?>, String) - Method in interface org.axonframework.eventsourcing.Snapshotter
-
Schedules snapshot taking for an aggregate with given aggregateIdentifier
.
- ScheduleToken - Interface in org.axonframework.eventhandling.scheduling
-
Token that identifies a single scheduled Event.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.axonframework.axonserver.connector.util.Scheduler
-
Schedules a command
to be executed periodically after initialDelay
.
- SchedulingException - Exception in org.axonframework.eventhandling.scheduling
-
Exception indicating a problem in the Event Scheduling mechanism.
- SchedulingException(String) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
-
Initialize a SchedulingException with the given message
.
- SchedulingException(String, Throwable) - Constructor for exception org.axonframework.eventhandling.scheduling.SchedulingException
-
Initialize a SchedulingException with the given message
and cause
.
- schema(TokenSchema) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
-
Sets the
schema
which describes a JDBC token entry for this
TokenStore
.
- schema(EventSchema) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
Sets the
EventSchema
describing the database schema of event entries.
- schema() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
Returns the
EventSchema
that defines the table and column names of event tables in the database.
- Scope - Class in org.axonframework.messaging
-
Describes functionality off processes which can be 'in scope', like an Aggregate or Saga.
- Scope() - Constructor for class org.axonframework.messaging.Scope
-
- SCOPE_AWARE_RESOLVER - Static variable in class org.axonframework.deadline.quartz.DeadlineJob
-
- ScopeAware - Interface in org.axonframework.messaging
-
Interface describing components which are
Scope
aware.
- scopeAwareProvider(ScopeAwareProvider) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
-
- scopeAwareProvider(ScopeAwareProvider) - Method in class org.axonframework.deadline.SimpleDeadlineManager.Builder
-
- ScopeAwareProvider - Interface in org.axonframework.messaging
-
Contract towards a mechanism to provide a
Stream
of components which are
ScopeAware
.
- scopeDescription() - Method in interface org.axonframework.messaging.ScopeDescriptor
-
- scopeDescription() - Method in class org.axonframework.modelling.command.AggregateScopeDescriptor
-
- scopeDescription() - Method in class org.axonframework.modelling.saga.SagaScopeDescriptor
-
- ScopeDescriptor - Interface in org.axonframework.messaging
-
Denotes the description of a
Scope
.
- Segment - Class in org.axonframework.eventhandling
-
A representation of a segment and corresponding mask with various capabilities.
- Segment(int, int) - Constructor for class org.axonframework.eventhandling.Segment
-
Construct a new Segment instance with given segmentId
and mask
- SEGMENT_ID_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus
-
- SEGMENT_IDENTIFIER_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference
-
- SEGMENT_STATUS_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.EventProcessorInfo
-
- segmentColumn() - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema
-
Returns the name of the column containing the segment of the processor to which the token belongs.
- segmentCount() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-
Returns this member's segment count which relates to the relative load factor of the member.
- selectForSegments(Connection, String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
Returns a
PreparedStatement
to select all segments ids for a given processorName from the underlying
storage.
- selectForUpdate(Connection, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
- selectImports(AnnotationMetadata) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer.ImportSelector
-
- send(String, PlatformInboundInstruction) - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Send the given instruction
for given context
to AxonServer.
- send(Member, CommandMessage<? extends C>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
-
Sends the given command
to the node assigned to handle messages with the given routingKey
.
- send(Member, CommandMessage<C>, CommandCallback<? super C, R>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
-
Sends the given command
to the node assigned to handle messages with the given routingKey
.
- send(C, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Sends the given command
, and invokes the callback
when the command is processed.
- send(C, CommandCallback<? super C, ? super R>) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
, and have the result of the command's execution reported to the given
callback
.
- send(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and returns immediately, without waiting for the command to execute.
- send(C, CommandCallback<? super C, ? super R>) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
- send(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
- send(Message<?>, ScopeDescriptor) - Method in interface org.axonframework.messaging.ScopeAware
-
Send a
Message
to a
Scope
which is described by the given
scopeDescription
.
- send(Message<?>, ScopeDescriptor) - Method in class org.axonframework.modelling.command.AbstractRepository
-
- send(Message<?>, ScopeDescriptor) - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-
- sendAck(String, boolean, ErrorMessage, StreamObserver<T>) - Method in class org.axonframework.axonserver.connector.DefaultInstructionAckSource
-
- sendAck(String, boolean, ErrorMessage, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
-
Sends an acknowledgement.
- sendAndForget(Object) - Method in class org.axonframework.commandhandling.gateway.AbstractCommandGateway
-
Dispatches a command without callback.
- sendAndWait(Object) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and wait for it to execute.
- sendAndWait(Object, long, TimeUnit) - Method in interface org.axonframework.commandhandling.gateway.CommandGateway
-
Sends the given command
and wait for it to execute.
- sendAndWait(Object) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Sends the given command
and waits for its execution to complete, or until the waiting thread is
interrupted.
- sendAndWait(Object, long, TimeUnit) - Method in class org.axonframework.commandhandling.gateway.DefaultCommandGateway
-
Sends the given command
and waits for its execution to complete, or until the given
timeout
has expired, or the waiting thread is interrupted.
- sendInitialPermits() - Method in class org.axonframework.axonserver.connector.util.FlowControllingStreamObserver
-
- sendSuccessfulAck(String, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
-
Sends successful acknowledgement.
- sendUnsuccessfulAck(String, ErrorMessage, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
-
Sends unsuccessful acknowledgement.
- sendUnsupportedInstruction(String, String, StreamObserver<T>) - Method in interface org.axonframework.axonserver.connector.InstructionAckSource
-
Sends acknowledgement of unsupported instruction.
- SequenceEventStorageEngine - Class in org.axonframework.eventsourcing.eventstore
-
EventStorageEngine implementation that combines the streams of two event storage engines.
- SequenceEventStorageEngine(EventStorageEngine, EventStorageEngine) - Constructor for class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- SequenceMatcher<T> - Class in org.axonframework.test.matchers
-
A matcher that will match if all the given matchers
each match against an item that the previous
matcher matched against.
- SequenceMatcher(Matcher<? super T>...) - Constructor for class org.axonframework.test.matchers.SequenceMatcher
-
Construct a matcher that will return true if all the given matchers
match against an item
positioned after the item that the previous matcher matched against.
- SequenceNumber - Annotation Type in org.axonframework.eventhandling
-
Annotation indicating that a parameter on an Event Handler method should be injected with the SequenceNumber of
a DomainEventMessage.
- sequenceNumberColumn(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
-
Sets the name of the event identifier column.
- sequenceNumberColumn() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Get the name of the column containing the aggregate sequence number of the event.
- SequenceNumberParameterResolver() - Constructor for class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver
-
- SequenceNumberParameterResolverFactory - Class in org.axonframework.eventhandling
-
An extension of the AbstractAnnotatedParameterResolverFactory that accepts parameters of a
Long
type
annotated with the
SequenceNumber
annotation and assigns the sequenceNumber of the DomainEventMessage.
- SequenceNumberParameterResolverFactory() - Constructor for class org.axonframework.eventhandling.SequenceNumberParameterResolverFactory
-
- SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver - Class in org.axonframework.eventhandling
-
ParameterResolver that resolves SequenceNumber parameters
- sequenceOf(Matcher<T>...) - Static method in class org.axonframework.test.matchers.Matchers
-
Matches a list of Events if each of the matchers
match against an Event that comes after the Event
that the previous matcher matched against.
- sequencingPolicy(String) - Method in interface org.axonframework.config.EventProcessingConfiguration
-
- sequencingPolicy(String) - Method in class org.axonframework.config.EventProcessingModule
-
- SequencingPolicy<T> - Interface in org.axonframework.eventhandling.async
-
Interface to a policy definition for concurrent processing, for example event handling.
- sequencingPolicy(SequencingPolicy<? super EventMessage<?>>) - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker.Builder
-
- SequentialPerAggregatePolicy - Class in org.axonframework.eventhandling.async
-
Concurrency policy that requires sequential processing of events raised by the same aggregate.
- SequentialPerAggregatePolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPerAggregatePolicy
-
- SequentialPolicy - Class in org.axonframework.eventhandling.async
-
SequencingPolicy that requires serialized handling of all events delivered to an event handler.
- SequentialPolicy() - Constructor for class org.axonframework.eventhandling.async.SequentialPolicy
-
- SerializationException - Exception in org.axonframework.serialization
-
Indicates that an exception occurred while serializing or deserializing an object.
- SerializationException(String) - Constructor for exception org.axonframework.serialization.SerializationException
-
Initializes the exception using the given message
.
- SerializationException(String, Throwable) - Constructor for exception org.axonframework.serialization.SerializationException
-
Initializes the exception using the given message
and cause
.
- serialize(CommandMessage<?>, String, int) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
-
- serialize(CommandResultMessage<?>, String) - Method in class org.axonframework.axonserver.connector.command.CommandSerializer
-
- serialize(SubscriptionQueryMessage) - Method in class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
-
- serialize(String, Throwable) - Static method in class org.axonframework.axonserver.connector.util.ExceptionSerializer
-
- serialize(A, Class<T>) - Method in interface org.axonframework.axonserver.connector.util.GrpcObjectSerializer.Serializer
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.AbstractXStreamSerializer
-
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.JavaSerializer
-
Deprecated.
- serialize(Object, Class<T>) - Method in class org.axonframework.serialization.json.JacksonSerializer
-
- serialize(Object, Class<T>) - Method in interface org.axonframework.serialization.Serializer
-
Serialize the given object
into a Serialized Object containing the given
expectedRepresentation
.
- SERIALIZED_DEADLINE_MESSAGE - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
-
- SERIALIZED_DEADLINE_MESSAGE_CLASS_NAME - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
-
- SERIALIZED_DEADLINE_SCOPE - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
-
- SERIALIZED_DEADLINE_SCOPE_CLASS_NAME - Static variable in class org.axonframework.deadline.quartz.DeadlineJob.DeadlineJobDataBinder
-
Key pointing to the class name of the deadline
ScopeDescriptor
in the
JobDataMap
- SERIALIZED_MESSAGE_PAYLOAD - Static variable in class org.axonframework.messaging.Headers
-
Key pointing to the serialized payload of a message.
- serializedException - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- SerializedMessage<T> - Class in org.axonframework.serialization
-
A message containing serialized payload data and metadata.
- SerializedMessage(String, SerializedObject<?>, SerializedObject<?>, Serializer) - Constructor for class org.axonframework.serialization.SerializedMessage
-
Initializes a
SerializedMessage
with given
identifier
from the given serialized payload and
metadata.
- SerializedMessage(String, LazyDeserializingObject<T>, LazyDeserializingObject<MetaData>) - Constructor for class org.axonframework.serialization.SerializedMessage
-
Initializes a
SerializedMessage
with given
identifier
from the given lazily deserializing payload
and metadata.
- serializedMetaData - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- serializedMetaData - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- SerializedMetaData<T> - Class in org.axonframework.serialization
-
Represents the serialized form of a
MetaData
instance.
- SerializedMetaData(T, Class<T>) - Constructor for class org.axonframework.serialization.SerializedMetaData
-
Construct an instance with given
bytes
representing the serialized form of a
MetaData
instance.
- SerializedObject - Class in io.axoniq.axonserver.grpc
-
Describes a serialized object
- SerializedObject<T> - Interface in org.axonframework.serialization
-
Interface describing the structure of a serialized object.
- SerializedObject.Builder - Class in io.axoniq.axonserver.grpc
-
Describes a serialized object
- SerializedObjectHolder - Class in org.axonframework.serialization
-
Holder that keeps references to serialized representations of a payload and meta data of a specific message.
- SerializedObjectHolder(Message) - Constructor for class org.axonframework.serialization.SerializedObjectHolder
-
Initialize the holder for the serialized representations of the payload and meta data of given
message
- SerializedObjectOrBuilder - Interface in io.axoniq.axonserver.grpc
-
- serializedObjectType() - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
-
Intended for clients to override.
- serializedPayload - Variable in class org.axonframework.commandhandling.distributed.DispatchMessage
-
- serializedPayload - Variable in class org.axonframework.commandhandling.distributed.ReplyMessage
-
- serializedSaga - Variable in class org.axonframework.modelling.saga.repository.jpa.AbstractSagaEntry
-
- SerializedSaga - Class in org.axonframework.modelling.saga.repository.jpa
-
Specialization of the SerializedObject for Sagas represented as byte array.
- SerializedSaga(byte[], String, String) - Constructor for class org.axonframework.modelling.saga.repository.jpa.SerializedSaga
-
Initialize a SerializedSaga instance with given data
, of given type
and
revision
.
- SerializedType - Interface in org.axonframework.serialization
-
Describes the type of a serialized object.
- serializedType() - Method in class org.axonframework.serialization.UnknownSerializedType
-
Returns the type of the serialized object, for which no class could be resolved.
- serializeExceptionResult(Serializer, Class<T>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- serializeExceptionResult(Serializer, Class<T>) - Method in interface org.axonframework.messaging.ResultMessage
-
Serializes the exception result.
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.messaging.GenericMessage
-
- serializeMetaData(Serializer, Class<R>) - Method in interface org.axonframework.messaging.Message
-
Serialize the meta data of this message to the expectedRepresentation
using given serializer
.
- serializeMetaData(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
-
- serializeMetaData(Serializer, Class<R1>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- serializeMetaData(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
-
- serializeMetaData(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
-
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.messaging.GenericMessage
-
- serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.GenericResultMessage
-
- serializePayload(Serializer, Class<R>) - Method in interface org.axonframework.messaging.Message
-
Serialize the payload of this message to the expectedRepresentation
using given serializer
.
- serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.MessageDecorator
-
- serializePayload(Serializer, Class<S>) - Method in class org.axonframework.messaging.responsetypes.ConvertingResponseMessage
-
- serializePayload(Serializer, Class<S>) - Method in interface org.axonframework.messaging.ResultMessage
-
- serializePayload(Serializer, Class<R>) - Method in class org.axonframework.serialization.SerializedMessage
-
- serializePayload(Serializer, Class<T>) - Method in class org.axonframework.serialization.SerializedObjectHolder
-
- serializer(Serializer) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus.Builder
-
Sets the
Serializer
used to de-/serialize incoming and outgoing commands and command results.
- serializer() - Method in interface org.axonframework.config.Configuration
-
Returns the serializer defined in this Configuration
- serializer(Serializer) - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager.Builder
-
- serializer(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore.Builder
-
- serializer(Serializer) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore.Builder
-
- serializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
-
Sets the
Serializer
used to de-/serialize a Saga instance.
- serializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore.Builder
-
Sets the
Serializer
used to de-/serialize a Saga instance.
- Serializer - Interface in org.axonframework.serialization
-
Interface describing a serialization mechanism.
- serializer(RevisionResolver) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-
- serializeRequest(QueryMessage<Q, R>, int, long, int) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
-
- serializeResponse(QueryResponseMessage<?>, String) - Method in class org.axonframework.axonserver.connector.query.QuerySerializer
-
- SerializerProperties - Class in org.axonframework.springboot
-
A group of properties that allows easy configuration of the serializers used for different types of objects that
Axon needs to serialize.
- SerializerProperties() - Constructor for class org.axonframework.springboot.SerializerProperties
-
- SerializerProperties.SerializerType - Enum in org.axonframework.springboot
-
Enumerates different possible standard serializers, available in Axon.
- SerialVersionUIDRevisionResolver - Class in org.axonframework.serialization
-
RevisionResolver implementation that returns the (String representation of the) serialVersionUID of a class.
- SerialVersionUIDRevisionResolver() - Constructor for class org.axonframework.serialization.SerialVersionUIDRevisionResolver
-
- ServerConnectorConfigurerModule - Class in org.axonframework.axonserver.connector
-
Configurer module which is auto-loadable by the
DefaultConfigurer
that sets
sensible default to use when the AxonServer connector is available on the classpath.
- ServerConnectorConfigurerModule() - Constructor for class org.axonframework.axonserver.connector.ServerConnectorConfigurerModule
-
- servers(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- SERVICE_NAME - Static variable in class io.axoniq.axonserver.grpc.command.CommandServiceGrpc
-
- SERVICE_NAME - Static variable in class io.axoniq.axonserver.grpc.control.PlatformServiceGrpc
-
- SERVICE_NAME - Static variable in class io.axoniq.axonserver.grpc.event.EventStoreGrpc
-
- SERVICE_NAME - Static variable in class io.axoniq.axonserver.grpc.query.QueryServiceGrpc
-
- ServiceRegistryException - Exception in org.axonframework.commandhandling.distributed
-
Exception that is triggered when an error occurs that is related to the registration or deregistration of a member to
the distributed command bus service registry.
- ServiceRegistryException(String) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
-
Initializes the exception using the given message
.
- ServiceRegistryException(String, Throwable) - Constructor for exception org.axonframework.commandhandling.distributed.ServiceRegistryException
-
Initializes the exception using the given message
and cause
.
- set(UnitOfWork<?>) - Static method in class org.axonframework.messaging.unitofwork.CurrentUnitOfWork
-
Binds the given unitOfWork
to the current thread.
- setAck(InstructionAck) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- setAck(InstructionAck.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- setAck(InstructionAck) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- setAck(InstructionAck.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- setAck(InstructionAck) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- setAck(InstructionAck.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- setAck(InstructionAck) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- setAck(InstructionAck.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- setAck(InstructionAck) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- setAck(InstructionAck.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Acknowledgement of previously sent instruction via outbound stream
- setAck(InstructionAck) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- setAck(InstructionAck.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Acknowledgement of previously sent instruction via inbound stream
- setActiveThreads(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The number of threads currently actively processing Events
- setAdditionalConverters(List<ContentTypeConverter>) - Method in class org.axonframework.serialization.ChainingConverter
-
Setter for dependency injection frameworks that require property methods.
- setAdditionalFactories(List<ParameterResolverFactory>) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-
Defines any additional parameter resolver factories that need to be used to resolve parameters.
- setAdditionalHandlers(List<HandlerDefinition>) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
Defines any additional handler definitions that should be used.
- setAdditionalHandlers(List<HandlerEnhancerDefinition>) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
Defines any additional handler enhancer definitions that should be used.
- setAggregateId(String) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The identifier of the aggregate to read events for
- setAggregateId(String) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The identifier to fetch the snapshots for
- setAggregateId(String) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Identifier of the Aggregate for which to load events
- setAggregateIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The identifier of the aggregate to read events for
- setAggregateIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The identifier to fetch the snapshots for
- setAggregateIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Identifier of the Aggregate for which to load events
- setAggregateIdentifier(String) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The identifier of the Aggregate instance that published this event, if any
- setAggregateIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The identifier of the Aggregate instance that published this event, if any
- setAggregateSequenceNumber(long) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The sequence number of the Event in the Aggregate instance that published it, if any
- setAggregateType(String) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Type of the Aggregate instance that published this Event, if any
- setAggregateTypeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Type of the Aggregate instance that published this Event, if any
- setAllowSnapshots(boolean) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
Whether a snapshot may be returned as first element in the stream
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.ApplicationContextLookupParameterResolverFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.AxonConfiguration
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.messaging.ApplicationContextEventPublisher
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.spring.saga.SpringResourceInjector
-
- setApplicationContext(ApplicationContext) - Method in class org.axonframework.springboot.autoconfig.AxonServerAutoConfiguration
-
- setAutoConfiguration(MetricsProperties.AutoConfiguration) - Method in class org.axonframework.springboot.MetricsProperties
-
Defines the AutoConfiguration settings for Metrics.
- setAutoStart(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
-
- setAvailableThreads(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The number of threads the processor has available to assign to Segments.
- setBatchSize(int) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the maximum size of a processing batch.
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-
- setBeanClassLoader(ClassLoader) - Method in class org.axonframework.springboot.autoconfig.AxonAutoConfiguration
-
- setBeanFactory(BeanFactory) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
-
- setBeanFactory(BeanFactory) - Method in class org.axonframework.spring.config.SpringAxonAutoConfigurer
-
- setBeanName(String) - Method in class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-
- setBindAddr(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Sets the Address to bind the JGroups to.
- setBindPort(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Returns the port to listen to JGroups connections (default 7800).
- setBlacklist(int, PayloadDescription) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- setBlacklist(int, PayloadDescription.Builder) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
An enumeration of payload types that need to be blacklisted.
- setBooleanValue(boolean) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The boolean value
- setBooleanValue(boolean) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The boolean value of the Meta Data entry.
- setBytesValue(SerializedObject) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The binary value of the Meta Data entry.
- setBytesValue(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The binary value of the Meta Data entry.
- setCallbackBehavior(CallbackBehavior) - Method in interface org.axonframework.test.saga.FixtureConfiguration
-
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback.
- setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.saga.SagaTestFixture
-
- setCallbackBehavior(CallbackBehavior) - Method in class org.axonframework.test.utils.RecordingCommandBus
-
Sets the instance that defines the behavior of the Command Bus when a command is dispatched with a callback.
- setCaughtUp(boolean) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Indicates whether the Segment has "Caught Up" with the Head of the Event Stream
- setCertFile(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the component dispatching this message
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The unique identifier of the component instance subscribing
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
A unique identifier for this client instance.
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The unique identifier of this client instance.
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The ClientID of the component providing additional permits
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The unique identifier of the client instance dispatching the query
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of the Client Instance containing the Query Handler
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The identifier of the Client instance providing the Update
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The identifier of the Client instance providing the Update
- setClientId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The identifier of the Client instance providing the Update
- setClientId(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the component dispatching this message
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The unique identifier of the component instance subscribing
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
A unique identifier for this client instance.
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The unique identifier of this client instance.
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The ClientID of the component providing additional permits
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The unique identifier of the client instance dispatching the query
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of the Client Instance containing the Query Handler
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The identifier of the Client instance providing the Update
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The identifier of the Client instance providing the Update
- setClientIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The identifier of the Client instance providing the Update
- setClusterName(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Sets the Cluster Name of the JGroups Cluster to connect with (defaults to "Axon").
- setColumn(int, String) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
The names of the columns provided in the query
- setColumns(ColumnsResponse) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response contains the names of the columns the response contains.
- setColumns(ColumnsResponse.Builder) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response contains the names of the columns the response contains.
- setCommand(Command) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
A command for this component to process
- setCommand(Command.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
A command for this component to process
- setCommand(String) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name of the command the component can handle
- setCommandBus(CommandBus) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
-
Sets the command bus to use when subscribing command handlers.
- setCommandBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name of the command the component can handle
- setCommandFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setCommandHandlers(Collection<MessageHandler>) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
-
Sets the command handlers to subscribe to the bus.
- setCommandLoadFactor(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setCommandResponse(CommandResponse) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Sends a result of Command processing
- setCommandResponse(CommandResponse.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Sends a result of Command processing
- setCommandThreads(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setCommandThreads(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setCommitTimeout(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setComplete(QueryUpdateComplete) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query is complete, and no more Updates will be sent
- setComplete(QueryUpdateComplete.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query is complete, and no more Updates will be sent
- setCompleteExceptionally(QueryUpdateCompleteExceptionally) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- setCompleteExceptionally(QueryUpdateCompleteExceptionally.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Indicates the Query failed exceptionally, and no more Updates will be sent
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name/type of the component dispatching this message
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name/type of the component handling the command
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
The name of the component.
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The component name of this client instance.
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The Name of the Component dispatching the query
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Component containing the Query Handler
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The Component Name of the Client providing the Update
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The Component Name of the Client providing the Update
- setComponentName(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Component Name of the Client providing the Update
- setComponentName(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name/type of the component dispatching this message
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
The name/type of the component handling the command
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
The name of the component.
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The component name of this client instance.
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The Name of the Component dispatching the query
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Component containing the Query Handler
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The Component Name of the Client providing the Update
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
The Component Name of the Client providing the Update
- setComponentNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Component Name of the Client providing the Update
- setConfigurationFile(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
Sets the path to the configuration file to use to configure the Groups instance.
- setConfigurerModules(List<ConfigurerModule>) - Method in class org.axonframework.spring.config.ConfigurerFactoryBean
-
Registers the configurerModules
that provide context-sensitive default settings for the Configurer.
- setConnectTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setContext(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setData(ByteString) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The actual data representing the object in serialized form.
- setDetails(int, String) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A collection of messages providing more details about root causes of the error
- setDisableEventBlacklisting(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setDoubleValue(double) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The (64 bits) floating point value
- setDoubleValue(double) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The floating point value of the Meta Data entry.
- setEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setEnabled(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
-
Enables (if true
) or disables (if false
, default) the auto-configuration of a Distributed
Command Bus instance in the application context.
- setEnabled(boolean) - Method in class org.axonframework.springboot.MetricsProperties.AutoConfiguration
-
Enables (if true
, default) or disables (if false
) the auto-configuration of Metrics within
the application context.
- setEntityManager(EntityManager) - Method in class org.axonframework.springboot.util.jpa.ContainerManagedEntityManagerProvider
-
Sets the container managed entityManager to use.
- setError(boolean) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Flag indicating whether the processor, when stopped, did so because of an irrecoverable Error
- setError(ErrorMessage) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Set if instruction acknowledgement failed.
- setError(ErrorMessage.Builder) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Set if instruction acknowledgement failed.
- setErrorCode(String) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
An error code describing the error, if any
- setErrorCode(String) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
An Error Code identifying the type of error
- setErrorCode(String) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
An Error Code identifying the type of error, if any
- setErrorCode(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Code describing the type of Error that occurred
- setErrorCodeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
An error code describing the error, if any
- setErrorCodeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
An Error Code identifying the type of error
- setErrorCodeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
An Error Code identifying the type of error, if any
- setErrorCodeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
The Code describing the type of Error that occurred
- setErrorMessage(ErrorMessage) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
A detailed description of the error
- setErrorMessage(ErrorMessage.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
A detailed description of the error
- setErrorMessage(ErrorMessage) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
A detailed description of the error, if any
- setErrorMessage(ErrorMessage.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
A detailed description of the error, if any
- setErrorMessage(ErrorMessage) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
A detailed description of the error, if available
- setErrorMessage(ErrorMessage.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
A detailed description of the error, if available
- setErrorState(String) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Information about the error state of the Segment, if applicable.
- setErrorStateBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Information about the error state of the Segment, if applicable.
- setEvent(Event) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The actual Event Message
- setEvent(Event.Builder) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The actual Event Message
- setEventBus(EventBus) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
Sets the eventBus that scheduled events should be published to.
- setEventBus(EventBus) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the event bus to which scheduled events need to be published.
- setEventFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setEventHandlers(List<Object>) - Method in class org.axonframework.spring.config.EventHandlerRegistrar
-
Registers the given beans
as event handlers with the Event Handler Configuration.
- setEventJobDataBinder(EventJobDataBinder) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the
EventJobDataBinder
instance which reads / writes the event message to publish to the
JobDataMap
.
- setEventProcessorInfo(EventProcessorInfo) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about Tracking Processors defined in the application.
- setEventProcessorInfo(EventProcessorInfo.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about Tracking Processors defined in the application.
- setEvents(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
-
The type of serializer to use to serialize the payload and meta data of Event Messages.
- setEventSecretKey(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- setEventStore(EventStore) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
Sets the Event Store instance to write the snapshots to
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Set the execution result of processing the current
Message
.
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- setExecutionResult(ExecutionResult) - Method in class org.axonframework.messaging.unitofwork.MessageProcessingContext
-
Set the execution result of processing the current
Message
.
- setExecutor(Executor) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
Sets the executor to process the creation (and storage) of each snapshot.
- setExecutorService(ScheduledExecutorService) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
Sets the ExecutorService implementation that monitors the triggers and provides the Threads to publish events.
- setFallbackToHttpGet(boolean) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
-
Whether to fall back to HTTP GET when retrieving Instance Meta Data from the Discovery Server fails.
- setFallbackUrl(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
-
Sets the URL relative to the host's root to retrieve Instance Meta Data from.
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- setField(Descriptors.FieldDescriptor, Object) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- setFieldValue(Field, Object, T) - Static method in class org.axonframework.common.ReflectionUtils
-
Set the field
of object
to a certain value
.
- setFilesCompleted(Confirmation) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when all historic events have been included in the query results
- setFilesCompleted(Confirmation.Builder) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when all historic events have been included in the query results
- setFlowControl(FlowControl) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to increase the number of instructions AxonServer may send to this component
- setFlowControl(FlowControl.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to increase the number of instructions AxonServer may send to this component
- setFlowControl(FlowControl) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Grant permits to AxonServer to send a number of messages to the client
- setFlowControl(FlowControl.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Grant permits to AxonServer to send a number of messages to the client
- setFlowControl(SubscriptionQuery) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Allows the Server to provide additional Updates to be sent.
- setFlowControl(SubscriptionQuery.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Allows the Server to provide additional Updates to be sent.
- setForceFlushOnSave(boolean) - Method in class org.axonframework.modelling.command.GenericJpaRepository
-
Indicates whether the EntityManager's state should be flushed each time an aggregate is saved.
- setFromSequenceNr(long) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
The Sequence Number of the first event expected
- setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- setGapCleaningThreshold(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Sets the threshold of number of gaps in a token before an attempt to clean gaps up is taken.
- setGapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- setGapTimeout(int) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Sets the amount of time until a 'gap' in a TrackingToken may be considered timed out.
- setGeneral(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
-
Sets the type of serializer to use to serialize any type of object, for which no more specific serializer is
configured.
- setGetInitialResult(SubscriptionQuery) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Requests the initial result of a subscription query to be sent.
- setGetInitialResult(SubscriptionQuery.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Requests the initial result of a subscription query to be sent.
- setGossip(DistributedCommandBusProperties.JGroupsProperties.Gossip) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties
-
- setGroupIdentifier(String) - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Sets the group identifier to use when scheduling jobs with Quartz.
- setGroupIdentifier(String) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the group identifier to use when scheduling jobs with Quartz.
- setGrpcPort(int) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The port number for gRPC connections
- setHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
-
Sets the HandlerDefinition to create concrete handlers.
- setHandlerDefinition(HandlerDefinition) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
Sets handler definition to be able to create concrete handlers.
- setHeartbeat(Heartbeat) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- setHeartbeat(Heartbeat.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
This heartbeat is used by AxonServer in order to check if the connection is still alive
- setHeartbeat(Heartbeat) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- setHeartbeat(Heartbeat.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
This heartbeat is used by AxonFramework in order to check if the connection is still alive
- setHostName(String) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The host name to use when connecting to this node
- setHostNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The host name to use when connecting to this node
- setHosts(String) - Method in class org.axonframework.springboot.DistributedCommandBusProperties.JGroupsProperties.Gossip
-
- setHttpPort(int) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The port number for HTTP connections
- setIdValues(int, QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- setIdValues(int, QueryValue.Builder) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The values which, when combined, uniquely update this row.
- setInitialNrOfPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-
- setInitialNrOfPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setInitialResult(QueryResponse) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Initial Response
- setInitialResult(QueryResponse.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Initial Response
- setInitialSegmentCount(int) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the number of initial segments that should be created, if no segments are already present.
- setInitialSequence(long) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
The sequence number of the first event to receive
- setInitialSequence(long) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The minimal sequence number of the snapshots to retrieve
- setInstant(long) - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
Timestamp expressed as milliseconds since epoch
- setInstructionId(String) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Instruction identifier.
- setInstructionId(String) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction identifier.
- setInstructionId(String) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Instruction identifier.
- setInstructionId(String) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction identifier.
- setInstructionId(String) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
The identifier of the instruction
- setInstructionId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Instruction identifier.
- setInstructionId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Instruction identifier.
- setInstructionIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
Instruction identifier.
- setInstructionIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction identifier.
- setInstructionIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Instruction identifier.
- setInstructionIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction identifier.
- setInstructionIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
The identifier of the instruction
- setInstructionIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Instruction identifier.
- setInstructionIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Instruction identifier.
- setJgroups(DistributedCommandBusProperties.JGroupsProperties) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
-
Sets the JGroups configuration to use (if JGroups is on the classpath).
- setKeepAliveTime(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setKeepAliveTimeout(long) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setKey(ProcessingKey) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The type of processing message.
- setKeyValue(int) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The type of processing message.
- setLiveEvents(boolean) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
Whether to keep the query running against incoming events once the Head of the Stream is reached
- setLoadFactor(int) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A number that represents the client's relative load capacity compared to other clients.
- setLoadFactor(int) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
-
Sets the load factor for this instance of the Distributed Command Bus (default 100).
- setLocation(String) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A description of the location (client component, server) where the error occurred
- setLocationBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A description of the location (client component, server) where the error occurred
- setMaxGrpcBufferedMessages(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setMaxMessageSize(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setMaxResults(int) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The maximum number of results to stream
- setMaxSequence(long) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
The maximum sequence number of the snapshots to retrieve
- setMergeEventProcessorSegment(EventProcessorSegmentReference) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to merge two Segments in a Tracking Event Processor
- setMergeEventProcessorSegment(EventProcessorSegmentReference.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to merge two Segments in a Tracking Event Processor
- setMessage(String) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A human readable message explaining the error
- setMessageBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
A human readable message explaining the error
- setMessageId(String) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A unique identifier for this subscription.
- setMessageId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
A unique identifier for this message
- setMessageId(String) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of this Message
- setMessageIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
A unique identifier for this subscription.
- setMessageIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
A unique identifier for this message
- setMessageIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The unique identifier of this Message
- setMessageIdentifier(String) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the Command Message
- setMessageIdentifier(String) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the response message
- setMessageIdentifier(String) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The unique identifier of this event
- setMessageIdentifier(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The message ID of the incoming Query
- setMessageIdentifier(String) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Response Message
- setMessageIdentifier(String) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The unique identifier of this Update
- setMessageIdentifier(String) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The unique identifier for this message
- setMessageIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The unique identifier of the Command Message
- setMessageIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the response message
- setMessageIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The unique identifier of this event
- setMessageIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The message ID of the incoming Query
- setMessageIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Response Message
- setMessageIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The unique identifier of this Update
- setMessageIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The unique identifier for this message
- setMessages(SerializerProperties.SerializerType) - Method in class org.axonframework.springboot.SerializerProperties
-
The type of serializer to use to serialize the payload and meta data of Messages.
- setMode(String) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- setMode(EventProcessorProperties.Mode) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the type of processor that should be configured.
- setModeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The mode in which this processor is reading Events, for example: 'Tracking' or 'Subscribing'
- setName(String) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name of the command, used for routing it to a destination capable of handling it
- setNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The name of the command, used for routing it to a destination capable of handling it
- setNewPermitsThreshold(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-
- setNewPermitsThreshold(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setNodeName(String) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The unique name of the node to connect with, for purpose of debugging
- setNodeNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The unique name of the node to connect with, for purpose of debugging
- setNodeNotification(NodeInfo) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- setNodeNotification(NodeInfo.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Information provided by AxonServer which provides information about the AxonServer node the application is connected with
- setNrOfHandlers(int) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The number of Query Handlers registered within this Component with the same details.
- setNrOfNewPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.FlowControlConfiguration
-
- setNrOfNewPermits(Integer) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setNumberOfPermits(long) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The number of messages the server may send before it needs to wait for more permits
- setNumberOfPermits(long) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The number of results AxonServer may send before new permits need to be provided
- setNumberOfPermits(long) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The number of messages the Server may send before needing to await additional permits
- setNumberValue(long) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The (64 bits) integer value
- setNumberValue(long) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The numeric value of the Meta Data entry.
- setOnePartOf(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The fraction this segment processes.
- setOwnerColum(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the owner column.
- setParameterResolverFactory(ParameterResolverFactory) - Method in class org.axonframework.spring.config.AbstractAnnotationHandlerBeanPostProcessor
-
Sets the ParameterResolverFactory to create the Parameter Resolvers with that provide the parameter values for
the handler methods.
- setPauseEventProcessor(EventProcessorReference) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- setPauseEventProcessor(EventProcessorReference.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Pause a Tracking Event Processor.
- setPayload(SerializedObject) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The payload of the Command, providing details on the instructions for the recipient
- setPayload(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The payload of the Command, providing details on the instructions for the recipient
- setPayload(SerializedObject) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The payload to provide as a result to the dispatcher
- setPayload(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The payload to provide as a result to the dispatcher
- setPayload(SerializedObject) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Payload of the Event
- setPayload(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The Payload of the Event
- setPayload(SerializedObject) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
A payload accompanying the Query
- setPayload(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
A payload accompanying the Query
- setPayload(SerializedObject) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The Payload of the Response Message
- setPayload(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The Payload of the Response Message
- setPayload(SerializedObject) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The object representing the Update
- setPayload(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
The object representing the Update
- setPermits(long) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
The number of permits to provide
- setPhase(UnitOfWork.Phase) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Overwrite the current phase with the given phase
.
- setPrimary(NodeInfo) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
The connection details of the node the client should connect with
- setPrimary(NodeInfo.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
The connection details of the node the client should connect with
- setProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- setProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
Instructions for AxonServer when routing this Command Message
- setProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- setProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
Instructions for AxonServer when routing this Command Response Message
- setProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- setProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
Any instructions for components Routing or Handling the Query
- setProcessingInstructions(int, ProcessingInstruction) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- setProcessingInstructions(int, ProcessingInstruction.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
Any instructions for components Routing or Handling the Response Message
- setProcessor(String) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The name of the processor requesting this stream.
- setProcessorBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The name of the processor requesting this stream.
- setProcessorName(String) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The logical name of this processor.
- setProcessorName(String) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
The name of the Event Processor
- setProcessorName(String) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The name of the Event Processor
- setProcessorNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
The logical name of this processor.
- setProcessorNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
The name of the Event Processor
- setProcessorNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The name of the Event Processor
- setProcessorNameColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the processor name column.
- setProcessorsNotificationInitialDelay(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setProcessorsNotificationRate(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setQuery(String) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The query to execute against the Event Stream
- setQuery(QueryRequest) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Query, for which this component is expected to provide a response
- setQuery(QueryRequest.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Query, for which this component is expected to provide a response
- setQuery(String) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The name of the Query to execute
- setQuery(String) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Query the Handler is subscribed to
- setQueryBus(QueryBus) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
-
- setQueryBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
The query to execute against the Event Stream
- setQueryBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The name of the Query to execute
- setQueryBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The name of the Query the Handler is subscribed to
- setQueryComplete(QueryComplete) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Indicator that all responses for Query have been sent
- setQueryComplete(QueryComplete.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Indicator that all responses for Query have been sent
- setQueryFlowControl(AxonServerConfiguration.FlowControlConfiguration) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setQueryHandlers(Collection<QueryHandlerAdapter>) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
-
- setQueryRequest(QueryRequest) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The Query describing the desire for information
- setQueryRequest(QueryRequest.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
The Query describing the desire for information
- setQueryResponse(QueryResponse) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a Response to a Query received via the inbound stream
- setQueryResponse(QueryResponse.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a Response to a Query received via the inbound stream
- setQueryThreads(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setRegister(ClientIdentification) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about the client being connected.
- setRegister(ClientIdentification.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
Information about the client being connected.
- setReleaseSegment(EventProcessorSegmentReference) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- setReleaseSegment(EventProcessorSegmentReference.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Release a specific segment in a Tracking Event Processor
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- setReplaying(boolean) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
Indicates whether the Segment is "Replaying" historic events after a Reset.
- setReportIllegalStateChange(boolean) - Method in class org.axonframework.test.aggregate.AggregateTestFixture
-
- setReportIllegalStateChange(boolean) - Method in interface org.axonframework.test.aggregate.FixtureConfiguration
-
Sets whether or not the fixture should detect and report state changes that occur outside of Event Handler
methods.
- setRepositoryProvider(RepositoryProvider) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
Sets repository provider in order to have possibility to spawn new aggregates from THE aggregate.
- setRequestEventProcessorInfo(EventProcessorReference) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- setRequestEventProcessorInfo(EventProcessorReference.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer for status information of a specific Tracking Event Processor
- setRequestId(String) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
The identifier of the incoming query to complete
- setRequestIdBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
The identifier of the incoming query to complete
- setRequestIdentifier(String) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the Command Message for which this is the response
- setRequestIdentifier(String) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Query to which this is a response
- setRequestIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
The unique identifier of the Command Message for which this is the response
- setRequestIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
The unique identifier of the Query to which this is a response
- setRequestReconnect(RequestReconnect) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer to the Application to migrate its connection to another node.
- setRequestReconnect(RequestReconnect.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
A request from AxonServer to the Application to migrate its connection to another node.
- setResponseType(SerializedObject) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
An object describing the expectations of the Response Type
- setResponseType(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
An object describing the expectations of the Response Type
- setResult(CommandResultMessage<?>) - Method in class org.axonframework.disruptor.commandhandling.CommandHandlingEntry
-
Registers the result of the command's execution, if successful.
- setResultName(String) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The type of Result this Handler produces
- setResultNameBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
The type of Result this Handler produces
- setRevision(String) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The revision of the Payload Type
- setRevision(String) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The revision of the serialized form of the given type.
- setRevisionBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The revision of the Payload Type
- setRevisionBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The revision of the serialized form of the given type.
- setRollbackCause(Throwable) - Method in class org.axonframework.disruptor.commandhandling.DisruptorUnitOfWork
-
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
Sets the cause for rolling back this Unit of Work.
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.BatchingUnitOfWork
-
- setRollbackCause(Throwable) - Method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
- setRollbackConfiguration(RollbackConfiguration) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
- setRow(RowResponse) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response message contains results of the Query
- setRow(RowResponse.Builder) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
Provided when the response message contains results of the Query
- setRunning(boolean) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Flag indicating whether the processor is running
- setSameConnection(boolean) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
Flag indicating that the connection may be reused to connect.
- setScheduler(Scheduler) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the backing Quartz Scheduler for this timer.
- setSegmentColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the processor segment column.
- setSegmentId(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The ID of the Segment for which the status is reported
- setSegmentIdentifier(int) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
The identifier of the Segment
- setSegmentStatus(int, EventProcessorInfo.SegmentStatus) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- setSegmentStatus(int, EventProcessorInfo.SegmentStatus.Builder) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
Status details of each of the Segments for which Events are being processed.
- setSequencingPolicy(String) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the name of the bean that defines the Sequencing Policy for this processor.
- setSerializer(Serializer) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore
-
Sets the Serializer instance to serialize Sagas with.
- setServers(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setSnapshot(boolean) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
Flag indicating whether the Event is a snapshot Event
- setSnapshotPrefetch(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setSortValues(int, QueryValue) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- setSortValues(int, QueryValue.Builder) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
The sorting values to use when sorting this response compared to the others.
- setSource(String) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the name of the bean that should be used as source for Event Messages.
- setSplitEventProcessorSegment(EventProcessorSegmentReference) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to split a Segment in a Tracking Event Processor
- setSplitEventProcessorSegment(EventProcessorSegmentReference.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction to split a Segment in a Tracking Event Processor
- setSpringCloud(DistributedCommandBusProperties.SpringCloudProperties) - Method in class org.axonframework.springboot.DistributedCommandBusProperties
-
Sets the Spring Cloud configuration to use (if Spring Cloud is on the classpath).
- setSslEnabled(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setStartEventProcessor(EventProcessorReference) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- setStartEventProcessor(EventProcessorReference.Builder) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
Instruction from AxonServer to Start a Tracking Event Processor.
- setSubscribe(CommandSubscription) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to subscribe this component as handler of a specific type of command
- setSubscribe(CommandSubscription.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to subscribe this component as handler of a specific type of command
- setSubscribe(QuerySubscription) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Registers a Query Handler with AxonServer
- setSubscribe(QuerySubscription.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Registers a Query Handler with AxonServer
- setSubscribe(SubscriptionQuery) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Start a Subscription Query with the given details.
- setSubscribe(SubscriptionQuery.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Start a Subscription Query with the given details.
- setSubscriptionIdentifier(String) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A unique identifier for this subscription
- setSubscriptionIdentifier(String) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The identifier of the subscription query this is a response for
- setSubscriptionIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A unique identifier for this subscription
- setSubscriptionIdentifierBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
The identifier of the subscription query this is a response for
- setSubscriptionQueryRequest(SubscriptionQueryRequest) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- setSubscriptionQueryRequest(SubscriptionQueryRequest.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
Represents an incoming Subscription Query, for which this component is expected to provide a response and updates
- setSubscriptionQueryResponse(SubscriptionQueryResponse) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- setSubscriptionQueryResponse(SubscriptionQueryResponse.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Sends a response for a Subscription Query that has been received via the inbound stream
- setSuccess(boolean) - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
True when successful, otherwise false
- setSuccess(boolean) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
Indicator whether the instruction was acknowledged successfully
- setSuppressDownloadMessage(boolean) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setTags(Map<String, String>) - Method in class org.axonframework.springboot.TagsConfigurationProperties
-
Sets tags.
- setTextValue(String) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The text value
- setTextValue(String) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The text value of the Meta Data entry.
- setTextValueBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
The text value
- setTextValueBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
The text value of the Meta Data entry.
- setThreadCount(int) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the number of threads to use to process Events, when in "tracking" mode.
- setTimestamp(long) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
The time at which the command was dispatched
- setTimestamp(long) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
The timestamp of the Event
- setTimestamp(long) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
The timestamp of the Query creation
- setTimestampColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the timestamp column.
- setToken(long) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
The Token representing the position of this Event in the Stream
- setToken(long) - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
The value of the Token
- setToken(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration
-
- setTokenClaimInterval(long) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the time to wait after a failed attempt to claim any token, before making another attempt.
- setTokenClaimIntervalTimeUnit(TimeUnit) - Method in class org.axonframework.springboot.EventProcessorProperties.ProcessorSettings
-
Sets the time unit used to defined tokens claim interval.
- setTokenColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the serialized token column.
- setTokenPosition(long) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
The approximate position of the token in the stream.
- setTokenTable(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the token entry table.
- setTokenTypeColumn(String) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.TokenSchema.Builder
-
Sets the name of the token type column.
- setToSequenceNr(long) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
The sequence number of the latest event
- setTrackingToken(long) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
The token to start streaming from
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
The TransactionDefinition to use by the transaction manager.
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
The TransactionDefinition to use by the transaction manager.
- setTransactionDefinition(TransactionDefinition) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
Optionally sets the transaction definition to use.
- setTransactionManager(Object) - Method in class org.axonframework.spring.config.TransactionManagerFactoryBean
-
Sets the actual transaction manager.
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
Sets the transaction manager that manages the transaction around the publication of an event.
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.eventhandling.scheduling.quartz.QuartzEventSchedulerFactoryBean
-
Sets the transaction manager that manages the transaction around the publication of an event.
- setTransactionManager(PlatformTransactionManager) - Method in class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
Sets the transaction manager to manager underlying transaction with.
- setType(String) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The type identifier of the Payload
- setType(String) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The type identifier of the serialized object.
- setTypeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
The type identifier of the Payload
- setTypeBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
The type identifier of the serialized object.
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.command.Command.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderInbound.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.command.CommandResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.command.CommandSubscription.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorInfo.SegmentStatus.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorReference.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.EventProcessorSegmentReference.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.Heartbeat.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.PlatformInboundInstruction.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.PlatformInfo.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.control.RequestReconnect.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.ErrorMessage.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.ColumnsResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.Confirmation.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.Event.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.EventWithToken.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateEventsRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.GetAggregateSnapshotsRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.GetEventsRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.GetFirstTokenRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.GetLastTokenRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.GetTokenAtRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.PayloadDescription.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.QueryEventsResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.QueryValue.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.ReadHighestSequenceNrResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.RowResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.event.TrackingToken.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.FlowControl.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.InstructionAck.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.MetaDataValue.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryComplete.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderInbound.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QuerySubscription.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdate.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateComplete.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.QueryUpdateCompleteExceptionally.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
- setUnknownFields(UnknownFieldSet) - Method in class io.axoniq.axonserver.grpc.SerializedObject.Builder
-
- setUnsubscribe(CommandSubscription) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to unsubscribe this component as handler of a specific type of command
- setUnsubscribe(CommandSubscription.Builder) - Method in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound.Builder
-
Instruction to unsubscribe this component as handler of a specific type of command
- setUnsubscribe(QuerySubscription) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Unregisters a Query Handler with AxonServer
- setUnsubscribe(QuerySubscription.Builder) - Method in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound.Builder
-
Unregisters a Query Handler with AxonServer
- setUnsubscribe(SubscriptionQuery) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Ends a previously started Subscription Query with the given details
- setUnsubscribe(SubscriptionQuery.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest.Builder
-
Ends a previously started Subscription Query with the given details
- setUpdate(QueryUpdate) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Update Response
- setUpdate(QueryUpdate.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse.Builder
-
Provides an Update Response
- setUpdateResponseType(SerializedObject) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A description of the type of Object expected as Update Responses
- setUpdateResponseType(SerializedObject.Builder) - Method in class io.axoniq.axonserver.grpc.query.SubscriptionQuery.Builder
-
A description of the type of Object expected as Update Responses
- setUseExplicitFlush(boolean) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
-
Sets whether or not to do an explicit EntityManager.flush()
after each data modifying
operation on the backing storage.
- setValue(MetaDataValue) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The value associated with the processing key.
- setValue(MetaDataValue.Builder) - Method in class io.axoniq.axonserver.grpc.ProcessingInstruction.Builder
-
The value associated with the processing key.
- setVersion(String) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Axon framework version used by the client application instance
- setVersion(int) - Method in class io.axoniq.axonserver.grpc.control.NodeInfo.Builder
-
The version identifier of the API
- setVersionBytes(ByteString) - Method in class io.axoniq.axonserver.grpc.control.ClientIdentification.Builder
-
Axon framework version used by the client application instance
- shouldInvokeInterceptorChain() - Method in interface org.axonframework.modelling.command.inspection.CommandHandlerInterceptorHandlingMember
-
Indicates whether interceptor chain (containing a command handler) should be invoked automatically or command
handler interceptor will invoke it manually.
- shutdown() - Method in class org.axonframework.axonserver.connector.AxonServerConnectionManager
-
Stops the Connection Manager, closing any active connections and preventing new connections from being created.
- shutdown() - Method in class org.axonframework.axonserver.connector.event.AxonServerEventStoreClient
-
- shutdown() - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
-
Stops the scheduled task and shutdown the monitor, that cannot be restarted again.
- shutdown() - Method in class org.axonframework.axonserver.connector.processor.schedule.ScheduledEventProcessorInfoSource
-
- shutdown() - Method in class org.axonframework.commandhandling.AsynchronousCommandBus
-
Shuts down the Executor used to asynchronously dispatch incoming commands.
- shutdown() - Method in interface org.axonframework.config.Configuration
-
Shuts down the components defined in this Configuration
- shutdown() - Method in class org.axonframework.config.MessageHandlerRegistrar
-
- shutdown() - Method in interface org.axonframework.config.ModuleConfiguration
-
- shutdown() - Method in interface org.axonframework.deadline.DeadlineManager
-
Shuts down this deadline manager.
- shutdown() - Method in class org.axonframework.deadline.quartz.QuartzDeadlineManager
-
Shuts down this deadline manager.
- shutdown() - Method in class org.axonframework.deadline.SimpleDeadlineManager
-
Shuts down this deadline manager.
- shutDown() - Method in interface org.axonframework.eventhandling.EventProcessor
-
Stops processing events.
- shutdown() - Method in interface org.axonframework.eventhandling.scheduling.EventScheduler
-
Shuts down this event scheduler.
- shutdown() - Method in class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
Shuts down this event scheduler.
- shutdown() - Method in class org.axonframework.eventhandling.scheduling.quartz.QuartzEventScheduler
-
Shuts down this event scheduler.
- shutDown() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-
Shut down this processor.
- shutDown() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Shuts down the processor.
- shutDown() - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore
-
Method to invoke when the application shuts down.
- shutdown() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- shutdownAsync() - Method in interface org.axonframework.eventhandling.EventProcessor
-
Initiates a shutdown, providing a
CompletableFuture
that completes when the shutdown process is
finished.
- shutdownAsync() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Initiates a shutdown, providing a
CompletableFuture
that completes when the shutdown process is
finished.
- shutdownDispatching() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-
Shutdown the command bus asynchronously for dispatching commands to Axon Server.
- shutdownDispatching() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
Shutdown the query bus asynchronously for dispatching queries to Axon Server.
- shutdownDispatching() - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Shutdown the command bus asynchronously for dispatching commands to other instances.
- ShutdownHandler - Annotation Type in org.axonframework.lifecycle
-
Annotation indicating that a member method should be a part of the shutdown cycle of an Axon application.
- ShutdownInProgressException - Exception in org.axonframework.lifecycle
-
Exception indicating a process tried to register an activity whilst the application is shutting down.
- ShutdownInProgressException() - Constructor for exception org.axonframework.lifecycle.ShutdownInProgressException
-
Construct this exception with the default message "Cannot start the activity, shutdown in progress"
.
- ShutdownInProgressException(String) - Constructor for exception org.axonframework.lifecycle.ShutdownInProgressException
-
Constructs this exception with given message
explaining the cause.
- ShutdownLatch - Class in org.axonframework.lifecycle
-
A latch implementation to be used in shutdown scenarios.
- ShutdownLatch() - Constructor for class org.axonframework.lifecycle.ShutdownLatch
-
- ShutdownLatch.ActivityHandle - Class in org.axonframework.lifecycle
-
- shutdownNow() - Method in interface org.axonframework.axonserver.connector.util.Scheduler
-
Cancels all scheduled tasks.
- silentOverride() - Static method in class org.axonframework.commandhandling.DuplicateCommandHandlerResolution
-
- SimpleCommandBus - Class in org.axonframework.commandhandling
-
Implementation of the CommandBus that dispatches commands to the handlers subscribed to that specific command's name.
- SimpleCommandBus(SimpleCommandBus.Builder) - Constructor for class org.axonframework.commandhandling.SimpleCommandBus
-
- SimpleCommandBus.Builder - Class in org.axonframework.commandhandling
-
- SimpleCorrelationDataProvider - Class in org.axonframework.messaging.correlation
-
CorrelationDataProvider implementation defines correlation headers by the header names.
- SimpleCorrelationDataProvider(String...) - Constructor for class org.axonframework.messaging.correlation.SimpleCorrelationDataProvider
-
Initializes the CorrelationDataProvider to return the meta data of messages with given metaDataKeys
as correlation data.
- SimpleDeadlineManager - Class in org.axonframework.deadline
-
- SimpleDeadlineManager(SimpleDeadlineManager.Builder) - Constructor for class org.axonframework.deadline.SimpleDeadlineManager
-
- SimpleDeadlineManager.Builder - Class in org.axonframework.deadline
-
- SimpleEntityManagerProvider - Class in org.axonframework.common.jpa
-
Simple implementation of the EntityManagerProvider that returns the EntityManager instance provided at construction
time.
- SimpleEntityManagerProvider(EntityManager) - Constructor for class org.axonframework.common.jpa.SimpleEntityManagerProvider
-
Initializes an instance that always returns the given entityManager
.
- SimpleEventBus - Class in org.axonframework.eventhandling
-
Implementation of the
EventBus
that dispatches events in the thread the publishes them.
- SimpleEventBus(SimpleEventBus.Builder) - Constructor for class org.axonframework.eventhandling.SimpleEventBus
-
- SimpleEventBus.Builder - Class in org.axonframework.eventhandling
-
- SimpleEventHandlerInvoker - Class in org.axonframework.eventhandling
-
- SimpleEventHandlerInvoker(SimpleEventHandlerInvoker.Builder) - Constructor for class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- SimpleEventHandlerInvoker.Builder - Class in org.axonframework.eventhandling
-
- SimpleEventScheduler - Class in org.axonframework.eventhandling.scheduling.java
-
An
EventScheduler
implementation that uses Java's ScheduledExecutorService as scheduling and triggering
mechanism.
- SimpleEventScheduler(SimpleEventScheduler.Builder) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleEventScheduler
-
- SimpleEventScheduler.Builder - Class in org.axonframework.eventhandling.scheduling.java
-
- SimpleEventSchedulerFactoryBean - Class in org.axonframework.spring.eventhandling.scheduling.java
-
Spring FactoryBean that creates a SimpleEventScheduler instance using resources found in the Spring Application
Context.
- SimpleEventSchedulerFactoryBean() - Constructor for class org.axonframework.spring.eventhandling.scheduling.java.SimpleEventSchedulerFactoryBean
-
- SimpleMember<E> - Class in org.axonframework.commandhandling.distributed
-
An endpoint in the network for a command handling service.
- SimpleMember(String, E, boolean, Consumer<SimpleMember<E>>) - Constructor for class org.axonframework.commandhandling.distributed.SimpleMember
-
Create the service member
- SimpleQueryBus - Class in org.axonframework.queryhandling
-
Implementation of the QueryBus that dispatches queries to the handlers within the JVM.
- SimpleQueryBus(SimpleQueryBus.Builder) - Constructor for class org.axonframework.queryhandling.SimpleQueryBus
-
- SimpleQueryBus.Builder - Class in org.axonframework.queryhandling
-
- SimpleQueryUpdateEmitter - Class in org.axonframework.queryhandling
-
Implementation of
QueryUpdateEmitter
that uses Project Reactor to implement Update Handlers.
- SimpleQueryUpdateEmitter(SimpleQueryUpdateEmitter.Builder) - Constructor for class org.axonframework.queryhandling.SimpleQueryUpdateEmitter
-
- SimpleQueryUpdateEmitter.Builder - Class in org.axonframework.queryhandling
-
- SimpleResourceInjector - Class in org.axonframework.modelling.saga
-
A resource injector that checks for @Inject annotated fields and setter methods to inject resources.
- SimpleResourceInjector(Object...) - Constructor for class org.axonframework.modelling.saga.SimpleResourceInjector
-
Initializes the resource injector to inject to given resources
.
- SimpleResourceInjector(Collection<?>) - Constructor for class org.axonframework.modelling.saga.SimpleResourceInjector
-
Initializes the resource injector to inject to given resources
.
- SimpleResourceParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
- SimpleResourceParameterResolverFactory(Iterable<?>) - Constructor for class org.axonframework.messaging.annotation.SimpleResourceParameterResolverFactory
-
Initialize the ParameterResolverFactory to inject the given resource
in applicable parameters.
- SimpleScheduleToken - Class in org.axonframework.eventhandling.scheduling.java
-
ScheduleToken for tasks event scheduled using the SimpleEventScheduler.
- SimpleScheduleToken(String) - Constructor for class org.axonframework.eventhandling.scheduling.java.SimpleScheduleToken
-
Creates a SimpleScheduleToken with the given tokenId
.
- SimpleSerializedObject<T> - Class in org.axonframework.serialization
-
SerializedObject implementation that takes all properties as constructor parameters.
- SimpleSerializedObject(T, Class<T>, SerializedType) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
-
Initializes a SimpleSerializedObject using given data
and serializedType
.
- SimpleSerializedObject(T, Class<T>, String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedObject
-
Initializes a SimpleSerializedObject using given data
and a serialized type identified by given
type
and revision
.
- SimpleSerializedType - Class in org.axonframework.serialization
-
SerializedType implementation that takes its properties as constructor parameters.
- SimpleSerializedType(String, String) - Constructor for class org.axonframework.serialization.SimpleSerializedType
-
Initialize with given objectType
and revisionNumber
- simulateAutoIncrement(Connection, String, String) - Static method in class org.axonframework.common.jdbc.Oracle11Utils
-
Oracle11 does not have auto incremented values.
- SingleEntryMultiUpcaster<T> - Class in org.axonframework.serialization.upcasting
-
Abstract implementation of an
Upcaster
that eases the common process of upcasting one intermediate
representation to several other representations by applying a simple flat mapping function to the input stream of
intermediate representations.
- SingleEntryMultiUpcaster() - Constructor for class org.axonframework.serialization.upcasting.SingleEntryMultiUpcaster
-
- SingleEntryUpcaster<T> - Class in org.axonframework.serialization.upcasting
-
Abstract implementation of an
Upcaster
that eases the common process of upcasting one intermediate
representation to another representation by applying a simple mapping function to the input stream of intermediate
representations.
- SingleEntryUpcaster() - Constructor for class org.axonframework.serialization.upcasting.SingleEntryUpcaster
-
- SingleEventUpcaster - Class in org.axonframework.serialization.upcasting.event
-
Abstract implementation of an event
Upcaster
that eases the common process of upcasting one intermediate
event representation to another representation by applying a simple mapping function to the input stream of
intermediate representations.
- SingleEventUpcaster() - Constructor for class org.axonframework.serialization.upcasting.event.SingleEventUpcaster
-
- size() - Method in class org.axonframework.messaging.MetaData
-
- size() - Method in interface org.axonframework.modelling.saga.AssociationValues
-
Returns the number of AssociationValue instances available in this container
- size() - Method in class org.axonframework.modelling.saga.AssociationValuesImpl
-
- size() - Method in class org.axonframework.modelling.saga.repository.AssociationValueMap
-
Returns an approximation of the size of this map.
- size() - Method in class org.axonframework.modelling.saga.repository.inmemory.InMemorySagaStore
-
Returns the number of Sagas currently contained in this repository.
- SlidingTimeWindowReservoir - Class in org.axonframework.micrometer.reservoir
-
A reservoir of measurements constrained by a sliding window that stores only the measurements made
in the last N
seconds (or other time unit).
- SlidingTimeWindowReservoir(long, TimeUnit, Clock) - Constructor for class org.axonframework.micrometer.reservoir.SlidingTimeWindowReservoir
-
- SNAPSHOT_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.Event
-
- SnapshotEventEntry - Class in org.axonframework.eventsourcing.eventstore.jpa
-
Default implementation of an event entry containing a serialized snapshot of an aggregate.
- SnapshotEventEntry(DomainEventMessage<?>, Serializer) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
-
Construct a new default snapshot event entry from an aggregate.
- SnapshotEventEntry() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SnapshotEventEntry
-
Default constructor required by JPA
- snapshotEventEntryEntityName() - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
Returns the name of the Snaphot event entity.
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
-
Sets the
Predicate
used to filter snapshots when returning aggregate events.
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
-
Sets the snapshotFilter
deciding whether to take a snapshot into account.
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
-
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- snapshotFilter(Predicate<? super DomainEventData<?>>) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-
- snapshotPrefetch(int) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- snapshotSerializer(Serializer) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
-
Sets the
Serializer
used to serialize and deserialize snapshots.
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine.Builder
-
Sets the
Serializer
used to serialize and deserialize snapshots.
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.BatchingEventStorageEngine.Builder
-
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine.Builder
-
- snapshotSerializer(Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine.Builder
-
- snapshotTable(String) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema.Builder
-
Sets the name of the snapshot events table.
- snapshotTable() - Method in class org.axonframework.eventsourcing.eventstore.jdbc.EventSchema
-
Returns the name of the snapshot event table.
- Snapshotter - Interface in org.axonframework.eventsourcing
-
Interface describing instances that are capable of creating snapshot events for aggregates.
- SnapshotTrigger - Interface in org.axonframework.eventsourcing
-
Interface describing a mechanism that keeps track of an Aggregate's activity in order to trigger a snapshot.
- snapshotTriggerDefinition - Variable in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-
- snapshotTriggerDefinition(SnapshotTriggerDefinition) - Method in class org.axonframework.eventsourcing.EventSourcingRepository.Builder
-
- SnapshotTriggerDefinition - Interface in org.axonframework.eventsourcing
-
Interface describing the mechanism for triggering Snapshots.
- SORT_VALUES_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.RowResponse
-
- source() - Method in exception org.axonframework.axonserver.connector.AxonServerException
-
- source() - Method in exception org.axonframework.axonserver.connector.query.AxonServerQueryDispatchException
-
Return a
String
defining the source where the error originated.
- SourceId - Annotation Type in org.axonframework.messaging.annotation
-
Annotation indication that a parameter on a Message Handler method should be
injected with the aggregate identifier of a DomainEventMessage.
- SourceIdParameterResolverFactory - Class in org.axonframework.messaging.annotation
-
An extension of the AbstractAnnotatedParameterResolverFactory that accepts
parameters of a
String
type that are annotated with the
SourceId
annotation and assigns the aggregate identifier of the DomainEventMessage.
- SourceIdParameterResolverFactory() - Constructor for class org.axonframework.messaging.annotation.SourceIdParameterResolverFactory
-
- split() - Method in class org.axonframework.eventhandling.Segment
-
- SPLIT_EVENT_PROCESSOR_SEGMENT_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- splitBalanced(Segment, int) - Static method in class org.axonframework.eventhandling.Segment
-
Split a given
Segment
n-times in round robin fashion.
- splitSegment(int) - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Instruct the processor to split the segment with given segmentId
into two segments, allowing an
additional thread to start processing events concurrently.
- splitSegmentId() - Method in class org.axonframework.eventhandling.Segment
-
Returns the segmentId of the counterpart of this segment, if this segment were to be split.
- SpringAggregateSnapshotter - Class in org.axonframework.spring.eventsourcing
-
Snapshotter implementation that uses the AggregateRoot as state for the snapshot.
- SpringAggregateSnapshotter(SpringAggregateSnapshotter.Builder) - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotter
-
- SpringAggregateSnapshotter.Builder - Class in org.axonframework.spring.eventsourcing
-
- SpringAggregateSnapshotterFactoryBean - Class in org.axonframework.spring.eventsourcing
-
Implementation of the
AggregateSnapshotter
that eases the configuration when
used within a Spring Application Context.
- SpringAggregateSnapshotterFactoryBean() - Constructor for class org.axonframework.spring.eventsourcing.SpringAggregateSnapshotterFactoryBean
-
- SpringAxonAutoConfigurer - Class in org.axonframework.spring.config
-
ImportBeanDefinitionRegistrar implementation that sets up an infrastructure Configuration based on beans available
in the application context.
- SpringAxonAutoConfigurer() - Constructor for class org.axonframework.spring.config.SpringAxonAutoConfigurer
-
- SpringAxonAutoConfigurer.ImportSelector - Class in org.axonframework.spring.config
-
- SpringBeanParameterResolverFactory - Class in org.axonframework.spring.config.annotation
-
ParameterResolverFactory implementation that resolves parameters in the Spring Application Context.
- SpringBeanParameterResolverFactory() - Constructor for class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
-
Default constructor, which relies on Spring to inject the application context.
- SpringBeanParameterResolverFactory(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringBeanParameterResolverFactory
-
Convenience constructor to use when an instance is not managed by Spring, but an application context is
available.
- SpringCloudProperties() - Constructor for class org.axonframework.springboot.DistributedCommandBusProperties.SpringCloudProperties
-
- SpringContextHandlerDefinitionBuilder - Class in org.axonframework.spring.config.annotation
-
Creates and registers a bean definition for a Spring Context aware HandlerDefinition.
- SpringContextParameterResolverFactoryBuilder - Class in org.axonframework.spring.config.annotation
-
Creates and registers a bean definition for a Spring Context aware ParameterResolverFactory.
- SpringDataSourceConnectionProvider - Class in org.axonframework.spring.jdbc
-
ConnectionProvider implementation that is aware of Transaction Managers and provides the connection attached to an
active transaction manager, instead of asking a Data Source directly.
- SpringDataSourceConnectionProvider(DataSource) - Constructor for class org.axonframework.spring.jdbc.SpringDataSourceConnectionProvider
-
Initialize the connection provider, using given dataSource
to obtain a connection, when required.
- SpringHandlerDefinitionBean - Class in org.axonframework.spring.config.annotation
-
Spring factory bean that creates a HandlerDefinition instance that is capable of resolving parameter values as Spring
Beans, in addition to the default behavior defined by Axon.
- SpringHandlerDefinitionBean() - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
Initializes definition bean with assumption that application context will be injected.
- SpringHandlerDefinitionBean(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerDefinitionBean
-
Initializes definition bean with given application context.
- SpringHandlerEnhancerDefinitionBean - Class in org.axonframework.spring.config.annotation
-
Spring factory bean that creates a HandlerEnhancerDefinition instance that is capable of resolving parameter values
as Spring Beans, in addition to the default behavior defined by Axon.
- SpringHandlerEnhancerDefinitionBean() - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
Initializes definition bean with assumption that application context will be injected.
- SpringHandlerEnhancerDefinitionBean(ApplicationContext) - Constructor for class org.axonframework.spring.config.annotation.SpringHandlerEnhancerDefinitionBean
-
Initializes definition bean with given application context.
- SpringParameterResolverFactoryBean - Class in org.axonframework.spring.config.annotation
-
Spring factory bean that creates a ParameterResolverFactory instance that is capable of resolving parameter values
as Spring Beans, in addition to the default behavior defined by Axon.
- SpringParameterResolverFactoryBean() - Constructor for class org.axonframework.spring.config.annotation.SpringParameterResolverFactoryBean
-
- SpringPrototypeAggregateFactory<T> - Class in org.axonframework.spring.eventsourcing
-
AggregateFactory implementation that uses Spring prototype beans to create new uninitialized instances of
Aggregates.
- SpringPrototypeAggregateFactory(String) - Constructor for class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-
Initializes the factory to create beans instances for the bean with given prototypeBeanName
.
- SpringPrototypeAggregateFactory(String, Map<Class<? extends T>, String>) - Constructor for class org.axonframework.spring.eventsourcing.SpringPrototypeAggregateFactory
-
Initializes the factory to create beans instances for the bean with given prototypeBeanName
and its
subtypes
.
- SpringResourceInjector - Class in org.axonframework.spring.saga
-
ResourceInjector implementation that injects Saga instances with resources available from the Spring Application
context the injector is registered in.
- SpringResourceInjector() - Constructor for class org.axonframework.spring.saga.SpringResourceInjector
-
- SpringTransactionManager - Class in org.axonframework.spring.messaging.unitofwork
-
TransactionManager implementation that uses a PlatformTransactionManager
as
underlying transaction manager.
- SpringTransactionManager(PlatformTransactionManager, TransactionDefinition) - Constructor for class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
-
- SpringTransactionManager(PlatformTransactionManager) - Constructor for class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
-
Initializes the SpringTransactionManager with the given transactionManager
and the default
transaction definition.
- SpringUtils - Class in org.axonframework.spring
-
Utility class for Spring specific helper functions.
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.HsqlSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.Oracle11SagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
-
- sql_createTableAssocValueEntry(Connection) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that creates the table for storing Association Values for Sagas.
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.Oracle11SagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in class org.axonframework.modelling.saga.repository.jdbc.PostgresSagaSqlSchema
-
- sql_createTableSagaEntry(Connection) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that creates the table for storing Sagas.
- sql_deleteAssociationEntries(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_deleteAssociationEntries(Connection, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that deletes all association entries for a Saga with given
sagaIdentifier
.
- sql_deleteSagaEntry(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_deleteSagaEntry(Connection, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that deletes a Saga with given sagaIdentifier
.
- sql_findAssociations(Connection, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_findAssociations(Connection, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that finds the associations of a Saga of given sagaType
and given sagaIdentifier
.
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_findAssocSagaIdentifiers(Connection, String, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that finds identifiers of Sagas of given sagaType
associated with the
given association key
and value
.
- sql_loadSaga(Connection, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_loadSaga(Connection, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that loads a single Saga, with given sagaId
.
- sql_removeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_removeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that removes an association value for given sagaIdentifier
, where the
association is identified with given key
and value
.
- sql_storeAssocValue(Connection, String, String, String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_storeAssocValue(Connection, String, String, String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that stores an association with given key
and value
, for a
Saga of given type
and identifier
.
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_storeSaga(Connection, String, String, String, byte[]) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that inserts a Saga entry, of given sagaType
and with given
sagaIdentifier
.
- sql_updateSaga(Connection, String, byte[], String, String) - Method in class org.axonframework.modelling.saga.repository.jdbc.GenericSagaSqlSchema
-
- sql_updateSaga(Connection, String, byte[], String, String) - Method in interface org.axonframework.modelling.saga.repository.jdbc.SagaSqlSchema
-
Creates a PreparedStatement that updates the serialized form of an existing Saga entry, of given
sagaType
and with given sagaIdentifier
.
- SQLErrorCodesResolver - Class in org.axonframework.eventsourcing.eventstore.jpa
-
SQLErrorCodesResolver is an implementation of PersistenceExceptionResolver used to resolve sql error codes to see if
it is an duplicate key constraint violation.
- SQLErrorCodesResolver(List<Integer>) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initializes the SQLErrorCodesResolver using the given list of SQL Codes representing Key Constraint Violations.
- SQLErrorCodesResolver(DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(Properties, String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize a SQLErrorCodesResolver, automatically detecting the database name through the given dataSource.
- SQLErrorCodesResolver(Properties, DataSource) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLErrorCodesResolver
-
Initialize the SQLErrorCodesResolver with the given properties
and use the dataSource
to automatically retrieve the database product name.
- sqlSchema(SagaSqlSchema) - Method in class org.axonframework.modelling.saga.repository.jdbc.JdbcSagaStore.Builder
-
- SQLStateResolver - Class in org.axonframework.eventsourcing.eventstore.jpa
-
SQLStateResolver is an implementation of PersistenceExceptionResolver used to resolve sql state values to see if it
violates a unique key constraint.
- SQLStateResolver() - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
-
Constructor that uses the standard SQL state category for the check.
- SQLStateResolver(String) - Constructor for class org.axonframework.eventsourcing.eventstore.jpa.SQLStateResolver
-
Constructor that can be used to supply a specific SQL state code for the check.
- ssl(String) - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- stagedDomainEventMessages(String) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
Returns a Stream of all DomainEventMessages that have been staged for publication by an Aggregate with given
aggregateIdentifier
.
- start() - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-
- start() - Method in class org.axonframework.axonserver.connector.heartbeat.HeartbeatMonitor
-
Schedule a task that verifies that the connection is still alive and, if it is not, invoke a callback in order to
react to the disconnection.
- start() - Method in class org.axonframework.axonserver.connector.processor.EventProcessorControlService
-
- start() - Method in class org.axonframework.axonserver.connector.processor.schedule.ScheduledEventProcessorInfoSource
-
Start an
Executor
using the given
initialDelay
and
schedulingPeriod
as milliseconds to notify event processor information.
- start() - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
Start the Axon Server
QueryBus
implementation.
- start() - Method in interface org.axonframework.config.Configuration
-
Starts this configuration.
- start() - Method in interface org.axonframework.config.Configurer
-
Builds the configuration and starts it immediately.
- start() - Method in class org.axonframework.config.MessageHandlerRegistrar
-
- start() - Method in interface org.axonframework.config.ModuleConfiguration
-
- start() - Method in interface org.axonframework.eventhandling.EventProcessor
-
Start processing events.
- start() - Method in class org.axonframework.eventhandling.SubscribingEventProcessor
-
Start this processor.
- start() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Start this processor.
- start() - Method in class org.axonframework.messaging.unitofwork.AbstractUnitOfWork
-
- start() - Method in interface org.axonframework.messaging.unitofwork.UnitOfWork
-
Starts the current unit of work.
- start() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- start() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
-
- start() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
-
- START_EVENT_PROCESSOR_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.control.PlatformOutboundInstruction
-
- startAndGet(T) - Static method in class org.axonframework.messaging.unitofwork.DefaultUnitOfWork
-
Starts a new DefaultUnitOfWork instance, registering it a CurrentUnitOfWork.
- StartHandler - Annotation Type in org.axonframework.lifecycle
-
Annotation indicating that a member method should be a part of the start cycle of an Axon application.
- startRecording() - Method in class org.axonframework.test.saga.CommandValidator
-
Starts recording commands on the command bus.
- startRecording() - Method in class org.axonframework.test.saga.EventValidator
-
Starts recording event published by the event bus.
- startRecording() - Method in class org.axonframework.test.saga.FixtureExecutionResultImpl
-
Tells this class to start monitoring activity in infrastructure classes.
- StartSaga - Annotation Type in org.axonframework.modelling.saga
-
Indicates that the annotated
SagaEventHandler
method can trigger the
creation of a new Saga instance.
- startScope() - Method in class org.axonframework.messaging.Scope
-
- startSegmentWorkers() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Starts workers for a number of segments.
- startTransaction() - Method in enum org.axonframework.common.transaction.NoTransactionManager
-
- startTransaction() - Method in interface org.axonframework.common.transaction.TransactionManager
-
Starts a transaction.
- startTransaction() - Method in class org.axonframework.spring.messaging.unitofwork.SpringTransactionManager
-
- state(boolean, Supplier<String>) - Static method in class org.axonframework.common.Assert
-
Asserts that the value of state
is true.
- stop() - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
Shuts down the command bus.
- stop() - Method in class org.axonframework.spring.config.AxonConfiguration
-
- stop(Runnable) - Method in class org.axonframework.spring.config.AxonConfiguration
-
- stop(Runnable) - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
-
- stop() - Method in class org.axonframework.spring.config.CommandHandlerSubscriber
-
- stop(Runnable) - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
-
- stop() - Method in class org.axonframework.spring.config.QueryHandlerSubscriber
-
- storageEngine(EventStorageEngine) - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore.Builder
-
- storageEngine() - Method in class org.axonframework.axonserver.connector.event.axon.AxonServerEventStore
-
- storageEngine - Variable in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
-
- storageEngine(EventStorageEngine) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore.Builder
-
- storageEngine() - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- storageEngine(EventStorageEngine) - Method in class org.axonframework.eventsourcing.eventstore.EmbeddedEventStore.Builder
-
- store(String, CommandCallbackWrapper<E, C, R>) - Method in class org.axonframework.commandhandling.distributed.CommandCallbackRepository
-
Stores a callback
- store() - Method in interface org.axonframework.config.SagaConfiguration
-
Retrieve the
SagaStore
in this Configuration.
- storeAssociationValue(EntityManager, Class<?>, String, AssociationValue) - Method in class org.axonframework.modelling.saga.repository.jpa.JpaSagaStore
-
Stores the given associationValue
of the saga with given sagaIdentifier
and sagaType
.
- storeSaga(AnnotatedSaga<T>) - Method in class org.axonframework.modelling.saga.repository.AnnotatedSagaRepository
-
Stores a newly created Saga instance.
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStorageEngine
-
Store the given snapshot
of an Aggregate.
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.AbstractEventStore
-
- storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStorageEngine
-
Store an event that contains a snapshot of an aggregate.
- storeSnapshot(DomainEventMessage<?>) - Method in interface org.axonframework.eventsourcing.eventstore.EventStore
-
Stores the given (temporary) snapshot
event.
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.inmemory.InMemoryEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jdbc.JdbcEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>, Serializer) - Method in class org.axonframework.eventsourcing.eventstore.jpa.JpaEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.eventstore.SequenceEventStorageEngine
-
- storeSnapshot(DomainEventMessage<?>) - Method in class org.axonframework.eventsourcing.FilteringEventStorageEngine
-
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.inmemory.InMemoryTokenStore
-
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jdbc.JdbcTokenStore
-
- storeToken(TrackingToken, String, int) - Method in class org.axonframework.eventhandling.tokenstore.jpa.JpaTokenStore
-
- storeToken(TrackingToken, String, int) - Method in interface org.axonframework.eventhandling.tokenstore.TokenStore
-
Stores the given token
in the store.
- storingTokensAfterProcessing() - Method in class org.axonframework.eventhandling.TrackingEventProcessor.Builder
-
Set this processor to store Tracking Tokens only at the end of processing.
- StreamableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
-
Interface for a source of
messages
that processors can track.
- StreamUtils - Class in org.axonframework.common.stream
-
Utility class for working with Streams.
- StringToByteArrayConverter - Class in org.axonframework.serialization.converters
-
ContentTypeConverter that converts String into byte arrays.
- StringToByteArrayConverter() - Constructor for class org.axonframework.serialization.converters.StringToByteArrayConverter
-
- StubAggregateLifecycle - Class in org.axonframework.test.aggregate
-
Stub implementation of an AggregateLifecycle that registers all applied events for verification later.
- StubAggregateLifecycle() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycle
-
- StubAggregateLifecycleRule - Class in org.axonframework.test.aggregate
-
Implementation of StubAggregateLifecycle that can be used as an Rule
annotated method or field
in a test class.
- StubAggregateLifecycleRule() - Constructor for class org.axonframework.test.aggregate.StubAggregateLifecycleRule
-
- StubDeadlineManager - Class in org.axonframework.test.deadline
-
- StubDeadlineManager() - Constructor for class org.axonframework.test.deadline.StubDeadlineManager
-
- StubDeadlineManager(TemporalAccessor) - Constructor for class org.axonframework.test.deadline.StubDeadlineManager
-
Initializes the manager with provided currentDateTime
as current time.
- StubEventScheduler - Class in org.axonframework.test.eventscheduler
-
EventScheduler implementation that uses it's own concept of "Current Time" for the purpose of testing.
- StubEventScheduler() - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
-
Creates an instance of the StubScheduler that uses the current date time as its conceptual "current time".
- StubEventScheduler(TemporalAccessor) - Constructor for class org.axonframework.test.eventscheduler.StubEventScheduler
-
Creates an instance of the StubScheduler that uses the given currentDateTime
as its conceptual
"current time".
- StubScheduleToken - Class in org.axonframework.test.eventscheduler
-
ScheduleToken returned by the StubEventScheduler.
- SubscribableMessageSource<M extends Message<?>> - Interface in org.axonframework.messaging
-
Interface for a source of
messages
to which message processors can subscribe.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.axonserver.connector.command.AxonServerCommandBus
-
- subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
- subscribe(CommandBus) - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
Subscribe this command handler to the given commandBus
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.CommandBus
-
Subscribe the given handler
to commands with the given commandName
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in interface org.axonframework.commandhandling.distributed.CommandBusConnector
-
Subscribes a command message handler for commands with given commandName
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.distributed.DistributedCommandBus
-
Subscribe the given handler
to commands with the given commandName
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.commandhandling.SimpleCommandBus
-
Subscribe the given handler
to commands with given commandName
.
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.disruptor.commandhandling.DisruptorCommandBus
-
- subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.eventhandling.AbstractEventBus
-
- subscribe(Consumer<List<? extends M>>) - Method in interface org.axonframework.messaging.SubscribableMessageSource
-
Subscribe the given messageProcessor
to this message source.
- subscribe(CommandBus) - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
-
Subscribe this command handler to the given commandBus
.
- subscribe(QueryBus) - Method in class org.axonframework.queryhandling.annotation.AnnotationQueryHandlerAdapter
-
- subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in interface org.axonframework.queryhandling.QueryBus
-
Subscribe the given handler
to queries with the given queryName
and responseType
.
- subscribe(QueryBus) - Method in interface org.axonframework.queryhandling.QueryHandlerAdapter
-
Subscribes query handlers to the given query bus
- subscribe(String, Type, MessageHandler<? super QueryMessage<?, R>>) - Method in class org.axonframework.queryhandling.SimpleQueryBus
-
- subscribe(Consumer<List<? extends EventMessage<?>>>) - Method in class org.axonframework.spring.messaging.InboundEventMessageChannelAdapter
-
- subscribe(String, MessageHandler<? super CommandMessage<?>>) - Method in class org.axonframework.test.utils.RecordingCommandBus
-
- SUBSCRIBE_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.command.CommandProviderOutbound
-
- SUBSCRIBE_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- SUBSCRIBE_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.SubscriptionQueryRequest
-
- SubscribingEventProcessor - Class in org.axonframework.eventhandling
-
- SubscribingEventProcessor(SubscribingEventProcessor.Builder) - Constructor for class org.axonframework.eventhandling.SubscribingEventProcessor
-
- SubscribingEventProcessor.Builder - Class in org.axonframework.eventhandling
-
- SubscribingEventProcessorInfoMessage - Class in org.axonframework.axonserver.connector.processor.grpc
-
- subscription(StreamObserver<SubscriptionQueryResponse>) - Method in class io.axoniq.axonserver.grpc.query.QueryServiceGrpc.QueryServiceImplBase
-
Opens a Subscription Query
- subscription(StreamObserver<SubscriptionQueryResponse>) - Method in class io.axoniq.axonserver.grpc.query.QueryServiceGrpc.QueryServiceStub
-
Opens a Subscription Query
- SUBSCRIPTION_IDENTIFIER_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.SubscriptionQuery
-
- SUBSCRIPTION_IDENTIFIER_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.SubscriptionQueryResponse
-
- SUBSCRIPTION_QUERY_REQUEST_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryProviderInbound
-
- SUBSCRIPTION_QUERY_RESPONSE_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.query.QueryProviderOutbound
-
- SubscriptionMessageSerializer - Class in org.axonframework.axonserver.connector.query.subscription
-
- SubscriptionMessageSerializer(Serializer, Serializer, AxonServerConfiguration) - Constructor for class org.axonframework.axonserver.connector.query.subscription.SubscriptionMessageSerializer
-
- SubscriptionQuery - Class in io.axoniq.axonserver.grpc.query
-
Message that represents a Subscription Query
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.axonserver.connector.query.AxonServerQueryBus
-
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.DefaultQueryGateway
-
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>) - Method in interface org.axonframework.queryhandling.QueryBus
-
Dispatch the given query
to a single QueryHandler subscribed to the given query
's
queryName/initialResponseType/updateResponseType.
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryBus
-
Dispatch the given query
to a single QueryHandler subscribed to the given query
's
queryName/initialResponseType/updateResponseType.
- subscriptionQuery(Q, Class<I>, Class<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
-
Sends given
query
over the
QueryBus
and returns result containing initial response and
incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
the emitting side).
- subscriptionQuery(String, Q, Class<I>, Class<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
-
Sends given
query
over the
QueryBus
and returns result containing initial response and
incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
the emitting side).
- subscriptionQuery(Q, ResponseType<I>, ResponseType<U>) - Method in interface org.axonframework.queryhandling.QueryGateway
-
Sends given
query
over the
QueryBus
and returns result containing initial response and
incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
the emitting side).
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure) - Method in interface org.axonframework.queryhandling.QueryGateway
-
Sends given
query
over the
QueryBus
and returns result containing initial response and
incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
the emitting side).
- subscriptionQuery(String, Q, ResponseType<I>, ResponseType<U>, SubscriptionQueryBackpressure, int) - Method in interface org.axonframework.queryhandling.QueryGateway
-
Sends given
query
over the
QueryBus
and returns result containing initial response and
incremental updates (received at the moment the query is sent, until it is cancelled by the caller or closed by
the emitting side).
- subscriptionQuery(SubscriptionQueryMessage<Q, I, U>, SubscriptionQueryBackpressure, int) - Method in class org.axonframework.queryhandling.SimpleQueryBus
-
- SubscriptionQuery.Builder - Class in io.axoniq.axonserver.grpc.query
-
Message that represents a Subscription Query
- SubscriptionQueryBackpressure - Class in org.axonframework.queryhandling
-
Backpressure mechanism used for subscription queries.
- SubscriptionQueryBackpressure(FluxSink.OverflowStrategy) - Constructor for class org.axonframework.queryhandling.SubscriptionQueryBackpressure
-
Initializes backpressure with reactor's overflow strategy.
- SubscriptionQueryMessage<Q,I,U> - Interface in org.axonframework.queryhandling
-
Message type that carries a Subscription Query: a request for information.
- SubscriptionQueryOrBuilder - Interface in io.axoniq.axonserver.grpc.query
-
- SubscriptionQueryRequest - Class in io.axoniq.axonserver.grpc.query
-
Message describing possible interactions for a Subscription Query
- SubscriptionQueryRequest.Builder - Class in io.axoniq.axonserver.grpc.query
-
Message describing possible interactions for a Subscription Query
- SubscriptionQueryRequest.RequestCase - Enum in io.axoniq.axonserver.grpc.query
-
- SubscriptionQueryRequestOrBuilder - Interface in io.axoniq.axonserver.grpc.query
-
- SubscriptionQueryRequestTarget - Class in org.axonframework.axonserver.connector.query.subscription
-
- SubscriptionQueryRequestTarget(QueryBus, Publisher<QueryProviderOutbound>, SubscriptionMessageSerializer) - Constructor for class org.axonframework.axonserver.connector.query.subscription.SubscriptionQueryRequestTarget
-
- SubscriptionQueryResponse - Class in io.axoniq.axonserver.grpc.query
-
Represents a Response Message for a Subscription Query
- SubscriptionQueryResponse.Builder - Class in io.axoniq.axonserver.grpc.query
-
Represents a Response Message for a Subscription Query
- SubscriptionQueryResponse.ResponseCase - Enum in io.axoniq.axonserver.grpc.query
-
- SubscriptionQueryResponseOrBuilder - Interface in io.axoniq.axonserver.grpc.query
-
- SubscriptionQueryResult<I,U> - Interface in org.axonframework.queryhandling
-
Result of the subscription query.
- SubscriptionQueryUpdateMessage<U> - Interface in org.axonframework.queryhandling
-
Message which holds incremental update of an subscription query.
- subset(String...) - Method in class org.axonframework.messaging.MetaData
-
Returns a MetaData instance containing a subset of the keys
in this instance.
- SUCCESS_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.event.Confirmation
-
- SUCCESS_FIELD_NUMBER - Static variable in class io.axoniq.axonserver.grpc.InstructionAck
-
- supplyException(String, long, long) - Method in interface org.axonframework.eventsourcing.conflictresolution.ConflictExceptionSupplier
-
Creates an instance of an exception indicating a conflict in an aggregate with given aggregateIdentifier
,
the given expectedVersion
and actualVersion
.
- supplyException(ConflictDescription) - Method in interface org.axonframework.eventsourcing.conflictresolution.ContextAwareConflictExceptionSupplier
-
Creates an instance of an exception indicating a conflict described by the given conflictDescription
.
- supportedCommandNames() - Method in class org.axonframework.commandhandling.AnnotationCommandHandlerAdapter
-
- supportedCommandNames() - Method in interface org.axonframework.commandhandling.CommandMessageHandler
-
Returns the set of command names this handler supports.
- supportedCommandNames() - Method in class org.axonframework.modelling.command.AggregateAnnotationCommandHandler
-
- supportedPayloadType() - Method in interface org.axonframework.messaging.annotation.ParameterResolver
-
Returns the class of the payload that is supported by this resolver.
- supportedPayloadType() - Method in class org.axonframework.messaging.annotation.PayloadParameterResolver
-
- supportsFormat(Class<T>) - Method in class org.axonframework.serialization.UnknownSerializedType
-
Indicates whether the given desiredFormat
is supported as a representation for this type.
- supportsReset() - Method in class org.axonframework.eventhandling.AnnotationEventHandlerAdapter
-
- supportsReset() - Method in interface org.axonframework.eventhandling.EventHandlerInvoker
-
Indicates whether the handlers managed by this invoker support a reset.
- supportsReset() - Method in interface org.axonframework.eventhandling.EventMessageHandler
-
Indicates whether the handlers managed by this invoker support a reset.
- supportsReset() - Method in class org.axonframework.eventhandling.MultiEventHandlerInvoker
-
- supportsReset() - Method in class org.axonframework.eventhandling.SimpleEventHandlerInvoker
-
- supportsReset() - Method in class org.axonframework.eventhandling.TrackingEventProcessor
-
Indicates whether this tracking processor supports a "reset".
- supportsReset() - Method in class org.axonframework.modelling.saga.AbstractSagaManager
-
- supportsReset() - Method in interface org.axonframework.modelling.saga.Saga
-
- suppressDownloadMessage() - Method in class org.axonframework.axonserver.connector.AxonServerConfiguration.Builder
-
- suspect() - Method in class org.axonframework.commandhandling.distributed.ConsistentHash.ConsistentHashMember
-
- suspect() - Method in interface org.axonframework.commandhandling.distributed.Member
-
Mark this member as suspect, i.e.
- suspect() - Method in class org.axonframework.commandhandling.distributed.SimpleMember
-
- SynchronizedStreamObserver<T> - Class in org.axonframework.axonserver.connector
-
Author: marc
- SynchronizedStreamObserver(StreamObserver<T>) - Constructor for class org.axonframework.axonserver.connector.SynchronizedStreamObserver
-