Uses of Interface
org.axonframework.messaging.core.unitofwork.ProcessingContext
Packages that use ProcessingContext
Package
Description
Classes related to event sourcing.
Definitions and implementations of the Event store, the mechanism that can load event streams and append events to
them.
JPA Implementation of the EventStore.
Utility classes used to connect Axon Event publishing mechanisms to a Spring Messaging Channel.
Classes that implement the concept of command handling using explicit command objects.
Classes related to message processing in Axon Framework.
Classes related to event handling and dispatching, such as
and the
invalid reference
Event Listeners
Event Bus.A collection of classes which may prove useful when testing Axon-based classes.
-
Uses of ProcessingContext in org.axonframework.axonserver.connector.command
Methods in org.axonframework.axonserver.connector.command with parameters of type ProcessingContextModifier and TypeMethodDescriptionAxonServerCommandBusConnector.dispatch(CommandMessage command, ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.axonserver.connector.event
Methods in org.axonframework.axonserver.connector.event with parameters of type ProcessingContextModifier and TypeMethodDescriptionAggregateBasedAxonServerEventStorageEngine.appendEvents(AppendCondition condition, ProcessingContext context, List<TaggedEventMessage<?>> events) AxonServerEventStorageEngine.appendEvents(AppendCondition condition, ProcessingContext context, List<TaggedEventMessage<?>> events) -
Uses of ProcessingContext in org.axonframework.axonserver.connector.query
Methods in org.axonframework.axonserver.connector.query with parameters of type ProcessingContextModifier and TypeMethodDescriptionAxonServerQueryBusConnector.query(QueryMessage query, ProcessingContext context) AxonServerQueryBusConnector.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) -
Uses of ProcessingContext in org.axonframework.eventsourcing
Methods in org.axonframework.eventsourcing with parameters of type ProcessingContextModifier and TypeMethodDescriptionEventSourcingRepository.attach(ManagedEntity<ID, E> entity, ProcessingContext processingContext) EventSourcedEntityFactory.create(ID id, EventMessage firstEventMessage, ProcessingContext context) Creates an entity of typeEwith the given identifier.EventSourcingRepository.load(ID identifier, ProcessingContext context) EventSourcingRepository.loadOrCreate(ID identifier, ProcessingContext context) EventSourcingRepository.persist(ID identifier, E entity, ProcessingContext processingContext) CriteriaResolver.resolve(I identifier, ProcessingContext context) Resolves the givenidentifierto anEventCriteria. -
Uses of ProcessingContext in org.axonframework.eventsourcing.annotation
Methods in org.axonframework.eventsourcing.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionAnnotationBasedEventCriteriaResolver.resolve(Object id, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.eventsourcing.annotation.reflection
Methods in org.axonframework.eventsourcing.annotation.reflection with parameters of type ProcessingContextModifier and TypeMethodDescriptionAnnotationBasedEventSourcedEntityFactory.create(ID id, EventMessage firstEventMessage, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.eventsourcing.eventstore
Methods in org.axonframework.eventsourcing.eventstore with parameters of type ProcessingContextModifier and TypeMethodDescriptionEventStorageEngine.appendEvents(AppendCondition condition, ProcessingContext context, List<TaggedEventMessage<?>> events) EventStorageEngine.appendEvents(AppendCondition condition, ProcessingContext context, TaggedEventMessage<?>... events) Append one or moreeventsto the underlying storage solution.InterceptingEventStore.firstToken(ProcessingContext context) StorageEngineBackedEventStore.firstToken(ProcessingContext context) InterceptingEventStore.latestToken(ProcessingContext context) StorageEngineBackedEventStore.latestToken(ProcessingContext context) InterceptingEventStore.open(StreamingCondition condition, ProcessingContext context) StorageEngineBackedEventStore.open(StreamingCondition condition, ProcessingContext context) InterceptingEventStore.publish(ProcessingContext context, List<EventMessage> events) StorageEngineBackedEventStore.publish(ProcessingContext context, List<EventMessage> events) InterceptingEventStore.tokenAt(Instant at, ProcessingContext context) StorageEngineBackedEventStore.tokenAt(Instant at, ProcessingContext context) EventStore.transaction(ProcessingContext processingContext) Retrieves thetransaction for appending eventsfor the givenprocessingContext.InterceptingEventStore.transaction(ProcessingContext processingContext) StorageEngineBackedEventStore.transaction(ProcessingContext processingContext) Method parameters in org.axonframework.eventsourcing.eventstore with type arguments of type ProcessingContextModifier and TypeMethodDescriptionInterceptingEventStore.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) StorageEngineBackedEventStore.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) Constructors in org.axonframework.eventsourcing.eventstore with parameters of type ProcessingContextModifierConstructorDescriptionDefaultEventStoreTransaction(EventStorageEngine eventStorageEngine, ProcessingContext processingContext, Function<EventMessage, TaggedEventMessage<?>> eventTagger) Constructs aDefaultEventStoreTransactionusing the giveneventStorageEnginetoappend eventsoriginating from the givencontext. -
Uses of ProcessingContext in org.axonframework.eventsourcing.eventstore.inmemory
Methods in org.axonframework.eventsourcing.eventstore.inmemory with parameters of type ProcessingContextModifier and TypeMethodDescriptionInMemoryEventStorageEngine.appendEvents(AppendCondition condition, ProcessingContext processingContext, List<TaggedEventMessage<?>> events) -
Uses of ProcessingContext in org.axonframework.eventsourcing.eventstore.jdbc
Methods in org.axonframework.eventsourcing.eventstore.jdbc with parameters of type ProcessingContextModifier and TypeMethodDescriptionJdbcTransactionalExecutorProvider.getTransactionalExecutor(ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.eventsourcing.eventstore.jpa
Methods in org.axonframework.eventsourcing.eventstore.jpa with parameters of type ProcessingContextModifier and TypeMethodDescriptionAggregateBasedJpaEventStorageEngine.appendEvents(AppendCondition condition, ProcessingContext processingContext, List<TaggedEventMessage<?>> events) TransactionalExecutor<jakarta.persistence.EntityManager> JpaTransactionalExecutorProvider.getTransactionalExecutor(ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.extension.spring.authorization
Methods in org.axonframework.extension.spring.authorization with parameters of type ProcessingContextModifier and TypeMethodDescriptionMessageAuthorizationDispatchInterceptor.interceptOnDispatch(T message, ProcessingContext context, MessageDispatchInterceptorChain<T> interceptorChain) MessageAuthorizationHandlerInterceptor.interceptOnHandle(M message, ProcessingContext context, MessageHandlerInterceptorChain<M> interceptorChain) -
Uses of ProcessingContext in org.axonframework.extension.spring.messaging
Methods in org.axonframework.extension.spring.messaging with parameters of type ProcessingContextModifier and TypeMethodDescriptionprotected voidOutboundEventMessageChannelAdapter.handle(List<? extends EventMessage> events, ProcessingContext context) If allows by the filter, wraps the giveneventin aGenericMessageands sends it to the configuredMessageChannel.Method parameters in org.axonframework.extension.spring.messaging with type arguments of type ProcessingContextModifier and TypeMethodDescriptionInboundEventMessageChannelAdapter.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) Constructor parameters in org.axonframework.extension.spring.messaging with type arguments of type ProcessingContextModifierConstructorDescriptionInboundEventMessageChannelAdapter(List<BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>>> processors, EventMessageConverter eventMessageConverter) Initialize the adapter to publish all incoming events to the subscribed processors. -
Uses of ProcessingContext in org.axonframework.messaging.commandhandling
Methods in org.axonframework.messaging.commandhandling with parameters of type ProcessingContextModifier and TypeMethodDescriptionCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext) SimpleCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext) CommandHandler.handle(CommandMessage command, ProcessingContext context) Handles the givencommandwithin the givencontext.SimpleCommandHandlingComponent.handle(CommandMessage command, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.commandhandling.annotation
Methods in org.axonframework.messaging.commandhandling.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionAnnotatedCommandHandlingComponent.handle(CommandMessage command, ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.messaging.commandhandling.distributed
Methods in org.axonframework.messaging.commandhandling.distributed with parameters of type ProcessingContextModifier and TypeMethodDescriptionCommandBusConnector.dispatch(CommandMessage command, ProcessingContext processingContext) Dispatches the givencommandto the appropriate command bus, which may be local or remote.DelegatingCommandBusConnector.dispatch(CommandMessage command, ProcessingContext processingContext) DistributedCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext) PayloadConvertingCommandBusConnector.dispatch(CommandMessage command, ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.messaging.commandhandling.gateway
Methods in org.axonframework.messaging.commandhandling.gateway with parameters of type ProcessingContextModifier and TypeMethodDescriptionstatic CommandDispatcherCommandDispatcher.forContext(ProcessingContext context) Creates a dispatcher for the givenProcessingContext.default <R> CompletableFuture<R> CommandGateway.send(Object command, Class<R> resultType, ProcessingContext context) Sends the givencommandand returns aCompletableFutureimmediately, without waiting for the command to execute.CommandGateway.send(Object command, Metadata metadata, ProcessingContext context) Sends the givencommandwith the givenmetadatain the providedcontext(if available) and returns aCommandResultimmediately, without waiting for the command to execute.default CommandResultCommandGateway.send(Object command, ProcessingContext context) Sends the givencommandin the providedcontext(if available) and returns aCommandResultimmediately, without waiting for the command to execute.ConvertingCommandGateway.send(Object command, Metadata metadata, ProcessingContext context) DefaultCommandGateway.send(Object command, Metadata metadata, ProcessingContext context) default <R> RCommandGateway.sendAndWait(Object command, Class<R> resultType, ProcessingContext context) Send the givencommandand waits for the result converted to theresultType.default ObjectCommandGateway.sendAndWait(Object command, ProcessingContext context) Send the givencommandand waits for completion. -
Uses of ProcessingContext in org.axonframework.messaging.commandhandling.interception
Methods in org.axonframework.messaging.commandhandling.interception with parameters of type ProcessingContextModifier and TypeMethodDescriptionInterceptingCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext) CommandMessageHandlerInterceptorChain.proceed(CommandMessage command, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.commandhandling.retry
Methods in org.axonframework.messaging.commandhandling.retry with parameters of type ProcessingContextModifier and TypeMethodDescriptionRetryingCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.messaging.commandhandling.tracing
Methods in org.axonframework.messaging.commandhandling.tracing with parameters of type ProcessingContextModifier and TypeMethodDescriptionTracingCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.messaging.core
Methods in org.axonframework.messaging.core that return ProcessingContextModifier and TypeMethodDescriptionstatic ProcessingContextMessage.addToContext(ProcessingContext context, Message message) Methods in org.axonframework.messaging.core with parameters of type ProcessingContextModifier and TypeMethodDescriptionstatic ProcessingContextMessage.addToContext(ProcessingContext context, Message message) static MessageMessage.fromContext(ProcessingContext context) MessageDispatchInterceptor.interceptOnDispatch(M message, ProcessingContext context, MessageDispatchInterceptorChain<M> interceptorChain) Intercepts a givenmessageon dispatching.MessageHandlerInterceptor.interceptOnHandle(M message, ProcessingContext context, MessageHandlerInterceptorChain<M> interceptorChain) Intercepts a givenmessageon handling before reaching the designatedMessageHandler.DefaultMessageDispatchInterceptorChain.proceed(M message, ProcessingContext context) MessageDispatchInterceptorChain.proceed(M message, ProcessingContext context) Signals this interceptor chain to continue processing themessage.MessageHandlerInterceptorChain.proceed(M message, ProcessingContext context) Signals this interceptor chain to continue processing themessage.Method parameters in org.axonframework.messaging.core with type arguments of type ProcessingContextModifier and TypeMethodDescriptionSubscribableEventSource.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) Subscribe the giveneventsBatchConsumerto this event source.Constructor parameters in org.axonframework.messaging.core with type arguments of type ProcessingContextModifierConstructorDescriptionDefaultMessageDispatchInterceptorChain(Collection<MessageDispatchInterceptor<? super M>> interceptors, BiFunction<? super M, ProcessingContext, MessageStream<?>> terminal) Constructs aDefaultMessageDispatchInterceptorChainfrom the giveninterceptors, invoking the giventerminaloperation when reaching the end of the interceptor chain. -
Uses of ProcessingContext in org.axonframework.messaging.core.annotation
Methods in org.axonframework.messaging.core.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionstatic <M extends Message>
MessageStream<?> InterceptorChainParameterResolverFactory.callWithInterceptorChain(ProcessingContext processingContext, MessageHandlerInterceptorChain<M> interceptorChain, Function<ProcessingContext, MessageStream<?>> action) Invoke the givenactionwith the giveninterceptorChainbeing available for parameter injection.booleanMessageHandlingMember.canHandle(Message message, ProcessingContext context) Checks if this handler is capable of handling the givenmessage.booleanMethodInvokingMessageHandlingMember.canHandle(Message message, ProcessingContext context) booleanWrappedMessageHandlingMember.canHandle(Message message, ProcessingContext context) static <M extends Message>
MessageHandlerInterceptorChain<M> InterceptorChainParameterResolverFactory.currentInterceptorChain(ProcessingContext processingContext) ChainedMessageHandlerInterceptorMember.handle(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) MessageHandlingMember.handle(Message message, ProcessingContext context, T target) Handles the givenmessagewithin the givencontextby invoking the appropriate method on giventarget.MethodInvokingMessageHandlingMember.handle(Message message, ProcessingContext context, T target) WrappedMessageHandlingMember.handle(Message message, ProcessingContext context, T target) ChainedMessageHandlerInterceptorMember.handleSync(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) MessageHandlingMember.handleSync(Message message, ProcessingContext context, T target) Deprecated, for removal: This API element is subject to removal in a future version.MethodInvokingMessageHandlingMember.handleSync(Message message, ProcessingContext context, T target) WrappedMessageHandlingMember.handleSync(Message message, ProcessingContext context, T target) booleanFixedValueParameterResolver.matches(ProcessingContext context) booleanInterceptorChainParameterResolverFactory.matches(ProcessingContext context) booleanParameterResolver.matches(ProcessingContext context) Indicates whether this resolver is capable of providing a value for the givencontext.booleanPayloadParameterResolver.matches(ProcessingContext context) protected booleanMethodInvokingMessageHandlingMember.parametersMatch(Message message, ProcessingContext processingContext) Checks if the parameter resolvers of this member are compatible with the givenmessage.FixedValueParameterResolver.resolveParameterValue(ProcessingContext context) InterceptorChainParameterResolverFactory.resolveParameterValue(ProcessingContext context) ParameterResolver.resolveParameterValue(ProcessingContext context) Asynchronously resolves the parameter value from thecontext.PayloadParameterResolver.resolveParameterValue(ProcessingContext context) Method parameters in org.axonframework.messaging.core.annotation with type arguments of type ProcessingContextModifier and TypeMethodDescriptionstatic <M extends Message>
MessageStream<?> InterceptorChainParameterResolverFactory.callWithInterceptorChain(ProcessingContext processingContext, MessageHandlerInterceptorChain<M> interceptorChain, Function<ProcessingContext, MessageStream<?>> action) Invoke the givenactionwith the giveninterceptorChainbeing available for parameter injection. -
Uses of ProcessingContext in org.axonframework.messaging.core.interception
Methods in org.axonframework.messaging.core.interception with parameters of type ProcessingContextModifier and TypeMethodDescriptionBeanValidationInterceptor.interceptOnDispatch(M message, ProcessingContext context, MessageDispatchInterceptorChain<M> dispatchInterceptorChain) CorrelationDataInterceptor.interceptOnDispatch(M message, ProcessingContext context, MessageDispatchInterceptorChain<M> chain) LoggingInterceptor.interceptOnDispatch(M message, ProcessingContext context, MessageDispatchInterceptorChain<M> interceptorChain) BeanValidationInterceptor.interceptOnHandle(M message, ProcessingContext context, MessageHandlerInterceptorChain<M> handlerInterceptorChain) CorrelationDataInterceptor.interceptOnHandle(M message, ProcessingContext context, MessageHandlerInterceptorChain<M> chain) LoggingInterceptor.interceptOnHandle(M message, ProcessingContext context, MessageHandlerInterceptorChain<M> interceptorChain) -
Uses of ProcessingContext in org.axonframework.messaging.core.interception.annotation
Methods in org.axonframework.messaging.core.interception.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionstatic <R> RResultParameterResolverFactory.callWithResult(Object result, ProcessingContext processingContext, Function<ProcessingContext, R> action) default MessageStream<?> MessageHandlerInterceptorMemberChain.handle(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) NoMoreInterceptors.handle(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) MessageHandlerInterceptorMemberChain.handleSync(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) Deprecated, for removal: This API element is subject to removal in a future version.NoMoreInterceptors.handleSync(Message message, ProcessingContext context, T target, MessageHandlingMember<? super T> handler) Deprecated.static <T> TResultParameterResolverFactory.ignoringResultParameters(ProcessingContext processingContext, Function<ProcessingContext, T> action) Performs the givenactionignoring any parameters expecting a result type.Method parameters in org.axonframework.messaging.core.interception.annotation with type arguments of type ProcessingContextModifier and TypeMethodDescriptionstatic <R> RResultParameterResolverFactory.callWithResult(Object result, ProcessingContext processingContext, Function<ProcessingContext, R> action) static <T> TResultParameterResolverFactory.ignoringResultParameters(ProcessingContext processingContext, Function<ProcessingContext, T> action) Performs the givenactionignoring any parameters expecting a result type. -
Uses of ProcessingContext in org.axonframework.messaging.core.retry
Methods in org.axonframework.messaging.core.retry with parameters of type ProcessingContextModifier and TypeMethodDescriptionRetryScheduler.Dispatcher.dispatch(M message, ProcessingContext processingContext) <M extends Message,R extends Message>
MessageStream<R> AsyncRetryScheduler.scheduleRetry(M message, ProcessingContext processingContext, Throwable cause, RetryScheduler.Dispatcher<M, R> dispatcher) <M extends Message,R extends Message>
MessageStream<R> RetryScheduler.scheduleRetry(M message, ProcessingContext processingContext, Throwable cause, RetryScheduler.Dispatcher<M, R> dispatcher) Schedules the givenmessageto retry dispatching using the givendispatchingfunction. -
Uses of ProcessingContext in org.axonframework.messaging.core.unitofwork
Classes in org.axonframework.messaging.core.unitofwork that implement ProcessingContextModifier and TypeClassDescriptionclassDeprecated.Only in use for legacy "sync" components.classAProcessingContextimplementation overriding a single resource from the wrappingProcessingContext.Methods in org.axonframework.messaging.core.unitofwork that return ProcessingContextModifier and TypeMethodDescriptiondefault <T> ProcessingContextProcessingContext.withResource(Context.ResourceKey<T> key, T resource) Methods in org.axonframework.messaging.core.unitofwork with parameters of type ProcessingContextModifier and TypeMethodDescriptionvoidProcessingLifecycle.ErrorHandler.handle(ProcessingContext processingContext, ProcessingLifecycle.Phase phase, Throwable error) Invoked when an error is detected in aProcessingLifecycleand it has been aborted.Method parameters in org.axonframework.messaging.core.unitofwork with type arguments of type ProcessingContextModifier and TypeMethodDescriptiondefault ProcessingLifecycleProcessingLifecycle.doFinally(Consumer<ProcessingContext> action) Registers the providedactionto be executedon errorof andwhen completingthisProcessingLifecycle.ResourceOverridingProcessingContext.doFinally(Consumer<ProcessingContext> action) <R> CompletableFuture<R> UnitOfWork.executeWithResult(Function<ProcessingContext, CompletableFuture<R>> action) Registers the givenactionfor theinvocation Phaseand executes this Unit of Work right away.LegacyMessageSupportingContext.on(ProcessingLifecycle.Phase phase, Function<ProcessingContext, CompletableFuture<?>> action) Deprecated.ProcessingLifecycle.on(ProcessingLifecycle.Phase phase, Function<ProcessingContext, CompletableFuture<?>> action) Registers the providedactionto be executed in the givenphase.ResourceOverridingProcessingContext.on(ProcessingLifecycle.Phase phase, Function<ProcessingContext, CompletableFuture<?>> action) UnitOfWork.on(ProcessingLifecycle.Phase phase, Function<ProcessingContext, CompletableFuture<?>> action) default ProcessingLifecycleProcessingLifecycle.onAfterCommit(Function<ProcessingContext, CompletableFuture<?>> action) Registers the providedactionto be executed in theafter commit phase.ResourceOverridingProcessingContext.onAfterCommit(Function<ProcessingContext, CompletableFuture<?>> action) default ProcessingLifecycleProcessingLifecycle.onCommit(Function<ProcessingContext, CompletableFuture<?>> action) Registers the providedactionto be executed in thecommit phase.ResourceOverridingProcessingContext.onCommit(Function<ProcessingContext, CompletableFuture<?>> action) default ProcessingLifecycleProcessingLifecycle.onInvocation(Function<ProcessingContext, CompletableFuture<?>> action) Registers the providedactionto be executed in theinvocation phase.ResourceOverridingProcessingContext.onInvocation(Function<ProcessingContext, CompletableFuture<?>> action) default ProcessingLifecycleProcessingLifecycle.onPostInvocation(Function<ProcessingContext, CompletableFuture<?>> action) Registers the providedactionto be executed in thepost invocation phase.ResourceOverridingProcessingContext.onPostInvocation(Function<ProcessingContext, CompletableFuture<?>> action) default ProcessingLifecycleProcessingLifecycle.onPreInvocation(Function<ProcessingContext, CompletableFuture<?>> action) Registers the providedactionto be executed in thepre-invocation phase.ResourceOverridingProcessingContext.onPreInvocation(Function<ProcessingContext, CompletableFuture<?>> action) default ProcessingLifecycleProcessingLifecycle.onPrepareCommit(Function<ProcessingContext, CompletableFuture<?>> action) Registers the providedactionto be executed in theprepare commit phase.ResourceOverridingProcessingContext.onPrepareCommit(Function<ProcessingContext, CompletableFuture<?>> action) default ProcessingLifecycleProcessingLifecycle.runOn(ProcessingLifecycle.Phase phase, Consumer<ProcessingContext> action) Registers the providedactionto be executed in the givenphase.ResourceOverridingProcessingContext.runOn(ProcessingLifecycle.Phase phase, Consumer<ProcessingContext> action) default ProcessingLifecycleProcessingLifecycle.runOnAfterCommit(Consumer<ProcessingContext> action) Registers the providedactionto be executed in theafter commit phase.ResourceOverridingProcessingContext.runOnAfterCommit(Consumer<ProcessingContext> action) default ProcessingLifecycleProcessingLifecycle.runOnCommit(Consumer<ProcessingContext> action) Registers the providedactionto be executed in thecommit phase.ResourceOverridingProcessingContext.runOnCommit(Consumer<ProcessingContext> action) default ProcessingLifecycleProcessingLifecycle.runOnInvocation(Consumer<ProcessingContext> action) Registers the providedactionto be executed in theinvocation phase.ResourceOverridingProcessingContext.runOnInvocation(Consumer<ProcessingContext> action) default ProcessingLifecycleProcessingLifecycle.runOnPostInvocation(Consumer<ProcessingContext> action) Registers the providedactionto be executed in thepost invocation phase.ResourceOverridingProcessingContext.runOnPostInvocation(Consumer<ProcessingContext> action) default ProcessingLifecycleProcessingLifecycle.runOnPreInvocation(Consumer<ProcessingContext> action) Registers the providedactionto be executed in thepre-invocation phase.ResourceOverridingProcessingContext.runOnPreInvocation(Consumer<ProcessingContext> action) default ProcessingLifecycleProcessingLifecycle.runOnPrepareCommit(Consumer<ProcessingContext> action) Registers the providedactionto be executed in theprepare commit phase.ResourceOverridingProcessingContext.runOnPrepareCommit(Consumer<ProcessingContext> action) LegacyMessageSupportingContext.whenComplete(Consumer<ProcessingContext> action) Deprecated.ProcessingLifecycle.whenComplete(Consumer<ProcessingContext> action) Registers the providedactionto be executed when thisProcessingLifecyclecompletes all registered actions.ResourceOverridingProcessingContext.whenComplete(Consumer<ProcessingContext> action) UnitOfWork.whenComplete(Consumer<ProcessingContext> action) Constructors in org.axonframework.messaging.core.unitofwork with parameters of type ProcessingContextModifierConstructorDescriptionResourceOverridingProcessingContext(ProcessingContext delegate, Context.ResourceKey<R> key, R resource) Constructs a resource-overridingProcessingContextusing the provided parameters. -
Uses of ProcessingContext in org.axonframework.messaging.core.unitofwork.annotation
Methods in org.axonframework.messaging.core.unitofwork.annotation that return types with arguments of type ProcessingContextModifier and TypeMethodDescriptionProcessingContextParameterResolverFactory.createInstance(Executable executable, Parameter[] parameters, int parameterIndex) -
Uses of ProcessingContext in org.axonframework.messaging.core.unitofwork.transaction
Methods in org.axonframework.messaging.core.unitofwork.transaction with parameters of type ProcessingContextModifier and TypeMethodDescriptionTransactionalExecutorProvider.getTransactionalExecutor(ProcessingContext processingContext) Provides aTransactionalExecutor, using the optional processing context. -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling
Methods in org.axonframework.messaging.eventhandling with parameters of type ProcessingContextModifier and TypeMethodDescriptionDelegatingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) EventHandler.handle(EventMessage event, ProcessingContext context) Handles the giveneventwithin the givencontext.SimpleEventHandlingComponent.handle(EventMessage event, ProcessingContext context) DelegatingEventBus.publish(ProcessingContext context, List<EventMessage> events) EventSink.publish(ProcessingContext context, List<EventMessage> events) Publishes the giveneventswithin the givencontext, when present.default CompletableFuture<Void> EventSink.publish(ProcessingContext context, EventMessage... events) Publishes the giveneventswithin the givencontext, when present.InterceptingEventBus.publish(ProcessingContext context, List<EventMessage> events) InterceptingEventSink.publish(ProcessingContext context, List<EventMessage> events) SimpleEventBus.publish(ProcessingContext context, List<EventMessage> events) DelegatingEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) EventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent.SimpleEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent.Method parameters in org.axonframework.messaging.eventhandling with type arguments of type ProcessingContextModifier and TypeMethodDescriptionDelegatingEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) InterceptingEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) SimpleEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.annotation
Methods in org.axonframework.messaging.eventhandling.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionAnnotatedEventHandlingComponent.handle(EventMessage event, ProcessingContext context) booleanSequenceNumberParameterResolverFactory.SequenceNumberParameterResolver.matches(ProcessingContext context) SequenceNumberParameterResolverFactory.SequenceNumberParameterResolver.resolveParameterValue(ProcessingContext context) AnnotatedEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.gateway
Methods in org.axonframework.messaging.eventhandling.gateway with parameters of type ProcessingContextModifier and TypeMethodDescriptionstatic EventAppenderEventAppender.forContext(ProcessingContext context) Creates an appender for the givenProcessingContext.static EventAppenderEventAppender.forContext(ProcessingContext context, EventSink eventSink, MessageTypeResolver messageTypeResolver) Creates an appender for the givenProcessingContextandEventSink.DefaultEventGateway.publish(ProcessingContext context, List<?> events) default CompletableFuture<Void> EventGateway.publish(ProcessingContext context, Object... events) Publishes the giveneventswithin the givencontext.EventGateway.publish(ProcessingContext context, List<?> events) Publishes the giveneventswithin the givencontext. -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.interception
Methods in org.axonframework.messaging.eventhandling.interception with parameters of type ProcessingContextModifier and TypeMethodDescriptionInterceptingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) EventMessageHandlerInterceptorChain.proceed(EventMessage event, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing
Methods in org.axonframework.messaging.eventhandling.processing with parameters of type ProcessingContextModifier and TypeMethodDescriptionProcessorEventHandlingComponents.handle(List<? extends EventMessage> events, ProcessingContext context) Processes a batch of events in the processing context.ProcessorEventHandlingComponents.sequenceIdentifiersFor(EventMessage event, ProcessingContext context) Retrieves a set of sequence identifiers for the given event message and processing context. -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing.streaming.pooled
Methods in org.axonframework.messaging.eventhandling.processing.streaming.pooled that return types with arguments of type ProcessingContextModifier and TypeMethodDescriptionPooledStreamingEventProcessorConfiguration.schedulingProcessingContextProvider()Returns theSupplierproviding theProcessingContextused to evaluate whether an event can be scheduled for processing by thisWorkPackage.Method parameters in org.axonframework.messaging.eventhandling.processing.streaming.pooled with type arguments of type ProcessingContextModifier and TypeMethodDescriptionPooledStreamingEventProcessorConfiguration.schedulingProcessingContextProvider(Supplier<ProcessingContext> schedulingProcessingContextProvider) Provides aProcessingContextused to evaluate whether an event can be scheduled for processing by thisWorkPackage. -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing.streaming.segmenting
Methods in org.axonframework.messaging.eventhandling.processing.streaming.segmenting with parameters of type ProcessingContextModifier and TypeMethodDescriptionSequenceOverridingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) SequencingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) booleanSegmentMatcher.matches(Segment segment, EventMessage event, ProcessingContext context) Checks whether the givensegmentmatches the givenevent, based on the configured sequencing policy.SegmentMatcher.sequenceIdentifier(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent, as defined by the configured sequencing policy.SequenceCachingEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) SequenceOverridingEventHandlingComponent.sequenceIdentifierFor(EventMessage event, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing.streaming.token.store
Methods in org.axonframework.messaging.eventhandling.processing.streaming.token.store with parameters of type ProcessingContextModifier and TypeMethodDescriptionTokenStore.deleteToken(String processorName, int segmentId, ProcessingContext context) Deletes the token associated with the specifiedprocessorNameandsegmentId.default CompletableFuture<Void> TokenStore.extendClaim(String processorName, int segmentId, ProcessingContext context) Extends the claim on the current token held by this node for the givenprocessorNameandsegment.TokenStore.fetchAvailableSegments(String processorName, ProcessingContext context) TokenStore.fetchSegment(String processorName, int segmentId, ProcessingContext context) Returns aCompletableFuturethat supplies the specifiedSegment, ornullif there was no such segment.TokenStore.fetchSegments(String processorName, ProcessingContext context) Returns aCompletableFuturethat supplies a list of knownsegmentsfor a givenprocessorNameon completion.TokenStore.fetchToken(String processorName, int segmentId, ProcessingContext context) default CompletableFuture<TrackingToken> TokenStore.fetchToken(String processorName, Segment segment, ProcessingContext context) TokenStore.initializeSegment(TrackingToken token, String processorName, Segment segment, ProcessingContext context) Initializes a segment with givensegmentfor the processor with givenprocessorNameto contain the giventoken.TokenStore.initializeTokenSegments(String processorName, int segmentCount, TrackingToken initialToken, ProcessingContext context) Initializes a given number of segments for the givenprocessorNameto track its tokens.TokenStore.releaseClaim(String processorName, int segmentId, ProcessingContext context) Release a claim of the token for givenprocessorNameandsegment.TokenStore.retrieveStorageIdentifier(ProcessingContext context) Retrieves the storage identifier associated with this store.TokenStore.storeToken(TrackingToken token, String processorName, int segmentId, ProcessingContext context) Stores the giventokenin the store. -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing.streaming.token.store.inmemory
Methods in org.axonframework.messaging.eventhandling.processing.streaming.token.store.inmemory with parameters of type ProcessingContextModifier and TypeMethodDescriptionInMemoryTokenStore.deleteToken(String processorName, int segment, ProcessingContext context) InMemoryTokenStore.fetchAvailableSegments(String processorName, ProcessingContext context) InMemoryTokenStore.fetchSegment(String processorName, int segmentId, ProcessingContext context) InMemoryTokenStore.fetchSegments(String processorName, ProcessingContext context) InMemoryTokenStore.fetchToken(String processorName, int segmentId, ProcessingContext context) InMemoryTokenStore.initializeSegment(TrackingToken token, String processorName, Segment segment, ProcessingContext context) InMemoryTokenStore.initializeTokenSegments(String processorName, int segmentCount, TrackingToken initialToken, ProcessingContext context) InMemoryTokenStore.releaseClaim(String processorName, int segment, ProcessingContext context) InMemoryTokenStore.retrieveStorageIdentifier(ProcessingContext context) InMemoryTokenStore.storeToken(TrackingToken token, String processorName, int segmentId, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing.streaming.token.store.jdbc
Methods in org.axonframework.messaging.eventhandling.processing.streaming.token.store.jdbc with parameters of type ProcessingContextModifier and TypeMethodDescriptionJdbcTokenStore.deleteToken(String processorName, int segment, ProcessingContext context) JdbcTokenStore.fetchAvailableSegments(String processorName, ProcessingContext context) JdbcTokenStore.fetchSegment(String processorName, int segmentId, ProcessingContext context) JdbcTokenStore.fetchSegments(String processorName, ProcessingContext context) JdbcTokenStore.fetchToken(String processorName, int segment, ProcessingContext context) JdbcTokenStore.fetchToken(String processorName, Segment segment, ProcessingContext context) JdbcTokenStore.initializeSegment(TrackingToken token, String processorName, Segment segment, ProcessingContext context) JdbcTokenStore.initializeTokenSegments(String processorName, int segmentCount, TrackingToken initialToken, ProcessingContext context) JdbcTokenStore.releaseClaim(String processorName, int segment, ProcessingContext context) JdbcTokenStore.retrieveStorageIdentifier(ProcessingContext context) JdbcTokenStore.storeToken(TrackingToken token, String processorName, int segment, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing.streaming.token.store.jpa
Methods in org.axonframework.messaging.eventhandling.processing.streaming.token.store.jpa with parameters of type ProcessingContextModifier and TypeMethodDescriptionJpaTokenStore.deleteToken(String processorName, int segment, ProcessingContext context) JpaTokenStore.extendClaim(String processorName, int segment, ProcessingContext context) JpaTokenStore.fetchAvailableSegments(String processorName, ProcessingContext context) JpaTokenStore.fetchSegment(String processorName, int segmentId, ProcessingContext context) JpaTokenStore.fetchSegments(String processorName, ProcessingContext context) JpaTokenStore.fetchToken(String processorName, int segment, ProcessingContext context) JpaTokenStore.fetchToken(String processorName, Segment segment, ProcessingContext context) JpaTokenStore.initializeSegment(TrackingToken token, String processorName, Segment segment, ProcessingContext context) JpaTokenStore.initializeTokenSegments(String processorName, int segmentCount, TrackingToken initialToken, ProcessingContext context) JpaTokenStore.releaseClaim(String processorName, int segment, ProcessingContext context) JpaTokenStore.retrieveStorageIdentifier(ProcessingContext context) JpaTokenStore.storeToken(TrackingToken token, String processorName, int segment, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.processing.subscribing
Methods in org.axonframework.messaging.eventhandling.processing.subscribing with parameters of type ProcessingContextModifier and TypeMethodDescriptionprotected voidSubscribingEventProcessor.process(List<EventMessage> eventMessages, ProcessingContext context) Process the given messages. -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.sequencing
Methods in org.axonframework.messaging.eventhandling.sequencing with parameters of type ProcessingContextModifier and TypeMethodDescriptionExtractionSequencingPolicy.getSequenceIdentifierFor(EventMessage eventMessage, ProcessingContext context) FallbackSequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) FullConcurrencyPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) HierarchicalSequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) MetadataSequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) SequencingPolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) Returns the sequence identifier for the givenevent.SequentialPerAggregatePolicy.getSequenceIdentifierFor(EventMessage event, ProcessingContext context) SequentialPolicy.getSequenceIdentifierFor(EventMessage task, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventhandling.tracing
Methods in org.axonframework.messaging.eventhandling.tracing with parameters of type ProcessingContextModifier and TypeMethodDescriptionTracingEventHandlingComponent.handle(EventMessage event, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.eventstreaming
Methods in org.axonframework.messaging.eventstreaming with parameters of type ProcessingContextModifier and TypeMethodDescriptionTrackingTokenSource.firstToken(ProcessingContext context) Creates aTrackingTokenrepresenting the first position of theevent stream.TrackingTokenSource.latestToken(ProcessingContext context) Creates aTrackingTokenrepresenting the latest position, thus pointing at the next event of theevent stream.StreamableEventSource.open(StreamingCondition condition, ProcessingContext context) TrackingTokenSource.tokenAt(Instant at, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.monitoring.interception
Methods in org.axonframework.messaging.monitoring.interception with parameters of type ProcessingContextModifier and TypeMethodDescriptionMonitoringEventDispatchInterceptor.interceptOnDispatch(EventMessage message, ProcessingContext context, MessageDispatchInterceptorChain<EventMessage> interceptorChain) MonitoringSubscriptionQueryUpdateDispatchInterceptor.interceptOnDispatch(SubscriptionQueryUpdateMessage message, ProcessingContext context, MessageDispatchInterceptorChain<SubscriptionQueryUpdateMessage> interceptorChain) MonitoringCommandHandlerInterceptor.interceptOnHandle(CommandMessage message, ProcessingContext context, MessageHandlerInterceptorChain<CommandMessage> interceptorChain) MonitoringEventHandlerInterceptor.interceptOnHandle(EventMessage message, ProcessingContext context, MessageHandlerInterceptorChain<EventMessage> interceptorChain) MonitoringQueryHandlerInterceptor.interceptOnHandle(QueryMessage message, ProcessingContext context, MessageHandlerInterceptorChain<QueryMessage> interceptorChain) -
Uses of ProcessingContext in org.axonframework.messaging.queryhandling
Methods in org.axonframework.messaging.queryhandling with parameters of type ProcessingContextModifier and TypeMethodDescriptionQueryBus.completeSubscriptions(Predicate<QueryMessage> filter, ProcessingContext context) Completessubscription queriesmatching the givenfilter.SimpleQueryBus.completeSubscriptions(Predicate<QueryMessage> filter, ProcessingContext context) QueryBus.completeSubscriptionsExceptionally(Predicate<QueryMessage> filter, Throwable cause, ProcessingContext context) SimpleQueryBus.completeSubscriptionsExceptionally(Predicate<QueryMessage> filter, Throwable cause, ProcessingContext context) QueryBus.emitUpdate(Predicate<QueryMessage> filter, Supplier<SubscriptionQueryUpdateMessage> updateSupplier, ProcessingContext context) Emits the outcome of theupdateSuppliertosubscription queriesmatching the givenqueryNameand givenfilter.SimpleQueryBus.emitUpdate(Predicate<QueryMessage> filter, Supplier<SubscriptionQueryUpdateMessage> updateSupplier, ProcessingContext context) static QueryUpdateEmitterQueryUpdateEmitter.forContext(ProcessingContext context) Creates a query update emitter for the givenProcessingContext.QueryHandler.handle(QueryMessage query, ProcessingContext context) Handles the givenquerywithin the givencontext.SimpleQueryHandlingComponent.handle(QueryMessage query, ProcessingContext context) QueryBus.query(QueryMessage query, ProcessingContext context) Dispatch the givenqueryto aQueryHandlersubscribedto the givenquery'squery name, returning aMessageStreamofresponsesto the givenquery.SimpleQueryBus.query(QueryMessage query, ProcessingContext context) QueryBus.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) Dispatch the givenqueryto a single QueryHandler subscribed to the givenquery's queryName/initialResponseType/updateResponseType.SimpleQueryBus.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) Constructors in org.axonframework.messaging.queryhandling with parameters of type ProcessingContextModifierConstructorDescriptionSimpleQueryUpdateEmitter(QueryBus queryBus, MessageTypeResolver messageTypeResolver, MessageConverter converter, ProcessingContext context) Construct aSimpleQueryUpdateEmitterwith the givenmessageTypeResolver,queryBus, andcontext. -
Uses of ProcessingContext in org.axonframework.messaging.queryhandling.annotation
Methods in org.axonframework.messaging.queryhandling.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionAnnotatedQueryHandlingComponent.handle(QueryMessage query, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.messaging.queryhandling.distributed
Methods in org.axonframework.messaging.queryhandling.distributed with parameters of type ProcessingContextModifier and TypeMethodDescriptionDistributedQueryBus.completeSubscriptions(Predicate<QueryMessage> filter, ProcessingContext context) DistributedQueryBus.completeSubscriptionsExceptionally(Predicate<QueryMessage> filter, Throwable cause, ProcessingContext context) DistributedQueryBus.emitUpdate(Predicate<QueryMessage> filter, Supplier<SubscriptionQueryUpdateMessage> updateSupplier, ProcessingContext context) DelegatingQueryBusConnector.query(QueryMessage query, ProcessingContext context) DistributedQueryBus.query(QueryMessage query, ProcessingContext context) PayloadConvertingQueryBusConnector.query(QueryMessage query, ProcessingContext context) QueryBusConnector.query(QueryMessage query, ProcessingContext context) Sends the givenqueryto the remote QueryBus.DelegatingQueryBusConnector.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) DistributedQueryBus.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) PayloadConvertingQueryBusConnector.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) QueryBusConnector.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) Sends the givenqueryto the remote QueryBus. -
Uses of ProcessingContext in org.axonframework.messaging.queryhandling.gateway
Methods in org.axonframework.messaging.queryhandling.gateway with parameters of type ProcessingContextModifier and TypeMethodDescription<R> CompletableFuture<R> DefaultQueryGateway.query(Object query, Class<R> responseType, ProcessingContext context) <R> CompletableFuture<R> QueryGateway.query(Object query, Class<R> responseType, ProcessingContext context) Sends givenqueryover theQueryBus, expecting a single response with the givenresponseTypefrom a single source.<R> CompletableFuture<List<R>> DefaultQueryGateway.queryMany(Object query, Class<R> responseType, ProcessingContext context) <R> CompletableFuture<List<R>> QueryGateway.queryMany(Object query, Class<R> responseType, ProcessingContext context) Sends givenqueryover theQueryBus, expecting multiple responses in the form ofresponseTypefrom a single source.<R> org.reactivestreams.Publisher<R> DefaultQueryGateway.streamingQuery(Object query, Class<R> responseType, ProcessingContext context) <R> org.reactivestreams.Publisher<R> QueryGateway.streamingQuery(Object query, Class<R> responseType, ProcessingContext context) <R> org.reactivestreams.Publisher<R> DefaultQueryGateway.subscriptionQuery(Object query, Class<R> responseType, ProcessingContext context, int updateBufferSize) <T> org.reactivestreams.Publisher<T> DefaultQueryGateway.subscriptionQuery(Object query, Class<T> responseType, Function<QueryResponseMessage, T> mapper, ProcessingContext context, int updateBufferSize) default <R> org.reactivestreams.Publisher<R> QueryGateway.subscriptionQuery(Object query, Class<R> responseType, Function<QueryResponseMessage, R> mapper, ProcessingContext context) Sends givenqueryover theQueryBusand returns aPublishersupplying the initial update followed by the update.<R> org.reactivestreams.Publisher<R> QueryGateway.subscriptionQuery(Object query, Class<R> responseType, Function<QueryResponseMessage, R> mapper, ProcessingContext context, int updateBufferSize) Sends givenqueryover theQueryBusand returns aPublishersupplying the initial update followed by the update.default <R> org.reactivestreams.Publisher<R> QueryGateway.subscriptionQuery(Object query, Class<R> responseType, ProcessingContext context) Sends givenqueryover theQueryBusas a subscription query, combining the initial result and emitted update as aPublisherof the givenresponseType.<R> org.reactivestreams.Publisher<R> QueryGateway.subscriptionQuery(Object query, Class<R> responseType, ProcessingContext context, int updateBufferSize) Sends givenqueryover theQueryBusas a subscription query, combining the initial result and emitted update as aPublisherof the givenresponseType. -
Uses of ProcessingContext in org.axonframework.messaging.queryhandling.interception
Methods in org.axonframework.messaging.queryhandling.interception with parameters of type ProcessingContextModifier and TypeMethodDescriptionInterceptingQueryBus.completeSubscriptions(Predicate<QueryMessage> filter, ProcessingContext context) InterceptingQueryBus.completeSubscriptionsExceptionally(Predicate<QueryMessage> filter, Throwable cause, ProcessingContext context) InterceptingQueryBus.emitUpdate(Predicate<QueryMessage> filter, Supplier<SubscriptionQueryUpdateMessage> updateSupplier, ProcessingContext context) QueryMessageHandlerInterceptorChain.proceed(QueryMessage query, ProcessingContext context) InterceptingQueryBus.query(QueryMessage query, ProcessingContext context) InterceptingQueryBus.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) -
Uses of ProcessingContext in org.axonframework.modelling
Methods in org.axonframework.modelling with parameters of type ProcessingContextModifier and TypeMethodDescriptionEntityEvolver.evolve(E entity, EventMessage event, ProcessingContext context) Evolve the givenentityby applying the giveneventto it.PayloadBasedEntityEvolver.evolve(E entity, EventMessage event, ProcessingContext context) SimpleEntityEvolvingComponent.evolve(E entity, EventMessage event, ProcessingContext context) default <I,T> CompletableFuture <T> StateManager.loadEntity(Class<T> type, I id, ProcessingContext context) Retrieves an entity of the giventypeandid.<I,T> CompletableFuture <ManagedEntity<I, T>> HierarchicalStateManager.loadManagedEntity(Class<T> type, I id, ProcessingContext context) <I,T> CompletableFuture <ManagedEntity<I, T>> SimpleStateManager.loadManagedEntity(Class<T> entityType, I id, ProcessingContext context) <ID,T> CompletableFuture <ManagedEntity<ID, T>> StateManager.loadManagedEntity(Class<T> type, ID id, ProcessingContext context) EntityIdResolver.resolve(Message message, ProcessingContext context) Resolve the id of the entity from the givenmessageandcontext.PropertyBasedEntityIdResolver.resolve(Message message, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.modelling.annotation
Methods in org.axonframework.modelling.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionAnnotationBasedEntityEvolvingComponent.evolve(E entity, EventMessage event, ProcessingContext context) AnnotationBasedEntityIdResolver.resolve(Message message, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.modelling.entity
Methods in org.axonframework.modelling.entity with parameters of type ProcessingContextModifier and TypeMethodDescriptionConcreteEntityMetamodel.evolve(E entity, EventMessage event, ProcessingContext context) PolymorphicEntityMetamodel.evolve(E entity, EventMessage event, ProcessingContext context) EntityCommandHandler.handle(CommandMessage command, E entity, ProcessingContext context) Handles the givenCommandMessagefor the givenentity.EntityCommandHandlingComponent.handle(CommandMessage command, ProcessingContext context) ConcreteEntityMetamodel.handleCreate(CommandMessage message, ProcessingContext context) EntityMetamodel.handleCreate(CommandMessage message, ProcessingContext context) Handles the givenCommandMessageas the creation of a new entity.PolymorphicEntityMetamodel.handleCreate(CommandMessage message, ProcessingContext context) ConcreteEntityMetamodel.handleInstance(CommandMessage message, E entity, ProcessingContext context) EntityMetamodel.handleInstance(CommandMessage message, E entity, ProcessingContext context) Handles the givenCommandMessagefor the givenentity.PolymorphicEntityMetamodel.handleInstance(CommandMessage message, E entity, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.modelling.entity.annotation
Methods in org.axonframework.modelling.entity.annotation with parameters of type ProcessingContextModifier and TypeMethodDescriptionAnnotatedEntityMetamodel.evolve(E entity, EventMessage event, ProcessingContext context) RoutingKeyCommandTargetResolver.getTargetChildEntity(List<E> childEntities, CommandMessage message, ProcessingContext context) AnnotatedEntityMetamodel.handleCreate(CommandMessage message, ProcessingContext context) AnnotatedEntityMetamodel.handleInstance(CommandMessage message, E entity, ProcessingContext context) booleanRoutingKeyEventTargetMatcher.matches(E childEntity, EventMessage message, ProcessingContext processingContext) AnnotatedEntityIdResolver.resolve(Message message, ProcessingContext context) -
Uses of ProcessingContext in org.axonframework.modelling.entity.child
Methods in org.axonframework.modelling.entity.child with parameters of type ProcessingContextModifier and TypeMethodDescriptionbooleanAbstractEntityChildMetamodel.canHandle(CommandMessage message, P parentEntity, ProcessingContext context) booleanEntityChildMetamodel.canHandle(CommandMessage message, P parentEntity, ProcessingContext context) Checks if this child can handle the givenCommandMessagefor the given parent entity, and a child entity is available to handle it.AbstractEntityChildMetamodel.evolve(P entity, EventMessage event, ProcessingContext context) CommandTargetResolver.getTargetChildEntity(List<E> candidates, CommandMessage message, ProcessingContext context) Returns the target child entity for the given command message.AbstractEntityChildMetamodel.handle(CommandMessage message, P parentEntity, ProcessingContext context) EntityChildMetamodel.handle(CommandMessage message, P parentEntity, ProcessingContext context) Handles the givenCommandMessagefor the given child entity, using the provided parent entity.booleanEventTargetMatcher.matches(E targetEntity, EventMessage message, ProcessingContext processingContext) -
Uses of ProcessingContext in org.axonframework.modelling.repository
Methods in org.axonframework.modelling.repository with parameters of type ProcessingContextModifier and TypeMethodDescriptionAccessSerializingRepository.attach(ManagedEntity<ID, E> entity, ProcessingContext processingContext) InMemoryRepository.attach(ManagedEntity<ID, E> entity, ProcessingContext processingContext) Repository.LifecycleManagement.attach(ManagedEntity<ID, E> entity, ProcessingContext processingContext) Ensures that the givenentityhas its lifecycle managed in the givenprocessingContext.SimpleRepository.attach(ManagedEntity<ID, E> entity, ProcessingContext context) AccessSerializingRepository.load(ID identifier, ProcessingContext processingContext) InMemoryRepository.load(ID identifier, ProcessingContext processingContext) Repository.load(ID identifier, ProcessingContext processingContext) Load the entity with the given unique identifier.SimpleRepository.load(ID id, ProcessingContext context) CompletableFuture<? extends T> SimpleRepositoryEntityLoader.load(I id, ProcessingContext context) Load an entity with givenidwithin the givencontext.AccessSerializingRepository.loadOrCreate(ID identifier, ProcessingContext processingContext) InMemoryRepository.loadOrCreate(ID identifier, ProcessingContext processingContext) Repository.loadOrCreate(ID identifier, ProcessingContext processingContext) Loads an entity from the repository.SimpleRepository.loadOrCreate(ID identifier, ProcessingContext processingContext) AccessSerializingRepository.persist(ID identifier, E entity, ProcessingContext processingContext) InMemoryRepository.persist(ID identifier, E entity, ProcessingContext processingContext) Repository.persist(ID identifier, E entity, ProcessingContext processingContext) Persists the givenentityin this repositorySimpleRepository.persist(ID id, E entity, ProcessingContext context) SimpleRepositoryEntityPersister.persist(I id, T entity, ProcessingContext context) Persist the givenentitywith givenidwithin the givencontext. -
Uses of ProcessingContext in org.axonframework.test.fixture
Methods in org.axonframework.test.fixture with parameters of type ProcessingContextModifier and TypeMethodDescriptionRecordingCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext) RecordingEventStore.firstToken(ProcessingContext context) RecordingEventStore.latestToken(ProcessingContext context) RecordingEventStore.open(StreamingCondition condition, ProcessingContext context) RecordingEventSink.publish(ProcessingContext context, List<EventMessage> events) RecordingEventStore.tokenAt(Instant at, ProcessingContext context) RecordingEventStore.transaction(@NotNull ProcessingContext processingContext) Method parameters in org.axonframework.test.fixture with type arguments of type ProcessingContextModifier and TypeMethodDescriptionRecordingEventBus.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) RecordingEventStore.subscribe(BiFunction<List<? extends EventMessage>, ProcessingContext, CompletableFuture<?>> eventsBatchConsumer) -
Uses of ProcessingContext in org.axonframework.test.util
Methods in org.axonframework.test.util with parameters of type ProcessingContextModifier and TypeMethodDescriptionRecordingCommandBus.dispatch(CommandMessage command, ProcessingContext processingContext)
MessageHandlingMember.handle(Message, ProcessingContext, Object).