Uses of Interface
org.axonframework.messaging.core.MessageStream
Packages that use MessageStream
Package
Description
Definitions and implementations of the Event store, the mechanism that can load event streams and append events to
them.
JPA Implementation of the EventStore.
Classes related to message processing in Axon Framework.
-
Uses of MessageStream in org.axonframework.axonserver.connector.event
Classes in org.axonframework.axonserver.connector.event that implement MessageStreamModifier and TypeClassDescriptionclassAMessageStreamimplementation backed by aResultStreamofSourceEventsResponsesfrom Axon Server, translating theSourceEventsResponsesintoEventMessagesas it moves along.classAMessageStreamimplementation backed by aResultStreamofStreamEventsResponsesfrom Axon Server, translating theStreamEventsResponsesintoEventMessagesas it moves along.Methods in org.axonframework.axonserver.connector.event that return MessageStreamModifier and TypeMethodDescriptionAggregateBasedAxonServerEventStorageEngine.source(SourcingCondition condition) AxonServerEventStorageEngine.source(SourcingCondition condition) AggregateBasedAxonServerEventStorageEngine.stream(StreamingCondition condition) AxonServerEventStorageEngine.stream(StreamingCondition condition) -
Uses of MessageStream in org.axonframework.axonserver.connector.query
Classes in org.axonframework.axonserver.connector.query that implement MessageStreamModifier and TypeClassDescriptionclassAn abstract implementation of theMessageStreaminterface that wraps aResultStream.classclassA specialized implementation ofAbstractQueryResponseMessageStreamthat processes a stream ofQueryUpdateobjects and transforms them intoQueryResponseMessageinstances.Methods in org.axonframework.axonserver.connector.query that return MessageStreamModifier and TypeMethodDescriptionAxonServerQueryBusConnector.query(QueryMessage query, ProcessingContext context) AxonServerQueryBusConnector.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) -
Uses of MessageStream in org.axonframework.eventsourcing.eventstore
Classes in org.axonframework.eventsourcing.eventstore that implement MessageStreamModifier and TypeClassDescriptionfinal classAMessageStreamimplementation that continuously fetches event messages from a configurable data source.Methods in org.axonframework.eventsourcing.eventstore that return MessageStreamModifier and TypeMethodDescriptionInterceptingEventStore.open(StreamingCondition condition, ProcessingContext context) StorageEngineBackedEventStore.open(StreamingCondition condition, ProcessingContext context) MessageStream<? extends EventMessage> DefaultEventStoreTransaction.source(SourcingCondition condition) EventStorageEngine.source(SourcingCondition condition) MessageStream<? extends EventMessage> EventStoreTransaction.source(SourcingCondition condition) Sources aMessageStreamof typeEventMessagebased on the givenconditionthat can be used to rehydrate a model.EventStorageEngine.stream(StreamingCondition condition) -
Uses of MessageStream in org.axonframework.eventsourcing.eventstore.inmemory
Methods in org.axonframework.eventsourcing.eventstore.inmemory that return MessageStreamModifier and TypeMethodDescriptionInMemoryEventStorageEngine.source(SourcingCondition condition) InMemoryEventStorageEngine.stream(StreamingCondition condition) -
Uses of MessageStream in org.axonframework.eventsourcing.eventstore.jpa
Methods in org.axonframework.eventsourcing.eventstore.jpa that return MessageStreamModifier and TypeMethodDescriptionAggregateBasedJpaEventStorageEngine.source(SourcingCondition condition) AggregateBasedJpaEventStorageEngine.stream(StreamingCondition condition) -
Uses of MessageStream in org.axonframework.extension.spring.authorization
Methods in org.axonframework.extension.spring.authorization that return MessageStreamModifier and TypeMethodDescriptionMessageAuthorizationDispatchInterceptor.interceptOnDispatch(T message, ProcessingContext context, MessageDispatchInterceptorChain<T> interceptorChain) MessageAuthorizationHandlerInterceptor.interceptOnHandle(M message, ProcessingContext context, MessageHandlerInterceptorChain<M> interceptorChain) -
Uses of MessageStream in org.axonframework.messaging.commandhandling.interception
Methods in org.axonframework.messaging.commandhandling.interception that return MessageStreamModifier and TypeMethodDescriptionCommandMessageHandlerInterceptorChain.proceed(CommandMessage command, ProcessingContext context) -
Uses of MessageStream in org.axonframework.messaging.core
Subinterfaces of MessageStream in org.axonframework.messaging.coreModifier and TypeInterfaceDescriptionstatic interfaceMessageStream.Empty<M extends Message>AMessageStreamimplementation that completes normally or with an error without returning any elements.static interfaceMessageStream.Single<M extends Message>AMessageStreamimplementation that returns at most a single result before completing.Classes in org.axonframework.messaging.core that implement MessageStreamModifier and TypeClassDescriptionclassCloseCallbackMessageStream<M extends Message>MessageStream implementation that invokes the givencloseHandleronce the stream is closed.classDelayedMessageStream<M extends Message>An implementation of theMessageStreamthat wraps a stream that will become available asynchronously.classDelegatingMessageStream<DM extends Message,RM extends Message> Abstract implementation of an MessageStream that delegates calls to a given delegate.classQueueMessageStream<M extends Message>MessageStream implementation that uses a Queue to make elements available to a consumer.Methods in org.axonframework.messaging.core that return MessageStreamModifier and TypeMethodDescriptionstatic <M extends Message>
MessageStream<M> FluxUtils.asMessageStream(reactor.core.publisher.Flux<M> flux) Create a stream that provides theMessagesreturned by the givenflux, automatically wrapped in anMessageStream.Entry.static <M extends Message>
MessageStream<M> FluxUtils.asMessageStream(reactor.core.publisher.Flux<M> flux, Function<M, Context> contextSupplier) Create a stream that provides theMessagesreturned by the givenflux, automatically wrapped in anMessageStream.Entrywith the resultingContextfrom thecontextSupplier.default <T extends Message>
MessageStream<T> MessageStream.cast()Casts this stream to the given type.default MessageStream<M> MessageStream.concatWith(MessageStream<M> other) Returns a stream that concatenates this stream with the givenotherstream, if this stream completes successfully.default MessageStream<M> MessageStream.Empty.concatWith(MessageStream<M> other) static <M extends Message>
MessageStream<M> DelayedMessageStream.create(CompletableFuture<? extends MessageStream<M>> delegate) Creates astreamthat delays actions to itsdelegatewhen it becomes available.protected MessageStream<DM> DelegatingMessageStream.delegate()Returns the delegate as provided in the constructor.default MessageStream<M> MessageStream.filter(Predicate<MessageStream.Entry<M>> filter) Returns a stream that will filterentriesbased on the givenfilter.static <M extends Message>
MessageStream<M> MessageStream.fromItems(M... items) Creates a MessageStream that provides the givenitemsand then completes.static <M extends Message>
MessageStream<M> MessageStream.fromIterable(Iterable<M> iterable) Create a stream that provides theMessagesreturned by the giveniterable, automatically wrapped in anMessageStream.Entry.static <M extends Message>
MessageStream<M> MessageStream.fromIterable(Iterable<M> iterable, Function<M, Context> contextSupplier) Create a stream that provides theMessagesreturned by the giveniterable, automatically wrapped in anMessageStream.Entrywith the resultingContextfrom thecontextSupplier.static <M extends Message>
MessageStream<M> MessageStream.fromStream(Stream<M> stream) Create a stream that provides theMessagesreturned by the givenstream, automatically wrapped in anMessageStream.Entry.static <M extends Message>
MessageStream<M> MessageStream.fromStream(Stream<M> stream, Function<M, Context> contextSupplier) Create a stream that provides theMessagesreturned by the givenstream, automatically wrapped in anMessageStream.Entrywith the resultingContextfrom thecontextSupplier.static <T,M extends Message>
MessageStream<M> MessageStream.fromStream(Stream<T> stream, Function<T, M> messageSupplier, Function<T, Context> contextSupplier) Create a stream that provides the items of typeTreturned by the givenstream, automatically wrapped in anMessageStream.Entrywith the resultingMessageandContextfrom themessageSupplierand thecontextSupplierrespectively.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.default <RM extends Message>
MessageStream<RM> MessageStream.map(Function<MessageStream.Entry<M>, MessageStream.Entry<RM>> mapper) default <RM extends Message>
MessageStream<RM> MessageStream.mapMessage(Function<M, RM> mapper) default MessageStream<M> Returns a stream that, when it is either explicitly closed usingclose(), or when this stream completes (regularly or with an error) calls the givencloseHandler.default MessageStream<M> MessageStream.onComplete(Runnable completeHandler) Returns a stream that invokes the givencompleteHandlerwhen the stream completes normally.default MessageStream<M> MessageStream.onErrorContinue(Function<Throwable, MessageStream<M>> onError) Returns a stream that, whenthisstream completes with an error, continues reading from the stream provided by givenonErrorfunction.default MessageStream<M> MessageStream.onNext(Consumer<MessageStream.Entry<M>> onNext) Invokes the givenonNexteach time anentryis consumed from this stream.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.Methods in org.axonframework.messaging.core with parameters of type MessageStreamModifier and TypeMethodDescriptionstatic <M extends Message>
CompletableFuture<MessageStream.Entry<M>> MessageStreamUtils.asCompletableFuture(MessageStream<M> source) default MessageStream<M> MessageStream.concatWith(MessageStream<M> other) Returns a stream that concatenates this stream with the givenotherstream, if this stream completes successfully.default MessageStream<M> MessageStream.Empty.concatWith(MessageStream<M> other) static <M extends Message>
reactor.core.publisher.Flux<MessageStream.Entry<M>> FluxUtils.of(MessageStream<M> source) Creates a Flux containing theentriesprovided by the givensource.static <M extends Message,R>
CompletableFuture<R> MessageStreamUtils.reduce(MessageStream<M> source, R identity, BiFunction<R, MessageStream.Entry<M>, R> accumulator) Returns aCompletableFuturethat completes with the given reduction of messages read from thesource.Method parameters in org.axonframework.messaging.core with type arguments of type MessageStreamModifier and TypeMethodDescriptionstatic <M extends Message>
MessageStream<M> DelayedMessageStream.create(CompletableFuture<? extends MessageStream<M>> delegate) Creates astreamthat delays actions to itsdelegatewhen it becomes available.default MessageStream<M> MessageStream.onErrorContinue(Function<Throwable, MessageStream<M>> onError) Returns a stream that, whenthisstream completes with an error, continues reading from the stream provided by givenonErrorfunction.static <M extends Message>
org.reactivestreams.Publisher<M> FluxUtils.streamToPublisher(Supplier<MessageStream<M>> stream) Constructors in org.axonframework.messaging.core with parameters of type MessageStreamModifierConstructorDescriptionCloseCallbackMessageStream(MessageStream<M> delegate, Runnable closeHandler) Creates an instance of the CloseCallbackMessageStream, calling the givencloseHandleronce this stream is closed, or the givendelegatecompletes.DelegatingMessageStream(MessageStream<DM> delegate) Constructs the DelegatingMessageStream with givendelegateto receive calls.Constructor parameters in org.axonframework.messaging.core with type arguments of type MessageStreamModifierConstructorDescriptionDefaultMessageDispatchInterceptorChain(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 MessageStream in org.axonframework.messaging.core.annotation
Methods in org.axonframework.messaging.core.annotation that return MessageStreamModifier 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.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) static MessageStream<?> MessageStreamResolverUtils.resolveToStream(Object result, MessageTypeResolver typeResolver) Resolves the givenresultinto aMessageStream, using thetypeResolverwhen aMessageis constructed to define theMessageType.Method parameters in org.axonframework.messaging.core.annotation with type arguments of type MessageStreamModifier 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.<T> Optional<MessageHandlingMember<T>> AnnotatedMessageHandlingMemberDefinition.createHandler(Class<T> declaringType, Method method, ParameterResolverFactory parameterResolverFactory, Function<Object, MessageStream<?>> messageStreamResolver) <T> Optional<MessageHandlingMember<T>> HandlerDefinition.createHandler(Class<T> declaringType, Method method, ParameterResolverFactory parameterResolverFactory, Function<Object, MessageStream<?>> messageStreamResolver) Create aMessageHandlingMemberfor the givenmethodmethod.<T> Optional<MessageHandlingMember<T>> MultiHandlerDefinition.createHandler(Class<T> declaringType, Method method, ParameterResolverFactory parameterResolverFactory, Function<Object, MessageStream<?>> messageStreamResolver) Constructor parameters in org.axonframework.messaging.core.annotation with type arguments of type MessageStreamModifierConstructorDescriptionMethodInvokingMessageHandlingMember(Method method, Class<? extends Message> messageType, Class<?> explicitPayloadType, ParameterResolverFactory parameterResolverFactory, Function<Object, MessageStream<?>> returnTypeConverter) Initializes a new instance that will invoke the givenexecutable(method) on a target to handle a message of the givenmessageType. -
Uses of MessageStream in org.axonframework.messaging.core.interception
Methods in org.axonframework.messaging.core.interception that return MessageStreamModifier 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 MessageStream in org.axonframework.messaging.core.interception.annotation
Methods in org.axonframework.messaging.core.interception.annotation that return MessageStreamModifier and TypeMethodDescriptiondefault 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) -
Uses of MessageStream in org.axonframework.messaging.core.retry
Methods in org.axonframework.messaging.core.retry that return MessageStreamModifier 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 MessageStream in org.axonframework.messaging.eventhandling.interception
Methods in org.axonframework.messaging.eventhandling.interception that return MessageStreamModifier and TypeMethodDescriptionEventMessageHandlerInterceptorChain.proceed(EventMessage event, ProcessingContext context) -
Uses of MessageStream in org.axonframework.messaging.eventstreaming
Methods in org.axonframework.messaging.eventstreaming that return MessageStreamModifier and TypeMethodDescriptionStreamableEventSource.open(StreamingCondition condition, ProcessingContext context) -
Uses of MessageStream in org.axonframework.messaging.monitoring.interception
Methods in org.axonframework.messaging.monitoring.interception that return MessageStreamModifier 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 MessageStream in org.axonframework.messaging.queryhandling
Methods in org.axonframework.messaging.queryhandling that return MessageStreamModifier and TypeMethodDescriptionQueryHandler.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.subscribeToUpdates(QueryMessage query, int updateBufferSize) Subscribes the givenquerywith the givenupdateBufferSize, and returns the MessageStream that provides the update of the subscription query.SimpleQueryBus.subscribeToUpdates(QueryMessage query, int updateBufferSize) 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) -
Uses of MessageStream in org.axonframework.messaging.queryhandling.annotation
Methods in org.axonframework.messaging.queryhandling.annotation that return MessageStreamModifier and TypeMethodDescriptionAnnotatedQueryHandlingComponent.handle(QueryMessage query, ProcessingContext context) -
Uses of MessageStream in org.axonframework.messaging.queryhandling.distributed
Methods in org.axonframework.messaging.queryhandling.distributed that return MessageStreamModifier and TypeMethodDescriptionDelegatingQueryBusConnector.query(QueryMessage query, ProcessingContext context) DistributedQueryBus.query(QueryMessage query, ProcessingContext context) PayloadConvertingQueryBusConnector.query(QueryMessage query, ProcessingContext context) QueryBusConnector.Handler.query(QueryMessage query) Handles the incoming query message.QueryBusConnector.query(QueryMessage query, ProcessingContext context) Sends the givenqueryto the remote QueryBus.DistributedQueryBus.subscribeToUpdates(QueryMessage query, int updateBufferSize) 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 MessageStream in org.axonframework.messaging.queryhandling.interception
Methods in org.axonframework.messaging.queryhandling.interception that return MessageStreamModifier and TypeMethodDescriptionQueryMessageHandlerInterceptorChain.proceed(QueryMessage query, ProcessingContext context) InterceptingQueryBus.query(QueryMessage query, ProcessingContext context) InterceptingQueryBus.subscribeToUpdates(QueryMessage query, int updateBufferSize) InterceptingQueryBus.subscriptionQuery(QueryMessage query, ProcessingContext context, int updateBufferSize) -
Uses of MessageStream in org.axonframework.test.fixture
Methods in org.axonframework.test.fixture that return MessageStreamModifier and TypeMethodDescriptionRecordingEventStore.open(StreamingCondition condition, ProcessingContext context)